From 41c781cf134fb12b7557b5688fa60d388d423c9c Mon Sep 17 00:00:00 2001 From: AlexSm Date: Thu, 1 Feb 2024 11:39:00 +0100 Subject: [PATCH 001/117] Only fomichev3000 can approve changes in this branch --- .github/CODEOWNERS | 14 +------------- 1 file changed, 1 insertion(+), 13 deletions(-) diff --git a/.github/CODEOWNERS b/.github/CODEOWNERS index 9a05ed6a3cb0..ef63b452ef81 100644 --- a/.github/CODEOWNERS +++ b/.github/CODEOWNERS @@ -1,13 +1 @@ -/ydb/core/fq/ @ydb-platform/fq -/ydb/core/public_http/ @ydb-platform/fq - -/ydb/docs/ @ydb-platform/docs - -/ydb/library/yql/ @ydb-platform/yql -/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/services/fq/ @ydb-platform/fq - +/ @ydb-platform/fomichev3000 From 2eba93f0abf5dc79ccabd38c11695ff2fdd3936c Mon Sep 17 00:00:00 2001 From: AlexSm Date: Thu, 1 Feb 2024 11:39:18 +0100 Subject: [PATCH 002/117] Update CODEOWNERS --- .github/CODEOWNERS | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/.github/CODEOWNERS b/.github/CODEOWNERS index ef63b452ef81..b2a9578b125c 100644 --- a/.github/CODEOWNERS +++ b/.github/CODEOWNERS @@ -1 +1 @@ -/ @ydb-platform/fomichev3000 +* @ydb-platform/fomichev3000 From 6149d927de31ec1073ab86ab237bdc107c20b296 Mon Sep 17 00:00:00 2001 From: AlexSm Date: Thu, 1 Feb 2024 11:47:05 +0100 Subject: [PATCH 003/117] Only members of ReleaseApprovers team can approve changes in this branch --- .github/CODEOWNERS | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/.github/CODEOWNERS b/.github/CODEOWNERS index b2a9578b125c..9c2edf68ce4b 100644 --- a/.github/CODEOWNERS +++ b/.github/CODEOWNERS @@ -1 +1 @@ -* @ydb-platform/fomichev3000 +* @ydb-platform/ReleaseApprovers From 8773c1c25bb30a6014fa1cb5e494371206f273b4 Mon Sep 17 00:00:00 2001 From: Vitalii Gridnev Date: Mon, 5 Feb 2024 15:10:15 +0300 Subject: [PATCH 004/117] merge performance improvement changes to stable-24-1 (#1576) * support trailing generic query responses (#1441) * improving potential bottleneck in grpc layer of the query service (#1278) --- ydb/core/driver_lib/run/run.cpp | 2 +- .../grpc_services/query/rpc_execute_query.cpp | 59 ++++--- ydb/core/kqp/common/events/query.h | 8 +- ydb/core/kqp/common/kqp_event_impl.cpp | 4 +- .../kqp/executer_actor/kqp_data_executer.cpp | 45 +----- .../kqp/executer_actor/kqp_executer_impl.h | 144 +++++++++++++++++- .../kqp/executer_actor/kqp_scan_executer.cpp | 33 +--- ydb/core/kqp/executer_actor/kqp_tasks_graph.h | 1 + ydb/core/kqp/gateway/kqp_gateway.h | 9 ++ ydb/core/kqp/query_data/kqp_query_data.cpp | 22 ++- ydb/core/kqp/query_data/kqp_query_data.h | 4 + .../kqp/session_actor/kqp_session_actor.cpp | 22 ++- ydb/core/protos/kqp.proto | 6 +- ydb/core/testlib/test_client.cpp | 2 +- ydb/services/ydb/ydb_query.cpp | 106 ++++++------- ydb/services/ydb/ydb_query.h | 17 +++ 16 files changed, 330 insertions(+), 154 deletions(-) diff --git a/ydb/core/driver_lib/run/run.cpp b/ydb/core/driver_lib/run/run.cpp index 9691bc7f542f..f75eb3c765e9 100644 --- a/ydb/core/driver_lib/run/run.cpp +++ b/ydb/core/driver_lib/run/run.cpp @@ -832,7 +832,7 @@ void TKikimrRunner::InitializeGRpc(const TKikimrRunConfig& runConfig) { if (hasQueryService) { server.AddService(new NGRpcService::TGRpcYdbQueryService(ActorSystem.Get(), Counters, - grpcRequestProxies[0], hasDataStreams.IsRlAllowed())); + grpcRequestProxies, hasDataStreams.IsRlAllowed(), grpcConfig.GetHandlersPerCompletionQueue())); } if (hasLogStore) { diff --git a/ydb/core/grpc_services/query/rpc_execute_query.cpp b/ydb/core/grpc_services/query/rpc_execute_query.cpp index 738c5ea52a41..3e642b39167c 100644 --- a/ydb/core/grpc_services/query/rpc_execute_query.cpp +++ b/ydb/core/grpc_services/query/rpc_execute_query.cpp @@ -24,6 +24,7 @@ using TEvExecuteQueryRequest = TGrpcRequestNoOperationCall LastSeqNo; ui64 AckedFreeSpaceBytes = 0; + TActorId ActorId; }; class TRpcFlowControlState { @@ -244,8 +245,7 @@ class TExecuteQueryRPC : public TActorBootstrapped { const auto traceId = Request_->GetTraceId(); NYql::TIssues issues; - NKikimrKqp::EQueryAction queryAction; - if (!ParseQueryAction(*req, queryAction, issues)) { + if (!ParseQueryAction(*req, QueryAction, issues)) { return ReplyFinishStream(Ydb::StatusIds::BAD_REQUEST, std::move(issues)); } @@ -274,7 +274,7 @@ class TExecuteQueryRPC : public TActorBootstrapped { cachePolicy->set_keep_in_cache(true); auto ev = MakeHolder( - queryAction, + QueryAction, queryType, SelfId(), Request_, @@ -288,7 +288,8 @@ class TExecuteQueryRPC : public TActorBootstrapped { nullptr, // operationParams false, // keepSession false, // useCancelAfter - syntax); + syntax, + true); if (!ctx.Send(NKqp::MakeKqpProxyID(ctx.SelfID.NodeId()), ev.Release())) { NYql::TIssues issues; @@ -322,23 +323,24 @@ class TExecuteQueryRPC : public TActorBootstrapped { ui64 freeSpaceBytes = FlowControl_.FreeSpaceBytes(); - for (auto& pair : StreamProducers_) { - const auto& producerId = pair.first; - auto& producer = pair.second; + for (auto& pair : StreamChannels_) { + const auto& channelId = pair.first; + auto& channel = pair.second; - if (freeSpaceBytes > 0 && producer.LastSeqNo && producer.AckedFreeSpaceBytes == 0) { + if (freeSpaceBytes > 0 && channel.LastSeqNo && channel.AckedFreeSpaceBytes == 0) { LOG_DEBUG_S(ctx, NKikimrServices::RPC_REQUEST, this->SelfId() << "Resume execution, " - << ", producer: " << producerId - << ", seqNo: " << producer.LastSeqNo + << ", channel: " << channelId + << ", seqNo: " << channel.LastSeqNo << ", freeSpace: " << freeSpaceBytes); auto resp = MakeHolder(); - resp->Record.SetSeqNo(*producer.LastSeqNo); + resp->Record.SetSeqNo(*channel.LastSeqNo); resp->Record.SetFreeSpace(freeSpaceBytes); + resp->Record.SetChannelId(channelId); - ctx.Send(producerId, resp.Release()); + ctx.Send(channel.ActorId, resp.Release()); - producer.AckedFreeSpaceBytes = freeSpaceBytes; + channel.AckedFreeSpaceBytes = freeSpaceBytes; } } @@ -358,9 +360,10 @@ class TExecuteQueryRPC : public TActorBootstrapped { Request_->SendSerializedResult(std::move(out), Ydb::StatusIds::SUCCESS); - auto& producer = StreamProducers_[ev->Sender]; - producer.LastSeqNo = ev->Get()->Record.GetSeqNo(); - producer.AckedFreeSpaceBytes = freeSpaceBytes; + auto& channel = StreamChannels_[ev->Get()->Record.GetChannelId()]; + channel.ActorId = ev->Sender; + channel.LastSeqNo = ev->Get()->Record.GetSeqNo(); + channel.AckedFreeSpaceBytes = freeSpaceBytes; LOG_DEBUG_S(ctx, NKikimrServices::RPC_REQUEST, this->SelfId() << "Send stream data ack" << ", seqNo: " << ev->Get()->Record.GetSeqNo() @@ -371,8 +374,9 @@ class TExecuteQueryRPC : public TActorBootstrapped { auto resp = MakeHolder(); resp->Record.SetSeqNo(ev->Get()->Record.GetSeqNo()); resp->Record.SetFreeSpace(freeSpaceBytes); + resp->Record.SetChannelId(ev->Get()->Record.GetChannelId()); - ctx.Send(ev->Sender, resp.Release()); + ctx.Send(channel.ActorId, resp.Release()); } void Handle(NKqp::TEvKqp::TEvQueryResponse::TPtr& ev, const TActorContext&) { @@ -381,7 +385,15 @@ class TExecuteQueryRPC : public TActorBootstrapped { const auto& issueMessage = record.GetResponse().GetQueryIssues(); bool hasTrailingMessage = false; - + + auto& kqpResponse = record.GetResponse(); + if (kqpResponse.GetYdbResults().size() > 1) { + auto issue = MakeIssue(NKikimrIssues::TIssuesIds::DEFAULT_ERROR, + "Unexpected trailing message with multiple result sets."); + ReplyFinishStream(Ydb::StatusIds::INTERNAL_ERROR, issue); + return; + } + if (record.GetYdbStatus() == Ydb::StatusIds::SUCCESS) { Request_->SetRuHeader(record.GetConsumedRu()); @@ -389,6 +401,14 @@ class TExecuteQueryRPC : public TActorBootstrapped { Ydb::Query::ExecuteQueryResponsePart response; + if (QueryAction == NKikimrKqp::QUERY_ACTION_EXECUTE) { + for(int i = 0; i < kqpResponse.GetYdbResults().size(); i++) { + hasTrailingMessage = true; + response.set_result_set_index(i); + response.mutable_result_set()->Swap(record.MutableResponse()->MutableYdbResults(i)); + } + } + AuditContextAppend(Request_.get(), *Request_->GetProtoRequest(), response); if (kqpResponse.HasTxMeta()) { @@ -492,8 +512,9 @@ class TExecuteQueryRPC : public TActorBootstrapped { private: std::shared_ptr Request_; + NKikimrKqp::EQueryAction QueryAction; TRpcFlowControlState FlowControl_; - TMap StreamProducers_; + TMap StreamChannels_; }; } // namespace diff --git a/ydb/core/kqp/common/events/query.h b/ydb/core/kqp/common/events/query.h index 38fa0f63d934..dac9241e55e7 100644 --- a/ydb/core/kqp/common/events/query.h +++ b/ydb/core/kqp/common/events/query.h @@ -34,7 +34,8 @@ struct TEvQueryRequest: public NActors::TEventLocal UserRequestContext; TDuration ProgressStatsPeriod; + bool SupportsStreamTrailingResult = false; }; struct TEvDataQueryStreamPart: public TEventPBGetDatabaseName().GetOrElse(""))) @@ -36,6 +37,7 @@ TEvKqp::TEvQueryRequest::TEvQueryRequest( , HasOperationParams(operationParams) , KeepSession(keepSession) , Syntax(syntax) + , SupportsStreamTrailingResult(supportsStreamTrailingResult) { if (HasOperationParams) { OperationTimeout = GetDuration(operationParams->operation_timeout()); diff --git a/ydb/core/kqp/executer_actor/kqp_data_executer.cpp b/ydb/core/kqp/executer_actor/kqp_data_executer.cpp index 219396b5cdcc..a6fdcac9a80d 100644 --- a/ydb/core/kqp/executer_actor/kqp_data_executer.cpp +++ b/ydb/core/kqp/executer_actor/kqp_data_executer.cpp @@ -130,10 +130,9 @@ class TKqpDataExecuter : public TKqpExecuterBase& userRequestContext, const bool enableOlapSink) : TBase(std::move(request), database, userToken, counters, executerRetriesConfig, chanTransportVersion, aggregation, - maximalSecretsSnapshotWaitTime, userRequestContext, TWilsonKqp::DataExecuter, "DataExecuter" + maximalSecretsSnapshotWaitTime, userRequestContext, TWilsonKqp::DataExecuter, "DataExecuter", streamResult ) , AsyncIoFactory(std::move(asyncIoFactory)) - , StreamResult(streamResult) , EnableOlapSink(enableOlapSink) { Target = creator; @@ -347,7 +346,8 @@ class TKqpDataExecuter : public TKqpExecuterBaseGet()->Record; - auto& channelData = record.GetChannelData(); - - TDqSerializedBatch batch; - batch.Proto = std::move(*record.MutableChannelData()->MutableData()); - if (batch.Proto.HasPayloadId()) { - batch.Payload = ev->Get()->GetPayload(batch.Proto.GetPayloadId()); - } - - auto& channel = TasksGraph.GetChannel(channelData.GetChannelId()); - YQL_ENSURE(channel.DstTask == 0); - auto shardId = TasksGraph.GetTask(channel.SrcTask).Meta.ShardId; - - if (Stats) { - Stats->ResultBytes += batch.Size(); - Stats->ResultRows += batch.RowCount(); - } - - LOG_T("Got result, channelId: " << channel.Id << ", shardId: " << shardId - << ", inputIndex: " << channel.DstInputIndex << ", from: " << ev->Sender - << ", finished: " << channelData.GetFinished()); - - ResponseEv->TakeResult(channel.DstInputIndex, std::move(batch)); - { - LOG_T("Send ack to channelId: " << channel.Id << ", seqNo: " << record.GetSeqNo() << ", to: " << ev->Sender); - - auto ackEv = MakeHolder(); - ackEv->Record.SetSeqNo(record.GetSeqNo()); - ackEv->Record.SetChannelId(channel.Id); - ackEv->Record.SetFreeSpace(50_MB); - Send(ev->Sender, ackEv.Release(), /* TODO: undelivery */ 0, /* cookie */ channel.Id); - } - } - private: bool IsReadOnlyTx() const { if (Request.TopicOperations.HasOperations()) { @@ -2417,7 +2383,6 @@ class TKqpDataExecuter : public TKqpExecuterBase #include +#include #include #include @@ -34,6 +35,7 @@ #include #include +#include #include #include #include @@ -45,6 +47,7 @@ #include #include + #include @@ -119,7 +122,7 @@ class TKqpExecuterBase : public TActorBootstrapped { const NKikimrConfig::TTableServiceConfig::EChannelTransportVersion chanTransportVersion, const NKikimrConfig::TTableServiceConfig::TAggregationConfig& aggregation, TDuration maximalSecretsSnapshotWaitTime, const TIntrusivePtr& userRequestContext, - ui64 spanVerbosity = 0, TString spanName = "KqpExecuterBase") + ui64 spanVerbosity = 0, TString spanName = "KqpExecuterBase", bool streamResult = false) : Request(std::move(request)) , Database(database) , UserToken(userToken) @@ -130,6 +133,7 @@ class TKqpExecuterBase : public TActorBootstrapped { , MaximalSecretsSnapshotWaitTime(maximalSecretsSnapshotWaitTime) , AggregationSettings(aggregation) , HasOlapTable(false) + , StreamResult(streamResult) { TasksGraph.GetMeta().Snapshot = IKqpGateway::TKqpSnapshot(Request.Snapshot.Step, Request.Snapshot.TxId); TasksGraph.GetMeta().Arena = MakeIntrusive(); @@ -234,6 +238,135 @@ class TKqpExecuterBase : public TActorBootstrapped { return true; } + struct TEvComputeChannelDataOOB { + NYql::NDqProto::TEvComputeChannelData Proto; + TRope Payload; + + size_t Size() const { + return Proto.GetChannelData().GetData().GetRaw().size() + Payload.size(); + } + + ui32 RowCount() const { + return Proto.GetChannelData().GetData().GetRows(); + } + }; + + void HandleChannelData(NYql::NDq::TEvDqCompute::TEvChannelData::TPtr& ev) { + auto& record = ev->Get()->Record; + auto& channelData = record.GetChannelData(); + auto& channel = TasksGraph.GetChannel(channelData.GetChannelId()); + auto& task = TasksGraph.GetTask(channel.SrcTask); + const TActorId channelComputeActorId = ev->Sender; + + auto& txResult = ResponseEv->TxResults[channel.DstInputIndex]; + auto [it, _] = ResultChannelToComputeActor.emplace(channel.Id, ev->Sender); + YQL_ENSURE(it->second == channelComputeActorId); + + if (StreamResult && txResult.IsStream && txResult.QueryResultIndex.Defined()) { + + TEvComputeChannelDataOOB computeData; + computeData.Proto = std::move(ev->Get()->Record); + if (computeData.Proto.GetChannelData().GetData().HasPayloadId()) { + computeData.Payload = ev->Get()->GetPayload(computeData.Proto.GetChannelData().GetData().GetPayloadId()); + } + + const bool trailingResults = ( + computeData.Proto.GetChannelData().GetFinished() && + Request.IsTrailingResultsAllowed()); + + TVector batches(1); + auto& batch = batches.front(); + + batch.Proto = std::move(*computeData.Proto.MutableChannelData()->MutableData()); + batch.Payload = std::move(computeData.Payload); + + TKqpProtoBuilder protoBuilder{*AppData()->FunctionRegistry}; + auto resultSet = protoBuilder.BuildYdbResultSet(std::move(batches), txResult.MkqlItemType, txResult.ColumnOrder); + + if (!trailingResults) { + auto streamEv = MakeHolder(); + streamEv->Record.SetSeqNo(computeData.Proto.GetSeqNo()); + streamEv->Record.SetQueryResultIndex(*txResult.QueryResultIndex); + streamEv->Record.SetChannelId(channel.Id); + streamEv->Record.MutableResultSet()->Swap(&resultSet); + + LOG_D("Send TEvStreamData to " << Target << ", seqNo: " << streamEv->Record.GetSeqNo() + << ", nRows: " << streamEv->Record.GetResultSet().rows().size()); + + this->Send(Target, streamEv.Release()); + + } else { + auto ackEv = MakeHolder(); + ackEv->Record.SetSeqNo(computeData.Proto.GetSeqNo()); + ackEv->Record.SetChannelId(channel.Id); + ackEv->Record.SetFreeSpace(50_MB); + this->Send(channelComputeActorId, ackEv.Release(), /* TODO: undelivery */ 0, /* cookie */ channel.Id); + txResult.TrailingResult.Swap(&resultSet); + txResult.HasTrailingResult = true; + LOG_D("staging TEvStreamData to " << Target << ", seqNo: " << computeData.Proto.GetSeqNo() + << ", nRows: " << txResult.TrailingResult.rows().size()); + } + + return; + } + + NYql::NDq::TDqSerializedBatch batch; + batch.Proto = std::move(*record.MutableChannelData()->MutableData()); + if (batch.Proto.HasPayloadId()) { + batch.Payload = ev->Get()->GetPayload(batch.Proto.GetPayloadId()); + } + + YQL_ENSURE(channel.DstTask == 0); + + if (Stats) { + Stats->ResultBytes += batch.Size(); + Stats->ResultRows += batch.RowCount(); + } + + LOG_T("Got result, channelId: " << channel.Id << ", shardId: " << task.Meta.ShardId + << ", inputIndex: " << channel.DstInputIndex << ", from: " << ev->Sender + << ", finished: " << channelData.GetFinished()); + + ResponseEv->TakeResult(channel.DstInputIndex, std::move(batch)); + LOG_T("Send ack to channelId: " << channel.Id << ", seqNo: " << record.GetSeqNo() << ", to: " << ev->Sender); + + auto ackEv = MakeHolder(); + ackEv->Record.SetSeqNo(record.GetSeqNo()); + ackEv->Record.SetChannelId(channel.Id); + ackEv->Record.SetFreeSpace(50_MB); + this->Send(channelComputeActorId, ackEv.Release(), /* TODO: undelivery */ 0, /* cookie */ channel.Id); + } + + void HandleStreamAck(TEvKqpExecuter::TEvStreamDataAck::TPtr& ev) { + ui64 channelId; + if (ResponseEv->TxResults.size() == 1) { + channelId = ResultChannelToComputeActor.begin()->first; + } else { + channelId = ev->Get()->Record.GetChannelId(); + } + + auto it = ResultChannelToComputeActor.find(channelId); + YQL_ENSURE(it != ResultChannelToComputeActor.end()); + const auto channelComputeActorId = it->second; + + ui64 seqNo = ev->Get()->Record.GetSeqNo(); + i64 freeSpace = ev->Get()->Record.GetFreeSpace(); + + LOG_ERROR_S(*NActors::TlsActivationContext, NKikimrServices::KQP_EXECUTER, "TxId: " << TxId + << ", send ack to channelId: " << channelId + << ", seqNo: " << seqNo + << ", enough: " << ev->Get()->Record.GetEnough() + << ", freeSpace: " << freeSpace + << ", to: " << channelComputeActorId); + + auto ackEv = MakeHolder(); + ackEv->Record.SetSeqNo(seqNo); + ackEv->Record.SetChannelId(channelId); + ackEv->Record.SetFreeSpace(freeSpace); + ackEv->Record.SetFinish(ev->Get()->Record.GetEnough()); + this->Send(channelComputeActorId, ackEv.Release(), /* TODO: undelivery */ 0, /* cookie */ channelId); + } + void HandleComputeStats(NYql::NDq::TEvDqCompute::TEvState::TPtr& ev) { TActorId computeActor = ev->Sender; auto& state = ev->Get()->Record; @@ -1595,6 +1728,12 @@ class TKqpExecuterBase : public TActorBootstrapped { } void InitializeChannelProxies() { + // notice: forward all respones to executer if + // trailing results are allowed. + // temporary, will be removed in the next pr. + if (Request.IsTrailingResultsAllowed()) + return; + for(const auto& channel: TasksGraph.GetChannels()) { if (channel.DstTask) { continue; @@ -1753,8 +1892,11 @@ class TKqpExecuterBase : public TActorBootstrapped { const NKikimrConfig::TTableServiceConfig::TAggregationConfig AggregationSettings; TVector ResourcesSnapshot; bool HasOlapTable = false; + bool StreamResult = false; bool HasDatashardSourceScan = false; bool UnknownAffectedShardCount = false; + + THashMap ResultChannelToComputeActor; THashMap> SourceScanStageIdToParititions; private: diff --git a/ydb/core/kqp/executer_actor/kqp_scan_executer.cpp b/ydb/core/kqp/executer_actor/kqp_scan_executer.cpp index 047bc9e007eb..d6f6f1e9813b 100644 --- a/ydb/core/kqp/executer_actor/kqp_scan_executer.cpp +++ b/ydb/core/kqp/executer_actor/kqp_scan_executer.cpp @@ -51,7 +51,8 @@ class TKqpScanExecuter : public TKqpExecuterBase& userRequestContext) : TBase(std::move(request), database, userToken, counters, executerRetriesConfig, chanTransportVersion, aggregation, - maximalSecretsSnapshotWaitTime, userRequestContext, TWilsonKqp::ScanExecuter, "ScanExecuter" + maximalSecretsSnapshotWaitTime, userRequestContext, TWilsonKqp::ScanExecuter, "ScanExecuter", + false ) , PreparedQuery(preparedQuery) { @@ -64,13 +65,13 @@ class TKqpScanExecuter : public TKqpExecuterBaseResultsSize(); YQL_ENSURE(resultsSize != 0); - bool streamResult = Request.Transactions[0].Body->GetResults(0).GetIsStream(); + StreamResult = Request.Transactions[0].Body->GetResults(0).GetIsStream(); - if (streamResult) { + if (StreamResult) { YQL_ENSURE(resultsSize == 1); } else { for (size_t i = 1; i < resultsSize; ++i) { - YQL_ENSURE(Request.Transactions[0].Body->GetResults(i).GetIsStream() == streamResult); + YQL_ENSURE(Request.Transactions[0].Body->GetResults(i).GetIsStream() == StreamResult); } } } @@ -109,7 +110,8 @@ class TKqpScanExecuter : public TKqpExecuterBaseGetTypeRewrite()) { hFunc(TEvDqCompute::TEvState, HandleComputeStats); - hFunc(TEvKqpExecuter::TEvStreamDataAck, HandleExecute); + hFunc(TEvDqCompute::TEvChannelData, HandleChannelData); // from CA + hFunc(TEvKqpExecuter::TEvStreamDataAck, HandleStreamAck); hFunc(TEvKqp::TEvAbortExecution, HandleAbortExecution); hFunc(TEvents::TEvUndelivered, HandleUndelivered); hFunc(TEvPrivate::TEvRetry, HandleRetry); @@ -126,25 +128,6 @@ class TKqpScanExecuter : public TKqpExecuterBaseGet()->Record.GetSeqNo() - << ", freeSpace: " << ev->Get()->Record.GetFreeSpace() - << ", enough: " << ev->Get()->Record.GetEnough() - << ", from: " << ev->Sender); - - auto& resultChannelProxies = GetResultChannelProxies(); - if (resultChannelProxies.empty()) { - return; - } - - // Forward only for stream results, data results acks event theirselves. - YQL_ENSURE(!ResponseEv->TxResults.empty() && ResponseEv->TxResults[0].IsStream); - - auto channelIt = resultChannelProxies.begin(); - auto handle = ev->Forward(channelIt->second->SelfId()); - channelIt->second->Receive(handle); - } - private: void HandleResolve(TEvKqpExecuter::TEvTableResolveStatus::TPtr& ev) { if (!TBase::HandleResolve(ev)) return; @@ -247,8 +230,6 @@ class TKqpScanExecuter : public TKqpExecuterBase computeTasks; - InitializeChannelProxies(); - // calc stats for (auto& task : TasksGraph.GetTasks()) { auto& stageInfo = TasksGraph.GetStageInfo(task.StageId); diff --git a/ydb/core/kqp/executer_actor/kqp_tasks_graph.h b/ydb/core/kqp/executer_actor/kqp_tasks_graph.h index 1a68edf17d16..bf27aec9dbcb 100644 --- a/ydb/core/kqp/executer_actor/kqp_tasks_graph.h +++ b/ydb/core/kqp/executer_actor/kqp_tasks_graph.h @@ -165,6 +165,7 @@ struct TTaskMeta { TActorId ExecuterId; ui32 Type = Unknown; + TActorId ResultChannelActorId; THashMap TaskParams; // Params for sources/sinks TVector ReadRanges; // Partitioning for sources THashMap SecureParams; diff --git a/ydb/core/kqp/gateway/kqp_gateway.h b/ydb/core/kqp/gateway/kqp_gateway.h index 21e16c3a710d..9171d2dbb71a 100644 --- a/ydb/core/kqp/gateway/kqp_gateway.h +++ b/ydb/core/kqp/gateway/kqp_gateway.h @@ -124,6 +124,8 @@ class IKqpGateway : public NYql::IKikimrGateway { : TxAlloc(txAlloc) {} + bool AllowTrailingResults = false; + NKikimrKqp::EQueryType QueryType = NKikimrKqp::EQueryType::QUERY_TYPE_UNDEFINED; NKikimr::TControlWrapper PerRequestDataSizeLimit; NKikimr::TControlWrapper MaxShardCount; TVector Transactions; @@ -150,6 +152,13 @@ class IKqpGateway : public NYql::IKikimrGateway { NWilson::TTraceId TraceId; NTopic::TTopicOperations TopicOperations; + + bool IsTrailingResultsAllowed() const { + return AllowTrailingResults && ( + QueryType == NKikimrKqp::EQueryType::QUERY_TYPE_SQL_GENERIC_QUERY || + QueryType == NKikimrKqp::EQueryType::QUERY_TYPE_SQL_GENERIC_CONCURRENT_QUERY + ); + } }; struct TExecPhysicalResult : public TGenericResult { diff --git a/ydb/core/kqp/query_data/kqp_query_data.cpp b/ydb/core/kqp/query_data/kqp_query_data.cpp index c673182b5111..c0bf8e338ed0 100644 --- a/ydb/core/kqp/query_data/kqp_query_data.cpp +++ b/ydb/core/kqp/query_data/kqp_query_data.cpp @@ -77,6 +77,19 @@ Ydb::ResultSet* TKqpExecuterTxResult::GetYdb(google::protobuf::Arena* arena, TMa return ydbResult; } +Ydb::ResultSet* TKqpExecuterTxResult::GetTrailingYdb(google::protobuf::Arena* arena) { + if (!HasTrailingResult) + return nullptr; + + Ydb::ResultSet* ydbResult = google::protobuf::Arena::CreateMessage(arena); + if (TrailingResult.rows().size() > 0) { + ydbResult->Swap(&TrailingResult); + } + + return ydbResult; +} + + void TKqpExecuterTxResult::FillYdb(Ydb::ResultSet* ydbResult, TMaybe rowsLimitPerWrite) { YQL_ENSURE(ydbResult); YQL_ENSURE(!Rows.IsWide()); @@ -89,7 +102,7 @@ void TKqpExecuterTxResult::FillYdb(Ydb::ResultSet* ydbResult, TMaybe rowsL column->set_name(TString(mkqlSrcRowStructType->GetMemberName(memberIndex))); ExportTypeToProto(mkqlSrcRowStructType->GetMemberType(memberIndex), *column->mutable_type()); } - + Rows.ForEachRow([&](const NUdf::TUnboxedValue& value) -> bool { if (rowsLimitPerWrite) { if (*rowsLimitPerWrite == 0) { @@ -224,6 +237,13 @@ NKikimrMiniKQL::TResult* TQueryData::GetMkqlTxResult(const NKqpProto::TKqpPhyRes return TxResults[txIndex][resultIndex].GetMkql(arena); } +Ydb::ResultSet* TQueryData::GetTrailingTxResult(const NKqpProto::TKqpPhyResultBinding& rb, google::protobuf::Arena* arena) { + auto txIndex = rb.GetTxResultBinding().GetTxIndex(); + auto resultIndex = rb.GetTxResultBinding().GetResultIndex(); + return TxResults[txIndex][resultIndex].GetTrailingYdb(arena); +} + + Ydb::ResultSet* TQueryData::GetYdbTxResult(const NKqpProto::TKqpPhyResultBinding& rb, google::protobuf::Arena* arena, TMaybe rowsLimitPerWrite) { auto txIndex = rb.GetTxResultBinding().GetTxIndex(); auto resultIndex = rb.GetTxResultBinding().GetResultIndex(); diff --git a/ydb/core/kqp/query_data/kqp_query_data.h b/ydb/core/kqp/query_data/kqp_query_data.h index 181e13bc3b8a..ca8e772d5bda 100644 --- a/ydb/core/kqp/query_data/kqp_query_data.h +++ b/ydb/core/kqp/query_data/kqp_query_data.h @@ -81,6 +81,8 @@ struct TKqpExecuterTxResult { const TVector* ColumnOrder = nullptr; TMaybe QueryResultIndex = 0; NKikimr::NMiniKQL::TUnboxedValueBatch Rows; + Ydb::ResultSet TrailingResult; + bool HasTrailingResult = false; explicit TKqpExecuterTxResult( bool isStream, @@ -98,6 +100,7 @@ struct TKqpExecuterTxResult { NKikimrMiniKQL::TResult* GetMkql(google::protobuf::Arena* arena); NKikimrMiniKQL::TResult GetMkql(); Ydb::ResultSet* GetYdb(google::protobuf::Arena* arena, TMaybe rowsLimitPerWrite); + Ydb::ResultSet* GetTrailingYdb(google::protobuf::Arena* arena); void FillMkql(NKikimrMiniKQL::TResult* mkqlResult); void FillYdb(Ydb::ResultSet* ydbResult, TMaybe rowsLimitPerWrite); @@ -250,6 +253,7 @@ class TQueryData : NMiniKQL::ITerminator { TTypedUnboxedValue GetTxResult(ui32 txIndex, ui32 resultIndex); NKikimrMiniKQL::TResult* GetMkqlTxResult(const NKqpProto::TKqpPhyResultBinding& rb, google::protobuf::Arena* arena); Ydb::ResultSet* GetYdbTxResult(const NKqpProto::TKqpPhyResultBinding& rb, google::protobuf::Arena* arena, TMaybe rowsLimitPerWrite); + Ydb::ResultSet* GetTrailingTxResult(const NKqpProto::TKqpPhyResultBinding& rb, google::protobuf::Arena* arena); std::pair GetInternalBindingValue(const NKqpProto::TKqpPhyParamBinding& paramBinding); TTypedUnboxedValue& GetParameterUnboxedValue(const TString& name); diff --git a/ydb/core/kqp/session_actor/kqp_session_actor.cpp b/ydb/core/kqp/session_actor/kqp_session_actor.cpp index 1977aad58837..00bb19061486 100644 --- a/ydb/core/kqp/session_actor/kqp_session_actor.cpp +++ b/ydb/core/kqp/session_actor/kqp_session_actor.cpp @@ -764,6 +764,12 @@ class TKqpSessionActor : public TActorBootstrapped { request.StatsMode = queryState->GetStatsMode(); request.ProgressStatsPeriod = queryState->GetProgressStatsPeriod(); + request.QueryType = queryState->GetType(); + if (Y_LIKELY(queryState->PreparedQuery)) { + ui64 resultSetsCount = queryState->PreparedQuery->GetPhysicalQuery().ResultBindingsSize(); + request.AllowTrailingResults = (resultSetsCount == 1); + request.AllowTrailingResults &= (QueryState->RequestEv->GetSupportsStreamTrailingResult()); + } } const auto& limits = GetQueryLimits(Settings); @@ -1537,10 +1543,24 @@ class TKqpSessionActor : public TActorBootstrapped { // Result for scan query is sent directly to target actor. Y_ABORT_UNLESS(response->GetArena()); - if (QueryState->PreparedQuery && !QueryState->IsStreamResult()) { + if (QueryState->PreparedQuery) { bool useYdbResponseFormat = QueryState->GetUsePublicResponseDataFormat(); auto& phyQuery = QueryState->PreparedQuery->GetPhysicalQuery(); + size_t trailingResultsCount = 0; for (size_t i = 0; i < phyQuery.ResultBindingsSize(); ++i) { + if (QueryState->IsStreamResult()) { + auto ydbResult = QueryState->QueryData->GetTrailingTxResult( + phyQuery.GetResultBindings(i), response->GetArena()); + + if (ydbResult) { + ++trailingResultsCount; + YQL_ENSURE(trailingResultsCount <= 1); + response->AddYdbResults()->Swap(ydbResult); + } + + continue; + } + if (useYdbResponseFormat) { TMaybe effectiveRowsLimit = FillSettings.RowsLimitPerWrite; if (QueryState->PreparedQuery->GetResults(i).GetRowsLimit()) { diff --git a/ydb/core/protos/kqp.proto b/ydb/core/protos/kqp.proto index 56497ea35034..bcfc0f9f499f 100644 --- a/ydb/core/protos/kqp.proto +++ b/ydb/core/protos/kqp.proto @@ -420,12 +420,16 @@ message TEvExecuterStreamData { optional Ydb.ResultSet ResultSet = 1; optional uint64 SeqNo = 2; optional uint32 QueryResultIndex = 3; + optional uint32 ChannelId = 4; + optional NActorsProto.TActorId ChannelActorId = 5; }; message TEvExecuterStreamDataAck { optional uint64 SeqNo = 1; optional int64 FreeSpace = 2; optional bool Enough = 3 [default = false]; + optional uint32 ChannelId = 4; + optional NActorsProto.TActorId ChannelActorId = 5; }; message TEvExecuterStreamProfile { @@ -434,7 +438,7 @@ message TEvExecuterStreamProfile { }; // 1. Executer fills progress stats from it's own execution -// 2. Session adds stats from early finished executions and builds complete plan +// 2. Session adds stats from early finished executions and builds complete plan message TEvExecuterProgress { optional NActorsProto.TActorId ExecuterActorId = 1; optional string QueryPlan = 2; diff --git a/ydb/core/testlib/test_client.cpp b/ydb/core/testlib/test_client.cpp index 58b5e29299b8..b4c35f7375ac 100644 --- a/ydb/core/testlib/test_client.cpp +++ b/ydb/core/testlib/test_client.cpp @@ -387,7 +387,7 @@ namespace Tests { GRpcServer->AddService(new NQuoter::TRateLimiterGRpcService(system, counters, grpcRequestProxies[0])); GRpcServer->AddService(new NGRpcService::TGRpcDataStreamsService(system, counters, grpcRequestProxies[0], true)); GRpcServer->AddService(new NGRpcService::TGRpcMonitoringService(system, counters, grpcRequestProxies[0], true)); - GRpcServer->AddService(new NGRpcService::TGRpcYdbQueryService(system, counters, grpcRequestProxies[0], true)); + GRpcServer->AddService(new NGRpcService::TGRpcYdbQueryService(system, counters, grpcRequestProxies, true, 1)); if (Settings->EnableYq) { GRpcServer->AddService(new NGRpcService::TGRpcFederatedQueryService(system, counters, grpcRequestProxies[0])); GRpcServer->AddService(new NGRpcService::TGRpcFqPrivateTaskService(system, counters, grpcRequestProxies[0])); diff --git a/ydb/services/ydb/ydb_query.cpp b/ydb/services/ydb/ydb_query.cpp index 03f031430f1e..760599e68ccc 100644 --- a/ydb/services/ydb/ydb_query.cpp +++ b/ydb/services/ydb/ydb_query.cpp @@ -7,76 +7,60 @@ namespace NKikimr::NGRpcService { +TGRpcYdbQueryService::TGRpcYdbQueryService(NActors::TActorSystem *system, + TIntrusivePtr<::NMonitoring::TDynamicCounters> counters, + const NActors::TActorId& proxyId, + bool rlAllowed, + size_t handlersPerCompletionQueue) + : TGrpcServiceBase(system, counters, proxyId, rlAllowed) + , HandlersPerCompletionQueue(Max(size_t{1}, handlersPerCompletionQueue)) +{ +} + +TGRpcYdbQueryService::TGRpcYdbQueryService(NActors::TActorSystem *system, + TIntrusivePtr<::NMonitoring::TDynamicCounters> counters, + const TVector& proxies, + bool rlAllowed, + size_t handlersPerCompletionQueue) + : TGrpcServiceBase(system, counters, proxies, rlAllowed) + , HandlersPerCompletionQueue(Max(size_t{1}, handlersPerCompletionQueue)) +{ +} + void TGRpcYdbQueryService::SetupIncomingRequests(NYdbGrpc::TLoggerPtr logger) { using namespace Ydb::Query; using namespace NQuery; auto getCounterBlock = CreateCounterCb(Counters_, ActorSystem_); + size_t proxyCounter = 0; #ifdef ADD_REQUEST #error ADD_REQUEST macro already defined #endif -#define ADD_REQUEST(NAME, IN, OUT, ACTION) \ - MakeIntrusive>(this, &Service_, CQ_, \ - [this](NYdbGrpc::IRequestContextBase* ctx) { \ - NGRpcService::ReportGrpcReqToMon(*ActorSystem_, ctx->GetPeer()); \ - ACTION; \ - }, &Ydb::Query::V1::QueryService::AsyncService::Request ## NAME, \ - #NAME, logger, getCounterBlock("query", #NAME))->Run(); - - ADD_REQUEST(ExecuteQuery, ExecuteQueryRequest, ExecuteQueryResponsePart, { - ActorSystem_->Send(GRpcRequestProxyId_, - new TGrpcRequestNoOperationCall - (ctx, &DoExecuteQuery, TRequestAuxSettings{RLSWITCH(TRateLimiterMode::Rps), nullptr, TAuditMode::Auditable})); - }) - - ADD_REQUEST(ExecuteScript, ExecuteScriptRequest, Ydb::Operations::Operation, { - ActorSystem_->Send(GRpcRequestProxyId_, - new TGrpcRequestNoOperationCall - (ctx, &DoExecuteScript, TRequestAuxSettings{RLSWITCH(TRateLimiterMode::Rps), nullptr, TAuditMode::Auditable})); - }) - - ADD_REQUEST(FetchScriptResults, FetchScriptResultsRequest, FetchScriptResultsResponse, { - ActorSystem_->Send(GRpcRequestProxyId_, - new TGrpcRequestNoOperationCall - (ctx, &DoFetchScriptResults, TRequestAuxSettings{RLSWITCH(TRateLimiterMode::Rps), nullptr})); - }) - - ADD_REQUEST(CreateSession, CreateSessionRequest, CreateSessionResponse, { - ActorSystem_->Send(GRpcRequestProxyId_, - new TGrpcRequestNoOperationCall - (ctx, &DoCreateSession, TRequestAuxSettings{RLSWITCH(TRateLimiterMode::Rps), nullptr})); - }) - - ADD_REQUEST(DeleteSession, DeleteSessionRequest, DeleteSessionResponse, { - ActorSystem_->Send(GRpcRequestProxyId_, - new TGrpcRequestNoOperationCall - (ctx, &DoDeleteSession, TRequestAuxSettings{RLSWITCH(TRateLimiterMode::Rps), nullptr})); - }) - - ADD_REQUEST(AttachSession, AttachSessionRequest, SessionState, { - ActorSystem_->Send(GRpcRequestProxyId_, - new TGrpcRequestNoOperationCall - (ctx, &DoAttachSession, TRequestAuxSettings{RLSWITCH(TRateLimiterMode::Rps), nullptr})); - }) - - ADD_REQUEST(BeginTransaction, BeginTransactionRequest, BeginTransactionResponse, { - ActorSystem_->Send(GRpcRequestProxyId_, - new TGrpcRequestNoOperationCall - (ctx, &DoBeginTransaction, TRequestAuxSettings{RLSWITCH(TRateLimiterMode::Rps), nullptr})); - }) - - ADD_REQUEST(CommitTransaction, CommitTransactionRequest, CommitTransactionResponse, { - ActorSystem_->Send(GRpcRequestProxyId_, - new TGrpcRequestNoOperationCall - (ctx, &DoCommitTransaction, TRequestAuxSettings{RLSWITCH(TRateLimiterMode::Rps), nullptr})); - }) - - ADD_REQUEST(RollbackTransaction, RollbackTransactionRequest, RollbackTransactionResponse, { - ActorSystem_->Send(GRpcRequestProxyId_, - new TGrpcRequestNoOperationCall - (ctx, &DoRollbackTransaction, TRequestAuxSettings{RLSWITCH(TRateLimiterMode::Rps), nullptr})); - }) +#define ADD_REQUEST(NAME, IN, OUT, CB, ...) \ + for (size_t i = 0; i < HandlersPerCompletionQueue; ++i) { \ + for (auto* cq: CQS) { \ + MakeIntrusive>(this, &Service_, cq, \ + [this, proxyCounter](NYdbGrpc::IRequestContextBase* ctx) { \ + NGRpcService::ReportGrpcReqToMon(*ActorSystem_, ctx->GetPeer()); \ + ActorSystem_->Send(GRpcProxies_[proxyCounter % GRpcProxies_.size()], \ + new TGrpcRequestNoOperationCall \ + (ctx, &CB, TRequestAuxSettings{RLSWITCH(TRateLimiterMode::Rps), nullptr __VA_OPT__(, TAuditMode::__VA_ARGS__)})); \ + }, &Ydb::Query::V1::QueryService::AsyncService::Request ## NAME, \ + #NAME, logger, getCounterBlock("query", #NAME))->Run(); \ + ++proxyCounter; \ + } \ + } + + ADD_REQUEST(ExecuteQuery, ExecuteQueryRequest, ExecuteQueryResponsePart, DoExecuteQuery, Auditable); + ADD_REQUEST(ExecuteScript, ExecuteScriptRequest, Ydb::Operations::Operation, DoExecuteScript, Auditable); + ADD_REQUEST(FetchScriptResults, FetchScriptResultsRequest, FetchScriptResultsResponse, DoFetchScriptResults); + ADD_REQUEST(CreateSession, CreateSessionRequest, CreateSessionResponse, DoCreateSession); + ADD_REQUEST(DeleteSession, DeleteSessionRequest, DeleteSessionResponse, DoDeleteSession); + ADD_REQUEST(AttachSession, AttachSessionRequest, SessionState, DoAttachSession); + ADD_REQUEST(BeginTransaction, BeginTransactionRequest, BeginTransactionResponse, DoBeginTransaction); + ADD_REQUEST(CommitTransaction, CommitTransactionRequest, CommitTransactionResponse, DoCommitTransaction); + ADD_REQUEST(RollbackTransaction, RollbackTransactionRequest, RollbackTransactionResponse, DoRollbackTransaction); #undef ADD_REQUEST } diff --git a/ydb/services/ydb/ydb_query.h b/ydb/services/ydb/ydb_query.h index 8dec5cc4fa7f..04e8ab915ee7 100644 --- a/ydb/services/ydb/ydb_query.h +++ b/ydb/services/ydb/ydb_query.h @@ -11,8 +11,25 @@ class TGRpcYdbQueryService public: using TGrpcServiceBase::TGrpcServiceBase; + TGRpcYdbQueryService( + NActors::TActorSystem *system, + TIntrusivePtr<::NMonitoring::TDynamicCounters> counters, + const NActors::TActorId& proxyId, + bool rlAllowed, + size_t handlersPerCompletionQueue = 1); + + TGRpcYdbQueryService( + NActors::TActorSystem *system, + TIntrusivePtr<::NMonitoring::TDynamicCounters> counters, + const TVector& proxies, + bool rlAllowed, + size_t handlersPerCompletionQueue); + private: void SetupIncomingRequests(NYdbGrpc::TLoggerPtr logger); + +private: + const size_t HandlersPerCompletionQueue; }; } // namespace NKikimr::NGRpcService From 4f74dd7a0c4a640e6e567fddb83694853ed5ac41 Mon Sep 17 00:00:00 2001 From: Sergey Belyakov Date: Mon, 5 Feb 2024 17:53:36 +0300 Subject: [PATCH 005/117] Add compatibility info (#1583) --- ydb/core/driver_lib/version/version.cpp | 38 +++++++++++++++++++++---- 1 file changed, 33 insertions(+), 5 deletions(-) diff --git a/ydb/core/driver_lib/version/version.cpp b/ydb/core/driver_lib/version/version.cpp index 4781640d0339..37e4ae626562 100644 --- a/ydb/core/driver_lib/version/version.cpp +++ b/ydb/core/driver_lib/version/version.cpp @@ -19,7 +19,7 @@ using TComponentId = NKikimrConfig::TCompatibilityRule::EComponentId; TCompatibilityInfo::TCompatibilityInfo() { using TCurrentConstructor = TCompatibilityInfo::TProtoConstructor::TCurrentCompatibilityInfo; using TStoredConstructor = TCompatibilityInfo::TProtoConstructor::TStoredCompatibilityInfo; - // using TCompatibilityRuleConstructor = TCompatibilityInfo::TProtoConstructor::TCompatibilityRule; + using TCompatibilityRuleConstructor = TCompatibilityInfo::TProtoConstructor::TCompatibilityRule; using TVersionConstructor = TCompatibilityInfo::TProtoConstructor::TVersion; ///////////////////////////////////////////////////////// @@ -27,10 +27,36 @@ TCompatibilityInfo::TCompatibilityInfo() { ///////////////////////////////////////////////////////// auto current = TCurrentConstructor{ - .Application = "ydb" + .Application = "ydb", + .Version = TVersionConstructor{ + .Year = 24, + .Major = 1, + }, + .CanLoadFrom = { + TCompatibilityRuleConstructor{ + .Application = "ydb", + .LowerLimit = TVersionConstructor{ .Year = 23, .Major = 3 }, + .UpperLimit = TVersionConstructor{ .Year = 24, .Major = 1 }, + }, + }, + .StoresReadableBy = { + TCompatibilityRuleConstructor{ + .Application = "ydb", + .LowerLimit = TVersionConstructor{ .Year = 23, .Major = 3 }, + .UpperLimit = TVersionConstructor{ .Year = 24, .Major = 1 }, + }, + }, + .CanConnectTo = { + TCompatibilityRuleConstructor{ + .Application = "ydb", + .LowerLimit = TVersionConstructor{ .Year = 23, .Major = 3 }, + .UpperLimit = TVersionConstructor{ .Year = 24, .Major = 1 }, + }, + } }.ToPB(); - // bool success = CompleteFromTag(current); + bool success = CompleteFromTag(current); + Y_UNUSED(success); // Y_ABORT_UNLESS(success); CurrentCompatibilityInfo.CopyFrom(current); @@ -76,12 +102,14 @@ const TStored* TCompatibilityInfo::GetDefault(TComponentId componentId) const { // obsolete version control TMaybe VERSION = NActors::TInterconnectProxyCommon::TVersionInfo{ // version of this binary - "trunk", + "stable-24-1", // compatible versions; must include all compatible old ones, including this one; version verification occurs on both // peers and connection is accepted if at least one of peers accepts the version of the other peer { - "trunk" + "stable-23-3", + "stable-23-4", + "stable-24-1" } }; From a2eb3837202bbde2f15cd093a23f5357b7e0a396 Mon Sep 17 00:00:00 2001 From: Innokentii Mokin Date: Tue, 6 Feb 2024 14:31:27 +0300 Subject: [PATCH 006/117] fix empty config requirement (#1622) --- ydb/core/driver_lib/cli_utils/cli_cmds_server.cpp | 3 +++ 1 file changed, 3 insertions(+) diff --git a/ydb/core/driver_lib/cli_utils/cli_cmds_server.cpp b/ydb/core/driver_lib/cli_utils/cli_cmds_server.cpp index 138f467ec37f..73cd6cf2b7b8 100644 --- a/ydb/core/driver_lib/cli_utils/cli_cmds_server.cpp +++ b/ydb/core/driver_lib/cli_utils/cli_cmds_server.cpp @@ -823,6 +823,9 @@ class TClientCommandServerBase : public TClientCommand { } inline void LoadYamlConfig(TCallContext callCtx) { + if (!YamlConfigFile) { + return; + } auto yamlConfig = TFileInput(YamlConfigFile); NKikimrConfig::TAppConfig parsedConfig; NKikimr::NYaml::Parse(yamlConfig.ReadAll(), parsedConfig); From afd43bdf82d60f6c59c3997101740e4c1b394ef6 Mon Sep 17 00:00:00 2001 From: spuchin Date: Wed, 7 Feb 2024 12:38:33 +0300 Subject: [PATCH 007/117] Set mkql runtime version. (#1609) Set mkql runtime version, fix tests. (KIKIMR-19847) --- .../kqp/opt/peephole/kqp_opt_peephole.cpp | 5 +++++ .../minikql/comp_nodes/ut/mkql_blocks_ut.cpp | 5 +++++ .../comp_nodes/ut/mkql_wide_combine_ut.cpp | 19 +++++++++++++++++-- .../yql/minikql/mkql_program_builder.cpp | 16 ++++++++++------ .../yql/minikql/mkql_runtime_version.h | 12 +++++++++++- .../yql/tests/s-expressions/common_file.py | 6 ++++++ ydb/library/yql/tests/sql/yt_file.py | 3 +++ 7 files changed, 57 insertions(+), 9 deletions(-) diff --git a/ydb/core/kqp/opt/peephole/kqp_opt_peephole.cpp b/ydb/core/kqp/opt/peephole/kqp_opt_peephole.cpp index bbb3dd54d221..abbb23f52b65 100644 --- a/ydb/core/kqp/opt/peephole/kqp_opt_peephole.cpp +++ b/ydb/core/kqp/opt/peephole/kqp_opt_peephole.cpp @@ -14,6 +14,7 @@ #include #include #include +#include #include #include @@ -181,6 +182,10 @@ class TKqpPeepholeFinalTransformer : public TOptimizeTransformerBase { } private: TMaybeNode SetCombinerMemoryLimit(TExprBase node, TExprContext& ctx) { + if (NMiniKQL::RuntimeVersion < 46U) { + return node; + } + if (const auto limit = node.Ref().Child(TCoWideCombiner::idx_MemLimit); limit->IsAtom("0")) { if (const auto limitSetting = Config->_KqpYqlCombinerMemoryLimit.Get(); limitSetting && *limitSetting) { return ctx.ChangeChild(node.Ref(), TCoWideCombiner::idx_MemLimit, ctx.RenameNode(*limit, ToString(-i64(*limitSetting)))); diff --git a/ydb/library/yql/minikql/comp_nodes/ut/mkql_blocks_ut.cpp b/ydb/library/yql/minikql/comp_nodes/ut/mkql_blocks_ut.cpp index ca4bb2e546c5..61e5dc0e7957 100644 --- a/ydb/library/yql/minikql/comp_nodes/ut/mkql_blocks_ut.cpp +++ b/ydb/library/yql/minikql/comp_nodes/ut/mkql_blocks_ut.cpp @@ -1,6 +1,7 @@ #include "mkql_computation_node_ut.h" #include +#include #include #include @@ -264,6 +265,10 @@ Y_UNIT_TEST(TestScalar) { } Y_UNIT_TEST_LLVM(TestReplicateScalar) { + if (RuntimeVersion < 43u) { + return; + } + const ui64 count = 1000; const ui32 value = 42; diff --git a/ydb/library/yql/minikql/comp_nodes/ut/mkql_wide_combine_ut.cpp b/ydb/library/yql/minikql/comp_nodes/ut/mkql_wide_combine_ut.cpp index 1984d7bde28e..884defdf971e 100644 --- a/ydb/library/yql/minikql/comp_nodes/ut/mkql_wide_combine_ut.cpp +++ b/ydb/library/yql/minikql/comp_nodes/ut/mkql_wide_combine_ut.cpp @@ -122,6 +122,10 @@ TRuntimeNode Combine(TProgramBuilder& pb, TRuntimeNode stream, std::function= 18u Y_UNIT_TEST_SUITE(TMiniKQLWideCombinerTest) { Y_UNIT_TEST_LLVM(TestLongStringsRefCounting) { + if (RuntimeVersion < 46u) { + return; + } + TSetup setup; TProgramBuilder& pb = *setup.PgmBuilder; @@ -199,6 +203,10 @@ Y_UNIT_TEST_SUITE(TMiniKQLWideCombinerTest) { } Y_UNIT_TEST_LLVM(TestLongStringsPasstroughtRefCounting) { + if (RuntimeVersion < 46u) { + return; + } + TSetup setup; TProgramBuilder& pb = *setup.PgmBuilder; @@ -274,6 +282,10 @@ Y_UNIT_TEST_SUITE(TMiniKQLWideCombinerTest) { } Y_UNIT_TEST_LLVM(TestDoNotCalculateUnusedInput) { + if (RuntimeVersion < 46u) { + return; + } + TSetup setup; TProgramBuilder& pb = *setup.PgmBuilder; @@ -427,8 +439,12 @@ Y_UNIT_TEST_SUITE(TMiniKQLWideCombinerTest) { UNIT_ASSERT(!iterator.Next(item)); UNIT_ASSERT(!iterator.Next(item)); } -#if !defined(MKQL_RUNTIME_VERSION) || MKQL_RUNTIME_VERSION >= 46u + Y_UNIT_TEST_LLVM(TestHasLimitButPasstroughtYields) { + if (RuntimeVersion < 46u) { + return; + } + TSetup setup(GetNodeFactory()); TProgramBuilder& pb = *setup.PgmBuilder; @@ -458,7 +474,6 @@ Y_UNIT_TEST_SUITE(TMiniKQLWideCombinerTest) { UNIT_ASSERT_EQUAL(streamVal.Fetch(result), NUdf::EFetchStatus::Finish); UNIT_ASSERT_EQUAL(streamVal.Fetch(result), NUdf::EFetchStatus::Finish); } -#endif } Y_UNIT_TEST_SUITE(TMiniKQLWideCombinerPerfTest) { diff --git a/ydb/library/yql/minikql/mkql_program_builder.cpp b/ydb/library/yql/minikql/mkql_program_builder.cpp index c12742d9a606..1812a9dd5c5f 100644 --- a/ydb/library/yql/minikql/mkql_program_builder.cpp +++ b/ydb/library/yql/minikql/mkql_program_builder.cpp @@ -5493,9 +5493,11 @@ TRuntimeNode TProgramBuilder::PgConst(TPgType* pgType, const std::string_view& v TRuntimeNode TProgramBuilder::PgResolvedCall(bool useContext, const std::string_view& name, ui32 id, const TArrayRef& args, TType* returnType, bool rangeFunction) { - if constexpr (RuntimeVersion < 45U) { - THROW yexception() << "Runtime version (" << RuntimeVersion << ") too old for " << __func__; - } + + // Disable runtime compatibility checks for PG callables in 24-1 + // if constexpr (RuntimeVersion < 45U) { + // THROW yexception() << "Runtime version (" << RuntimeVersion << ") too old for " << __func__; + // } TCallableBuilder callableBuilder(Env, __func__, returnType); callableBuilder.Add(NewDataLiteral(useContext)); @@ -5540,9 +5542,11 @@ TRuntimeNode TProgramBuilder::PgTableContent( const std::string_view& cluster, const std::string_view& table, TType* returnType) { - if constexpr (RuntimeVersion < 47U) { - THROW yexception() << "Runtime version (" << RuntimeVersion << ") too old for " << __func__; - } + + // Disable runtime compatibility checks for PG callables in 24-1 + // if constexpr (RuntimeVersion < 47U) { + // THROW yexception() << "Runtime version (" << RuntimeVersion << ") too old for " << __func__; + // } TCallableBuilder callableBuilder(Env, __func__, returnType); callableBuilder.Add(NewDataLiteral(cluster)); diff --git a/ydb/library/yql/minikql/mkql_runtime_version.h b/ydb/library/yql/minikql/mkql_runtime_version.h index e7f39f9b250b..ea538c42c4af 100644 --- a/ydb/library/yql/minikql/mkql_runtime_version.h +++ b/ydb/library/yql/minikql/mkql_runtime_version.h @@ -24,12 +24,22 @@ namespace NMiniKQL { // 1. Bump this version every time incompatible runtime nodes are introduced. // 2. Make sure you provide runtime node generation for previous runtime versions. #ifndef MKQL_RUNTIME_VERSION -#define MKQL_RUNTIME_VERSION 47U +#define MKQL_RUNTIME_VERSION 39U #endif // History: // v4 is the version supported by kikimr-19-6 // v14 is the version supported by kikimr-20-2 +// v14 is the version supported by kikimr-20-2 +// v21 is the version supported by kikimr-20-4 +// v21 is the version supported by kikimr-20-6 +// v23 is the version supported by kikimr-21-2 +// v24 is the version supported by kikimr-21-4 +// v29 is the version supported by kikimr-22-2 +// v30 is the version supported by kikimr-22-4 +// v32 is the version supported by kikimr-23-1 +// v39 is the version supported by kikimr-23-3 +// v47 is the version supported by kikimr-24-1 constexpr ui32 RuntimeVersion = MKQL_RUNTIME_VERSION; } diff --git a/ydb/library/yql/tests/s-expressions/common_file.py b/ydb/library/yql/tests/s-expressions/common_file.py index e17ada446df7..e1c7d337146f 100644 --- a/ydb/library/yql/tests/s-expressions/common_file.py +++ b/ydb/library/yql/tests/s-expressions/common_file.py @@ -68,6 +68,12 @@ def yqlrun_yt_results(provider, prepare, suite, case, config): def run_test(provider, prepare, suite, case, tmpdir, what): + if "TimeOrder" in suite: + pytest.skip('Unsupported in runtime version v39') + + if "SelfJoinCore" in case: + pytest.skip('Unsupported in runtime version v39') + if get_param('TARGET_PLATFORM'): if "ArcPython" in case: pytest.skip('ArcPython is not supported on non-default target platform') diff --git a/ydb/library/yql/tests/sql/yt_file.py b/ydb/library/yql/tests/sql/yt_file.py index 17afde5cdda5..a299f18a4e4d 100644 --- a/ydb/library/yql/tests/sql/yt_file.py +++ b/ydb/library/yql/tests/sql/yt_file.py @@ -18,6 +18,9 @@ def run_test(suite, case, cfg, tmpdir, what, yql_http_file_server): + if "match_recognize" in suite: + pytest.skip('Unsupported TimeOrder* in runtime version v39') + if get_param('SQL_FLAGS'): if what == 'Debug' or what == 'Plan' or what == 'Peephole' or what == 'Lineage': pytest.skip('SKIP') From 0d8c09ca8d2273da014921c127ce790a59ce67e9 Mon Sep 17 00:00:00 2001 From: Vitalii Gridnev Date: Wed, 7 Feb 2024 12:57:07 +0300 Subject: [PATCH 008/117] Fix scheme_tests canondata (#1493) (#1643) * Initial commit * Fixes Co-authored-by: Nikolay Shumkov <153636981+shnikd@users.noreply.github.com> --- .../flat_schemeshard.schema | 28 +++++++++++++++++-- 1 file changed, 26 insertions(+), 2 deletions(-) diff --git a/ydb/tests/functional/scheme_tests/canondata/tablet_scheme_tests.TestTabletSchemes.test_tablet_schemes_flat_schemeshard_/flat_schemeshard.schema b/ydb/tests/functional/scheme_tests/canondata/tablet_scheme_tests.TestTabletSchemes.test_tablet_schemes_flat_schemeshard_/flat_schemeshard.schema index 937270748b93..ac60dcdd47f0 100644 --- a/ydb/tests/functional/scheme_tests/canondata/tablet_scheme_tests.TestTabletSchemes.test_tablet_schemes_flat_schemeshard_/flat_schemeshard.schema +++ b/ydb/tests/functional/scheme_tests/canondata/tablet_scheme_tests.TestTabletSchemes.test_tablet_schemes_flat_schemeshard_/flat_schemeshard.schema @@ -346,6 +346,16 @@ "ColumnId": 10, "ColumnName": "ReplicationConfig", "ColumnType": "String" + }, + { + "ColumnId": 11, + "ColumnName": "IsTemporary", + "ColumnType": "Bool" + }, + { + "ColumnId": 12, + "ColumnName": "OwnerActorId", + "ColumnType": "String" } ], "ColumnsDropped": [], @@ -361,7 +371,9 @@ 7, 8, 9, - 10 + 10, + 11, + 12 ], "RoomID": 0, "Codec": 0, @@ -3533,6 +3545,16 @@ "ColumnId": 11, "ColumnName": "ReplicationConfig", "ColumnType": "String" + }, + { + "ColumnId": 12, + "ColumnName": "IsTemporary", + "ColumnType": "Bool" + }, + { + "ColumnId": 13, + "ColumnName": "OwnerActorId", + "ColumnType": "String" } ], "ColumnsDropped": [], @@ -3549,7 +3571,9 @@ 8, 9, 10, - 11 + 11, + 12, + 13 ], "RoomID": 0, "Codec": 0, From 9b503c29549c49f781a42854cafca51e584d10b6 Mon Sep 17 00:00:00 2001 From: Vitalii Gridnev Date: Wed, 7 Feb 2024 12:57:24 +0300 Subject: [PATCH 009/117] remove debugging cerr (24-1) (#1642) --- ydb/core/kqp/provider/yql_kikimr_opt_build.cpp | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/ydb/core/kqp/provider/yql_kikimr_opt_build.cpp b/ydb/core/kqp/provider/yql_kikimr_opt_build.cpp index 55c8adf074d6..9ba5c0fb5647 100644 --- a/ydb/core/kqp/provider/yql_kikimr_opt_build.cpp +++ b/ydb/core/kqp/provider/yql_kikimr_opt_build.cpp @@ -654,7 +654,7 @@ bool ExploreTx(TExprBase node, TExprContext& ctx, const TKiDataSink& dataSink, T { txRes.Ops.insert(node.Raw()); bool result = ExploreTx(TExprBase(node.Ref().ChildPtr(0)), ctx, dataSink, txRes, tablesData, types); - Cerr << KqpExprToPrettyString(*node.Raw(), ctx) << Endl; +// Cerr << KqpExprToPrettyString(*node.Raw(), ctx) << Endl; txRes.AddResult(node); return result; } From 2751a13c9c7863a27ea9d1bcfa5a50ce975abb17 Mon Sep 17 00:00:00 2001 From: Alexander Rutkovsky Date: Wed, 7 Feb 2024 19:13:12 +0300 Subject: [PATCH 010/117] Merge some fixes from main (#1672) * Fix scrubbing and flapping unittest (#1640) * Fix leaking blobs via using patching (#1639) --------- Co-authored-by: kruall --- ydb/core/blobstorage/backpressure/queue.h | 4 + .../queue_backpressure_client.cpp | 6 +- .../backpressure/queue_backpressure_server.h | 4 +- .../blobstorage/dsproxy/dsproxy_get_impl.cpp | 5 +- .../blobstorage/dsproxy/dsproxy_patch.cpp | 26 +-- .../blobstorage/pdisk/mock/pdisk_mock.cpp | 9 ++ ydb/core/blobstorage/pdisk/mock/pdisk_mock.h | 1 + .../blobstorage/ut_blobstorage/scrub_fast.cpp | 152 +++++++++++++----- .../blobstorage/vdisk/common/vdisk_events.h | 13 +- .../vdisk/scrub/blob_recovery_impl.h | 4 +- .../vdisk/scrub/blob_recovery_process.cpp | 111 ++++++++----- .../vdisk/scrub/blob_recovery_request.cpp | 9 +- .../scrub/restore_corrupted_blob_actor.cpp | 8 + .../skeleton/blobstorage_skeletonfront.cpp | 4 +- .../vdisk/skeleton/skeleton_vpatch_actor.cpp | 11 +- 15 files changed, 255 insertions(+), 112 deletions(-) diff --git a/ydb/core/blobstorage/backpressure/queue.h b/ydb/core/blobstorage/backpressure/queue.h index 5ba7a745a73c..f7e49e66805d 100644 --- a/ydb/core/blobstorage/backpressure/queue.h +++ b/ydb/core/blobstorage/backpressure/queue.h @@ -180,6 +180,10 @@ class TBlobStorageQueue { return Queues.InFlight.size(); } + ui64 GetInFlightCost() const { + return InFlightCost; + } + void UpdateCostModel(TInstant now, const NKikimrBlobStorage::TVDiskCostSettings& settings, const TBlobStorageGroupType& type); void InvalidateCosts(); diff --git a/ydb/core/blobstorage/backpressure/queue_backpressure_client.cpp b/ydb/core/blobstorage/backpressure/queue_backpressure_client.cpp index b3c9d1d33c4d..f60b2d78a0ac 100644 --- a/ydb/core/blobstorage/backpressure/queue_backpressure_client.cpp +++ b/ydb/core/blobstorage/backpressure/queue_backpressure_client.cpp @@ -365,7 +365,11 @@ class TVDiskBackpressureClientActor : public TActorBootstrapped= cost); Cost -= cost; --InFlight; diff --git a/ydb/core/blobstorage/dsproxy/dsproxy_get_impl.cpp b/ydb/core/blobstorage/dsproxy/dsproxy_get_impl.cpp index 003a4e1a777d..87cdf96a2bf9 100644 --- a/ydb/core/blobstorage/dsproxy/dsproxy_get_impl.cpp +++ b/ydb/core/blobstorage/dsproxy/dsproxy_get_impl.cpp @@ -293,12 +293,13 @@ void TGetImpl::PrepareRequests(TLogContext &logCtx, TDequeSetId(ReaderTabletData->Id); msg->SetGeneration(ReaderTabletData->Generation); } - R_LOG_DEBUG_SX(logCtx, "BPG14", "Send get to orderNumber# " << get.OrderNumber - << " vget# " << vget->ToString()); } for (auto& vget : gets) { if (vget) { + R_LOG_DEBUG_SX(logCtx, "BPG14", "Send get to orderNumber# " + << Info->GetTopology().GetOrderNumber(VDiskIDFromVDiskID(vget->Record.GetVDiskID())) + << " vget# " << vget->ToString()); outVGets.push_back(std::move(vget)); ++RequestIndex; } diff --git a/ydb/core/blobstorage/dsproxy/dsproxy_patch.cpp b/ydb/core/blobstorage/dsproxy/dsproxy_patch.cpp index 131112c799d5..e3429b5f3de4 100644 --- a/ydb/core/blobstorage/dsproxy/dsproxy_patch.cpp +++ b/ydb/core/blobstorage/dsproxy/dsproxy_patch.cpp @@ -68,6 +68,7 @@ class TBlobStorageGroupPatchRequest : public TBlobStorageGroupRequestActor ReceivedResponseFlags; TStackVec EmptyResponseFlags; TStackVec ErrorResponseFlags; + TStackVec ForceStopFlags; TBlobStorageGroupInfo::TVDiskIds VDisks; bool UseVPatch = false; @@ -332,8 +333,15 @@ class TBlobStorageGroupPatchRequest : public TBlobStorageGroupRequestActorGet()->Record; + + Y_ABORT_UNLESS(record.HasCookie()); + ui8 subgroupIdx = record.GetCookie(); + if (ForceStopFlags[subgroupIdx]) { + return; // ignore force stop response + } + ReceivedResults++; + PullOutStatusFlagsAndFressSpace(record); Y_ABORT_UNLESS(record.HasStatus()); NKikimrProto::EReplyStatus status = record.GetStatus(); @@ -342,9 +350,6 @@ class TBlobStorageGroupPatchRequest : public TBlobStorageGroupRequestActor> events; - for (ui32 vdiskIdx = 0; vdiskIdx < VDisks.size(); ++vdiskIdx) { - if (!ErrorResponseFlags[vdiskIdx] && !EmptyResponseFlags[vdiskIdx] && ReceivedResponseFlags[vdiskIdx]) { + for (ui32 subgroupIdx = 0; subgroupIdx < VDisks.size(); ++subgroupIdx) { + if (!ErrorResponseFlags[subgroupIdx] && !EmptyResponseFlags[subgroupIdx] && ReceivedResponseFlags[subgroupIdx]) { std::unique_ptr ev = std::make_unique( - OriginalId, PatchedId, VDisks[vdiskIdx], 0, Deadline, vdiskIdx); + OriginalId, PatchedId, VDisks[subgroupIdx], 0, Deadline, subgroupIdx); ev->SetForceEnd(); + ForceStopFlags[subgroupIdx] = true; events.emplace_back(std::move(ev)); PATCH_LOG(PRI_DEBUG, BS_PROXY_PATCH, BPPA19, "Send stop message", - (VDiskIdxInSubgroup, vdiskIdx), - (VDiskId, VDisks[vdiskIdx])); + (VDiskIdxInSubgroup, subgroupIdx), + (VDiskId, VDisks[subgroupIdx])); } } SendToQueues(events, false); @@ -495,6 +501,7 @@ class TBlobStorageGroupPatchRequest : public TBlobStorageGroupRequestActor> events; diff --git a/ydb/core/blobstorage/pdisk/mock/pdisk_mock.cpp b/ydb/core/blobstorage/pdisk/mock/pdisk_mock.cpp index f057bb46d5df..90969f236cbe 100644 --- a/ydb/core/blobstorage/pdisk/mock/pdisk_mock.cpp +++ b/ydb/core/blobstorage/pdisk/mock/pdisk_mock.cpp @@ -207,6 +207,11 @@ struct TPDiskMockState::TImpl { } } + bool HasCorruptedArea(ui32 chunkIdx, ui32 begin, ui32 end) { + const ui64 chunkBegin = ui64(chunkIdx) * ChunkSize; + return static_cast(Corrupted & TIntervalSet{chunkBegin + begin, chunkBegin + end}); + } + std::set GetChunks() { std::set res; for (auto& [ownerId, owner] : Owners) { @@ -290,6 +295,10 @@ void TPDiskMockState::SetCorruptedArea(ui32 chunkIdx, ui32 begin, ui32 end, bool Impl->SetCorruptedArea(chunkIdx, begin, end, enabled); } +bool TPDiskMockState::HasCorruptedArea(ui32 chunkIdx, ui32 begin, ui32 end) { + return Impl->HasCorruptedArea(chunkIdx, begin, end); +} + std::set TPDiskMockState::GetChunks() { return Impl->GetChunks(); } diff --git a/ydb/core/blobstorage/pdisk/mock/pdisk_mock.h b/ydb/core/blobstorage/pdisk/mock/pdisk_mock.h index c22944034760..2198b0615c34 100644 --- a/ydb/core/blobstorage/pdisk/mock/pdisk_mock.h +++ b/ydb/core/blobstorage/pdisk/mock/pdisk_mock.h @@ -26,6 +26,7 @@ namespace NKikimr { ~TPDiskMockState(); void SetCorruptedArea(ui32 chunkIdx, ui32 begin, ui32 end, bool enabled); + bool HasCorruptedArea(ui32 chunkIdx, ui32 begin, ui32 end); std::set GetChunks(); TMaybe GetOwnerRound(const TVDiskID& vDiskId) const; ui32 GetChunkSize() const; diff --git a/ydb/core/blobstorage/ut_blobstorage/scrub_fast.cpp b/ydb/core/blobstorage/ut_blobstorage/scrub_fast.cpp index 4ceb6595d927..2e24b5318d41 100644 --- a/ydb/core/blobstorage/ut_blobstorage/scrub_fast.cpp +++ b/ydb/core/blobstorage/ut_blobstorage/scrub_fast.cpp @@ -16,60 +16,125 @@ void Test() { TString data = TString::Uninitialized(8_MB); memset(data.Detach(), 'X', data.size()); - TLogoBlobID id(1, 1, 1, 0, data.size(), 0); - - { // write data to group - TActorId sender = runtime->AllocateEdgeActor(1); - runtime->WrapInActorContext(sender, [&] { - SendToBSProxy(sender, info->GroupID, new TEvBlobStorage::TEvPut(id, data, TInstant::Max())); - }); - auto res = env.WaitForEdgeActorEvent(sender); - UNIT_ASSERT_VALUES_EQUAL(res->Get()->Status, NKikimrProto::OK); - } - auto checkReadable = [&](NKikimrProto::EReplyStatus status) { - TActorId sender = runtime->AllocateEdgeActor(1); - runtime->WrapInActorContext(sender, [&] { - SendToBSProxy(sender, info->GroupID, new TEvBlobStorage::TEvGet(id, 0, 0, TInstant::Max(), - NKikimrBlobStorage::EGetHandleClass::FastRead)); - }); - auto res = env.WaitForEdgeActorEvent(sender); - UNIT_ASSERT_VALUES_EQUAL(res->Get()->Status, NKikimrProto::OK); - UNIT_ASSERT_VALUES_EQUAL(res->Get()->ResponseSz, 1); - auto& r = res->Get()->Responses[0]; - UNIT_ASSERT_VALUES_EQUAL(r.Status, status); - if (status == NKikimrProto::OK) { - UNIT_ASSERT_VALUES_EQUAL(r.Buffer.ConvertToString(), data); + for (ui32 step = 1; step < 100; ++step) { + TLogoBlobID id(1, 1, step, 0, data.size(), 0); + + { // write data to group + TActorId sender = runtime->AllocateEdgeActor(1); + runtime->WrapInActorContext(sender, [&] { + SendToBSProxy(sender, info->GroupID, new TEvBlobStorage::TEvPut(id, data, TInstant::Max())); + }); + auto res = env.WaitForEdgeActorEvent(sender); + UNIT_ASSERT_VALUES_EQUAL(res->Get()->Status, NKikimrProto::OK); } - }; - checkReadable(NKikimrProto::OK); + auto checkReadable = [&] { + TActorId sender = runtime->AllocateEdgeActor(1); + runtime->WrapInActorContext(sender, [&] { + SendToBSProxy(sender, info->GroupID, new TEvBlobStorage::TEvGet(id, 0, 0, TInstant::Max(), + NKikimrBlobStorage::EGetHandleClass::FastRead)); + }); + auto res = env.WaitForEdgeActorEvent(sender); + UNIT_ASSERT_VALUES_EQUAL(res->Get()->Status, NKikimrProto::OK); + UNIT_ASSERT_VALUES_EQUAL(res->Get()->ResponseSz, 1); + auto& r = res->Get()->Responses[0]; + UNIT_ASSERT_VALUES_EQUAL(r.Status, NKikimrProto::OK); + UNIT_ASSERT_VALUES_EQUAL(r.Buffer.ConvertToString(), data); + + ui32 partsMask = 0; + for (ui32 i = 0; i < info->GetTotalVDisksNum(); ++i) { + const TVDiskID& vdiskId = info->GetVDiskId(i); + env.WithQueueId(vdiskId, NKikimrBlobStorage::EVDiskQueueId::GetFastRead, [&](TActorId queueId) { + const TActorId sender = runtime->AllocateEdgeActor(1); + auto ev = TEvBlobStorage::TEvVGet::CreateExtremeDataQuery(vdiskId, TInstant::Max(), + NKikimrBlobStorage::EGetHandleClass::FastRead); + ev->AddExtremeQuery(id, 0, 0); + runtime->Send(new IEventHandle(queueId, sender, ev.release()), sender.NodeId()); + auto reply = env.WaitForEdgeActorEvent(sender); + auto& record = reply->Get()->Record; + UNIT_ASSERT_VALUES_EQUAL(record.GetStatus(), NKikimrProto::OK); + UNIT_ASSERT_VALUES_EQUAL(record.ResultSize(), 1); + for (const auto& result : record.GetResult()) { + if (result.GetStatus() == NKikimrProto::OK) { + const TLogoBlobID& id = LogoBlobIDFromLogoBlobID(result.GetBlobID()); + UNIT_ASSERT(id.PartId()); + const ui32 partIdx = id.PartId() - 1; + const ui32 mask = 1 << partIdx; + UNIT_ASSERT(!(partsMask & mask)); + partsMask |= mask; + } else { + UNIT_ASSERT_VALUES_EQUAL(result.GetStatus(), NKikimrProto::NODATA); + } + } + }); + } + UNIT_ASSERT_VALUES_EQUAL(partsMask, (1 << info->Type.TotalPartCount()) - 1); + }; - for (ui32 i = 0; i < info->GetTotalVDisksNum(); ++i) { - const TActorId vdiskActorId = info->GetActorId(i); + checkReadable(); - ui32 nodeId, pdiskId; - std::tie(nodeId, pdiskId, std::ignore) = DecomposeVDiskServiceId(vdiskActorId); - auto it = env.PDiskMockStates.find(std::make_pair(nodeId, pdiskId)); - Y_ABORT_UNLESS(it != env.PDiskMockStates.end()); + ui32 mask = 0; - const TActorId sender = runtime->AllocateEdgeActor(vdiskActorId.NodeId()); - env.Runtime->Send(new IEventHandle(vdiskActorId, sender, new TEvBlobStorage::TEvCaptureVDiskLayout), sender.NodeId()); - auto res = env.WaitForEdgeActorEvent(sender); + for (ui32 i = 0; i < info->GetTotalVDisksNum(); ++i) { + const TActorId vdiskActorId = info->GetActorId(i); - for (auto& item : res->Get()->Layout) { - using T = TEvBlobStorage::TEvCaptureVDiskLayoutResult; - if (item.Database == T::EDatabase::LogoBlobs && item.RecordType == T::ERecordType::HugeBlob) { - const TDiskPart& part = item.Location; - it->second->SetCorruptedArea(part.ChunkIdx, part.Offset, part.Offset + part.Size, true); - break; + ui32 nodeId, pdiskId; + std::tie(nodeId, pdiskId, std::ignore) = DecomposeVDiskServiceId(vdiskActorId); + auto it = env.PDiskMockStates.find(std::make_pair(nodeId, pdiskId)); + Y_ABORT_UNLESS(it != env.PDiskMockStates.end()); + + const TActorId sender = runtime->AllocateEdgeActor(vdiskActorId.NodeId()); + env.Runtime->Send(new IEventHandle(vdiskActorId, sender, new TEvBlobStorage::TEvCaptureVDiskLayout), sender.NodeId()); + auto res = env.WaitForEdgeActorEvent(sender); + + for (auto& item : res->Get()->Layout) { + using T = TEvBlobStorage::TEvCaptureVDiskLayoutResult; + if (item.Database == T::EDatabase::LogoBlobs && item.RecordType == T::ERecordType::HugeBlob && item.BlobId.FullID() == id) { + const TDiskPart& part = item.Location; + mask |= 1 << i; + it->second->SetCorruptedArea(part.ChunkIdx, part.Offset, part.Offset + 1 + RandomNumber(part.Size), true); + break; + } } + + checkReadable(); } - checkReadable(NKikimrProto::OK); - } + env.Sim(TDuration::Seconds(60)); - env.Sim(TDuration::Seconds(60)); + for (ui32 i = 0; i < info->GetTotalVDisksNum(); ++i) { + if (~mask >> i & 1) { + continue; + } + + const TActorId vdiskActorId = info->GetActorId(i); + + ui32 nodeId, pdiskId; + std::tie(nodeId, pdiskId, std::ignore) = DecomposeVDiskServiceId(vdiskActorId); + auto it = env.PDiskMockStates.find(std::make_pair(nodeId, pdiskId)); + Y_ABORT_UNLESS(it != env.PDiskMockStates.end()); + + const TActorId sender = runtime->AllocateEdgeActor(vdiskActorId.NodeId()); + env.Runtime->Send(new IEventHandle(vdiskActorId, sender, new TEvBlobStorage::TEvCaptureVDiskLayout), sender.NodeId()); + auto res = env.WaitForEdgeActorEvent(sender); + + bool anyPartReadable = false; + + for (auto& item : res->Get()->Layout) { + using T = TEvBlobStorage::TEvCaptureVDiskLayoutResult; + if (item.Database == T::EDatabase::LogoBlobs && item.RecordType == T::ERecordType::HugeBlob && item.BlobId.FullID() == id) { + const TDiskPart& part = item.Location; + anyPartReadable = !it->second->HasCorruptedArea(part.ChunkIdx, part.Offset, part.Offset + part.Size); + if (anyPartReadable) { + break; + } + } + } + + UNIT_ASSERT(anyPartReadable); + } + } } Y_UNIT_TEST_SUITE(ScrubFast) { @@ -77,3 +142,4 @@ Y_UNIT_TEST_SUITE(ScrubFast) { Test(); } } + diff --git a/ydb/core/blobstorage/vdisk/common/vdisk_events.h b/ydb/core/blobstorage/vdisk/common/vdisk_events.h index f33888e534a9..dfc24c096ff9 100644 --- a/ydb/core/blobstorage/vdisk/common/vdisk_events.h +++ b/ydb/core/blobstorage/vdisk/common/vdisk_events.h @@ -366,10 +366,12 @@ namespace NKikimr { : public TEventLocal { TVMsgContext Ctx; std::unique_ptr Event; + bool DoNotResend; - TEvVDiskRequestCompleted(const TVMsgContext &ctx, std::unique_ptr event) + TEvVDiskRequestCompleted(const TVMsgContext &ctx, std::unique_ptr event, bool doNotResend = false) : Ctx(ctx) , Event(std::move(event)) + , DoNotResend(doNotResend) { Y_DEBUG_ABORT_UNLESS(Ctx.ExtQueueId != NKikimrBlobStorage::EVDiskQueueId::Unknown); Y_DEBUG_ABORT_UNLESS(Ctx.IntQueueId != NKikimrBlobStorage::EVDiskInternalQueueId::IntUnknown); @@ -468,6 +470,9 @@ namespace NKikimr { TActorIDPtr SkeletonFrontIDPtr; THPTimer ExecutionTimer; + protected: + bool DoNotResendFromSkeletonFront = false; + public: TEvVResultBaseWithQoSPB() = default; @@ -526,7 +531,7 @@ namespace NKikimr { byteSize, this->ToString().data()); if (SkeletonFrontIDPtr && MsgCtx.IntQueueId != NKikimrBlobStorage::IntUnknown) { - ctx.Send(*SkeletonFrontIDPtr, new TEvVDiskRequestCompleted(MsgCtx, std::move(ev))); + ctx.Send(*SkeletonFrontIDPtr, new TEvVDiskRequestCompleted(MsgCtx, std::move(ev), DoNotResendFromSkeletonFront)); } else { TActivationContext::Send(ev.release()); } @@ -2182,6 +2187,10 @@ namespace NKikimr { Record.SetApproximateFreeSpaceShare(approximateFreeSpaceShare); } + void SetForceEndResponse() { + DoNotResendFromSkeletonFront = true; + } + void MakeError(NKikimrProto::EReplyStatus status, const TString &errorReason, const NKikimrBlobStorage::TEvVPatchDiff &request) { diff --git a/ydb/core/blobstorage/vdisk/scrub/blob_recovery_impl.h b/ydb/core/blobstorage/vdisk/scrub/blob_recovery_impl.h index 0e9022168f2c..cf645679aad6 100644 --- a/ydb/core/blobstorage/vdisk/scrub/blob_recovery_impl.h +++ b/ydb/core/blobstorage/vdisk/scrub/blob_recovery_impl.h @@ -99,15 +99,15 @@ namespace NKikimr { // a map to fill upon receiving VGet result struct TPerBlobInfo { - const TInstant Deadline; std::weak_ptr Context; TEvRecoverBlobResult::TItem *Item; // item to update ui32 BlobReplyCounter = 0; // number of unreplied queries for this blob }; std::unordered_multimap> VGetResultMap; + std::set> GetsInFlight; void AddBlobQuery(const TLogoBlobID& id, NMatrix::TVectorType needed, const std::shared_ptr& context, TEvRecoverBlobResult::TItem *item); - void AddExtremeQuery(const TVDiskID& vdiskId, const TLogoBlobID& id, TInstant deadline, ui32 worstReplySize); + void AddExtremeQuery(const TVDiskID& vdiskId, const TLogoBlobID& id, TInstant deadline, ui32 idxInSubgroup); void SendPendingQueries(); void Handle(TEvBlobStorage::TEvVGetResult::TPtr ev); NKikimrProto::EReplyStatus ProcessItemData(TEvRecoverBlobResult::TItem& item); diff --git a/ydb/core/blobstorage/vdisk/scrub/blob_recovery_process.cpp b/ydb/core/blobstorage/vdisk/scrub/blob_recovery_process.cpp index 24a1d5dd087a..378c689fc4f3 100644 --- a/ydb/core/blobstorage/vdisk/scrub/blob_recovery_process.cpp +++ b/ydb/core/blobstorage/vdisk/scrub/blob_recovery_process.cpp @@ -7,46 +7,56 @@ namespace NKikimr { STLOG(PRI_DEBUG, BS_VDISK_SCRUB, VDS32, VDISKP(LogPrefix, "AddBlobQuery"), (SelfId, SelfId()), (Id, id), (Needed, needed), (RequestId, context->RequestId)); const TInstant deadline = context->Iterator->first; - const TBlobStorageGroupType& gtype = Info->Type; TBlobStorageGroupInfo::TOrderNums nums; Info->GetTopology().PickSubgroup(id.Hash(), nums); ui32 blobReplyCounter = 0; for (ui32 i = 0; i < nums.size(); ++i) { const TVDiskID& vdiskId = Info->GetVDiskId(i); // obtain VDisk - if (TVDiskIdShort(vdiskId) == VCtx->ShortSelfVDisk) { - continue; + if (TVDiskIdShort(vdiskId) != VCtx->ShortSelfVDisk) { + AddExtremeQuery(vdiskId, id, deadline, i); + ++blobReplyCounter; } + } + VGetResultMap.emplace(id, TPerBlobInfo{context, item, blobReplyCounter}); + } + + void TBlobRecoveryActor::AddExtremeQuery(const TVDiskID& vdiskId, const TLogoBlobID& id, TInstant deadline, ui32 idxInSubgroup) { + const auto [_, inserted] = GetsInFlight.emplace(vdiskId, id); + + ui32 worstReplySize = 0; + if (inserted) { + const TBlobStorageGroupType& gtype = Info->Type; switch (TIngress::IngressMode(gtype)) { case TIngress::EMode::GENERIC: - ui32 maxSize; - maxSize = 0; if (gtype.GetErasure() == TBlobStorageGroupType::ErasureMirror3dc) { - maxSize += gtype.PartSize(TLogoBlobID(id, i % 3 + 1)); + worstReplySize = gtype.PartSize(TLogoBlobID(id, idxInSubgroup % 3 + 1)); } else { for (ui32 k = 0; k < gtype.TotalPartCount(); ++k) { - maxSize += i >= gtype.TotalPartCount() || k == i ? gtype.PartSize(TLogoBlobID(id, k + 1)) : 0; + worstReplySize += idxInSubgroup >= gtype.TotalPartCount() || k == idxInSubgroup + ? gtype.PartSize(TLogoBlobID(id, k + 1)) : 0; } } - AddExtremeQuery(vdiskId, id, deadline, maxSize); break; case TIngress::EMode::MIRROR3OF4: - AddExtremeQuery(vdiskId, id, deadline, gtype.PartSize(TLogoBlobID(id, 1)) + - gtype.PartSize(TLogoBlobID(id, 2))); + for (ui32 i = 0; i < 2; ++i) { + if (idxInSubgroup % 2 == i || idxInSubgroup >= 4) { + worstReplySize += gtype.PartSize(TLogoBlobID(id, i + 1)); + } + } break; } - ++blobReplyCounter; } - VGetResultMap.emplace(id, TPerBlobInfo{context->Iterator->first, context, item, blobReplyCounter}); - } - void TBlobRecoveryActor::AddExtremeQuery(const TVDiskID& vdiskId, const TLogoBlobID& id, TInstant deadline, ui32 worstReplySize) { STLOG(PRI_DEBUG, BS_VDISK_SCRUB, VDS33, VDISKP(LogPrefix, "AddExtremeQuery"), (SelfId, SelfId()), - (VDiskId, vdiskId), (Id, id), (WorstReplySize, worstReplySize)); + (VDiskId, vdiskId), (Id, id), (WorstReplySize, worstReplySize), (AlreadyInFlight, !inserted)); + if (!inserted) { // the request is already in flight + return; + } TQuery& query = Queries[vdiskId]; - const ui32 maxReplySize = 10000000; // FIXME + const ui32 maxReplySize = 32_MB; if (query.VGet && query.WorstReplySize + worstReplySize > maxReplySize) { // send the request on overflow query.Pending.push_back(std::move(query.VGet)); query.WorstReplySize = 0; @@ -79,35 +89,51 @@ namespace NKikimr { STLOG(PRI_DEBUG, BS_VDISK_SCRUB, VDS35, VDISKP(LogPrefix, "received TEvVGetResult"), (SelfId, SelfId()), (Msg, ev->Get()->ToString())); + const TInstant now = TActivationContext::Now(); const auto& record = ev->Get()->Record; + const TVDiskID vdiskId = VDiskIDFromVDiskID(record.GetVDiskID()); + std::unordered_map> rerequest; + std::unordered_set done; + for (const auto& res : record.GetResult()) { const TLogoBlobID& id = LogoBlobIDFromLogoBlobID(res.GetBlobID()); const TLogoBlobID& fullId = id.FullID(); // whole blob id - auto r = VGetResultMap.equal_range(fullId); - for (auto it = r.first; it != r.second; ) { + done.insert(fullId); + const NKikimrProto::EReplyStatus status = res.GetStatus(); + auto [begin, end] = VGetResultMap.equal_range(fullId); + for (auto it = begin; it != end; ) { TPerBlobInfo& info = it->second; if (auto context = info.Context.lock()) { // context acquired, request is still intact - auto& item = *info.Item; // only here we can access item, after obtaining context pointer - TRope data = ev->Get()->GetBlobData(res); - bool update = false; - if (res.GetStatus() == NKikimrProto::OK && data) { - item.SetPartData(id, std::move(data)); - update = true; - } - const bool term = !--info.BlobReplyCounter; - if (item.Status == NKikimrProto::UNKNOWN && (term || update)) { - const NKikimrProto::EReplyStatus prevStatus = std::exchange(item.Status, ProcessItemData(item)); - if (item.Status == NKikimrProto::UNKNOWN && term) { // not enough parts to fulfill request - item.Status = NKikimrProto::NODATA; + if (status == NKikimrProto::DEADLINE && now < context->Iterator->first) { + auto& deadline = rerequest[fullId]; + deadline = Max(deadline, context->Iterator->first); + } else { + auto& item = *info.Item; // only here we can access item, after obtaining context pointer + TRope data = ev->Get()->GetBlobData(res); + bool update = false; + if (res.GetStatus() == NKikimrProto::OK && data) { + item.SetPartData(id, std::move(data)); + update = true; + } + const bool term = !--info.BlobReplyCounter; + if (item.Status == NKikimrProto::UNKNOWN && (term || update)) { + const NKikimrProto::EReplyStatus prevStatus = std::exchange(item.Status, ProcessItemData(item)); + if (item.Status == NKikimrProto::UNKNOWN && term) { // not enough parts to fulfill request + item.Status = NKikimrProto::NODATA; + } + STLOG(PRI_DEBUG, BS_VDISK_SCRUB, VDS36, VDISKP(LogPrefix, "processing item"), + (SelfId, SelfId()), (RequestId, context->RequestId), (Id, id), + (Status, res.GetStatus()), (Last, term), (DataUpdated, update), + (EntryStatus, prevStatus), (ExitStatus, item.Status)); + } + if (item.Status != NKikimrProto::UNKNOWN && !--context->NumUnrespondedBlobs) { // request fully completed + context->SendResult(SelfId()); + InFlight.erase(context->Iterator); + } + if (term) { // this was the last reply for current blob + it = VGetResultMap.erase(it); + continue; } - STLOG(PRI_DEBUG, BS_VDISK_SCRUB, VDS36, VDISKP(LogPrefix, "processing item"), - (SelfId, SelfId()), (RequestId, context->RequestId), (Id, id), - (Status, res.GetStatus()), (Last, term), (DataUpdated, update), - (EntryStatus, prevStatus), (ExitStatus, item.Status)); - } - if (item.Status != NKikimrProto::UNKNOWN && !--context->NumUnrespondedBlobs) { - context->SendResult(SelfId()); - InFlight.erase(context->Iterator); } ++it; } else { // request deadlined or canceled, we erase it from the map @@ -115,6 +141,15 @@ namespace NKikimr { } } } + + for (const auto& id : done) { + const size_t n = GetsInFlight.erase(std::make_tuple(vdiskId, id)); + Y_DEBUG_ABORT_UNLESS(n == 1); + } + for (const auto& [id, deadline] : rerequest) { + AddExtremeQuery(vdiskId, id, deadline, Info->GetTopology().GetIdxInSubgroup(vdiskId, id.Hash())); + } + SendPendingQueries(); } NKikimrProto::EReplyStatus TBlobRecoveryActor::ProcessItemData(TEvRecoverBlobResult::TItem& item) { diff --git a/ydb/core/blobstorage/vdisk/scrub/blob_recovery_request.cpp b/ydb/core/blobstorage/vdisk/scrub/blob_recovery_request.cpp index fcfbd6ed9f3a..e86edcacbbb9 100644 --- a/ydb/core/blobstorage/vdisk/scrub/blob_recovery_request.cpp +++ b/ydb/core/blobstorage/vdisk/scrub/blob_recovery_request.cpp @@ -49,14 +49,9 @@ namespace NKikimr { } InFlight.erase(InFlight.begin(), it); - TInstant deadline = TInstant::Max(); // next deadline - if (it != InFlight.end()) { - deadline = it->first; - } - // reschedule timer - if (deadline != TInstant::Max()) { - Schedule(deadline, new TEvents::TEvWakeup); + if (it != InFlight.end()) { + Schedule(it->first, new TEvents::TEvWakeup); } else { WakeupScheduled = false; } diff --git a/ydb/core/blobstorage/vdisk/scrub/restore_corrupted_blob_actor.cpp b/ydb/core/blobstorage/vdisk/scrub/restore_corrupted_blob_actor.cpp index 87b1113d5f2e..8957d7a998da 100644 --- a/ydb/core/blobstorage/vdisk/scrub/restore_corrupted_blob_actor.cpp +++ b/ydb/core/blobstorage/vdisk/scrub/restore_corrupted_blob_actor.cpp @@ -196,6 +196,8 @@ namespace NKikimr { } void IssueQuery() { + STLOG(PRI_DEBUG, BS_VDISK_SCRUB, VDS00, VDISKP(LogPrefix, "IssueQuery"), (SelfId, SelfId())); + std::unique_ptr ev; for (size_t i = 0; i < Items.size(); ++i) { const auto& item = Items[i]; @@ -205,6 +207,8 @@ namespace NKikimr { ev->Deadline = Deadline; } ev->Items.emplace_back(item.BlobId, TStackVec(item.Parts), item.PartsMask, item.Needed, TDiskPart(), i); + STLOG(PRI_DEBUG, BS_VDISK_SCRUB, VDS17, VDISKP(LogPrefix, "IssueQuery item"), (SelfId, SelfId()), + (BlobId, item.BlobId), (PartsMask, item.PartsMask), (Needed, item.Needed)); } } if (ev) { @@ -222,6 +226,8 @@ namespace NKikimr { } void Handle(TEvRecoverBlobResult::TPtr ev) { + STLOG(PRI_DEBUG, BS_VDISK_SCRUB, VDS24, VDISKP(LogPrefix, "Handle(TEvRecoverBlobResult)"), (SelfId, SelfId())); + for (auto& item : ev->Get()->Items) { auto& myItem = Items[item.Cookie]; Y_ABORT_UNLESS(myItem.Status == NKikimrProto::UNKNOWN); @@ -233,6 +239,8 @@ namespace NKikimr { IssueWrite(myItem, item.Cookie); } } + STLOG(PRI_DEBUG, BS_VDISK_SCRUB, VDS43, VDISKP(LogPrefix, "Handle(TEvRecoverBlobResult) item"), + (SelfId, SelfId()), (BlobId, item.BlobId), (Status, item.Status), (PartsMask, item.PartsMask)); } for (const auto& item : Items) { if (item.Status == NKikimrProto::UNKNOWN) { diff --git a/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeletonfront.cpp b/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeletonfront.cpp index 238a69e391c5..290ac985d8a8 100644 --- a/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeletonfront.cpp +++ b/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeletonfront.cpp @@ -1632,7 +1632,9 @@ namespace NKikimr { extQueue.Completed(ctx, msgCtx, event); TIntQueueClass &intQueue = GetIntQueue(msgCtx.IntQueueId); intQueue.Completed(ctx, msgCtx, *this, id); - TActivationContext::Send(event.release()); + if (!ev->Get()->DoNotResend) { + TActivationContext::Send(event.release()); + } } void ChangeGeneration(const TVDiskID& vdiskId, const TIntrusivePtr& info, diff --git a/ydb/core/blobstorage/vdisk/skeleton/skeleton_vpatch_actor.cpp b/ydb/core/blobstorage/vdisk/skeleton/skeleton_vpatch_actor.cpp index 8aaec57b68b4..a3587f75ef24 100644 --- a/ydb/core/blobstorage/vdisk/skeleton/skeleton_vpatch_actor.cpp +++ b/ydb/core/blobstorage/vdisk/skeleton/skeleton_vpatch_actor.cpp @@ -291,7 +291,7 @@ namespace NKikimr::NPrivate { } } - void SendVPatchResult(NKikimrProto::EReplyStatus status) + void SendVPatchResult(NKikimrProto::EReplyStatus status, bool forceEnd = false) { STLOG(PRI_INFO, BS_VDISK_PATCH, BSVSP07, VDiskLogPrefix << " TEvVPatch: send patch result;", @@ -308,6 +308,9 @@ namespace NKikimr::NPrivate { } AddMark((status == NKikimrProto::OK ? "Patch ends with OK" : "Patch ends witn NOT OK")); CurrentEventTrace = nullptr; + if (forceEnd) { + ResultEvent->SetForceEndResponse(); + } SendVDiskResponse(TActivationContext::AsActorContext(), Sender, ResultEvent.release(), Cookie); } @@ -501,7 +504,7 @@ namespace NKikimr::NPrivate { Cookie = ev->Cookie; CurrentEventTrace = ev->Get()->VDiskSkeletonTrace; AddMark("Error: HandleError TEvVPatchDiff"); - SendVPatchResult(NKikimrProto::ERROR); + SendVPatchResult(NKikimrProto::ERROR, ev->Get()->IsForceEnd()); } void HandleForceEnd(TEvBlobStorage::TEvVPatchDiff::TPtr &ev) { @@ -509,7 +512,7 @@ namespace NKikimr::NPrivate { SendVPatchFoundParts(NKikimrProto::ERROR); if (forceEnd) { AddMark("Force end"); - SendVPatchResult(NKikimrProto::OK); + SendVPatchResult(NKikimrProto::OK, true); } else { AddMark("Force end by error"); SendVPatchResult(NKikimrProto::ERROR); @@ -566,7 +569,7 @@ namespace NKikimr::NPrivate { if (forceEnd) { AddMark("Force end"); - SendVPatchResult(NKikimrProto::OK); + SendVPatchResult(NKikimrProto::OK, true); NotifySkeletonAboutDying(); Become(&TThis::ErrorState); return; From 9608841555eddf779dcecb754040b1da5fbc4739 Mon Sep 17 00:00:00 2001 From: kruall Date: Thu, 8 Feb 2024 14:25:39 +0300 Subject: [PATCH 011/117] Fix autoconfig's compute cpu table (#1701) --- .../run/auto_config_initializer.cpp | 56 +++++++++++-------- 1 file changed, 33 insertions(+), 23 deletions(-) diff --git a/ydb/core/driver_lib/run/auto_config_initializer.cpp b/ydb/core/driver_lib/run/auto_config_initializer.cpp index d74c37609602..0aa3d8ce66e9 100644 --- a/ydb/core/driver_lib/run/auto_config_initializer.cpp +++ b/ydb/core/driver_lib/run/auto_config_initializer.cpp @@ -3,6 +3,7 @@ #include #include +#include #include namespace { @@ -50,27 +51,27 @@ namespace { { {2, 4}, {4, 8}, {1, 2}, {0, 0}, {1, 3} }, // 8 { {2, 5}, {4, 9}, {2, 3}, {0, 0}, {1, 3} }, // 9 { {2, 5}, {5, 10}, {2, 3}, {0, 0}, {1, 3} }, // 10 - { {2, 6}, {6, 11}, {2, 3}, {0, 0}, {2, 4} }, // 11 - { {2, 6}, {7, 12}, {2, 3}, {0, 0}, {2, 5} }, // 12 - { {3, 7}, {7, 13}, {2, 3}, {0, 0}, {2, 5} }, // 13 - { {3, 7}, {7, 14}, {2, 3}, {0, 0}, {3, 6} }, // 14 - { {3, 8}, {8, 15}, {2, 4}, {0, 0}, {3, 6} }, // 15 - { {3, 8}, {9, 16}, {2, 4}, {0, 0}, {3, 6} }, // 16 - { {3, 9}, {10, 17}, {2, 4}, {0, 0}, {3, 7} }, // 17 - { {3, 9}, {10, 18}, {3, 5}, {0, 0}, {3, 7} }, // 18 - { {4, 10}, {10, 19}, {3, 5}, {0, 0}, {4, 8} }, // 19 - { {4, 10}, {10, 20}, {3, 5}, {0, 0}, {4, 8} }, // 20 - { {4, 11}, {11, 21}, {3, 5}, {0, 0}, {4, 8} }, // 21 - { {4, 11}, {12, 22}, {3, 5}, {0, 0}, {4, 9} }, // 22 - { {4, 12}, {13, 23}, {3, 6}, {0, 0}, {4, 9} }, // 23 - { {4, 12}, {13, 24}, {3, 6}, {0, 0}, {5, 10} }, // 24 - { {5, 13}, {13, 25}, {3, 6}, {0, 0}, {5, 10} }, // 25 - { {5, 13}, {13, 26}, {4, 7}, {0, 0}, {5, 10} }, // 26 - { {5, 14}, {14, 27}, {4, 7}, {0, 0}, {5, 11} }, // 27 + { {2, 6}, {5, 11}, {2, 3}, {0, 0}, {2, 4} }, // 11 + { {2, 6}, {6, 12}, {2, 3}, {0, 0}, {2, 5} }, // 12 + { {3, 7}, {6, 13}, {2, 3}, {0, 0}, {2, 5} }, // 13 + { {3, 7}, {6, 14}, {2, 3}, {0, 0}, {3, 6} }, // 14 + { {3, 8}, {7, 15}, {2, 4}, {0, 0}, {3, 6} }, // 15 + { {3, 8}, {8, 16}, {2, 4}, {0, 0}, {3, 6} }, // 16 + { {3, 9}, {9, 17}, {2, 4}, {0, 0}, {3, 7} }, // 17 + { {3, 9}, {9, 18}, {3, 5}, {0, 0}, {3, 7} }, // 18 + { {3, 10}, {9, 19}, {3, 5}, {0, 0}, {4, 8} }, // 19 + { {4, 10}, {9, 20}, {3, 5}, {0, 0}, {4, 8} }, // 20 + { {4, 11}, {10, 21}, {3, 5}, {0, 0}, {4, 8} }, // 21 + { {4, 11}, {11, 22}, {3, 5}, {0, 0}, {4, 9} }, // 22 + { {4, 12}, {12, 23}, {3, 6}, {0, 0}, {4, 9} }, // 23 + { {4, 12}, {12, 24}, {3, 6}, {0, 0}, {5, 10} }, // 24 + { {5, 13}, {12, 25}, {3, 6}, {0, 0}, {5, 10} }, // 25 + { {5, 13}, {12, 26}, {4, 7}, {0, 0}, {5, 10} }, // 26 + { {5, 14}, {13, 27}, {4, 7}, {0, 0}, {5, 11} }, // 27 { {5, 14}, {14, 28}, {4, 7}, {0, 0}, {5, 11} }, // 28 - { {5, 15}, {15, 29}, {4, 8}, {0, 0}, {6, 12} }, // 29 - { {5, 15}, {16, 30}, {4, 8}, {0, 0}, {6, 12} }, // 30 - { {6, 18}, {16, 31}, {4, 8}, {0, 0}, {6, 12} }, // 31 + { {5, 15}, {14, 29}, {4, 8}, {0, 0}, {6, 12} }, // 29 + { {5, 15}, {15, 30}, {4, 8}, {0, 0}, {6, 12} }, // 30 + { {6, 18}, {15, 31}, {4, 8}, {0, 0}, {6, 12} }, // 31 }; TShortPoolCfg HybridCpuTable[MaxPreparedCpuCount + 1][5] { @@ -158,9 +159,11 @@ namespace { TShortPoolCfg result = cpuTable[MaxPreparedCpuCount][poolIdx]; result.ThreadCount *= k; result.MaxThreadCount *= k; - TShortPoolCfg additional = cpuTable[mod][poolIdx]; - result.ThreadCount += additional.ThreadCount; - result.MaxThreadCount += additional.MaxThreadCount; + if (mod) { + TShortPoolCfg additional = cpuTable[mod][poolIdx]; + result.ThreadCount += additional.ThreadCount; + result.MaxThreadCount += additional.MaxThreadCount; + } return result; } @@ -274,6 +277,13 @@ namespace NKikimr::NAutoConfigInitializer { config->GetNodeType() == NKikimrConfig::TActorSystemConfig::COMPUTE ? ComputeCpuTable : HybridCpuTable ); + // check cpu table + i16 cpuSum = 0; + for (auto poolKind : {EPoolKind::System, EPoolKind::User, EPoolKind::Batch, EPoolKind::IC}) { + TShortPoolCfg cfg = GetShortPoolChg(poolKind, cpuCount, cpuTable); + cpuSum += cfg.ThreadCount; + } + Y_VERIFY_S(cpuSum == cpuCount, "cpuSum# " << cpuSum << " cpuCount# " << cpuCount); for (ui32 poolIdx = 0; poolIdx < poolCount; ++poolIdx) { auto *executor = executors[poolIdx]; From ae6ef0c00a5201a522aae47b7002cf5f257ad0e3 Mon Sep 17 00:00:00 2001 From: zverevgeny Date: Fri, 9 Feb 2024 06:09:50 +0300 Subject: [PATCH 012/117] YQL-17542 finalize split sync async CAs (#1689) * Yql 17542 simplify alloc in compute actor (#1452) * YQL-17542 Simplify allocator usage in ComputeActors * fix build * fix dup * YQL-17542 move SaveState LoadState (#1474) * YQL-17703 always use sized allocator in CA (#1522) * YQL-17542 split FillIoMaps (#1537) * YQL-17755 fix drying input up (#1604) * YQL-17542 split stat (#1553) * YQL-17542 remove transition guards (#1610) * YQL-17542 get rid of std::any in handling sources state (#1635) * YQL-17755 ut for TComputeActorAsyncInputHelperTest::PollAsyncInput (#1626) * YQL-17542 move TaskRunner dependent Execute to TDqSyncComputeActorBase (#1599) * YQL-17542 move TaskRunner dependent Execute to TDqSyncComputeActorBase (#1666) --- .../compute_actor/kqp_scan_compute_actor.cpp | 8 +- .../compute_actor/kqp_scan_compute_actor.h | 4 +- .../actors/compute/dq_async_compute_actor.cpp | 24 +- .../yql/dq/actors/compute/dq_compute_actor.h | 3 - .../dq_compute_actor_async_input_helper.h | 3 +- .../dq/actors/compute/dq_compute_actor_impl.h | 211 ++++++------------ .../compute/dq_sync_compute_actor_base.h | 122 +++++++++- ...dq_compute_actor_async_input_helper_ut.cpp | 84 +++++++ ydb/library/yql/dq/actors/compute/ut/ya.make | 3 + .../dq/actors/task_runner/task_runner_actor.h | 2 - 10 files changed, 281 insertions(+), 183 deletions(-) create mode 100644 ydb/library/yql/dq/actors/compute/ut/dq_compute_actor_async_input_helper_ut.cpp diff --git a/ydb/core/kqp/compute_actor/kqp_scan_compute_actor.cpp b/ydb/core/kqp/compute_actor/kqp_scan_compute_actor.cpp index f6a48b208c7b..d4cd835e37fe 100644 --- a/ydb/core/kqp/compute_actor/kqp_scan_compute_actor.cpp +++ b/ydb/core/kqp/compute_actor/kqp_scan_compute_actor.cpp @@ -156,22 +156,18 @@ void TKqpScanComputeActor::Handle(TEvScanExchange::TEvFetcherFinished::TPtr& ev) } } -void TKqpScanComputeActor::PollSources(std::any prev) { +void TKqpScanComputeActor::PollSources(ui64 prevFreeSpace) { if (!ScanData || ScanData->IsFinished()) { return; } const auto hasNewMemoryPred = [&]() { - if (!prev.has_value()) { - return false; - } const ui64 freeSpace = CalculateFreeSpace(); - const ui64 prevFreeSpace = std::any_cast(prev); return freeSpace > prevFreeSpace; }; if (!hasNewMemoryPred() && ScanData->GetStoredBytes()) { return; } - const ui32 freeSpace = CalculateFreeSpace(); + const ui64 freeSpace = CalculateFreeSpace(); CA_LOG_D("POLL_SOURCES:START:" << Fetchers.size() << ";fs=" << freeSpace); for (auto&& i : Fetchers) { Send(i, new TEvScanExchange::TEvAckData(freeSpace)); diff --git a/ydb/core/kqp/compute_actor/kqp_scan_compute_actor.h b/ydb/core/kqp/compute_actor/kqp_scan_compute_actor.h index ccf548819a8c..dd9d78091ec6 100644 --- a/ydb/core/kqp/compute_actor/kqp_scan_compute_actor.h +++ b/ydb/core/kqp/compute_actor/kqp_scan_compute_actor.h @@ -82,14 +82,14 @@ class TKqpScanComputeActor: public NYql::NDq::TDqSyncComputeActorBaseFreeSpace; } - TGuard BindAllocator() override { - return TypeEnv->BindAllocator(); - } - - std::optional> MaybeBindAllocator() override { - std::optional> guard; - if (TypeEnv) { - guard.emplace(TypeEnv->BindAllocator()); - } - return guard; - } - void OnTaskRunnerCreated(NTaskRunnerActor::TEvTaskRunnerCreateFinished::TPtr& ev) { const auto& secureParams = ev->Get()->SecureParams; const auto& taskParams = ev->Get()->TaskParams; @@ -483,7 +471,7 @@ class TDqAsyncComputeActor : public TDqComputeActorBaseAddCounters2(ev->Get()->Sensors); } TypeEnv = const_cast(&typeEnv); - FillIoMaps(holderFactory, typeEnv, secureParams, taskParams, readRanges); + FillIoMaps(holderFactory, typeEnv, secureParams, taskParams, readRanges, nullptr); { // say "Hello" to executer @@ -517,7 +505,6 @@ class TDqAsyncComputeActor : public TDqComputeActorBaseGet()->MkqlMemoryLimit; ProfileStats = std::move(ev->Get()->ProfileStats); - auto sourcesState = GetSourcesState(); auto status = ev->Get()->RunStatus; CA_LOG_T("Resume execution, run status: " << status << " checkpoint: " << (bool) ev->Get()->ProgramState @@ -536,10 +523,6 @@ class TDqAsyncComputeActor : public TDqComputeActorBaseGet()->WatermarkInjectedToOutputs && !WatermarksTracker.HasOutputChannels()) { ResumeInputsByWatermark(*WatermarksTracker.GetPendingWatermark()); WatermarksTracker.PopPendingWatermark(); @@ -801,6 +784,11 @@ class TDqAsyncComputeActor : public TDqComputeActorBase TVector GetIds(const THashMap& collection) { TVector ids; diff --git a/ydb/library/yql/dq/actors/compute/dq_compute_actor.h b/ydb/library/yql/dq/actors/compute/dq_compute_actor.h index c3710181e7e5..88c5d8e458e9 100644 --- a/ydb/library/yql/dq/actors/compute/dq_compute_actor.h +++ b/ydb/library/yql/dq/actors/compute/dq_compute_actor.h @@ -364,9 +364,6 @@ struct TComputeMemoryLimits { IMemoryQuotaManager::TPtr MemoryQuotaManager; }; -//temporary flag to integarate changes in interface -#define Y_YQL_DQ_TASK_RUNNER_REQUIRES_ALLOCATOR 1 - using TTaskRunnerFactory = std::function< TIntrusivePtr(NKikimr::NMiniKQL::TScopedAlloc& alloc, const TDqTaskSettings& task, NDqProto::EDqStatsMode statsMode, const TLogFunc& logFunc) >; diff --git a/ydb/library/yql/dq/actors/compute/dq_compute_actor_async_input_helper.h b/ydb/library/yql/dq/actors/compute/dq_compute_actor_async_input_helper.h index 1c41ac1ebd9c..95a8cc1ffd91 100644 --- a/ydb/library/yql/dq/actors/compute/dq_compute_actor_async_input_helper.h +++ b/ydb/library/yql/dq/actors/compute/dq_compute_actor_async_input_helper.h @@ -83,8 +83,9 @@ struct TComputeActorAsyncInputHelper { Pause(*watermark); } } + const bool emptyBatch = batch.empty(); AsyncInputPush(std::move(batch), space, finished); - if (!batch.empty()) { + if (!emptyBatch) { // If we have read some data, we must run such reading again // to process the case when async input notified us about new data // but we haven't read all of it. diff --git a/ydb/library/yql/dq/actors/compute/dq_compute_actor_impl.h b/ydb/library/yql/dq/actors/compute/dq_compute_actor_impl.h index 5b4a3fa59793..888a8456b33d 100644 --- a/ydb/library/yql/dq/actors/compute/dq_compute_actor_impl.h +++ b/ydb/library/yql/dq/actors/compute/dq_compute_actor_impl.h @@ -186,7 +186,7 @@ class TDqComputeActorBase : public NActors::TActorBootstrapped Alloc = std::make_shared( __LOCATION__, NKikimr::TAlignedPagePoolCounters(), - FunctionRegistry->SupportsSizedAllocators(), + true, false ); InitMonCounters(taskCounters); @@ -304,30 +304,14 @@ class TDqComputeActorBase : public NActors::TActorBootstrapped ReportStats(TInstant::Now(), ESendStats::IfPossible); } if (Terminated) { - TaskRunner.Reset(); + DoTerminateImpl(); MemoryQuota.Reset(); MemoryLimits.MemoryQuotaManager.reset(); } } - virtual void DoExecuteImpl() { - auto sourcesState = GetSourcesState(); - - PollAsyncInput(); - ERunStatus status = TaskRunner->Run(); - - CA_LOG_T("Resume execution, run status: " << status); - - if (status != ERunStatus::Finished) { - PollSources(std::move(sourcesState)); - } - - if ((status == ERunStatus::PendingInput || status == ERunStatus::Finished) && Checkpoints && Checkpoints->HasPendingCheckpoint() && !Checkpoints->ComputeActorStateSaved() && ReadyToCheckpoint()) { - Checkpoints->DoCheckpoint(); - } - - ProcessOutputsImpl(status); - } + virtual void DoExecuteImpl() = 0; + virtual void DoTerminateImpl() {} virtual bool DoHandleChannelsAfterFinishImpl() { Y_ABORT_UNLESS(Checkpoints); @@ -477,7 +461,7 @@ class TDqComputeActorBase : public NActors::TActorBootstrapped } { - auto guard = MaybeBindAllocator(); // Source/Sink could destroy mkql values inside PassAway, which requires allocator to be bound + auto guard = BindAllocator(); // Source/Sink could destroy mkql values inside PassAway, which requires allocator to be bound for (auto& [_, source] : SourcesMap) { if (source.Actor) { @@ -606,12 +590,11 @@ class TDqComputeActorBase : public NActors::TActorBootstrapped InternalError(statusCode, TIssues({std::move(issue)})); } + virtual void InvalidateMeminfo() {} + void InternalError(NYql::NDqProto::StatusIds::StatusCode statusCode, TIssues issues) { CA_LOG_E(InternalErrorLogString(statusCode, issues)); - if (TaskRunner) { - TaskRunner->GetAllocator().InvalidateMemInfo(); - TaskRunner->GetAllocator().DisableStrictAllocationCheck(); - } + InvalidateMeminfo(); State = NDqProto::COMPUTE_STATE_FAILURE; ReportStateAndMaybeDie(statusCode, issues); } @@ -741,22 +724,6 @@ class TDqComputeActorBase : public NActors::TActorBootstrapped return true; } - void SaveState(const NDqProto::TCheckpoint& checkpoint, NDqProto::TComputeActorState& state) const override { - CA_LOG_D("Save state"); - NDqProto::TMiniKqlProgramState& mkqlProgramState = *state.MutableMiniKqlProgram(); - mkqlProgramState.SetRuntimeVersion(NDqProto::RUNTIME_VERSION_YQL_1_0); - NDqProto::TStateData::TData& data = *mkqlProgramState.MutableData()->MutableStateData(); - data.SetVersion(TDqComputeActorCheckpoints::ComputeActorCurrentStateVersion); - data.SetBlob(TaskRunner->Save()); - - for (auto& [inputIndex, source] : SourcesMap) { - YQL_ENSURE(source.AsyncInput, "Source[" << inputIndex << "] is not created"); - NDqProto::TSourceState& sourceState = *state.AddSources(); - source.AsyncInput->SaveState(checkpoint, sourceState); - sourceState.SetInputIndex(inputIndex); - } - } - void CommitState(const NDqProto::TCheckpoint& checkpoint) override { CA_LOG_D("Commit state"); for (auto& [inputIndex, source] : SourcesMap) { @@ -810,15 +777,7 @@ class TDqComputeActorBase : public NActors::TActorBootstrapped } } - virtual void DoLoadRunnerState(TString&& blob) { - TMaybe error = Nothing(); - try { - TaskRunner->Load(blob); - } catch (const std::exception& e) { - error = e.what(); - } - Checkpoints->AfterStateLoading(error); - } + virtual void DoLoadRunnerState(TString&& blob) = 0; void LoadState(NDqProto::TComputeActorState&& state) override { CA_LOG_D("Load state"); @@ -1073,13 +1032,6 @@ class TDqComputeActorBase : public NActors::TActorBootstrapped protected: // virtual methods (TODO: replace with static_cast(this)->Foo() - virtual std::any GetSourcesState() { - return nullptr; - } - - virtual void PollSources(std::any /* state */) { - } - virtual void TerminateSources(const TIssues& /* issues */, bool /* success */) { } @@ -1087,18 +1039,16 @@ class TDqComputeActorBase : public NActors::TActorBootstrapped TerminateSources(TIssues({TIssue(message)}), success); } - virtual TGuard BindAllocator() { - return TaskRunner->BindAllocator(); - } - - virtual std::optional> MaybeBindAllocator() { - return TaskRunner->BindAllocator(); + TGuard BindAllocator() { + return Guard(GetAllocator()); } virtual bool SayHelloOnBootstrap() { return true; } + + protected: void HandleExecuteBase(TEvDqCompute::TEvResumeExecution::TPtr&) { ResumeEventScheduled = false; @@ -1469,19 +1419,12 @@ class TDqComputeActorBase : public NActors::TActorBootstrapped const NKikimr::NMiniKQL::TTypeEnvironment& typeEnv, const THashMap& secureParams, const THashMap& taskParams, - const TVector& readRanges) + const TVector& readRanges, + IRandomProvider* randomProvider + ) { - if (TaskRunner) { - for (auto& [channelId, channel] : InputChannelsMap) { - channel.Channel = TaskRunner->GetInputChannel(channelId); - } - } auto collectStatsLevel = StatsModeToCollectStatsLevel(RuntimeSettings.StatsMode); for (auto& [inputIndex, source] : SourcesMap) { - if constexpr (!TDerived::HasAsyncTaskRunner) { - source.Buffer = TaskRunner->GetSource(inputIndex); - Y_ABORT_UNLESS(source.Buffer); - } Y_ABORT_UNLESS(AsyncIoFactory); const auto& inputDesc = Task.GetInputs(inputIndex); Y_ABORT_UNLESS(inputDesc.HasSource()); @@ -1503,7 +1446,7 @@ class TDqComputeActorBase : public NActors::TActorBootstrapped .TypeEnv = typeEnv, .HolderFactory = holderFactory, .TaskCounters = TaskCounters, - .Alloc = TaskRunner ? Alloc : nullptr, + .Alloc = Alloc, .MemoryQuotaManager = MemoryLimits.MemoryQuotaManager, .SourceSettings = (!settings.empty() ? settings.at(inputIndex) : nullptr), .Arena = Task.GetArena(), @@ -1515,71 +1458,59 @@ class TDqComputeActorBase : public NActors::TActorBootstrapped this->RegisterWithSameMailbox(source.Actor); } for (auto& [inputIndex, transform] : InputTransformsMap) { - if constexpr (!TDerived::HasAsyncTaskRunner) { - transform.ProgramBuilder.ConstructInPlace(TaskRunner->GetTypeEnv(), *FunctionRegistry); - std::tie(transform.InputBuffer, transform.Buffer) = TaskRunner->GetInputTransform(inputIndex); - Y_ABORT_UNLESS(AsyncIoFactory); - const auto& inputDesc = Task.GetInputs(inputIndex); - CA_LOG_D("Create transform for input " << inputIndex << " " << inputDesc.ShortDebugString()); - try { - std::tie(transform.AsyncInput, transform.Actor) = AsyncIoFactory->CreateDqInputTransform( - IDqAsyncIoFactory::TInputTransformArguments { - .InputDesc = inputDesc, - .InputIndex = inputIndex, - .StatsLevel = collectStatsLevel, - .TxId = TxId, - .TaskId = Task.GetId(), - .TransformInput = transform.InputBuffer, - .SecureParams = secureParams, - .TaskParams = taskParams, - .ComputeActorId = this->SelfId(), - .TypeEnv = typeEnv, - .HolderFactory = holderFactory, - .ProgramBuilder = *transform.ProgramBuilder, - .Alloc = Alloc, - .TraceId = ComputeActorSpan.GetTraceId() - }); - } catch (const std::exception& ex) { - throw yexception() << "Failed to create input transform " << inputDesc.GetTransform().GetType() << ": " << ex.what(); - } - this->RegisterWithSameMailbox(transform.Actor); - } - } - if (TaskRunner) { - for (auto& [channelId, channel] : OutputChannelsMap) { - channel.Channel = TaskRunner->GetOutputChannel(channelId); + transform.ProgramBuilder.ConstructInPlace(typeEnv, *FunctionRegistry); + Y_ABORT_UNLESS(AsyncIoFactory); + const auto& inputDesc = Task.GetInputs(inputIndex); + CA_LOG_D("Create transform for input " << inputIndex << " " << inputDesc.ShortDebugString()); + try { + std::tie(transform.AsyncInput, transform.Actor) = AsyncIoFactory->CreateDqInputTransform( + IDqAsyncIoFactory::TInputTransformArguments { + .InputDesc = inputDesc, + .InputIndex = inputIndex, + .StatsLevel = collectStatsLevel, + .TxId = TxId, + .TaskId = Task.GetId(), + .TransformInput = transform.InputBuffer, + .SecureParams = secureParams, + .TaskParams = taskParams, + .ComputeActorId = this->SelfId(), + .TypeEnv = typeEnv, + .HolderFactory = holderFactory, + .ProgramBuilder = *transform.ProgramBuilder, + .Alloc = Alloc, + .TraceId = ComputeActorSpan.GetTraceId() + }); + } catch (const std::exception& ex) { + throw yexception() << "Failed to create input transform " << inputDesc.GetTransform().GetType() << ": " << ex.what(); } + this->RegisterWithSameMailbox(transform.Actor); } for (auto& [outputIndex, transform] : OutputTransformsMap) { - if (TaskRunner) { - transform.ProgramBuilder.ConstructInPlace(TaskRunner->GetTypeEnv(), *FunctionRegistry); - std::tie(transform.Buffer, transform.OutputBuffer) = TaskRunner->GetOutputTransform(outputIndex); - Y_ABORT_UNLESS(AsyncIoFactory); - const auto& outputDesc = Task.GetOutputs(outputIndex); - CA_LOG_D("Create transform for output " << outputIndex << " " << outputDesc.ShortDebugString()); - try { - std::tie(transform.AsyncOutput, transform.Actor) = AsyncIoFactory->CreateDqOutputTransform( - IDqAsyncIoFactory::TOutputTransformArguments { - .OutputDesc = outputDesc, - .OutputIndex = outputIndex, - .StatsLevel = collectStatsLevel, - .TxId = TxId, - .TransformOutput = transform.OutputBuffer, - .Callback = static_cast(this), - .SecureParams = secureParams, - .TaskParams = taskParams, - .TypeEnv = typeEnv, - .HolderFactory = holderFactory, - .ProgramBuilder = *transform.ProgramBuilder - }); - } catch (const std::exception& ex) { - throw yexception() << "Failed to create output transform " << outputDesc.GetTransform().GetType() << ": " << ex.what(); - } - this->RegisterWithSameMailbox(transform.Actor); + transform.ProgramBuilder.ConstructInPlace(typeEnv, *FunctionRegistry); + Y_ABORT_UNLESS(AsyncIoFactory); + const auto& outputDesc = Task.GetOutputs(outputIndex); + CA_LOG_D("Create transform for output " << outputIndex << " " << outputDesc.ShortDebugString()); + try { + std::tie(transform.AsyncOutput, transform.Actor) = AsyncIoFactory->CreateDqOutputTransform( + IDqAsyncIoFactory::TOutputTransformArguments { + .OutputDesc = outputDesc, + .OutputIndex = outputIndex, + .StatsLevel = collectStatsLevel, + .TxId = TxId, + .TransformOutput = transform.OutputBuffer, + .Callback = static_cast(this), + .SecureParams = secureParams, + .TaskParams = taskParams, + .TypeEnv = typeEnv, + .HolderFactory = holderFactory, + .ProgramBuilder = *transform.ProgramBuilder + }); + } catch (const std::exception& ex) { + throw yexception() << "Failed to create output transform " << outputDesc.GetTransform().GetType() << ": " << ex.what(); } + this->RegisterWithSameMailbox(transform.Actor); } for (auto& [outputIndex, sink] : SinksMap) { - if (TaskRunner) { sink.Buffer = TaskRunner->GetSink(outputIndex); } Y_ABORT_UNLESS(AsyncIoFactory); const auto& outputDesc = Task.GetOutputs(outputIndex); Y_ABORT_UNLESS(outputDesc.HasSink()); @@ -1597,7 +1528,7 @@ class TDqComputeActorBase : public NActors::TActorBootstrapped .TaskParams = taskParams, .TypeEnv = typeEnv, .HolderFactory = holderFactory, - .RandomProvider = TaskRunner ? TaskRunner->GetRandomProvider() : nullptr + .RandomProvider = randomProvider }); } catch (const std::exception& ex) { throw yexception() << "Failed to create sink " << outputDesc.GetSink().GetType() << ": " << ex.what(); @@ -1804,9 +1735,8 @@ class TDqComputeActorBase : public NActors::TActorBootstrapped } } - virtual const NYql::NDq::TTaskRunnerStatsBase* GetTaskRunnerStats() { - return TaskRunner ? TaskRunner->GetStats() : nullptr; - } + virtual const NYql::NDq::TTaskRunnerStatsBase* GetTaskRunnerStats() = 0; + virtual const NYql::NDq::TDqMeteringStats* GetMeteringStats() = 0; virtual const IDqAsyncOutputBuffer* GetSink(ui64, const TAsyncOutputInfoBase& sinkInfo) const { return sinkInfo.Buffer.Get(); @@ -1866,8 +1796,7 @@ class TDqComputeActorBase : public NActors::TActorBootstrapped for (auto& [inputIndex, sourceInfo] : SourcesMap) { if (auto* source = sourceInfo.AsyncInput) { - // TODO: support async CA - source->FillExtraStats(protoTask, last, TaskRunner ? TaskRunner->GetMeteringStats() : nullptr); + source->FillExtraStats(protoTask, last, GetMeteringStats()); } } FillTaskRunnerStats(Task.GetId(), Task.GetStageId(), *taskStats, protoTask, RuntimeSettings.GetCollectStatsLevel()); @@ -1972,8 +1901,7 @@ class TDqComputeActorBase : public NActors::TActorBootstrapped } if (auto* transform = transformInfo.AsyncInput) { - // TODO: support async CA - transform->FillExtraStats(protoTask, last, TaskRunner ? TaskRunner->GetMeteringStats() : 0); + transform->FillExtraStats(protoTask, last, GetMeteringStats()); } } @@ -2102,7 +2030,6 @@ class TDqComputeActorBase : public NActors::TActorBootstrapped const IDqAsyncIoFactory::TPtr AsyncIoFactory; const NKikimr::NMiniKQL::IFunctionRegistry* FunctionRegistry = nullptr; const NDqProto::ECheckpointingMode CheckpointingMode; - TIntrusivePtr TaskRunner; TDqComputeActorChannels* Channels = nullptr; TDqComputeActorCheckpoints* Checkpoints = nullptr; THashMap InputChannelsMap; // Channel id -> Channel info diff --git a/ydb/library/yql/dq/actors/compute/dq_sync_compute_actor_base.h b/ydb/library/yql/dq/actors/compute/dq_sync_compute_actor_base.h index 8d2ffb00924b..7e21910ca760 100644 --- a/ydb/library/yql/dq/actors/compute/dq_sync_compute_actor_base.h +++ b/ydb/library/yql/dq/actors/compute/dq_sync_compute_actor_base.h @@ -44,15 +44,73 @@ class TDqSyncComputeActorBase: public TDqComputeActorBase(this)->GetSourcesState(); + + TBase::PollAsyncInput(); + ERunStatus status = TaskRunner->Run(); + + CA_LOG_T("Resume execution, run status: " << status); + + if (status != ERunStatus::Finished) { + static_cast(this)->PollSources(std::move(sourcesState)); + } + + if ((status == ERunStatus::PendingInput || status == ERunStatus::Finished) && this->Checkpoints && this->Checkpoints->HasPendingCheckpoint() && !this->Checkpoints->ComputeActorStateSaved() && TBase::ReadyToCheckpoint()) { + this->Checkpoints->DoCheckpoint(); + } + + TBase::ProcessOutputsImpl(status); + } + + void DoTerminateImpl() override { + TaskRunner.Reset(); + } + + void InvalidateMeminfo() override { + if (TaskRunner) { + TaskRunner->GetAllocator().InvalidateMemInfo(); + TaskRunner->GetAllocator().DisableStrictAllocationCheck(); + } + } + + void SaveState(const NDqProto::TCheckpoint& checkpoint, NDqProto::TComputeActorState& state) const override { + CA_LOG_D("Save state"); + NDqProto::TMiniKqlProgramState& mkqlProgramState = *state.MutableMiniKqlProgram(); + mkqlProgramState.SetRuntimeVersion(NDqProto::RUNTIME_VERSION_YQL_1_0); + NDqProto::TStateData::TData& data = *mkqlProgramState.MutableData()->MutableStateData(); + data.SetVersion(TDqComputeActorCheckpoints::ComputeActorCurrentStateVersion); + data.SetBlob(TaskRunner->Save()); + + for (auto& [inputIndex, source] : this->SourcesMap) { + YQL_ENSURE(source.AsyncInput, "Source[" << inputIndex << "] is not created"); + NDqProto::TSourceState& sourceState = *state.AddSources(); + source.AsyncInput->SaveState(checkpoint, sourceState); + sourceState.SetInputIndex(inputIndex); + } + } + + void DoLoadRunnerState(TString&& blob) override { + TMaybe error = Nothing(); + try { + TaskRunner->Load(blob); + } catch (const std::exception& e) { + error = e.what(); + } + this->Checkpoints->AfterStateLoading(error); + } + void SetTaskRunner(const TIntrusivePtr& taskRunner) { - this->TaskRunner = taskRunner; + TaskRunner = taskRunner; } void PrepareTaskRunner(const IDqTaskRunnerExecutionContext& execCtx) { - YQL_ENSURE(this->TaskRunner); + YQL_ENSURE(TaskRunner); - auto guard = this->TaskRunner->BindAllocator(this->MemoryQuota->GetMkqlMemoryLimit()); + auto guard = TBase::BindAllocator(); auto* alloc = guard.GetMutex(); + alloc->SetLimit(this->MemoryQuota->GetMkqlMemoryLimit()); this->MemoryQuota->TrySetIncreaseMemoryLimitCallback(alloc); @@ -60,15 +118,61 @@ class TDqSyncComputeActorBase: public TDqComputeActorBaseMemoryLimits.ChannelBufferSize; limits.OutputChunkMaxSize = GetDqExecutionSettings().FlowControl.MaxOutputChunkSize; - this->TaskRunner->Prepare(this->Task, limits, execCtx); + TaskRunner->Prepare(this->Task, limits, execCtx); + + for (auto& [channelId, channel] : this->InputChannelsMap) { + channel.Channel = TaskRunner->GetInputChannel(channelId); + } + + for (auto& [inputIndex, source] : this->SourcesMap) { + source.Buffer = TaskRunner->GetSource(inputIndex); + Y_ABORT_UNLESS(source.Buffer); + } + + for (auto& [inputIndex, transform] : this->InputTransformsMap) { + std::tie(transform.InputBuffer, transform.Buffer) = TaskRunner->GetInputTransform(inputIndex); + } + + for (auto& [channelId, channel] : this->OutputChannelsMap) { + channel.Channel = TaskRunner->GetOutputChannel(channelId); + } + + for (auto& [outputIndex, transform] : this->OutputTransformsMap) { + std::tie(transform.Buffer, transform.OutputBuffer) = TaskRunner->GetOutputTransform(outputIndex); + } + + for (auto& [outputIndex, sink] : this->SinksMap) { + sink.Buffer = TaskRunner->GetSink(outputIndex); + } TBase::FillIoMaps( - this->TaskRunner->GetHolderFactory(), - this->TaskRunner->GetTypeEnv(), - this->TaskRunner->GetSecureParams(), - this->TaskRunner->GetTaskParams(), - this->TaskRunner->GetReadRanges()); + TaskRunner->GetHolderFactory(), + TaskRunner->GetTypeEnv(), + TaskRunner->GetSecureParams(), + TaskRunner->GetTaskParams(), + TaskRunner->GetReadRanges(), + TaskRunner->GetRandomProvider() + ); + } + + const NYql::NDq::TTaskRunnerStatsBase* GetTaskRunnerStats() override { + return TaskRunner ? TaskRunner->GetStats() : nullptr; } + + const NYql::NDq::TDqMeteringStats* GetMeteringStats() override { + return TaskRunner ? TaskRunner->GetMeteringStats() : nullptr; + } + +protected: + // methods that are called via static_cast(this) and may be overriden by a dervied class + void* GetSourcesState() const { + return nullptr; + } + void PollSources(void* /* state */) { + } + + TIntrusivePtr TaskRunner; + }; } //namespace NYql::NDq diff --git a/ydb/library/yql/dq/actors/compute/ut/dq_compute_actor_async_input_helper_ut.cpp b/ydb/library/yql/dq/actors/compute/ut/dq_compute_actor_async_input_helper_ut.cpp new file mode 100644 index 000000000000..137816bcbe57 --- /dev/null +++ b/ydb/library/yql/dq/actors/compute/ut/dq_compute_actor_async_input_helper_ut.cpp @@ -0,0 +1,84 @@ + +#include +#include +#include +#include + +#undef IS_CTX_LOG_PRIORITY_ENABLED +#define IS_CTX_LOG_PRIORITY_ENABLED(actorCtxOrSystem, priority, component, sampleBy) false +#include + +namespace NYql::NDq { + +Y_UNIT_TEST_SUITE(TComputeActorAsyncInputHelperTest) { + + struct TDummyDqComputeActorAsyncInput: IDqComputeActorAsyncInput { + TDummyDqComputeActorAsyncInput() { + Batch.emplace_back(NUdf::TUnboxedValue{}); + Batch.emplace_back(NUdf::TUnboxedValue{}); + } + ui64 GetInputIndex() const override { + return 4; + } + + const TDqAsyncStats& GetIngressStats() const override{ + static TDqAsyncStats stats; + return stats; + } + + i64 GetAsyncInputData( + NKikimr::NMiniKQL::TUnboxedValueBatch& batch, + TMaybe& watermark, + bool& finished, + i64 freeSpace) override + { + Y_ABORT_IF(Batch.empty()); + batch = Batch; + Y_UNUSED(watermark); + Y_UNUSED(finished); + Y_UNUSED(freeSpace); + return 2; + } + + // Checkpointing. + void SaveState(const NDqProto::TCheckpoint& checkpoint, NDqProto::TSourceState& state) override { + Y_UNUSED(checkpoint); + Y_UNUSED(state); + } + void CommitState(const NDqProto::TCheckpoint& checkpoint) override { + Y_UNUSED(checkpoint); + } + void LoadState(const NDqProto::TSourceState& state) override { + Y_UNUSED(state); + } + + void PassAway() override {} + NKikimr::NMiniKQL::TUnboxedValueBatch Batch; + }; + + struct TDummyAsyncInputHelper: TComputeActorAsyncInputHelper{ + using TComputeActorAsyncInputHelper::TComputeActorAsyncInputHelper; + i64 GetFreeSpace() const override{ + return 10; + } + void AsyncInputPush(NKikimr::NMiniKQL::TUnboxedValueBatch&& batch, i64 space, bool finished) override{ + batch.clear(); + Y_UNUSED(space); + Y_UNUSED(finished); + return; + } + }; + + Y_UNIT_TEST(PollAsyncInput) { + NKikimr::NMiniKQL::TScopedAlloc alloc(__LOCATION__, NKikimr::TAlignedPagePoolCounters(), true, true); + TDummyDqComputeActorAsyncInput input; + TDummyAsyncInputHelper helper("MyPrefix", 13, NDqProto::EWatermarksMode::WATERMARKS_MODE_DISABLED); + helper.AsyncInput = &input; + TDqComputeActorMetrics metrics{NMonitoring::TDynamicCounterPtr{}}; + TDqComputeActorWatermarks watermarks(NActors::TActorIdentity{NActors::TActorId{}}, TTxId{}, 7); + auto result = helper.PollAsyncInput(metrics, watermarks, 20); + UNIT_ASSERT(result && EResumeSource::CAPollAsync == *result); + } +} + +} //namespace NYql::NDq diff --git a/ydb/library/yql/dq/actors/compute/ut/ya.make b/ydb/library/yql/dq/actors/compute/ut/ya.make index 6dfca084a033..617f9e30f149 100644 --- a/ydb/library/yql/dq/actors/compute/ut/ya.make +++ b/ydb/library/yql/dq/actors/compute/ut/ya.make @@ -1,6 +1,7 @@ UNITTEST_FOR(ydb/library/yql/dq/actors/compute) SRCS( + dq_compute_actor_async_input_helper_ut.cpp dq_compute_issues_buffer_ut.cpp dq_source_watermark_tracker_ut.cpp ) @@ -12,4 +13,6 @@ PEERDIR( ydb/library/yql/sql/pg_dummy ) +YQL_LAST_ABI_VERSION() + END() diff --git a/ydb/library/yql/dq/actors/task_runner/task_runner_actor.h b/ydb/library/yql/dq/actors/task_runner/task_runner_actor.h index 295e5ce693ca..f9acea3d2464 100644 --- a/ydb/library/yql/dq/actors/task_runner/task_runner_actor.h +++ b/ydb/library/yql/dq/actors/task_runner/task_runner_actor.h @@ -50,8 +50,6 @@ struct ITaskRunnerActorFactory { THolder&& memoryQuota = {}) = 0; }; -// temporary for YQL-17542 -#define Y_YQL_DQ_TASK_RUNNER_ACTOR_FACTORY_COMPATIBILITY_1 ITaskRunnerActorFactory::TPtr CreateLocalTaskRunnerActorFactory(const TTaskRunnerFactory& factory); } // namespace NTaskRunnerActor From 679ef9f1531bbf8fb4e37f600b8c5834f771a239 Mon Sep 17 00:00:00 2001 From: =?UTF-8?q?=D0=9E=D0=BB=D0=B5=D0=B3?= <150132506+iddqdex@users.noreply.github.com> Date: Mon, 12 Feb 2024 13:09:19 +0300 Subject: [PATCH 013/117] =?UTF-8?q?KIKIMR-21016:=20=D0=9F=D1=80=D0=BE?= =?UTF-8?q?=D1=81=D1=82=D0=B0=D0=B2=D0=B8=D1=82=D1=8C=20=D0=B2=D0=B5=D1=80?= =?UTF-8?q?=D1=81=D0=B8=D1=8E=20SSA=20Runtime=20=D0=B2=2024-1=20(#1785)?= MIME-Version: 1.0 Content-Type: text/plain; charset=UTF-8 Content-Transfer-Encoding: 8bit Co-authored-by: Tony-Romanov <150126326+Tony-Romanov@users.noreply.github.com> --- ydb/core/formats/arrow/ssa_runtime_version.h | 2 +- .../opt/physical/kqp_opt_phy_olap_filter.cpp | 1 + .../kqp/query_compiler/kqp_olap_compiler.cpp | 38 +++++++++++++++---- ydb/core/kqp/ut/olap/kqp_olap_ut.cpp | 4 ++ ydb/core/kqp/ut/query/kqp_explain_ut.cpp | 4 ++ 5 files changed, 40 insertions(+), 9 deletions(-) diff --git a/ydb/core/formats/arrow/ssa_runtime_version.h b/ydb/core/formats/arrow/ssa_runtime_version.h index 5b6559980b52..7f9b78aa760a 100644 --- a/ydb/core/formats/arrow/ssa_runtime_version.h +++ b/ydb/core/formats/arrow/ssa_runtime_version.h @@ -19,7 +19,7 @@ namespace NKikimr::NSsa { // Bump this version every time incompatible runtime functions are introduced. #ifndef SSA_RUNTIME_VERSION -#define SSA_RUNTIME_VERSION 4U +#define SSA_RUNTIME_VERSION 3U #endif // History: diff --git a/ydb/core/kqp/opt/physical/kqp_opt_phy_olap_filter.cpp b/ydb/core/kqp/opt/physical/kqp_opt_phy_olap_filter.cpp index de70e17d40f1..40a07ed8a083 100644 --- a/ydb/core/kqp/opt/physical/kqp_opt_phy_olap_filter.cpp +++ b/ydb/core/kqp/opt/physical/kqp_opt_phy_olap_filter.cpp @@ -140,6 +140,7 @@ std::vector> ExtractComparisonParameters(const T TMaybeNode ComparisonPushdown(const std::vector>& parameters, const TCoCompare& predicate, TExprContext& ctx, TPositionHandle pos); +[[maybe_unused]] TMaybeNode YqlCoalescePushdown(const TCoCoalesce& coalesce, TExprContext& ctx) { if (const auto params = ExtractBinaryFunctionParameters(coalesce, ctx, coalesce.Pos())) { return Build(ctx, coalesce.Pos()) diff --git a/ydb/core/kqp/query_compiler/kqp_olap_compiler.cpp b/ydb/core/kqp/query_compiler/kqp_olap_compiler.cpp index 99020fee6c3c..bd9336adb041 100644 --- a/ydb/core/kqp/query_compiler/kqp_olap_compiler.cpp +++ b/ydb/core/kqp/query_compiler/kqp_olap_compiler.cpp @@ -489,6 +489,12 @@ ui64 CompileSimpleArrowComparison(const TKqpOlapFilterBinaryOp& comparison, TKqp function = TProgram::TAssignment::FUNC_CMP_GREATER; } else if (comparison.Operator() == "gte") { function = TProgram::TAssignment::FUNC_CMP_GREATER_EQUAL; + } else if (comparison.Operator() == "string_contains") { + function = TProgram::TAssignment::FUNC_STR_MATCH; + } else if (comparison.Operator() == "starts_with") { + function = TProgram::TAssignment::FUNC_STR_STARTS_WITH; + } else if (comparison.Operator() == "ends_with") { + function = TProgram::TAssignment::FUNC_STR_ENDS_WITH; } cmpFunc->SetId(function); @@ -620,6 +626,7 @@ TTypedColumn CompileYqlKernelUnaryOperation(const TKqpOlapFilterUnaryOp& operati return {command->GetColumn().GetId(), resultType}; } +[[maybe_unused]] TTypedColumn CompileYqlKernelBinaryOperation(const TKqpOlapFilterBinaryOp& operation, TKqpOlapCompileContext& ctx) { // Columns should be created before operation, otherwise operation fail to find columns @@ -708,7 +715,6 @@ const TTypedColumn BuildLogicalProgram(const TExprNode::TChildrenType& args, con logicalFunc->SetFunctionType(TProgram::YQL_KERNEL); logicalFunc->SetYqlOperationId((ui32)function); } else { - logicalFunc->SetFunctionType(function); logicalFunc->SetId((ui32)function); } @@ -740,22 +746,38 @@ const TTypedColumn BuildLogicalNot(const TExprBase& arg, TKqpOlapCompileContext& TTypedColumn GetOrCreateColumnIdAndType(const TExprBase& node, TKqpOlapCompileContext& ctx) { if (const auto& maybeBinaryOp = node.Maybe()) { - if (const auto& binaryOp = maybeBinaryOp.Cast(); ctx.CheckYqlCompatibleArgsTypes(binaryOp)) { - return CompileYqlKernelBinaryOperation(binaryOp, ctx); + if constexpr (NSsa::RuntimeVersion >= 4U) { + if (const auto& binaryOp = maybeBinaryOp.Cast(); ctx.CheckYqlCompatibleArgsTypes(binaryOp)) { + return CompileYqlKernelBinaryOperation(binaryOp, ctx); + } else { + return { + ConvertSafeCastToColumn(CompileSimpleArrowComparison(binaryOp, ctx), "Uint8", ctx), + ctx.ExprCtx().MakeType(ctx.ExprCtx().MakeType(EDataSlot::Bool)) + }; + } } else { return { - ConvertSafeCastToColumn(CompileSimpleArrowComparison(binaryOp, ctx), "Uint8", ctx), - ctx.ExprCtx().MakeType(ctx.ExprCtx().MakeType(EDataSlot::Uint8)) + CompileSimpleArrowComparison(maybeBinaryOp.Cast(), ctx), + ctx.ExprCtx().MakeType(ctx.ExprCtx().MakeType(EDataSlot::Bool)) }; } } else if (const auto& maybeUnaryOp = node.Maybe()) { return CompileYqlKernelUnaryOperation(maybeUnaryOp.Cast(), ctx); } else if (const auto& maybeAnd = node.Maybe()) { - return BuildLogicalProgram(maybeAnd.Ref().Children(), TKernelRequestBuilder::EBinaryOp::And, ctx); + if constexpr (NSsa::RuntimeVersion >= 4U) + return BuildLogicalProgram(maybeAnd.Ref().Children(), TKernelRequestBuilder::EBinaryOp::And, ctx); + else + return BuildLogicalProgram(maybeAnd.Ref().Children(), TProgram::TAssignment::FUNC_BINARY_AND, ctx); } else if (const auto& maybeOr = node.Maybe()) { - return BuildLogicalProgram(maybeOr.Ref().Children(), TKernelRequestBuilder::EBinaryOp::Or, ctx); + if constexpr (NSsa::RuntimeVersion >= 4U) + return BuildLogicalProgram(maybeOr.Ref().Children(), TKernelRequestBuilder::EBinaryOp::Or, ctx); + else + return BuildLogicalProgram(maybeOr.Ref().Children(), TProgram::TAssignment::FUNC_BINARY_OR, ctx); } else if (const auto& maybeXor = node.Maybe()) { - return BuildLogicalProgram(maybeXor.Ref().Children(), TKernelRequestBuilder::EBinaryOp::Xor, ctx); + if constexpr (NSsa::RuntimeVersion >= 4U) + return BuildLogicalProgram(maybeXor.Ref().Children(), TKernelRequestBuilder::EBinaryOp::Xor, ctx); + else + return BuildLogicalProgram(maybeXor.Ref().Children(), TProgram::TAssignment::FUNC_BINARY_XOR, ctx); } else if (const auto& maybeNot = node.Maybe()) { return BuildLogicalNot(maybeNot.Cast().Value(), ctx); } else if (const auto& maybeJsonValue = node.Maybe()) { diff --git a/ydb/core/kqp/ut/olap/kqp_olap_ut.cpp b/ydb/core/kqp/ut/olap/kqp_olap_ut.cpp index 6f53286948f2..76a94877e767 100644 --- a/ydb/core/kqp/ut/olap/kqp_olap_ut.cpp +++ b/ydb/core/kqp/ut/olap/kqp_olap_ut.cpp @@ -1709,7 +1709,11 @@ Y_UNIT_TEST_SUITE(KqpOlap) { scanSettings.Explain(true); TLocalHelper(kikimr).CreateTestOlapTable(); +#if SSA_RUNTIME_VERSION >= 4U WriteTestData(kikimr, "/Root/olapStore/olapTable", 10000, 3000000, 5, true); +#else + WriteTestData(kikimr, "/Root/olapStore/olapTable", 10000, 3000000, 5, false); +#endif Tests::NCommon::TLoggerInit(kikimr).Initialize(); auto tableClient = kikimr.GetTableClient(); diff --git a/ydb/core/kqp/ut/query/kqp_explain_ut.cpp b/ydb/core/kqp/ut/query/kqp_explain_ut.cpp index 0a101ca68902..e84fa7c3cc9c 100644 --- a/ydb/core/kqp/ut/query/kqp_explain_ut.cpp +++ b/ydb/core/kqp/ut/query/kqp_explain_ut.cpp @@ -855,7 +855,11 @@ Y_UNIT_TEST_SUITE(KqpExplain) { NJson::ReadJsonTree(*streamRes.PlanJson, &plan, true); UNIT_ASSERT(ValidatePlanNodeIds(plan)); +#if SSA_RUNTIME_VERSION >= 4U auto readNode = FindPlanNodeByKv(plan, "Node Type", "TableFullScan"); +#else + auto readNode = FindPlanNodeByKv(plan, "Node Type", "Filter-TableFullScan"); +#endif UNIT_ASSERT(readNode.IsDefined()); auto& operators = readNode.GetMapSafe().at("Operators").GetArraySafe(); From 9e902292d8fe7324edb5424160ddd04c983554fb Mon Sep 17 00:00:00 2001 From: Daniil Cherednik Date: Mon, 12 Feb 2024 16:55:02 +0100 Subject: [PATCH 014/117] Do not call TypeName if trace is not used. (#1506) --- ydb/core/tx/datashard/datashard_pipeline.cpp | 8 +++++--- 1 file changed, 5 insertions(+), 3 deletions(-) diff --git a/ydb/core/tx/datashard/datashard_pipeline.cpp b/ydb/core/tx/datashard/datashard_pipeline.cpp index 4c2cd578930b..1e0c3353c9af 100644 --- a/ydb/core/tx/datashard/datashard_pipeline.cpp +++ b/ydb/core/tx/datashard/datashard_pipeline.cpp @@ -1729,9 +1729,11 @@ EExecutionStatus TPipeline::RunExecutionPlan(TOperation::TPtr op, auto status = unit.Execute(op, txc, ctx); op->AddExecutionTime(timer.GetTime()); - unitSpan.Attribute("Type", TypeName(unit)) - .Attribute("Status", static_cast(status)) - .EndOk(); + if (unitSpan) { + unitSpan.Attribute("Type", TypeName(unit)) + .Attribute("Status", static_cast(status)) + .EndOk(); + } LOG_TRACE_S(ctx, NKikimrServices::TX_DATASHARD, "Execution status for " << *op << " at " << Self->TabletID() From 2e2efae4088ed4d3aa7ccf25b46a8a73e6a1b1b5 Mon Sep 17 00:00:00 2001 From: Aleksandr Dmitriev Date: Tue, 13 Feb 2024 12:24:22 +0300 Subject: [PATCH 015/117] improve base stats propagation logic (#1741) (#1857) --- ydb/core/protos/statistics.proto | 7 +- .../statistics/aggregator/aggregator_impl.cpp | 142 +++++++++++++----- .../statistics/aggregator/aggregator_impl.h | 24 ++- ydb/core/statistics/aggregator/tx_init.cpp | 2 + ydb/core/statistics/events.h | 7 + ydb/core/statistics/stat_service.cpp | 78 +++++++++- 6 files changed, 211 insertions(+), 49 deletions(-) diff --git a/ydb/core/protos/statistics.proto b/ydb/core/protos/statistics.proto index 88efbd1b70e5..6767ca6fc251 100644 --- a/ydb/core/protos/statistics.proto +++ b/ydb/core/protos/statistics.proto @@ -44,9 +44,10 @@ message TEvConnectNode { message TEvRequestStats { optional uint32 NodeId = 1; repeated fixed64 NeedSchemeShards = 2; + optional bool Urgent = 3; } -// SA -> nodes +// SA -> nodes, node -> nodes message TEvPropagateStatistics { repeated uint32 NodeIds = 1; // hierarchical propagation message TStatsEntry { @@ -57,6 +58,10 @@ message TEvPropagateStatistics { repeated TStatsEntry Entries = 2; } +// node -> SA, node -> node +message TEvPropagateStatisticsResponse { +} + // SA -> nodes message TEvStatisticsIsDisabled { } diff --git a/ydb/core/statistics/aggregator/aggregator_impl.cpp b/ydb/core/statistics/aggregator/aggregator_impl.cpp index 07f98b283b23..755eda40399b 100644 --- a/ydb/core/statistics/aggregator/aggregator_impl.cpp +++ b/ydb/core/statistics/aggregator/aggregator_impl.cpp @@ -12,6 +12,7 @@ TStatisticsAggregator::TStatisticsAggregator(const NActors::TActorId& tablet, TT , TTabletExecutedFlat(info, tablet, new NMiniKQL::TMiniKQLFactory) { PropagateInterval = forTests ? TDuration::Seconds(5) : TDuration::Minutes(3); + PropagateTimeout = forTests ? TDuration::Seconds(3) : TDuration::Minutes(2); auto seed = std::random_device{}(); RandomGenerator.seed(seed); @@ -124,11 +125,6 @@ void TStatisticsAggregator::Handle(TEvStatistics::TEvConnectNode::TPtr& ev) { return; } - if (!IsPropagateInFlight) { - Schedule(PropagateInterval, new TEvPrivate::TEvPropagate()); - IsPropagateInFlight = true; - } - if (!record.NeedSchemeShardsSize()) { return; } @@ -149,7 +145,8 @@ void TStatisticsAggregator::Handle(TEvStatistics::TEvRequestStats::TPtr& ev) { SA_LOG_D("[" << TabletID() << "] EvRequestStats" << ", node id = " << nodeId - << ", schemeshard count = " << record.NeedSchemeShardsSize()); + << ", schemeshard count = " << record.NeedSchemeShardsSize() + << ", urgent = " << record.GetUrgent()); if (!EnableStatistics) { auto disabled = std::make_unique(); @@ -157,6 +154,19 @@ void TStatisticsAggregator::Handle(TEvStatistics::TEvRequestStats::TPtr& ev) { return; } + for (const auto& ssId : record.GetNeedSchemeShards()) { + RequestedSchemeShards.insert(ssId); + } + + if (record.GetUrgent()) { + PendingRequests.push(std::move(ev)); + if (!ProcessUrgentInFlight) { + Send(SelfId(), new TEvPrivate::TEvProcessUrgent()); + ProcessUrgentInFlight = true; + } + return; + } + std::vector ssIds; ssIds.reserve(record.NeedSchemeShardsSize()); for (const auto& ssId : record.GetNeedSchemeShards()) { @@ -206,6 +216,60 @@ void TStatisticsAggregator::Handle(TEvPrivate::TEvPropagate::TPtr&) { Schedule(PropagateInterval, new TEvPrivate::TEvPropagate()); } +void TStatisticsAggregator::Handle(TEvStatistics::TEvPropagateStatisticsResponse::TPtr&) { + if (!PropagationInFlight) { + return; + } + if (LastSSIndex < PropagationSchemeShards.size()) { + LastSSIndex = PropagatePart(PropagationNodes, PropagationSchemeShards, LastSSIndex, true); + } else { + PropagationInFlight = false; + PropagationNodes.clear(); + PropagationSchemeShards.clear(); + LastSSIndex = 0; + } +} + +void TStatisticsAggregator::Handle(TEvPrivate::TEvProcessUrgent::TPtr&) { + SA_LOG_D("[" << TabletID() << "] EvProcessUrgent"); + + ProcessUrgentInFlight = false; + + if (PendingRequests.empty()) { + return; + } + + TEvStatistics::TEvRequestStats::TPtr ev = std::move(PendingRequests.front()); + PendingRequests.pop(); + + if (!PendingRequests.empty()) { + Send(SelfId(), new TEvPrivate::TEvProcessUrgent()); + ProcessUrgentInFlight = true; + } + + auto record = ev->Get()->Record; + const auto nodeId = record.GetNodeId(); + + std::vector ssIds; + ssIds.reserve(record.NeedSchemeShardsSize()); + for (const auto& ssId : record.GetNeedSchemeShards()) { + ssIds.push_back(ssId); + } + + SendStatisticsToNode(nodeId, ssIds); +} + +void TStatisticsAggregator::Handle(TEvPrivate::TEvPropagateTimeout::TPtr&) { + SA_LOG_D("[" << TabletID() << "] EvPropagateTimeout"); + + if (PropagationInFlight) { + PropagationInFlight = false; + PropagationNodes.clear(); + PropagationSchemeShards.clear(); + LastSSIndex = 0; + } +} + void TStatisticsAggregator::ProcessRequests(TNodeId nodeId, const std::vector& ssIds) { if (FastCounter > 0) { --FastCounter; @@ -217,7 +281,7 @@ void TStatisticsAggregator::ProcessRequests(TNodeId nodeId, const std::vector nodeIds; nodeIds.push_back(nodeId); - PropagateStatisticsImpl(nodeIds, ssIds); + PropagatePart(nodeIds, ssIds, 0, false); } void TStatisticsAggregator::PropagateStatistics() { @@ -255,7 +319,13 @@ void TStatisticsAggregator::PropagateStatistics() { ssIds.push_back(ssId); } - PropagateStatisticsImpl(nodeIds, ssIds); + Schedule(PropagateTimeout, new TEvPrivate::TEvPropagateTimeout); + + PropagationInFlight = true; + PropagationNodes = std::move(nodeIds); + PropagationSchemeShards = std::move(ssIds); + + LastSSIndex = PropagatePart(PropagationNodes, PropagationSchemeShards, 0, true); } void TStatisticsAggregator::PropagateFastStatistics() { @@ -280,43 +350,39 @@ void TStatisticsAggregator::PropagateFastStatistics() { ssIds.push_back(ssId); } - PropagateStatisticsImpl(nodeIds, ssIds); + PropagatePart(nodeIds, ssIds, 0, false); } -void TStatisticsAggregator::PropagateStatisticsImpl( - const std::vector& nodeIds, const std::vector& ssIds) +size_t TStatisticsAggregator::PropagatePart(const std::vector& nodeIds, const std::vector& ssIds, + size_t lastSSIndex, bool useSizeLimit) { - if (nodeIds.empty() || ssIds.empty()) { - return; - } + auto propagate = std::make_unique(); + auto* record = propagate->MutableRecord(); TNodeId leadingNodeId = nodeIds[0]; + record->MutableNodeIds()->Reserve(nodeIds.size() - 1); + for (size_t i = 1; i < nodeIds.size(); ++i) { + record->AddNodeIds(nodeIds[i]); + } - for (size_t index = 0; index < ssIds.size(); ) { - auto propagate = std::make_unique(); - auto* record = propagate->MutableRecord(); - record->MutableNodeIds()->Reserve(nodeIds.size() - 1); - for (size_t i = 1; i < nodeIds.size(); ++i) { - record->AddNodeIds(nodeIds[i]); - } - for (size_t size = 0; index < ssIds.size(); ++index) { - auto ssId = ssIds[index]; - auto* entry = record->AddEntries(); - entry->SetSchemeShardId(ssId); - auto itStats = BaseStats.find(ssId); - if (itStats != BaseStats.end()) { - entry->SetStats(itStats->second); - size += itStats->second.size(); - } else { - entry->SetStats(TString()); // stats are not sent from SA yet - } - if (size >= StatsSizeLimitBytes) { - ++index; - break; - } + size_t sizeLimit = useSizeLimit ? StatsSizeLimitBytes : std::numeric_limits::max(); + size_t index = lastSSIndex; + for (size_t size = 0; index < ssIds.size() && size < sizeLimit; ++index) { + auto ssId = ssIds[index]; + auto* entry = record->AddEntries(); + entry->SetSchemeShardId(ssId); + auto itStats = BaseStats.find(ssId); + if (itStats != BaseStats.end()) { + entry->SetStats(itStats->second); + size += itStats->second.size(); + } else { + entry->SetStats(TString()); // stats are not sent from SS yet } - Send(NStat::MakeStatServiceID(leadingNodeId), propagate.release()); } + + Send(NStat::MakeStatServiceID(leadingNodeId), propagate.release()); + + return index; } void TStatisticsAggregator::PersistSysParam(NIceDb::TNiceDb& db, ui64 id, const TString& value) { diff --git a/ydb/core/statistics/aggregator/aggregator_impl.h b/ydb/core/statistics/aggregator/aggregator_impl.h index d2ce8c500b10..609422f8f675 100644 --- a/ydb/core/statistics/aggregator/aggregator_impl.h +++ b/ydb/core/statistics/aggregator/aggregator_impl.h @@ -42,12 +42,16 @@ class TStatisticsAggregator : public TActor, public NTabl enum EEv { EvPropagate = EventSpaceBegin(TEvents::ES_PRIVATE), EvFastPropagateCheck, + EvProcessUrgent, + EvPropagateTimeout, EvEnd }; struct TEvPropagate : public TEventLocal {}; struct TEvFastPropagateCheck : public TEventLocal {}; + struct TEvProcessUrgent : public TEventLocal {}; + struct TEvPropagateTimeout : public TEventLocal {}; }; private: @@ -73,12 +77,16 @@ class TStatisticsAggregator : public TActor, public NTabl void Handle(TEvTabletPipe::TEvServerConnected::TPtr& ev); void Handle(TEvTabletPipe::TEvServerDisconnected::TPtr& ev); void Handle(TEvPrivate::TEvFastPropagateCheck::TPtr& ev); + void Handle(TEvStatistics::TEvPropagateStatisticsResponse::TPtr& ev); + void Handle(TEvPrivate::TEvProcessUrgent::TPtr& ev); + void Handle(TEvPrivate::TEvPropagateTimeout::TPtr& ev); void ProcessRequests(TNodeId nodeId, const std::vector& ssIds); void SendStatisticsToNode(TNodeId nodeId, const std::vector& ssIds); void PropagateStatistics(); void PropagateFastStatistics(); - void PropagateStatisticsImpl(const std::vector& nodeIds, const std::vector& ssIds); + size_t PropagatePart(const std::vector& nodeIds, const std::vector& ssIds, + size_t lastSSIndex, bool useSizeLimit); void PersistSysParam(NIceDb::TNiceDb& db, ui64 id, const TString& value); @@ -99,6 +107,9 @@ class TStatisticsAggregator : public TActor, public NTabl hFunc(TEvTabletPipe::TEvServerConnected, Handle); hFunc(TEvTabletPipe::TEvServerDisconnected, Handle); hFunc(TEvPrivate::TEvFastPropagateCheck, Handle); + hFunc(TEvStatistics::TEvPropagateStatisticsResponse, Handle); + hFunc(TEvPrivate::TEvProcessUrgent, Handle); + hFunc(TEvPrivate::TEvPropagateTimeout, Handle); default: if (!HandleDefaultEvents(ev, SelfId())) { LOG_CRIT(TlsActivationContext->AsActorContext(), NKikimrServices::STATISTICS, @@ -118,7 +129,8 @@ class TStatisticsAggregator : public TActor, public NTabl static constexpr size_t StatsSizeLimitBytes = 2 << 20; // limit for stats size in one message TDuration PropagateInterval; - bool IsPropagateInFlight = false; // is slow propagation started + TDuration PropagateTimeout; + static constexpr TDuration FastCheckInterval = TDuration::MilliSeconds(50); std::unordered_map BaseStats; // schemeshard id -> serialized stats for all paths @@ -134,6 +146,14 @@ class TStatisticsAggregator : public TActor, public NTabl bool FastCheckInFlight = false; std::unordered_set FastNodes; // nodes for fast propagation std::unordered_set FastSchemeShards; // schemeshards for fast propagation + + bool PropagationInFlight = false; + std::vector PropagationNodes; + std::vector PropagationSchemeShards; + size_t LastSSIndex = 0; + + std::queue PendingRequests; + bool ProcessUrgentInFlight = false; }; } // NKikimr::NStat diff --git a/ydb/core/statistics/aggregator/tx_init.cpp b/ydb/core/statistics/aggregator/tx_init.cpp index 88f6428dedc6..9fa487dc8b7c 100644 --- a/ydb/core/statistics/aggregator/tx_init.cpp +++ b/ydb/core/statistics/aggregator/tx_init.cpp @@ -89,6 +89,8 @@ struct TStatisticsAggregator::TTxInit : public TTxBase { Self->EnableStatistics = AppData(ctx)->FeatureFlags.GetEnableStatistics(); Self->SubscribeForConfigChanges(ctx); + Self->Schedule(Self->PropagateInterval, new TEvPrivate::TEvPropagate()); + Self->Become(&TThis::StateWork); } }; diff --git a/ydb/core/statistics/events.h b/ydb/core/statistics/events.h index a24600338a9d..cf16952f95a4 100644 --- a/ydb/core/statistics/events.h +++ b/ydb/core/statistics/events.h @@ -55,6 +55,7 @@ struct TEvStatistics { EvRequestStats, EvPropagateStatistics, EvStatisticsIsDisabled, + EvPropagateStatisticsResponse, EvEnd }; @@ -115,6 +116,12 @@ struct TEvStatistics { NKikimrStat::TEvStatisticsIsDisabled, EvStatisticsIsDisabled> {}; + + struct TEvPropagateStatisticsResponse : public TEventPB< + TEvPropagateStatisticsResponse, + NKikimrStat::TEvPropagateStatisticsResponse, + EvPropagateStatisticsResponse> + {}; }; } // NStat diff --git a/ydb/core/statistics/stat_service.cpp b/ydb/core/statistics/stat_service.cpp index ef2864e92056..cb4e3009d28a 100644 --- a/ydb/core/statistics/stat_service.cpp +++ b/ydb/core/statistics/stat_service.cpp @@ -24,6 +24,19 @@ class TStatService : public TActorBootstrapped { return NKikimrServices::TActivity::STAT_SERVICE; } + struct TEvPrivate { + enum EEv { + EvRequestTimeout = EventSpaceBegin(TEvents::ES_PRIVATE), + + EvEnd + }; + + struct TEvRequestTimeout : public TEventLocal { + std::unordered_set NeedSchemeShards; + TActorId PipeClientId; + }; + }; + void Bootstrap() { EnableStatistics = AppData()->FeatureFlags.GetEnableStatistics(); @@ -41,9 +54,11 @@ class TStatService : public TActorBootstrapped { hFunc(TEvStatistics::TEvGetStatistics, Handle); hFunc(TEvTxProxySchemeCache::TEvNavigateKeySetResult, Handle); hFunc(TEvStatistics::TEvPropagateStatistics, Handle); + IgnoreFunc(TEvStatistics::TEvPropagateStatisticsResponse); hFunc(TEvTabletPipe::TEvClientConnected, Handle); hFunc(TEvTabletPipe::TEvClientDestroyed, Handle); hFunc(TEvStatistics::TEvStatisticsIsDisabled, Handle); + hFunc(TEvPrivate::TEvRequestTimeout, Handle); cFunc(TEvents::TEvPoison::EventType, PassAway); default: LOG_CRIT_S(TlsActivationContext->AsActorContext(), NKikimrServices::STATISTICS, @@ -160,6 +175,11 @@ class TStatService : public TActorBootstrapped { return; } + bool isNewSS = (NeedSchemeShards.find(request.SchemeShardId) == NeedSchemeShards.end()); + if (isNewSS) { + NeedSchemeShards.insert(request.SchemeShardId); + } + auto navigateDomainKey = [this] (TPathId domainKey) { using TNavigate = NSchemeCache::TSchemeCacheNavigate; auto navigate = std::make_unique(); @@ -202,11 +222,18 @@ class TStatService : public TActorBootstrapped { if (!SAPipeClientId) { ConnectToSA(); SyncNode(); - } else { + + } else if (isNewSS) { auto requestStats = std::make_unique(); requestStats->Record.SetNodeId(SelfId().NodeId()); + requestStats->Record.SetUrgent(false); requestStats->Record.AddNeedSchemeShards(request.SchemeShardId); NTabletPipe::SendData(SelfId(), SAPipeClientId, requestStats.release()); + + auto timeout = std::make_unique(); + timeout->NeedSchemeShards.insert(request.SchemeShardId); + timeout->PipeClientId = SAPipeClientId; + Schedule(RequestTimeout, timeout.release()); } } @@ -214,9 +241,12 @@ class TStatService : public TActorBootstrapped { LOG_DEBUG_S(TlsActivationContext->AsActorContext(), NKikimrServices::STATISTICS, "EvPropagateStatistics, node id = " << SelfId().NodeId()); + Send(ev->Sender, new TEvStatistics::TEvPropagateStatisticsResponse); + auto* record = ev->Get()->MutableRecord(); for (const auto& entry : record->GetEntries()) { ui64 schemeShardId = entry.GetSchemeShardId(); + NeedSchemeShards.erase(schemeShardId); auto& statisticsState = Statistics[schemeShardId]; if (entry.GetStats().empty()) { @@ -319,6 +349,32 @@ class TStatService : public TActorBootstrapped { ReplyAllFailed(); } + void Handle(TEvPrivate::TEvRequestTimeout::TPtr& ev) { + LOG_DEBUG_S(TlsActivationContext->AsActorContext(), NKikimrServices::STATISTICS, + "EvRequestTimeout" + << ", pipe client id = " << ev->Get()->PipeClientId + << ", schemeshard count = " << ev->Get()->NeedSchemeShards.size()); + + if (SAPipeClientId != ev->Get()->PipeClientId) { + return; + } + auto requestStats = std::make_unique(); + bool hasNeedSchemeShards = false; + for (auto& ssId : ev->Get()->NeedSchemeShards) { + if (NeedSchemeShards.find(ssId) != NeedSchemeShards.end()) { + requestStats->Record.AddNeedSchemeShards(ssId); + hasNeedSchemeShards = true; + } + } + if (!hasNeedSchemeShards) { + return; + } + requestStats->Record.SetNodeId(SelfId().NodeId()); + requestStats->Record.SetUrgent(true); + + NTabletPipe::SendData(SelfId(), SAPipeClientId, requestStats.release()); + } + void ConnectToSA() { if (SAPipeClientId || !StatisticsAggregatorId) { return; @@ -338,23 +394,25 @@ class TStatService : public TActorBootstrapped { auto connect = std::make_unique(); auto& record = connect->Record; + auto timeout = std::make_unique(); + timeout->PipeClientId = SAPipeClientId; + record.SetNodeId(SelfId().NodeId()); for (const auto& [ssId, ssState] : Statistics) { auto* entry = record.AddHaveSchemeShards(); entry->SetSchemeShardId(ssId); entry->SetTimestamp(ssState.Timestamp); } - std::unordered_set ssIds; - for (const auto& [reqId, reqState] : InFlight) { - if (reqState.SchemeShardId != 0) { - ssIds.insert(reqState.SchemeShardId); - } - } - for (const auto& ssId : ssIds) { + for (const auto& ssId : NeedSchemeShards) { record.AddNeedSchemeShards(ssId); + timeout->NeedSchemeShards.insert(ssId); } NTabletPipe::SendData(SelfId(), SAPipeClientId, connect.release()); + if (!NeedSchemeShards.empty()) { + Schedule(RequestTimeout, timeout.release()); + } + LOG_DEBUG_S(TlsActivationContext->AsActorContext(), NKikimrServices::STATISTICS, "SyncNode(), pipe client id = " << SAPipeClientId); } @@ -465,6 +523,8 @@ class TStatService : public TActorBootstrapped { std::unordered_map InFlight; // request id -> state ui64 NextRequestId = 1; + std::unordered_set NeedSchemeShards; + struct TStatEntry { ui64 RowCount = 0; ui64 BytesSize = 0; @@ -486,6 +546,8 @@ class TStatService : public TActorBootstrapped { RSA_FINISHED }; EResolveSAStage ResolveSAStage = RSA_INITIAL; + + static constexpr TDuration RequestTimeout = TDuration::MilliSeconds(100); }; THolder CreateStatService() { From 3db86df6b9ae1cd30e9c3ef66e14bbef9165d611 Mon Sep 17 00:00:00 2001 From: Nikolay Shestakov Date: Tue, 13 Feb 2024 15:00:57 +0500 Subject: [PATCH 016/117] Fix the processing of incorrect SourceId (#1555) (#1581) --- .../persqueue/ut/partition_chooser_ut.cpp | 25 +++++++++++++++++++ ...ion_chooser_impl__abstract_chooser_actor.h | 9 +++++-- ...artition_chooser_impl__old_chooser_actor.h | 4 ++- ...partition_chooser_impl__sm_chooser_actor.h | 4 ++- .../partition_chooser_impl__table_helper.h | 2 +- 5 files changed, 39 insertions(+), 5 deletions(-) diff --git a/ydb/core/persqueue/ut/partition_chooser_ut.cpp b/ydb/core/persqueue/ut/partition_chooser_ut.cpp index 17eefd280848..7961aa8b04f4 100644 --- a/ydb/core/persqueue/ut/partition_chooser_ut.cpp +++ b/ydb/core/persqueue/ut/partition_chooser_ut.cpp @@ -621,6 +621,19 @@ Y_UNIT_TEST(TPartitionChooserActor_SplitMergeEnabled_PreferedPartition_OtherPart AssertTable(server, "A_Source_10", 0, 13); } +Y_UNIT_TEST(TPartitionChooserActor_SplitMergeEnabled_BadSourceId_Test) { + NPersQueue::TTestServer server = CreateServer(); + + auto config = CreateConfig0(true); + AddPartition(config, 0, {}, {}); + CreatePQTabletMock(server, 0, ETopicPartitionStatus::Active); + + auto r = ChoosePartition(server, config, "base64:a***"); + + UNIT_ASSERT(r->Error); +} + + Y_UNIT_TEST(TPartitionChooserActor_SplitMergeDisabled_NewSourceId_Test) { NPersQueue::TTestServer server = CreateServer(); @@ -692,4 +705,16 @@ Y_UNIT_TEST(TPartitionChooserActor_SplitMergeDisabled_PreferedPartition_Inactive UNIT_ASSERT(r->Error); } +Y_UNIT_TEST(TPartitionChooserActor_SplitMergeDisabled_BadSourceId_Test) { + NPersQueue::TTestServer server = CreateServer(); + + auto config = CreateConfig0(false); + AddPartition(config, 0, {}, {}); + + auto r = ChoosePartition(server, config, "base64:a***"); + + UNIT_ASSERT(r->Error); +} + + } diff --git a/ydb/core/persqueue/writer/partition_chooser_impl__abstract_chooser_actor.h b/ydb/core/persqueue/writer/partition_chooser_impl__abstract_chooser_actor.h index 9f8f4be0df09..4b385f779cda 100644 --- a/ydb/core/persqueue/writer/partition_chooser_impl__abstract_chooser_actor.h +++ b/ydb/core/persqueue/writer/partition_chooser_impl__abstract_chooser_actor.h @@ -54,8 +54,13 @@ class TAbstractPartitionChooserActor: public TActorBootstrapped { return TActor::SelfId(); } - void Initialize(const NActors::TActorContext& ctx) { - TableHelper.Initialize(ctx, SourceId); + [[nodiscard]] bool Initialize(const NActors::TActorContext& ctx) { + if (TableHelper.Initialize(ctx, SourceId)) { + return true; + } + StartIdle(); + TThis::ReplyError(ErrorCode::BAD_REQUEST, "Bad SourceId", ctx); + return false; } void PassAway() { diff --git a/ydb/core/persqueue/writer/partition_chooser_impl__old_chooser_actor.h b/ydb/core/persqueue/writer/partition_chooser_impl__old_chooser_actor.h index f8d9d35e6eed..33e1f3dd2786 100644 --- a/ydb/core/persqueue/writer/partition_chooser_impl__old_chooser_actor.h +++ b/ydb/core/persqueue/writer/partition_chooser_impl__old_chooser_actor.h @@ -37,7 +37,9 @@ class TPartitionChooserActor: public TAbstractPartitionChooserActorPQConfig; TableGeneration = pqConfig.GetTopicsAreFirstClassCitizen() ? ESourceIdTableGeneration::PartitionMapping From e95a49c1b53a04b400ce73c199ae3f9cdc21bc72 Mon Sep 17 00:00:00 2001 From: Aleksei Borzenkov Date: Tue, 13 Feb 2024 14:44:56 +0300 Subject: [PATCH 017/117] =?UTF-8?q?Make=20coordination=20session=20ping=20?= =?UTF-8?q?period=20dependent=20on=20session=20timeout=20KI=E2=80=A6=20(#1?= =?UTF-8?q?837)?= MIME-Version: 1.0 Content-Type: text/plain; charset=UTF-8 Content-Transfer-Encoding: 8bit --- ydb/services/kesus/grpc_service.cpp | 14 ++++++++++++-- 1 file changed, 12 insertions(+), 2 deletions(-) diff --git a/ydb/services/kesus/grpc_service.cpp b/ydb/services/kesus/grpc_service.cpp index 13f7ddafc4df..b5913217d90c 100644 --- a/ydb/services/kesus/grpc_service.cpp +++ b/ydb/services/kesus/grpc_service.cpp @@ -27,6 +27,9 @@ namespace NKesus { class TGRpcSessionActor : public TActorBootstrapped { + static constexpr TDuration MinPingPeriod = TDuration::MilliSeconds(10); + static constexpr TDuration MaxPingPeriod = TDuration::Seconds(5); + public: using TRequest = Ydb::Coordination::SessionRequest; using TResponse = Ydb::Coordination::SessionResponse; @@ -132,6 +135,13 @@ class TGRpcSessionActor return PassAway(); } + PingPeriod = TDuration::MilliSeconds(StartRequest->Record.session_start().timeout_millis() / 3); + if (PingPeriod > MaxPingPeriod) { + PingPeriod = MaxPingPeriod; + } else if (PingPeriod < MinPingPeriod) { + PingPeriod = MinPingPeriod; + } + KesusPath = StartRequest->Record.session_start().path(); auto resolve = MakeHolder(KesusPath); @@ -540,8 +550,7 @@ class TGRpcSessionActor ping->set_opaque(CurrentPingData); Reply(std::move(response)); - // TODO: configure timeout - Schedule(TDuration::MilliSeconds(5000), new TEvPrivate::TEvPingScheduled()); + Schedule(PingPeriod, new TEvPrivate::TEvPingScheduled()); } void Handle(const TEvPrivate::TEvPingScheduled::TPtr& ev) { @@ -599,6 +608,7 @@ class TGRpcSessionActor ui64 SessionId = 0; bool SessionEstablished = false; ui64 CurrentPingData = 0; + TDuration PingPeriod; }; //////////////////////////////////////////////////////////////////////////////// From 781d28dbfc25791e3c81f02b630c9e363b8ef7bd Mon Sep 17 00:00:00 2001 From: Aleksei Borzenkov Date: Tue, 13 Feb 2024 14:45:12 +0300 Subject: [PATCH 018/117] =?UTF-8?q?Make=20stopping=20result/notification?= =?UTF-8?q?=20sending=20dependent=20on=20operation=20type=E2=80=A6=20(#183?= =?UTF-8?q?5)?= MIME-Version: 1.0 Content-Type: text/plain; charset=UTF-8 Content-Transfer-Encoding: 8bit --- ydb/core/tx/datashard/datashard.cpp | 35 ++-------- .../datashard_active_transaction.cpp | 41 ++++++++++++ .../datashard/datashard_active_transaction.h | 2 + ydb/core/tx/datashard/datashard_ut_order.cpp | 66 +++++++++++++++++++ ydb/core/tx/datashard/operation.cpp | 7 ++ ydb/core/tx/datashard/operation.h | 12 ++++ 6 files changed, 134 insertions(+), 29 deletions(-) diff --git a/ydb/core/tx/datashard/datashard.cpp b/ydb/core/tx/datashard/datashard.cpp index f71f7231e516..6539b5a4243e 100644 --- a/ydb/core/tx/datashard/datashard.cpp +++ b/ydb/core/tx/datashard/datashard.cpp @@ -226,41 +226,18 @@ void TDataShard::OnStopGuardStarting(const TActorContext &ctx) { // Handle immediate ops that have completed BuildAndWaitDependencies for (const auto &kv : Pipeline.GetImmediateOps()) { const auto &op = kv.second; - // Send reject result immediately, because we cannot control when - // a new datashard tablet may start and block us from commiting - // anything new. The usual progress queue is too slow for that. - if (!op->Result() && !op->HasResultSentFlag()) { - auto kind = static_cast(op->GetKind()); - auto rejectStatus = NKikimrTxDataShard::TEvProposeTransactionResult::OVERLOADED; - TString rejectReason = TStringBuilder() - << "Rejecting immediate tx " - << op->GetTxId() - << " because datashard " - << TabletID() - << " is restarting"; - auto result = MakeHolder( - kind, TabletID(), op->GetTxId(), rejectStatus); - result->AddError(NKikimrTxDataShard::TError::WRONG_SHARD_STATE, rejectReason); - LOG_NOTICE_S(ctx, NKikimrServices::TX_DATASHARD, rejectReason); - - ctx.Send(op->GetTarget(), result.Release(), 0, op->GetCookie()); - - IncCounter(COUNTER_PREPARE_OVERLOADED); - IncCounter(COUNTER_PREPARE_COMPLETE); - op->SetResultSentFlag(); + if (op->OnStopping(*this, ctx)) { + Pipeline.AddCandidateOp(op); + PlanQueue.Progress(ctx); } - // Add op to candidates because IsReadyToExecute just became true - Pipeline.AddCandidateOp(op); - PlanQueue.Progress(ctx); } // Handle prepared ops by notifying about imminent shutdown for (const auto &kv : TransQueue.GetTxsInFly()) { const auto &op = kv.second; - if (op->GetTarget() && !op->HasCompletedFlag()) { - auto notify = MakeHolder( - TabletID(), op->GetTxId()); - ctx.Send(op->GetTarget(), notify.Release(), 0, op->GetCookie()); + if (op->OnStopping(*this, ctx)) { + Pipeline.AddCandidateOp(op); + PlanQueue.Progress(ctx); } } } diff --git a/ydb/core/tx/datashard/datashard_active_transaction.cpp b/ydb/core/tx/datashard/datashard_active_transaction.cpp index b54f21d39a82..a4a2c4ea5b5a 100644 --- a/ydb/core/tx/datashard/datashard_active_transaction.cpp +++ b/ydb/core/tx/datashard/datashard_active_transaction.cpp @@ -937,4 +937,45 @@ void TActiveTransaction::UntrackMemory() const { NActors::NMemory::TLabel::Sub(TxBody.size()); } +bool TActiveTransaction::OnStopping(TDataShard& self, const TActorContext& ctx) { + if (IsImmediate()) { + // Send reject result immediately, because we cannot control when + // a new datashard tablet may start and block us from commiting + // anything new. The usual progress queue is too slow for that. + if (!HasResultSentFlag() && !Result()) { + auto kind = static_cast(GetKind()); + auto rejectStatus = NKikimrTxDataShard::TEvProposeTransactionResult::OVERLOADED; + TString rejectReason = TStringBuilder() + << "Rejecting immediate tx " + << GetTxId() + << " because datashard " + << self.TabletID() + << " is restarting"; + auto result = MakeHolder( + kind, self.TabletID(), GetTxId(), rejectStatus); + result->AddError(NKikimrTxDataShard::TError::WRONG_SHARD_STATE, rejectReason); + LOG_NOTICE_S(ctx, NKikimrServices::TX_DATASHARD, rejectReason); + + ctx.Send(GetTarget(), result.Release(), 0, GetCookie()); + + self.IncCounter(COUNTER_PREPARE_OVERLOADED); + self.IncCounter(COUNTER_PREPARE_COMPLETE); + SetResultSentFlag(); + } + + // Immediate ops become ready when stopping flag is set + return true; + } else { + // Distributed operations send notification when proposed + if (GetTarget() && !HasCompletedFlag()) { + auto notify = MakeHolder( + self.TabletID(), GetTxId()); + ctx.Send(GetTarget(), notify.Release(), 0, GetCookie()); + } + + // Distributed ops avoid doing new work when stopping + return false; + } +} + }} diff --git a/ydb/core/tx/datashard/datashard_active_transaction.h b/ydb/core/tx/datashard/datashard_active_transaction.h index cca5b12b876f..247b5335c0c9 100644 --- a/ydb/core/tx/datashard/datashard_active_transaction.h +++ b/ydb/core/tx/datashard/datashard_active_transaction.h @@ -603,6 +603,8 @@ class TActiveTransaction : public TOperation { return ++PageFaultCount; } + bool OnStopping(TDataShard& self, const TActorContext& ctx) override; + private: void TrackMemory() const; void UntrackMemory() const; diff --git a/ydb/core/tx/datashard/datashard_ut_order.cpp b/ydb/core/tx/datashard/datashard_ut_order.cpp index 194f826743e6..406020263c70 100644 --- a/ydb/core/tx/datashard/datashard_ut_order.cpp +++ b/ydb/core/tx/datashard/datashard_ut_order.cpp @@ -3386,6 +3386,72 @@ Y_UNIT_TEST_TWIN(TestShardRestartPlannedCommitShouldSucceed, StreamLookup) { } } +Y_UNIT_TEST(TestShardRestartDuringWaitingRead) { + TPortManager pm; + NKikimrConfig::TAppConfig app; + app.MutableTableServiceConfig()->SetEnableKqpDataQuerySourceRead(true); + TServerSettings serverSettings(pm.GetPort(2134)); + serverSettings.SetDomainName("Root") + .SetUseRealThreads(false) + .SetAppConfig(app) + // We read from an unresolved volatile tx + .SetEnableDataShardVolatileTransactions(true); + + Tests::TServer::TPtr server = new TServer(serverSettings); + auto &runtime = *server->GetRuntime(); + auto sender = runtime.AllocateEdgeActor(); + + InitRoot(server, sender); + + CreateShardedTable(server, sender, "/Root", "table-1", 1); + CreateShardedTable(server, sender, "/Root", "table-2", 1); + auto table1shards = GetTableShards(server, sender, "/Root/table-1"); + + ExecSQL(server, sender, Q_("UPSERT INTO `/Root/table-1` (key, value) VALUES (1, 10)")); + ExecSQL(server, sender, Q_("UPSERT INTO `/Root/table-2` (key, value) VALUES (2, 20)")); + + // Block readset exchange + std::vector> readSets; + auto blockReadSets = runtime.AddObserver([&](TEvTxProcessing::TEvReadSet::TPtr& ev) { + readSets.emplace_back(ev.Release()); + }); + + // Start a distributed write to both tables + TString sessionId = CreateSessionRPC(runtime, "/Root"); + auto upsertResult = SendRequest( + runtime, + MakeSimpleRequestRPC(R"( + UPSERT INTO `/Root/table-1` (key, value) VALUES (3, 30); + UPSERT INTO `/Root/table-2` (key, value) VALUES (4, 40); + )", sessionId, /* txId */ "", /* commitTx */ true), + "/Root"); + WaitFor(runtime, [&]{ return readSets.size() >= 4; }, "readsets"); + + // Start reading the first table + TString readSessionId = CreateSessionRPC(runtime, "/Root"); + auto readResult = SendRequest( + runtime, + MakeSimpleRequestRPC(R"( + SELECT key, value FROM `/Root/table-1` + ORDER BY key; + )", readSessionId, /* txId */ "", /* commitTx */ true), + "/Root"); + + // Sleep to ensure read is properly waiting + runtime.SimulateSleep(TDuration::Seconds(1)); + + // Gracefully restart the first table shard + blockReadSets.Remove(); + GracefulRestartTablet(runtime, table1shards[0], sender); + + // Read succeeds because it is automatically retried + // No assert should be triggered in debug builds + UNIT_ASSERT_VALUES_EQUAL( + FormatResult(AwaitResponse(runtime, std::move(readResult))), + "{ items { uint32_value: 1 } items { uint32_value: 10 } }, " + "{ items { uint32_value: 3 } items { uint32_value: 30 } }"); +} + Y_UNIT_TEST(TestShardSnapshotReadNoEarlyReply) { TPortManager pm; TServerSettings serverSettings(pm.GetPort(2134)); diff --git a/ydb/core/tx/datashard/operation.cpp b/ydb/core/tx/datashard/operation.cpp index c217cbf5c6ca..f1779c24bf91 100644 --- a/ydb/core/tx/datashard/operation.cpp +++ b/ydb/core/tx/datashard/operation.cpp @@ -289,5 +289,12 @@ void TOperation::SetFinishProposeTs() noexcept SetFinishProposeTs(AppData()->MonotonicTimeProvider->Now()); } +bool TOperation::OnStopping(TDataShard&, const TActorContext&) +{ + // By default operations don't do anything when stopping + // However they may become ready so add to candidates + return true; +} + } // namespace NDataShard } // namespace NKikimr diff --git a/ydb/core/tx/datashard/operation.h b/ydb/core/tx/datashard/operation.h index 7c7e5bf13769..201e22636a74 100644 --- a/ydb/core/tx/datashard/operation.h +++ b/ydb/core/tx/datashard/operation.h @@ -812,6 +812,18 @@ class TOperation return OperationSpan.GetTraceId(); } + /** + * Called when datashard is going to stop soon + * + * Operation may override this method to support sending notifications or + * results signalling that the operation will never complete. When result + * is sent operation is supposed to set its ResultSentFlag. + * + * When this method returns true the operation will be added to the + * pipeline as a candidate for execution. + */ + virtual bool OnStopping(TDataShard& self, const TActorContext& ctx); + protected: TOperation() : TOperation(TBasicOpInfo()) From 494165b54cca15c705822b0022ba6c66e945f43b Mon Sep 17 00:00:00 2001 From: Aleksei Borzenkov Date: Tue, 13 Feb 2024 18:24:40 +0300 Subject: [PATCH 019/117] Disable volatile transactions KIKIMR-21060 (#1888) --- ydb/core/protos/feature_flags.proto | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/ydb/core/protos/feature_flags.proto b/ydb/core/protos/feature_flags.proto index dcb82a099d61..2d1d2289766a 100644 --- a/ydb/core/protos/feature_flags.proto +++ b/ydb/core/protos/feature_flags.proto @@ -97,7 +97,7 @@ message TFeatureFlags { optional bool EnableAlterDatabaseCreateHiveFirst = 82 [default = false]; reserved 83; // EnableKqpDataQuerySourceRead optional bool EnableSmallDiskOptimization = 84 [default = true]; - optional bool EnableDataShardVolatileTransactions = 85 [default = true]; + optional bool EnableDataShardVolatileTransactions = 85 [default = false]; optional bool EnableTopicServiceTx = 86 [default = false]; optional bool EnableLLVMCache = 87 [default = false]; optional bool EnableExternalDataSources = 88 [default = false]; From 8e8a246c188978046cd01ce1e33a1ba5f8036a9c Mon Sep 17 00:00:00 2001 From: spuchin Date: Wed, 14 Feb 2024 13:29:27 +0300 Subject: [PATCH 020/117] Disable KQP feature flags for stable branch. (#1885) --- ydb/core/kqp/ut/pg/kqp_pg_ut.cpp | 24 ++++++++++++++++--- ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp | 23 +++++++++--------- ydb/core/protos/feature_flags.proto | 2 +- ydb/core/protos/table_service_config.proto | 4 ++-- 4 files changed, 36 insertions(+), 17 deletions(-) diff --git a/ydb/core/kqp/ut/pg/kqp_pg_ut.cpp b/ydb/core/kqp/ut/pg/kqp_pg_ut.cpp index 9887464a6ae2..05ca03d898a0 100644 --- a/ydb/core/kqp/ut/pg/kqp_pg_ut.cpp +++ b/ydb/core/kqp/ut/pg/kqp_pg_ut.cpp @@ -1256,6 +1256,7 @@ Y_UNIT_TEST_SUITE(KqpPg) { Y_UNIT_TEST(InsertFromSelect_Serial) { NKikimrConfig::TAppConfig appConfig; appConfig.MutableTableServiceConfig()->SetEnablePreparedDdl(true); + appConfig.MutableTableServiceConfig()->SetEnableSequences(true); auto setting = NKikimrKqp::TKqpSetting(); auto serverSettings = TKikimrSettings() .SetAppConfig(appConfig) @@ -1439,7 +1440,12 @@ Y_UNIT_TEST_SUITE(KqpPg) { } Y_UNIT_TEST(Returning) { - TKikimrRunner kikimr(NKqp::TKikimrSettings().SetWithSampleTables(false)); + NKikimrConfig::TAppConfig appConfig; + appConfig.MutableTableServiceConfig()->SetEnableSequences(true); + appConfig.MutableTableServiceConfig()->SetEnableColumnsWithDefault(true); + + TKikimrRunner kikimr(NKqp::TKikimrSettings().SetAppConfig(appConfig) + .SetWithSampleTables(false)); auto client = kikimr.GetTableClient(); auto session = client.CreateSession().GetValueSync().GetSession(); @@ -1598,7 +1604,11 @@ Y_UNIT_TEST_SUITE(KqpPg) { } Y_UNIT_TEST(CreateTableSerialColumns) { - TKikimrRunner kikimr(NKqp::TKikimrSettings().SetWithSampleTables(false).SetEnableNotNullDataColumns(true)); + NKikimrConfig::TAppConfig appConfig; + appConfig.MutableTableServiceConfig()->SetEnableSequences(true); + + TKikimrRunner kikimr(NKqp::TKikimrSettings().SetAppConfig(appConfig) + .SetWithSampleTables(false).SetEnableNotNullDataColumns(true)); auto client = kikimr.GetTableClient(); auto session = client.CreateSession().GetValueSync().GetSession(); { @@ -2074,7 +2084,8 @@ Y_UNIT_TEST_SUITE(KqpPg) { Y_UNIT_TEST(CreateTempTableSerial) { NKikimrConfig::TAppConfig appConfig; - appConfig.MutableTableServiceConfig()->SetEnablePreparedDdl(true);; + appConfig.MutableTableServiceConfig()->SetEnablePreparedDdl(true); + appConfig.MutableTableServiceConfig()->SetEnableSequences(true); auto setting = NKikimrKqp::TKqpSetting(); auto serverSettings = TKikimrSettings() .SetAppConfig(appConfig) @@ -3287,6 +3298,7 @@ Y_UNIT_TEST_SUITE(KqpPg) { Y_UNIT_TEST(Insert_Serial) { NKikimrConfig::TAppConfig appConfig; appConfig.MutableTableServiceConfig()->SetEnablePreparedDdl(true); + appConfig.MutableTableServiceConfig()->SetEnableSequences(true); auto setting = NKikimrKqp::TKqpSetting(); auto serverSettings = TKikimrSettings() .SetAppConfig(appConfig) @@ -3323,6 +3335,7 @@ Y_UNIT_TEST_SUITE(KqpPg) { Y_UNIT_TEST(InsertNoTargetColumns_Serial) { NKikimrConfig::TAppConfig appConfig; appConfig.MutableTableServiceConfig()->SetEnablePreparedDdl(true); + appConfig.MutableTableServiceConfig()->SetEnableSequences(true); auto setting = NKikimrKqp::TKqpSetting(); auto serverSettings = TKikimrSettings() .SetAppConfig(appConfig) @@ -3358,6 +3371,7 @@ Y_UNIT_TEST_SUITE(KqpPg) { Y_UNIT_TEST(InsertValuesFromTableWithDefault) { NKikimrConfig::TAppConfig appConfig; appConfig.MutableTableServiceConfig()->SetEnablePreparedDdl(true); + appConfig.MutableTableServiceConfig()->SetEnableColumnsWithDefault(true); auto setting = NKikimrKqp::TKqpSetting(); auto serverSettings = TKikimrSettings() .SetAppConfig(appConfig) @@ -3393,6 +3407,7 @@ Y_UNIT_TEST_SUITE(KqpPg) { Y_UNIT_TEST(InsertValuesFromTableWithDefaultBool) { NKikimrConfig::TAppConfig appConfig; appConfig.MutableTableServiceConfig()->SetEnablePreparedDdl(true); + appConfig.MutableTableServiceConfig()->SetEnableColumnsWithDefault(true); auto setting = NKikimrKqp::TKqpSetting(); auto serverSettings = TKikimrSettings() .SetAppConfig(appConfig) @@ -3428,6 +3443,7 @@ Y_UNIT_TEST_SUITE(KqpPg) { Y_UNIT_TEST(InsertValuesFromTableWithDefaultText) { NKikimrConfig::TAppConfig appConfig; appConfig.MutableTableServiceConfig()->SetEnablePreparedDdl(true); + appConfig.MutableTableServiceConfig()->SetEnableColumnsWithDefault(true); auto setting = NKikimrKqp::TKqpSetting(); auto serverSettings = TKikimrSettings() .SetAppConfig(appConfig) @@ -3463,6 +3479,7 @@ Y_UNIT_TEST_SUITE(KqpPg) { Y_UNIT_TEST(InsertValuesFromTableWithDefaultTextNotNull) { NKikimrConfig::TAppConfig appConfig; appConfig.MutableTableServiceConfig()->SetEnablePreparedDdl(true); + appConfig.MutableTableServiceConfig()->SetEnableColumnsWithDefault(true); auto setting = NKikimrKqp::TKqpSetting(); auto serverSettings = TKikimrSettings() .SetAppConfig(appConfig) @@ -3536,6 +3553,7 @@ Y_UNIT_TEST_SUITE(KqpPg) { Y_UNIT_TEST(InsertNoTargetColumns_SerialNotNull) { NKikimrConfig::TAppConfig appConfig; appConfig.MutableTableServiceConfig()->SetEnablePreparedDdl(true); + appConfig.MutableTableServiceConfig()->SetEnableSequences(true); auto setting = NKikimrKqp::TKqpSetting(); auto serverSettings = TKikimrSettings() .SetAppConfig(appConfig) diff --git a/ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp b/ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp index d09a196b7af5..d3326432c2d0 100644 --- a/ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp +++ b/ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp @@ -291,6 +291,7 @@ Y_UNIT_TEST_SUITE(KqpConstraints) { Y_UNIT_TEST(AlterTableAddColumnWithDefaultValue) { NKikimrConfig::TAppConfig appConfig; appConfig.MutableTableServiceConfig()->SetEnableSequences(false); + appConfig.MutableTableServiceConfig()->SetEnableColumnsWithDefault(true); appConfig.MutableFeatureFlags()->SetEnableAddColumsWithDefaults(true); auto serverSettings = TKikimrSettings().SetAppConfig(appConfig); TKikimrRunner kikimr(serverSettings); @@ -345,7 +346,7 @@ Y_UNIT_TEST_SUITE(KqpConstraints) { auto result = session.ExecuteSchemeQuery(query).GetValueSync(); UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, result.GetIssues().ToString()); - } + } { TString query = R"( @@ -412,7 +413,7 @@ Y_UNIT_TEST_SUITE(KqpConstraints) { auto result = session.ExecuteSchemeQuery(query).GetValueSync(); UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, result.GetIssues().ToString()); - } + } } Y_UNIT_TEST(DefaultValuesForTableNegative3) { @@ -437,7 +438,7 @@ Y_UNIT_TEST_SUITE(KqpConstraints) { UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::GENERIC_ERROR, result.GetIssues().ToString()); UNIT_ASSERT_STRING_CONTAINS(result.GetIssues().ToString(), "Default expr Key is nullable or optional, but column has not null constraint"); - } + } } Y_UNIT_TEST(DefaultValuesForTableNegative4) { @@ -463,7 +464,7 @@ Y_UNIT_TEST_SUITE(KqpConstraints) { auto result = session.ExecuteSchemeQuery(query).GetValueSync(); UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::GENERIC_ERROR, result.GetIssues().ToString()); - } + } } Y_UNIT_TEST(IndexedTableAndNotNullColumn) { @@ -506,7 +507,7 @@ Y_UNIT_TEST_SUITE(KqpConstraints) { UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, result.GetIssues().ToString()); - if (result.GetResultSets().size() > 0) + if (result.GetResultSets().size() > 0) return NYdb::FormatResultSetYson(result.GetResultSet(0)); return ""; }; @@ -538,7 +539,7 @@ Y_UNIT_TEST_SUITE(KqpConstraints) { ] )"); - + fQuery(R"( UPSERT INTO `/Root/AlterTableAddNotNullColumn` (Key, Value, Value2) VALUES (2, "New", 2); )"); @@ -551,7 +552,7 @@ Y_UNIT_TEST_SUITE(KqpConstraints) { fQuery(R"( UPSERT INTO `/Root/AlterTableAddNotNullColumn` (Key, Value) VALUES (2, "OldNew"); - )"); + )"); fQuery(R"( UPSERT INTO `/Root/AlterTableAddNotNullColumn` (Key, Value) VALUES (3, "BrandNew"); @@ -715,7 +716,7 @@ Y_UNIT_TEST_SUITE(KqpConstraints) { UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, result.GetIssues().ToString()); - if (result.GetResultSets().size() > 0) + if (result.GetResultSets().size() > 0) return NYdb::FormatResultSetYson(result.GetResultSet(0)); return ""; }; @@ -760,7 +761,7 @@ Y_UNIT_TEST_SUITE(KqpConstraints) { ] )"); - + fQuery(R"( UPSERT INTO `/Root/AlterTableAddNotNullColumn` (Key, Value, Value2) VALUES (2, "New", 2); )"); @@ -773,7 +774,7 @@ Y_UNIT_TEST_SUITE(KqpConstraints) { fQuery(R"( UPSERT INTO `/Root/AlterTableAddNotNullColumn` (Key, Value) VALUES (2, "OldNew"); - )"); + )"); fQuery(R"( UPSERT INTO `/Root/AlterTableAddNotNullColumn` (Key, Value) VALUES (3, "BrandNew"); @@ -788,4 +789,4 @@ Y_UNIT_TEST_SUITE(KqpConstraints) { } } -} // namespace NKikimr::NKqp \ No newline at end of file +} // namespace NKikimr::NKqp diff --git a/ydb/core/protos/feature_flags.proto b/ydb/core/protos/feature_flags.proto index 2d1d2289766a..5035f3b0f897 100644 --- a/ydb/core/protos/feature_flags.proto +++ b/ydb/core/protos/feature_flags.proto @@ -105,7 +105,7 @@ message TFeatureFlags { optional bool EnableSeparationComputeActorsFromRead = 90 [default = false]; optional bool EnablePQConfigTransactionsAtSchemeShard = 91 [default = false]; optional bool EnableScriptExecutionOperations = 92 [default = false]; - optional bool EnableImplicitQueryParameterTypes = 93 [default = true]; + optional bool EnableImplicitQueryParameterTypes = 93 [default = false]; optional bool EnableForceImmediateEffectsExecution = 94 [default = false]; optional bool EnableTopicSplitMerge = 95 [default = false]; optional bool EnableChangefeedDynamoDBStreamsFormat = 96 [default = true]; diff --git a/ydb/core/protos/table_service_config.proto b/ydb/core/protos/table_service_config.proto index 54aa9c0d8335..8653d314d56a 100644 --- a/ydb/core/protos/table_service_config.proto +++ b/ydb/core/protos/table_service_config.proto @@ -235,7 +235,7 @@ message TTableServiceConfig { optional bool EnableKqpImmediateEffects = 38 [default = true]; optional bool EnableSequentialReads = 39 [default = true]; optional bool EnablePreparedDdl = 42 [default = false]; - optional bool EnableSequences = 43 [default = true]; + optional bool EnableSequences = 43 [default = false]; optional bool EnableAsyncComputationPatternCompilation = 48 [default = true]; optional TCompileComputationPatternServiceConfig CompileComputationPatternServiceConfig = 47; @@ -266,7 +266,7 @@ message TTableServiceConfig { } optional EIndexAutoChooseMode IndexAutoChooseMode = 50 [default = DISABLED]; - optional bool EnableColumnsWithDefault = 51 [default = true]; + optional bool EnableColumnsWithDefault = 51 [default = false]; optional bool EnableAstCache = 52 [default = false]; optional bool EnablePgConstsToParams = 53 [default = false]; From e479c3cd88960ca9b01c3308415f88f24204a542 Mon Sep 17 00:00:00 2001 From: Aleksei Borzenkov Date: Wed, 14 Feb 2024 17:19:23 +0300 Subject: [PATCH 021/117] Remove MvccTestOutOfOrderRestartLocksSingleWithoutBarrier (#1905) (#1907) --- ydb/core/tx/datashard/datashard_ut_order.cpp | 123 ------------------- 1 file changed, 123 deletions(-) diff --git a/ydb/core/tx/datashard/datashard_ut_order.cpp b/ydb/core/tx/datashard/datashard_ut_order.cpp index 406020263c70..ee1af9e056c1 100644 --- a/ydb/core/tx/datashard/datashard_ut_order.cpp +++ b/ydb/core/tx/datashard/datashard_ut_order.cpp @@ -1662,129 +1662,6 @@ Y_UNIT_TEST_TWIN(TestOutOfOrderNonConflictingWrites, StreamLookup) { } } -Y_UNIT_TEST(MvccTestOutOfOrderRestartLocksSingleWithoutBarrier) { - TPortManager pm; - NKikimrConfig::TAppConfig app; - app.MutableTableServiceConfig()->SetEnableKqpDataQueryStreamLookup(false); - TServerSettings serverSettings(pm.GetPort(2134)); - serverSettings.SetDomainName("Root") - .SetAppConfig(app) - .SetUseRealThreads(false); - - Tests::TServer::TPtr server = new TServer(serverSettings); - auto &runtime = *server->GetRuntime(); - auto sender = runtime.AllocateEdgeActor(); - - // This test requires barrier to be disabled - runtime.GetAppData().FeatureFlags.SetDisableDataShardBarrier(true); - - runtime.SetLogPriority(NKikimrServices::TX_DATASHARD, NLog::PRI_TRACE); - runtime.SetLogPriority(NKikimrServices::KQP_EXECUTER, NLog::PRI_DEBUG); - - const bool usesVolatileTxs = runtime.GetAppData(0).FeatureFlags.GetEnableDataShardVolatileTransactions(); - - InitRoot(server, sender); - - CreateShardedTable(server, sender, "/Root", "table-1", 1); - CreateShardedTable(server, sender, "/Root", "table-2", 1); - auto table1shards = GetTableShards(server, sender, "/Root/table-1"); - auto table2shards = GetTableShards(server, sender, "/Root/table-2"); - - ExecSQL(server, sender, Q_("UPSERT INTO `/Root/table-1` (key, value) VALUES (1, 1);")); - ExecSQL(server, sender, Q_("UPSERT INTO `/Root/table-2` (key, value) VALUES (2, 1);")); - - TString sessionId = CreateSessionRPC(runtime); - - TString txId; - { - auto result = KqpSimpleBegin(runtime, sessionId, txId, Q_(R"( - SELECT * FROM `/Root/table-1` WHERE key = 1 - UNION ALL - SELECT * FROM `/Root/table-2` WHERE key = 2 - ORDER BY key)")); - UNIT_ASSERT_VALUES_EQUAL( - result, - "{ items { uint32_value: 1 } items { uint32_value: 1 } }, " - "{ items { uint32_value: 2 } items { uint32_value: 1 } }"); - } - - // Capture and block all readset messages - TVector> readSets; - auto captureRS = [&](TAutoPtr &event) -> auto { - if (event->GetTypeRewrite() == TEvTxProcessing::EvReadSet) { - readSets.push_back(std::move(event)); - return TTestActorRuntime::EEventAction::DROP; - } - return TTestActorRuntime::EEventAction::PROCESS; - }; - auto prevObserverFunc = runtime.SetObserverFunc(captureRS); - - // Send a commit request, it would block on readset exchange - SendRequest(runtime, MakeSimpleRequestRPC(Q_(R"( - UPSERT INTO `/Root/table-1` (key, value) VALUES (3, 2); - UPSERT INTO `/Root/table-2` (key, value) VALUES (4, 2))"), sessionId, txId, true)); - - // Wait until we captured both readsets - const size_t expectedReadSets = usesVolatileTxs ? 4 : 2; - if (readSets.size() < expectedReadSets) { - TDispatchOptions options; - options.FinalEvents.emplace_back( - [&](IEventHandle &) -> bool { - return readSets.size() >= expectedReadSets; - }); - runtime.DispatchEvents(options); - } - UNIT_ASSERT_VALUES_EQUAL(readSets.size(), expectedReadSets); - - // Reboot table-1 tablet - readSets.clear(); - RebootTablet(runtime, table1shards[0], sender); - - // Wait until we captured both readsets again - if (readSets.size() < expectedReadSets) { - TDispatchOptions options; - options.FinalEvents.emplace_back( - [&](IEventHandle &) -> bool { - return readSets.size() >= expectedReadSets; - }); - runtime.DispatchEvents(options); - } - UNIT_ASSERT_VALUES_EQUAL(readSets.size(), expectedReadSets); - - // Select keys 1 and 3, we expect this immediate tx to succeed - // Note that key 3 is not written yet, but we pretend immediate tx - // executes before that waiting transaction (no key 3 yet). - // Note: volatile transactions block reads until they are resolved, so this read is skipped - if (!usesVolatileTxs) { - auto result = KqpSimpleExec(runtime, Q_("SELECT key, value FROM `/Root/table-1` WHERE key = 1 OR key = 3;")); - UNIT_ASSERT_VALUES_EQUAL(result, "{ items { uint32_value: 1 } items { uint32_value: 1 } }"); - } - - // Upsert key 1, we expect this immediate tx to be executed successfully because it lies to the right on the global timeline - { - auto result = KqpSimpleExec(runtime, Q_("UPSERT INTO `/Root/table-1` (key, value) VALUES (1, 3);")); - UNIT_ASSERT_VALUES_EQUAL(result, ""); - } - - // Upsert key 5, this immediate tx should be executed successfully too - { - auto result = KqpSimpleExec(runtime, Q_("UPSERT INTO `/Root/table-1` (key, value) VALUES (5, 3);")); - UNIT_ASSERT_VALUES_EQUAL(result, ""); - } - - // Release readsets allowing tx to progress - runtime.SetObserverFunc(prevObserverFunc); - for (auto& ev : readSets) { - runtime.Send(ev.Release(), 0, /* viaActorSystem */ true); - } - - // Select key 3, we expect a success - { - auto result = KqpSimpleExec(runtime, Q_("SELECT key, value FROM `/Root/table-1` WHERE key = 3;")); - UNIT_ASSERT_VALUES_EQUAL(result, "{ items { uint32_value: 3 } items { uint32_value: 2 } }"); - } -} - Y_UNIT_TEST_TWIN(TestOutOfOrderRestartLocksReorderedWithoutBarrier, StreamLookup) { TPortManager pm; NKikimrConfig::TAppConfig app; From 81296f9b554aa008f59fea6d1a62547db020d32e Mon Sep 17 00:00:00 2001 From: Sergey Belyakov Date: Wed, 14 Feb 2024 20:02:30 +0300 Subject: [PATCH 022/117] Mute CostMetrics tests in 24-1 (#1948) --- .github/config/muted_ya.txt | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/.github/config/muted_ya.txt b/.github/config/muted_ya.txt index 0ab48b1f2287..d8a23a51436d 100644 --- a/.github/config/muted_ya.txt +++ b/.github/config/muted_ya.txt @@ -2,7 +2,7 @@ ydb/core/blobstorage/dsproxy/ut TBlobStorageProxySequenceTest.TestBlock42PutWith ydb/core/blobstorage/dsproxy/ut_fat TBlobStorageProxyTest.TestBatchedPutRequestDoesNotContainAHugeBlob ydb/core/blobstorage/pdisk/ut TSectorMap.* ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk ReadOnlyVDisk.TestStorageLoad -ydb/core/blobstorage/ut_blobstorage CostMetricsGetBlock4Plus2.TestGet4Plus2BlockRequests10000Inflight1BlobSize1000 +ydb/core/blobstorage/ut_blobstorage CostMetrics* ydb/core/blobstorage/ut_blobstorage Defragmentation.DoesItWork ydb/core/blobstorage/ut_blobstorage SpaceCheckForDiskReassign.* ydb/core/blobstorage/ut_blobstorage ScrubFast.SingleBlob From c076edf419f5ad71f1e196c06d4c5170d0a175e8 Mon Sep 17 00:00:00 2001 From: Mikhail Surin Date: Thu, 15 Feb 2024 19:08:27 +0300 Subject: [PATCH 023/117] Merge to 24.1 (#1772) Co-authored-by: Iuliia Sidorina --- ydb/core/kqp/opt/logical/kqp_opt_log.cpp | 4 +- .../kqp/opt/logical/kqp_opt_log_effects.cpp | 162 +++++++++++++++--- .../kqp/opt/logical/kqp_opt_log_extract.cpp | 11 ++ .../kqp/opt/logical/kqp_opt_log_ranges.cpp | 56 +++++- .../logical/kqp_opt_log_ranges_predext.cpp | 4 - ydb/core/kqp/opt/logical/kqp_opt_log_rules.h | 2 +- ydb/core/kqp/runtime/kqp_read_actor.cpp | 4 +- .../opt/kqp_extract_predicate_unpack_ut.cpp | 76 -------- ydb/core/kqp/ut/opt/kqp_ne_ut.cpp | 28 ++- ydb/core/kqp/ut/pg/kqp_pg_ut.cpp | 3 + ydb/core/kqp/ut/query/kqp_explain_ut.cpp | 19 +- ydb/core/kqp/ut/tx/kqp_mvcc_ut.cpp | 21 +-- ydb/core/kqp/ut/yql/kqp_scripting_ut.cpp | 3 +- ydb/core/tx/datashard/datashard_ut_trace.cpp | 33 ++-- .../pk_predicate_pk_predicate_bool.sql.plan | 19 +- ..._predicate_pk_predicate_dependent.sql.plan | 3 +- ...dicate_pk_predicate_equi_multi_rp.sql.plan | 8 +- ...cate_pk_predicate_equi_multi_rp_1.sql.plan | 10 +- .../pk_predicate_pk_predicate_in.sql.plan | 10 +- .../pk_predicate_pk_predicate_in_rp.sql.plan | 7 +- 20 files changed, 301 insertions(+), 182 deletions(-) diff --git a/ydb/core/kqp/opt/logical/kqp_opt_log.cpp b/ydb/core/kqp/opt/logical/kqp_opt_log.cpp index 5119d7769d20..7ec98aa7f569 100644 --- a/ydb/core/kqp/opt/logical/kqp_opt_log.cpp +++ b/ydb/core/kqp/opt/logical/kqp_opt_log.cpp @@ -210,8 +210,8 @@ class TKqpLogicalOptTransformer : public TOptimizeTransformerBase { return output; } - TMaybeNode DeleteOverLookup(TExprBase node, TExprContext& ctx) { - TExprBase output = KqpDeleteOverLookup(node, ctx, KqpCtx); + TMaybeNode DeleteOverLookup(TExprBase node, TExprContext& ctx, const TGetParents& getParents) { + TExprBase output = KqpDeleteOverLookup(node, ctx, KqpCtx, *getParents()); DumpAppliedRule("DeleteOverLookup", node.Ptr(), output.Ptr(), ctx); return output; } diff --git a/ydb/core/kqp/opt/logical/kqp_opt_log_effects.cpp b/ydb/core/kqp/opt/logical/kqp_opt_log_effects.cpp index 7dcf855ce037..97eb40f86824 100644 --- a/ydb/core/kqp/opt/logical/kqp_opt_log_effects.cpp +++ b/ydb/core/kqp/opt/logical/kqp_opt_log_effects.cpp @@ -2,57 +2,175 @@ #include #include +#include + +namespace { + +bool CanPushFlatMap(const NYql::NNodes::TCoFlatMapBase& flatMap, const NYql::TKikimrTableDescription& tableDesc, const NYql::TParentsMap& parentsMap, TVector & extraColumns) { + auto flatMapLambda = flatMap.Lambda(); + if (!NYql::IsFilterFlatMap(flatMapLambda)) { + return false; + } + + const auto & flatMapLambdaArgument = flatMapLambda.Args().Arg(0).Ref(); + auto flatMapLambdaConditional = flatMapLambda.Body().Cast(); + + TSet lambdaSubset; + auto isSubSet = HaveFieldsSubset(flatMapLambdaConditional.Predicate().Ptr(), flatMapLambdaArgument, lambdaSubset, parentsMap, true); + auto argType = NYql::RemoveOptionalType(flatMapLambdaArgument.GetTypeAnn()); + if (argType->GetKind() != NYql::ETypeAnnotationKind::Struct) { + return false; + } + // helper doesn't accept if all columns are used + if (!isSubSet && lambdaSubset.size() != argType->Cast()->GetSize()) { + return false; + } + + for (auto & lambdaColumn : lambdaSubset) { + auto columnIndex = tableDesc.GetKeyColumnIndex(lambdaColumn); + if (!columnIndex) { + return false; + } + } + + extraColumns.insert(extraColumns.end(), lambdaSubset.begin(), lambdaSubset.end()); + return true; +} + +} namespace NKikimr::NKqp::NOpt { using namespace NYql; using namespace NYql::NNodes; -TExprBase KqpDeleteOverLookup(const TExprBase& node, TExprContext& ctx, const TKqpOptimizeContext &kqpCtx) { +TExprBase KqpDeleteOverLookup(const TExprBase& node, TExprContext& ctx, const TKqpOptimizeContext &kqpCtx, const NYql::TParentsMap& parentsMap) { if (!node.Maybe()) { return node; } auto deleteRows = node.Cast(); + TMaybeNode filter; + TMaybeNode lookup; + TMaybeNode read; TMaybeNode skipNulMembers; + TMaybeNode readranges; if (deleteRows.Input().Maybe()) { lookup = deleteRows.Input().Cast(); } else if (deleteRows.Input().Maybe().Input().Maybe()) { skipNulMembers = deleteRows.Input().Cast(); lookup = skipNulMembers.Input().Cast(); + } else if (deleteRows.Input().Maybe()) { + read = deleteRows.Input().Cast(); } else { - return node; - } - - YQL_ENSURE(lookup); - if (deleteRows.Table().Raw() != lookup.Cast().Table().Raw()) { - return node; + TMaybeNode input = deleteRows.Input(); + if (input.Maybe()) { + filter = deleteRows.Input().Cast(); + input = filter.Input(); + } + readranges = input.Maybe(); + if (!readranges) { + return node; + } } - auto lookupKeysType = lookup.Cast().LookupKeys().Ref().GetTypeAnn(); - auto lookupKeyType = lookupKeysType->Cast()->GetItemType()->Cast(); - YQL_ENSURE(lookupKeyType); - - // Only consider complete PK lookups + TMaybeNode deleteInput; const auto& tableDesc = GetTableData(*kqpCtx.Tables, kqpCtx.Cluster, deleteRows.Table().Path()); - if (lookupKeyType->GetSize() != tableDesc.Metadata->KeyColumnNames.size()) { - return node; - } - - TExprBase deleteInput = lookup.Cast().LookupKeys(); - if (skipNulMembers) { - deleteInput = Build(ctx, skipNulMembers.Cast().Pos()) - .Input(deleteInput) - .Members(skipNulMembers.Cast().Members()) + if (lookup) { + if (deleteRows.Table().Raw() != lookup.Cast().Table().Raw()) { + return node; + } + + auto lookupKeysType = lookup.Cast().LookupKeys().Ref().GetTypeAnn(); + auto lookupKeyType = lookupKeysType->Cast()->GetItemType()->Cast(); + YQL_ENSURE(lookupKeyType); + + // Only consider complete PK lookups + if (lookupKeyType->GetSize() != tableDesc.Metadata->KeyColumnNames.size()) { + return node; + } + + deleteInput = lookup.Cast().LookupKeys(); + if (skipNulMembers) { + deleteInput = Build(ctx, skipNulMembers.Cast().Pos()) + .Input(deleteInput.Cast()) + .Members(skipNulMembers.Cast().Members()) + .Done(); + } + } else if (read) { + if (deleteRows.Table().Raw() != read.Cast().Table().Raw()) { + return node; + } + + const auto& rangeFrom = read.Cast().Range().From(); + const auto& rangeTo = read.Cast().Range().To(); + + if (!rangeFrom.Maybe() || !rangeTo.Maybe()) { + return node; + } + + if (rangeFrom.Raw() != rangeTo.Raw()) { + return node; + } + + if (rangeFrom.ArgCount() != tableDesc.Metadata->KeyColumnNames.size()) { + return node; + } + + TVector structMembers; + for (ui32 i = 0; i < rangeFrom.ArgCount(); ++i) { + TCoAtom columnNameAtom(ctx.NewAtom(node.Pos(), tableDesc.Metadata->KeyColumnNames[i])); + + auto member = Build(ctx, node.Pos()) + .Name(columnNameAtom) + .Value(rangeFrom.Arg(i)) + .Done(); + + structMembers.push_back(member); + } + + deleteInput = Build(ctx, node.Pos()) + .Add() + .Add(structMembers) + .Build() .Done(); + } else if (readranges) { + if (deleteRows.Table().Raw() != readranges.Cast().Table().Raw()) { + return node; + } + + if (!readranges.Cast().PrefixPointsExpr()) { + return node; + } + + const auto& tableDesc = kqpCtx.Tables->ExistingTable(kqpCtx.Cluster, readranges.Cast().Table().Path().Value()); + auto hint = TKqpReadTableExplainPrompt::Parse(readranges.Cast().ExplainPrompt()); + if (hint.PointPrefixLen != tableDesc.Metadata->KeyColumnNames.size()) { + return node; + } + + if (filter) { + TVector extraColumns; + if (!CanPushFlatMap(filter.Cast(), tableDesc, parentsMap, extraColumns)) { + return node; + } + deleteInput = Build(ctx, node.Pos()) + .Lambda(filter.Lambda().Cast()) + .Input(readranges.PrefixPointsExpr().Cast()) + .Done(); + } else { + deleteInput = readranges.PrefixPointsExpr(); + } } + YQL_ENSURE(deleteInput); + return Build(ctx, deleteRows.Pos()) .Table(deleteRows.Table()) - .Input(deleteInput) + .Input(deleteInput.Cast()) .Done(); } diff --git a/ydb/core/kqp/opt/logical/kqp_opt_log_extract.cpp b/ydb/core/kqp/opt/logical/kqp_opt_log_extract.cpp index 6e1d01c5568f..72fe19fd8a11 100644 --- a/ydb/core/kqp/opt/logical/kqp_opt_log_extract.cpp +++ b/ydb/core/kqp/opt/logical/kqp_opt_log_extract.cpp @@ -124,6 +124,17 @@ TExprBase KqpApplyExtractMembersToReadTableRanges(TExprBase node, TExprContext& .Done(); } + if (auto readRange = node.Maybe()) { + return Build(ctx, read.Pos()) + .Table(read.Table()) + .Ranges(read.Ranges()) + .Columns(usedColumns.Cast()) + .Settings(read.Settings()) + .ExplainPrompt(read.ExplainPrompt()) + .PrefixPointsExpr(readRange.PrefixPointsExpr()) + .Done(); + } + return Build(ctx, read.Pos()) .CallableName(read.CallableName()) .Table(read.Table()) diff --git a/ydb/core/kqp/opt/logical/kqp_opt_log_ranges.cpp b/ydb/core/kqp/opt/logical/kqp_opt_log_ranges.cpp index 7d28a665766c..a5eba5e404a5 100644 --- a/ydb/core/kqp/opt/logical/kqp_opt_log_ranges.cpp +++ b/ydb/core/kqp/opt/logical/kqp_opt_log_ranges.cpp @@ -353,6 +353,59 @@ TMaybeNode KqpRewriteLiteralLookup(const TExprBase& node, TExprContex lookupKeys = skipNullMembers.Input(); } + TKqpReadTableSettings settings; + if (skipNullMembers) { + auto skipNullColumns = skipNullMembers.Cast().Members(); + + if (skipNullColumns) { + for (const auto &column : skipNullColumns.Cast()) { + settings.AddSkipNullKey(TString(column.Value())); + } + } + } + + const auto& table = kqpCtx.Tables->ExistingTable(kqpCtx.Cluster, lookup.Table().Path().Value()); + if (auto lookupKeysFlatMap = lookupKeys.Maybe()) { + auto flatMapRangeInput = lookupKeysFlatMap.Cast().Input().Maybe(); + + // This rule should depend on feature flag for safety + if (!flatMapRangeInput || !kqpCtx.Config->EnableKqpDataQueryStreamLookup) { + return {}; + } + + auto lookupKeysType = lookupKeys.Ref().GetTypeAnn(); + YQL_ENSURE(lookupKeysType); + YQL_ENSURE(lookupKeysType->GetKind() == ETypeAnnotationKind::List); + auto itemType = lookupKeysType->Cast()->GetItemType(); + YQL_ENSURE(itemType->GetKind() == ETypeAnnotationKind::Struct); + auto structType = itemType->Cast(); + + TVector usedColumns; + usedColumns.reserve(structType->GetSize()); + for (const auto& keyColumnName : table.Metadata->KeyColumnNames) { + if (!structType->FindItem(keyColumnName)) { + break; + } + + usedColumns.emplace_back(keyColumnName); + } + + YQL_ENSURE(usedColumns.size() == structType->GetSize()); + + TKqpReadTableExplainPrompt prompt; + prompt.SetUsedKeyColumns(std::move(usedColumns)); + prompt.SetPointPrefixLen(structType->GetSize()); + + + return Build(ctx, lookup.Pos()) + .Table(lookup.Table()) + .Ranges(flatMapRangeInput.Cast()) + .Columns(lookup.Columns()) + .Settings(settings.BuildNode(ctx, lookup.Pos())) + .ExplainPrompt(prompt.BuildNode(ctx, lookup.Pos())) + .Done(); + } + auto maybeAsList = lookupKeys.Maybe(); if (!maybeAsList) { return {}; @@ -369,7 +422,6 @@ TMaybeNode KqpRewriteLiteralLookup(const TExprBase& node, TExprContex } // full pk expected - const auto& table = kqpCtx.Tables->ExistingTable(kqpCtx.Cluster, lookup.Table().Path().Value()); if (table.Metadata->KeyColumnNames.size() != maybeStruct.Cast().ArgCount()) { return {}; } @@ -380,7 +432,6 @@ TMaybeNode KqpRewriteLiteralLookup(const TExprBase& node, TExprContex keyColumnsStruct.insert({TString(tuple.Name().Value()), tuple.Value().Cast()}); } - TKqpReadTableSettings settings; TVector keyValues; keyValues.reserve(maybeStruct.Cast().ArgCount()); for (const auto& name : table.Metadata->KeyColumnNames) { @@ -396,7 +447,6 @@ TMaybeNode KqpRewriteLiteralLookup(const TExprBase& node, TExprContex for (const auto &column : skipNullColumns.Cast()) { settings.AddSkipNullKey(TString(column.Value())); } - } } diff --git a/ydb/core/kqp/opt/logical/kqp_opt_log_ranges_predext.cpp b/ydb/core/kqp/opt/logical/kqp_opt_log_ranges_predext.cpp index 5a8ff001bcd5..a4ed3c3c62bf 100644 --- a/ydb/core/kqp/opt/logical/kqp_opt_log_ranges_predext.cpp +++ b/ydb/core/kqp/opt/logical/kqp_opt_log_ranges_predext.cpp @@ -466,10 +466,6 @@ TExprBase KqpPushExtractedPredicateToReadTable(TExprBase node, TExprContext& ctx .Done(); } } - } else if (buildResult.PointPrefixLen == tableDesc.Metadata->KeyColumnNames.size()) { - YQL_ENSURE(prefixPointsExpr); - residualLambda = pointsExtractionResult.PrunedLambda; - buildLookup(prefixPointsExpr, input); } } diff --git a/ydb/core/kqp/opt/logical/kqp_opt_log_rules.h b/ydb/core/kqp/opt/logical/kqp_opt_log_rules.h index 97b61b836c0b..9f4852eff0c9 100644 --- a/ydb/core/kqp/opt/logical/kqp_opt_log_rules.h +++ b/ydb/core/kqp/opt/logical/kqp_opt_log_rules.h @@ -53,7 +53,7 @@ NYql::NNodes::TExprBase KqpRewriteTakeOverIndexRead(const NYql::NNodes::TExprBas const TKqpOptimizeContext& kqpCtx, const NYql::TParentsMap& parentsMap); NYql::NNodes::TExprBase KqpDeleteOverLookup(const NYql::NNodes::TExprBase& node, NYql::TExprContext& ctx, - const TKqpOptimizeContext &kqpCtx); + const TKqpOptimizeContext &kqpCtx, const NYql::TParentsMap& parentsMap); NYql::NNodes::TExprBase KqpExcessUpsertInputColumns(const NYql::NNodes::TExprBase& node, NYql::TExprContext& ctx); diff --git a/ydb/core/kqp/runtime/kqp_read_actor.cpp b/ydb/core/kqp/runtime/kqp_read_actor.cpp index 9d1815092fab..22f1bf9bcfc9 100644 --- a/ydb/core/kqp/runtime/kqp_read_actor.cpp +++ b/ydb/core/kqp/runtime/kqp_read_actor.cpp @@ -728,8 +728,8 @@ class TKqpReadActor : public TActorBootstrapped, public NYql::NDq if (intersection == 0) { newShard->AddPoint(std::move(points[pointIndex])); CA_LOG_D("Add point to new shardId: " << partition.ShardId); - } - if (intersection < 0) { + } else { + YQL_ENSURE(intersection > 0, "Missed intersection of point and partition ranges."); break; } pointIndex += 1; diff --git a/ydb/core/kqp/ut/opt/kqp_extract_predicate_unpack_ut.cpp b/ydb/core/kqp/ut/opt/kqp_extract_predicate_unpack_ut.cpp index 6977d7981c5c..8c2c10f23a39 100644 --- a/ydb/core/kqp/ut/opt/kqp_extract_predicate_unpack_ut.cpp +++ b/ydb/core/kqp/ut/opt/kqp_extract_predicate_unpack_ut.cpp @@ -359,82 +359,6 @@ Y_UNIT_TEST(ComplexRange) { 2); } -Y_UNIT_TEST(SqlIn) { - Test( - R"( - SELECT * FROM `/Root/SimpleKey` - WHERE Key IN AsList(100, 102, (100 + 3)) - ORDER BY Key; - )", - R"([ - [[100];["Value20"]];[[102];["Value22"]];[[103];["Value23"]] - ])"); -} - -Y_UNIT_TEST(BasicLookup) { - Test( - R"( - SELECT * FROM `/Root/SimpleKey` - WHERE Key = 100 or Key = 102 or Key = 103 or Key = null; - )", - R"([ - [[100];["Value20"]];[[102];["Value22"]];[[103];["Value23"]] - ])"); -} - -Y_UNIT_TEST(ComplexLookup) { - Test( - R"( - SELECT Key, Value FROM `/Root/SimpleKey` - WHERE Key = 100 or Key = 102 or Key = (100 + 3); - )", - R"([ - [[100];["Value20"]];[[102];["Value22"]];[[103];["Value23"]] - ])"); -} - -Y_UNIT_TEST(SqlInComplexKey) { - Test( - R"( - SELECT Key, Fk, Value FROM `/Root/ComplexKey` - WHERE (Key, Fk) IN AsList( - (1, 101), - (2, 102), - (2, 102 + 1), - ) - ORDER BY Key, Fk; - )", - R"([ - [[1];[101];["Value1"]];[[2];[102];["Value1"]];[[2];[103];["Value3"]] - ])"); -} - -Y_UNIT_TEST(BasicLookupComplexKey) { - Test( - R"( - SELECT Key, Fk, Value FROM `/Root/ComplexKey` - WHERE (Key = 1 and Fk = 101) OR - (2 = Key and 102 = Fk) OR - (2 = Key and 103 = Fk); - )", - R"([ - [[1];[101];["Value1"]];[[2];[102];["Value1"]];[[2];[103];["Value3"]] - ])"); -} - -Y_UNIT_TEST(ComplexLookupComplexKey) { - Test( - R"( - SELECT Key, Fk, Value FROM `/Root/ComplexKey` - WHERE (Key = 1 and Fk = 101) OR - (2 = Key and 102 = Fk) OR - (2 = Key and 102 + 1 = Fk); - )", - R"([ - [[1];[101];["Value1"]];[[2];[102];["Value1"]];[[2];[103];["Value3"]] - ])"); -} - Y_UNIT_TEST(PointJoin) { Test( R"( diff --git a/ydb/core/kqp/ut/opt/kqp_ne_ut.cpp b/ydb/core/kqp/ut/opt/kqp_ne_ut.cpp index d79e0f3440a1..8744f969f7a8 100644 --- a/ydb/core/kqp/ut/opt/kqp_ne_ut.cpp +++ b/ydb/core/kqp/ut/opt/kqp_ne_ut.cpp @@ -203,25 +203,23 @@ Y_UNIT_TEST_SUITE(KqpNewEngine) { SELECT * FROM `/Root/Test` WHERE Group = $group AND Name = $name; )"; - auto explainResult = session.ExplainDataQuery(query).GetValueSync(); - UNIT_ASSERT_VALUES_EQUAL_C(explainResult.GetStatus(), EStatus::SUCCESS, explainResult.GetIssues().ToString()); - - if (settings.AppConfig.GetTableServiceConfig().GetEnableKqpDataQueryStreamLookup()) { - UNIT_ASSERT_C(explainResult.GetAst().Contains("KqpCnStreamLookup"), explainResult.GetAst()); - } else { - UNIT_ASSERT_C(explainResult.GetAst().Contains("KqpLookupTable"), explainResult.GetAst()); - } - auto params = kikimr.GetTableClient().GetParamsBuilder() .AddParam("$group").OptionalUint32(1).Build() .AddParam("$name").OptionalString("Paul").Build() .Build(); + NYdb::NTable::TExecDataQuerySettings execSettings; + execSettings.CollectQueryStats(ECollectQueryStatsMode::Profile); + auto result = session.ExecuteDataQuery(query, - TTxControl::BeginTx(TTxSettings::SerializableRW()).CommitTx(), params).ExtractValueSync(); + TTxControl::BeginTx(TTxSettings::SerializableRW()).CommitTx(), params, execSettings).ExtractValueSync(); UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, result.GetIssues().ToString()); CompareYson(R"([[[300u];["None"];[1u];["Paul"]]])", FormatResultSetYson(result.GetResultSet(0))); + AssertTableStats(result, "/Root/Test", { + .ExpectedReads = 1, + }); + params = kikimr.GetTableClient().GetParamsBuilder() .AddParam("$group").OptionalUint32(1).Build() .Build(); @@ -3520,14 +3518,14 @@ Y_UNIT_TEST_SUITE(KqpNewEngine) { NJson::TJsonValue plan; NJson::ReadJsonTree(result.GetQueryPlan(), &plan, true); - auto streamLookup = FindPlanNodeByKv(plan, "Node Type", "TableLookup"); + auto streamLookup = FindPlanNodeByKv(plan, "Node Type", "TableRangeScan"); UNIT_ASSERT(streamLookup.IsDefined()); auto stats = NYdb::TProtoAccessor::GetProto(*result.GetStats()); - UNIT_ASSERT_VALUES_EQUAL(stats.query_phases().size(), 1); - UNIT_ASSERT_VALUES_EQUAL(stats.query_phases(0).table_access().size(), 1); - UNIT_ASSERT_VALUES_EQUAL(stats.query_phases(0).table_access(0).name(), "/Root/KeyValue"); - UNIT_ASSERT_VALUES_EQUAL(stats.query_phases(0).table_access(0).reads().rows(), 2); + UNIT_ASSERT_VALUES_EQUAL(stats.query_phases().size(), 2); + UNIT_ASSERT_VALUES_EQUAL(stats.query_phases(1).table_access().size(), 1); + UNIT_ASSERT_VALUES_EQUAL(stats.query_phases(1).table_access(0).name(), "/Root/KeyValue"); + UNIT_ASSERT_VALUES_EQUAL(stats.query_phases(1).table_access(0).reads().rows(), 2); } } diff --git a/ydb/core/kqp/ut/pg/kqp_pg_ut.cpp b/ydb/core/kqp/ut/pg/kqp_pg_ut.cpp index 05ca03d898a0..86e34adf31d2 100644 --- a/ydb/core/kqp/ut/pg/kqp_pg_ut.cpp +++ b/ydb/core/kqp/ut/pg/kqp_pg_ut.cpp @@ -3900,6 +3900,9 @@ Y_UNIT_TEST_SUITE(KqpPg) { auto fullScan = FindPlanNodeByKv(plan, "Node Type", "Filter-TableFullScan"); UNIT_ASSERT_C(!fullScan.IsDefined(), "got fullscan, expected lookup"); auto lookup = FindPlanNodeByKv(plan, "Node Type", "TableLookup"); + if (!lookup.IsDefined()) { + lookup = FindPlanNodeByKv(plan, "Node Type", "TableRangeScan"); + } UNIT_ASSERT_C(lookup.IsDefined(), "no Table Lookup in plan"); } { diff --git a/ydb/core/kqp/ut/query/kqp_explain_ut.cpp b/ydb/core/kqp/ut/query/kqp_explain_ut.cpp index e84fa7c3cc9c..cd4bd820d53f 100644 --- a/ydb/core/kqp/ut/query/kqp_explain_ut.cpp +++ b/ydb/core/kqp/ut/query/kqp_explain_ut.cpp @@ -493,18 +493,23 @@ Y_UNIT_TEST_SUITE(KqpExplain) { NJson::ReadJsonTree(result.GetPlan(), &plan, true); UNIT_ASSERT(ValidatePlanNodeIds(plan)); + Cerr << "Plan " << result.GetPlan() << Endl; + auto node = FindPlanNodeByKv(plan, "Name", "TableRangeScan"); UNIT_ASSERT_EQUAL(node.GetMapSafe().at("Table").GetStringSafe(), "KeyValue"); node = FindPlanNodeByKv(plan, "Name", "TableFullScan"); UNIT_ASSERT_EQUAL(node.GetMapSafe().at("Table").GetStringSafe(), "KeyValue"); + if (settings.AppConfig.GetTableServiceConfig().GetEnableKqpDataQueryStreamLookup()) { node = FindPlanNodeByKv(plan, "Node Type", "TableLookup"); } else { node = FindPlanNodeByKv(plan, "Name", "TablePointLookup"); } - UNIT_ASSERT_EQUAL(node.GetMapSafe().at("Table").GetStringSafe(), "KeyValue"); + if (node.IsDefined()) { + UNIT_ASSERT_EQUAL(node.GetMapSafe().at("Table").GetStringSafe(), "KeyValue"); + } } Y_UNIT_TEST(FewEffects) { @@ -536,16 +541,7 @@ Y_UNIT_TEST_SUITE(KqpExplain) { UNIT_ASSERT_VALUES_EQUAL(fullScansCount, 1); auto rangeScansCount = CountPlanNodesByKv(plan, "Node Type", "TableRangeScan"); - UNIT_ASSERT_VALUES_EQUAL(rangeScansCount, 1); - - ui32 lookupsCount = 0; - if (settings.AppConfig.GetTableServiceConfig().GetEnableKqpDataQueryStreamLookup()) { - lookupsCount = CountPlanNodesByKv(plan, "Node Type", "TableLookup"); - } else { - lookupsCount = CountPlanNodesByKv(plan, "Node Type", "TablePointLookup-ConstantExpr"); - } - - UNIT_ASSERT_VALUES_EQUAL(lookupsCount, 1); + UNIT_ASSERT_VALUES_EQUAL(rangeScansCount, 2); /* check tables section */ const auto& tableInfo = plan.GetMapSafe().at("tables").GetArraySafe()[0].GetMapSafe(); @@ -565,7 +561,6 @@ Y_UNIT_TEST_SUITE(KqpExplain) { UNIT_ASSERT_VALUES_EQUAL(counter["MultiErase"], deletesCount); UNIT_ASSERT_VALUES_EQUAL(counter["FullScan"], fullScansCount); UNIT_ASSERT_VALUES_EQUAL(counter["Scan"], rangeScansCount); - UNIT_ASSERT_VALUES_EQUAL(counter["Lookup"], lookupsCount); } Y_UNIT_TEST(ExplainDataQueryWithParams) { diff --git a/ydb/core/kqp/ut/tx/kqp_mvcc_ut.cpp b/ydb/core/kqp/ut/tx/kqp_mvcc_ut.cpp index bf56e63e7985..a39c839e6ee2 100644 --- a/ydb/core/kqp/ut/tx/kqp_mvcc_ut.cpp +++ b/ydb/core/kqp/ut/tx/kqp_mvcc_ut.cpp @@ -50,21 +50,12 @@ Y_UNIT_TEST_SUITE(KqpSnapshotRead) { if (result.GetStatus() == EStatus::SUCCESS) continue; - if (settings.AppConfig.GetTableServiceConfig().GetEnableKqpDataQueryStreamLookup()) { - UNIT_ASSERT_C(HasIssue(result.GetIssues(), NYql::TIssuesIds::DEFAULT_ERROR, - [](const NYql::TIssue& issue){ - return issue.GetMessage().Contains("has no snapshot at"); - }), result.GetIssues().ToString()); - - UNIT_ASSERT_VALUES_EQUAL(result.GetStatus(), EStatus::ABORTED); - } else { - UNIT_ASSERT_C(HasIssue(result.GetIssues(), NYql::TIssuesIds::DEFAULT_ERROR, - [](const NYql::TIssue& issue){ - return issue.GetMessage().Contains("stale snapshot"); - }), result.GetIssues().ToString()); - - UNIT_ASSERT_VALUES_EQUAL(result.GetStatus(), EStatus::PRECONDITION_FAILED); - } + UNIT_ASSERT_C(HasIssue(result.GetIssues(), NYql::TIssuesIds::DEFAULT_ERROR, + [](const NYql::TIssue& issue){ + return issue.GetMessage().Contains("has no snapshot at"); + }), result.GetIssues().ToString()); + + UNIT_ASSERT_VALUES_EQUAL(result.GetStatus(), EStatus::ABORTED); caught = true; break; diff --git a/ydb/core/kqp/ut/yql/kqp_scripting_ut.cpp b/ydb/core/kqp/ut/yql/kqp_scripting_ut.cpp index 077bab42893b..6525749d7ce2 100644 --- a/ydb/core/kqp/ut/yql/kqp_scripting_ut.cpp +++ b/ydb/core/kqp/ut/yql/kqp_scripting_ut.cpp @@ -942,7 +942,8 @@ Y_UNIT_TEST_SUITE(KqpScripting) { auto stats = NYdb::TProtoAccessor::GetProto(*result.GetStats()); - UNIT_ASSERT_VALUES_EQUAL(stats.query_phases().size(), 2); + UNIT_ASSERT_VALUES_EQUAL(stats.query_phases().size(), 3); + UNIT_ASSERT(stats.query_phases(1).table_access().empty()); for (const auto& phase : stats.query_phases()) { if (phase.table_access().size()) { if (phase.table_access(0).name() == "/Root/EightShard") { diff --git a/ydb/core/tx/datashard/datashard_ut_trace.cpp b/ydb/core/tx/datashard/datashard_ut_trace.cpp index 16719754f7a4..b7be979310cc 100644 --- a/ydb/core/tx/datashard/datashard_ut_trace.cpp +++ b/ydb/core/tx/datashard/datashard_ut_trace.cpp @@ -292,27 +292,24 @@ Y_UNIT_TEST_SUITE(TDataShardTrace) { TFakeWilsonUploader::Trace &trace = uploader->Traces.begin()->second; std::string canon; - if (server->GetSettings().AppConfig->GetTableServiceConfig().GetEnableKqpDataQueryStreamLookup()) { - auto lookupActorSpan = trace.Root.BFSFindOne("LookupActor"); - UNIT_ASSERT(lookupActorSpan); + if (server->GetSettings().AppConfig->GetTableServiceConfig().GetEnableKqpDataQueryStreamLookup() || server->GetSettings().AppConfig->GetTableServiceConfig().GetPredicateExtract20()) { + auto readActorSpan = trace.Root.BFSFindOne("ReadActor"); + UNIT_ASSERT(readActorSpan); - auto dsReads = lookupActorSpan->get().FindAll("Datashard.Read"); // Lookup actor sends EvRead to each shard. + auto dsReads = readActorSpan->get().FindAll("Datashard.Read"); // Read actor sends EvRead to each shard. UNIT_ASSERT_EQUAL(dsReads.size(), 2); - canon = "(Session.query.QUERY_ACTION_EXECUTE -> [(CompileService -> [(CompileActor)]) " - ", (DataExecuter -> [(WaitForTableResolve) , (WaitForSnapshot) , (ComputeActor) " - ", (ComputeActor -> [(LookupActor -> [(WaitForShardsResolve) , (Datashard.Read " - "-> [(Tablet.Transaction -> [(Tablet.Transaction.Execute -> [(Datashard.Unit) " - ", (Datashard.Unit) , (Datashard.Unit)]) , (Tablet.Transaction.Wait) , (Tablet.Transaction.Enqueued) " - ", (Tablet.Transaction.Execute -> [(Datashard.Unit)]) , (Tablet.Transaction.Wait) , (Tablet.Transaction.Enqueued) " - ", (Tablet.Transaction.Execute -> [(Datashard.Unit) , (Datashard.Unit)]) , (Tablet.WriteLog " - "-> [(Tablet.WriteLog.LogEntry)])])]) , (Datashard.Read " - "-> [(Tablet.Transaction -> [(Tablet.Transaction.Execute -> [(Datashard.Unit) , (Datashard.Unit) " - ", (Datashard.Unit)]) , (Tablet.Transaction.Wait) , (Tablet.Transaction.Enqueued) " - ", (Tablet.Transaction.Execute -> [(Datashard.Unit)]) , (Tablet.Transaction.Wait) " - ", (Tablet.Transaction.Enqueued) , (Tablet.Transaction.Execute -> [(Datashard.Unit) " - ", (Datashard.Unit)]) , (Tablet.WriteLog -> [(Tablet.WriteLog.LogEntry)])])" - "])])]) , (ComputeActor) , (RunTasks)])])"; + canon = "(Session.query.QUERY_ACTION_EXECUTE -> [(CompileService -> [(CompileActor)]) , (LiteralExecuter) " + ", (DataExecuter -> [(WaitForTableResolve) , (WaitForShardsResolve) , (WaitForSnapshot) , (ComputeActor) " + ", (RunTasks) , (KqpNode.SendTasks) , (ComputeActor -> [(ReadActor -> [(WaitForShardsResolve) , (Datashard.Read " + "-> [(Tablet.Transaction -> [(Tablet.Transaction.Execute -> [(Datashard.Unit) , (Datashard.Unit) , (Datashard.Unit)]) " + ", (Tablet.Transaction.Wait) , (Tablet.Transaction.Enqueued) , (Tablet.Transaction.Execute -> [(Datashard.Unit)]) " + ", (Tablet.Transaction.Wait) , (Tablet.Transaction.Enqueued) , (Tablet.Transaction.Execute -> [(Datashard.Unit) " + ", (Datashard.Unit)]) , (Tablet.WriteLog -> [(Tablet.WriteLog.LogEntry)])])]) , (Datashard.Read -> [(Tablet.Transaction " + "-> [(Tablet.Transaction.Execute -> [(Datashard.Unit) , (Datashard.Unit) , (Datashard.Unit)]) , (Tablet.Transaction.Wait) " + ", (Tablet.Transaction.Enqueued) , (Tablet.Transaction.Execute -> [(Datashard.Unit)]) , (Tablet.Transaction.Wait) " + ", (Tablet.Transaction.Enqueued) , (Tablet.Transaction.Execute -> [(Datashard.Unit) , (Datashard.Unit)]) , (Tablet.WriteLog " + "-> [(Tablet.WriteLog.LogEntry)])])])])])])])"; } else { auto deSpan = trace.Root.BFSFindOne("DataExecuter"); UNIT_ASSERT(deSpan); diff --git a/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_bool.sql-plan_/pk_predicate_pk_predicate_bool.sql.plan b/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_bool.sql-plan_/pk_predicate_pk_predicate_bool.sql.plan index 2e90591dc305..0e2fc1666096 100644 --- a/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_bool.sql-plan_/pk_predicate_pk_predicate_bool.sql.plan +++ b/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_bool.sql-plan_/pk_predicate_pk_predicate_bool.sql.plan @@ -7,6 +7,19 @@ { "name": "/local/base_pk_predicate_pk_predicate_bool_sql_plan/Input4", "reads": [ + { + "columns": [ + "Value" + ], + "limit": "1001", + "scan_by": [ + "Key1 [false, false]", + "Key2 [true, true]", + "Key1 [true, true]", + "Key2 [false, false]" + ], + "type": "Scan" + }, { "columns": [ "Value" @@ -32,12 +45,6 @@ "Key2 (null, true)" ], "type": "Scan" - }, - { - "columns": [ - "Value" - ], - "type": "Lookup" } ] } diff --git a/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_dependent.sql-plan_/pk_predicate_pk_predicate_dependent.sql.plan b/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_dependent.sql-plan_/pk_predicate_pk_predicate_dependent.sql.plan index 20d68d9abb57..c917ac54fb0b 100644 --- a/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_dependent.sql-plan_/pk_predicate_pk_predicate_dependent.sql.plan +++ b/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_dependent.sql-plan_/pk_predicate_pk_predicate_dependent.sql.plan @@ -14,7 +14,8 @@ "Group", "Name" ], - "type": "Lookup" + "limit": "1001", + "type": "Scan" } ] }, diff --git a/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_equi_multi_rp.sql-plan_/pk_predicate_pk_predicate_equi_multi_rp.sql.plan b/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_equi_multi_rp.sql-plan_/pk_predicate_pk_predicate_equi_multi_rp.sql.plan index 8630c3197bd2..ae37c577fefd 100644 --- a/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_equi_multi_rp.sql-plan_/pk_predicate_pk_predicate_equi_multi_rp.sql.plan +++ b/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_equi_multi_rp.sql-plan_/pk_predicate_pk_predicate_equi_multi_rp.sql.plan @@ -14,7 +14,13 @@ "Group", "Name" ], - "type": "Lookup" + "scan_by": [ + "Group [1, 1]", + "Name [Name1, Name1]", + "Group [4, 4]", + "Name [Name4, Name4]" + ], + "type": "Scan" } ] } diff --git a/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_equi_multi_rp_1.sql-plan_/pk_predicate_pk_predicate_equi_multi_rp_1.sql.plan b/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_equi_multi_rp_1.sql-plan_/pk_predicate_pk_predicate_equi_multi_rp_1.sql.plan index 99d5ddfc731a..abe86d3d8ec2 100644 --- a/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_equi_multi_rp_1.sql-plan_/pk_predicate_pk_predicate_equi_multi_rp_1.sql.plan +++ b/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_equi_multi_rp_1.sql-plan_/pk_predicate_pk_predicate_equi_multi_rp_1.sql.plan @@ -14,7 +14,15 @@ "Group", "Name" ], - "type": "Lookup" + "scan_by": [ + "Group [1, 1]", + "Name [Name1, Name1]", + "Group [4, 4]", + "Name [Name4, Name4]", + "Group [6, 6]", + "Name [Name2, Name2]" + ], + "type": "Scan" } ] } diff --git a/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_in.sql-plan_/pk_predicate_pk_predicate_in.sql.plan b/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_in.sql-plan_/pk_predicate_pk_predicate_in.sql.plan index 8800e380e74f..aa77245cbddc 100644 --- a/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_in.sql-plan_/pk_predicate_pk_predicate_in.sql.plan +++ b/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_in.sql-plan_/pk_predicate_pk_predicate_in.sql.plan @@ -13,7 +13,15 @@ "Value1", "Value2" ], - "type": "Lookup" + "limit": "1001", + "scan_by": [ + "Key [1, 1]", + "Key [3, 3]", + "Key [7, 7]", + "Key [9, 9]", + "Key [11, 11]" + ], + "type": "Scan" } ] } diff --git a/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_in_rp.sql-plan_/pk_predicate_pk_predicate_in_rp.sql.plan b/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_in_rp.sql-plan_/pk_predicate_pk_predicate_in_rp.sql.plan index 27f04a14075d..67605c614ec1 100644 --- a/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_in_rp.sql-plan_/pk_predicate_pk_predicate_in_rp.sql.plan +++ b/ydb/tests/functional/canonical/canondata/test_sql.TestCanonicalFolder1.test_case_pk_predicate_pk_predicate_in_rp.sql-plan_/pk_predicate_pk_predicate_in_rp.sql.plan @@ -13,7 +13,12 @@ "Value1", "Value2" ], - "type": "Lookup" + "scan_by": [ + "Key [1, 1]", + "Key [3, 3]", + "Key [5, 5]" + ], + "type": "Scan" } ] } From 0c2f2827258ac903e7e08a0952ef4da4b01ec35b Mon Sep 17 00:00:00 2001 From: Aleksei Borzenkov Date: Fri, 16 Feb 2024 16:19:18 +0300 Subject: [PATCH 024/117] Fix readset acks sent too early in volatile transactions (#1961) --- .../tx/datashard/datashard_ut_volatile.cpp | 108 ++++++++++++++++++ ydb/core/tx/datashard/volatile_tx.cpp | 4 +- 2 files changed, 110 insertions(+), 2 deletions(-) diff --git a/ydb/core/tx/datashard/datashard_ut_volatile.cpp b/ydb/core/tx/datashard/datashard_ut_volatile.cpp index efc134ed160e..9d12f0ee2deb 100644 --- a/ydb/core/tx/datashard/datashard_ut_volatile.cpp +++ b/ydb/core/tx/datashard/datashard_ut_volatile.cpp @@ -3,6 +3,7 @@ #include "datashard_ut_common_pq.h" #include "datashard_active_transaction.h" +#include #include namespace NKikimr { @@ -2106,6 +2107,113 @@ Y_UNIT_TEST_SUITE(DataShardVolatile) { "{ items { uint32_value: 6 } items { uint32_value: 6 } }"); } + // Regression test for KIKIMR-21060 + Y_UNIT_TEST(DistributedWriteRSNotAckedBeforeCommit) { + TPortManager pm; + TServerSettings serverSettings(pm.GetPort(2134)); + serverSettings.SetDomainName("Root") + .SetUseRealThreads(false) + .SetDomainPlanResolution(1000) + .SetEnableDataShardVolatileTransactions(true); + + Tests::TServer::TPtr server = new TServer(serverSettings); + auto &runtime = *server->GetRuntime(); + auto sender = runtime.AllocateEdgeActor(); + + runtime.SetLogPriority(NKikimrServices::TX_DATASHARD, NLog::PRI_TRACE); + runtime.SetLogPriority(NKikimrServices::TX_PROXY, NLog::PRI_DEBUG); + + InitRoot(server, sender); + + CreateShardedTable(server, sender, "/Root", "table-1", 1); + CreateShardedTable(server, sender, "/Root", "table-2", 1); + + ExecSQL(server, sender, "UPSERT INTO `/Root/table-1` (key, value) VALUES (1, 10);"); + ExecSQL(server, sender, "UPSERT INTO `/Root/table-2` (key, value) VALUES (2, 20);"); + + // Block readset exchange + std::vector> readSets; + auto blockReadSets = runtime.AddObserver([&](TEvTxProcessing::TEvReadSet::TPtr& ev) { + Cerr << "... blocking readset" << Endl; + readSets.emplace_back(ev.Release()); + }); + + // Start a distributed write to both tables + TString sessionId = CreateSessionRPC(runtime, "/Root"); + auto upsertResult = SendRequest( + runtime, + MakeSimpleRequestRPC(R"( + UPSERT INTO `/Root/table-1` (key, value) VALUES (3, 30); + UPSERT INTO `/Root/table-2` (key, value) VALUES (4, 40); + )", sessionId, /* txId */ "", /* commitTx */ true), + "/Root"); + WaitFor(runtime, [&]{ return readSets.size() >= 4; }, "readsets"); + + // Stop blocking further readsets + blockReadSets.Remove(); + + // Sleep a little to make sure everything so far is fully committed + runtime.SimulateSleep(TDuration::Seconds(1)); + + // Start blocking commits for table-1 + const auto shards1 = GetTableShards(server, sender, "/Root/table-1"); + UNIT_ASSERT_VALUES_EQUAL(shards1.size(), 1u); + std::vector> putResponses; + auto blockCommits = runtime.AddObserver([&](TEvBlobStorage::TEvPut::TPtr& ev) { + auto* msg = ev->Get(); + // Drop all put requests for table-1 + if (msg->Id.TabletID() == shards1.at(0)) { + // We can't just drop requests, we must reply to it later + putResponses.emplace_back(new IEventHandle( + ev->Sender, + ev->GetRecipientRewrite(), + msg->MakeErrorResponse(NKikimrProto::BLOCKED, "Fake blocked response", 0).release(), + 0, + ev->Cookie)); + Cerr << "... dropping put " << msg->Id << Endl; + ev.Reset(); + } + }); + + // Unblock readsets + for (auto& ev : readSets) { + runtime.Send(ev.release(), 0, true); + } + readSets.clear(); + + // Sleep to make sure those readsets are fully processed + // Bug was acknowledging readsets before tx state is fully persisted + runtime.SimulateSleep(TDuration::Seconds(1)); + + // Transaction will return success even when commits are blocked at this point + Cerr << "... awaiting upsert result" << Endl; + UNIT_ASSERT_VALUES_EQUAL( + FormatResult(AwaitResponse(runtime, std::move(upsertResult))), + ""); + + // Now we stop blocking commits and gracefully restart the tablet, all pending commits will be lost + blockCommits.Remove(); + for (auto& ev : putResponses) { + runtime.Send(ev.release(), 0, true); + } + Cerr << "... restarting tablet " << shards1.at(0) << Endl; + GracefulRestartTablet(runtime, shards1.at(0), sender); + + // We must see all rows as committed, i.e. nothing should be lost + Cerr << "... reading final result" << Endl; + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleExec(runtime, R"( + SELECT key, value FROM `/Root/table-1` + UNION ALL + SELECT key, value FROM `/Root/table-2` + ORDER BY key + )"), + "{ items { uint32_value: 1 } items { uint32_value: 10 } }, " + "{ items { uint32_value: 2 } items { uint32_value: 20 } }, " + "{ items { uint32_value: 3 } items { uint32_value: 30 } }, " + "{ items { uint32_value: 4 } items { uint32_value: 40 } }"); + } + } // Y_UNIT_TEST_SUITE(DataShardVolatile) } // namespace NKikimr diff --git a/ydb/core/tx/datashard/volatile_tx.cpp b/ydb/core/tx/datashard/volatile_tx.cpp index edd5ca149d69..73a233ae0d55 100644 --- a/ydb/core/tx/datashard/volatile_tx.cpp +++ b/ydb/core/tx/datashard/volatile_tx.cpp @@ -824,7 +824,7 @@ namespace NKikimr::NDataShard { } info->DelayedConfirmations.clear(); - // Send delayed acks on commit + // Send delayed acks when changes are persisted // TODO: maybe move it into a parameter? struct TDelayedAcksState : public TThrRefBase { TVector> DelayedAcks; @@ -833,7 +833,7 @@ namespace NKikimr::NDataShard { : DelayedAcks(std::move(info->DelayedAcks)) {} }; - txc.DB.OnCommit([state = MakeIntrusive(info)]() { + txc.DB.OnPersistent([state = MakeIntrusive(info)]() { for (auto& ev : state->DelayedAcks) { TActivationContext::Send(ev.Release()); } From 16776666eac817b2d6c89004d95a49c0e0b3688d Mon Sep 17 00:00:00 2001 From: Ilnaz Nizametdinov Date: Mon, 19 Feb 2024 17:21:23 +0300 Subject: [PATCH 025/117] Use uid as idempotency key KIKIMR-21059 (#2059) --- .../schemeshard_export__create.cpp | 19 ++++--- .../schemeshard_import__create.cpp | 19 ++++--- .../tx/schemeshard/ut_export/ut_export.cpp | 48 +++++++++++++++++ .../tx/schemeshard/ut_restore/ut_restore.cpp | 53 +++++++++++++++++++ 4 files changed, 127 insertions(+), 12 deletions(-) diff --git a/ydb/core/tx/schemeshard/schemeshard_export__create.cpp b/ydb/core/tx/schemeshard/schemeshard_export__create.cpp index 8c7fb7cd995e..cc630e8d2043 100644 --- a/ydb/core/tx/schemeshard/schemeshard_export__create.cpp +++ b/ydb/core/tx/schemeshard/schemeshard_export__create.cpp @@ -51,12 +51,19 @@ struct TSchemeShard::TExport::TTxCreate: public TSchemeShard::TXxport::TTxBase { } const TString& uid = GetUid(request.GetRequest().GetOperationParams().labels()); - if (uid && Self->ExportsByUid.contains(uid)) { - return Reply( - std::move(response), - Ydb::StatusIds::ALREADY_EXISTS, - TStringBuilder() << "Export with uid '" << uid << "' already exists" - ); + if (uid) { + if (auto it = Self->ExportsByUid.find(uid); it != Self->ExportsByUid.end()) { + if (IsSameDomain(it->second, request.GetDatabaseName())) { + Self->FromXxportInfo(*response->Record.MutableResponse()->MutableEntry(), it->second); + return Reply(std::move(response)); + } else { + return Reply( + std::move(response), + Ydb::StatusIds::ALREADY_EXISTS, + TStringBuilder() << "Export with uid '" << uid << "' already exists" + ); + } + } } const TPath domainPath = TPath::Resolve(request.GetDatabaseName(), Self); diff --git a/ydb/core/tx/schemeshard/schemeshard_import__create.cpp b/ydb/core/tx/schemeshard/schemeshard_import__create.cpp index d20e9f9ab317..adcae1ce16bb 100644 --- a/ydb/core/tx/schemeshard/schemeshard_import__create.cpp +++ b/ydb/core/tx/schemeshard/schemeshard_import__create.cpp @@ -53,12 +53,19 @@ struct TSchemeShard::TImport::TTxCreate: public TSchemeShard::TXxport::TTxBase { } const TString& uid = GetUid(request.GetRequest().GetOperationParams().labels()); - if (uid && Self->ImportsByUid.contains(uid)) { - return Reply( - std::move(response), - Ydb::StatusIds::ALREADY_EXISTS, - TStringBuilder() << "Import with uid '" << uid << "' already exists" - ); + if (uid) { + if (auto it = Self->ImportsByUid.find(uid); it != Self->ImportsByUid.end()) { + if (IsSameDomain(it->second, request.GetDatabaseName())) { + Self->FromXxportInfo(*response->Record.MutableResponse()->MutableEntry(), it->second); + return Reply(std::move(response)); + } else { + return Reply( + std::move(response), + Ydb::StatusIds::ALREADY_EXISTS, + TStringBuilder() << "Import with uid '" << uid << "' already exists" + ); + } + } } const TPath domainPath = TPath::Resolve(request.GetDatabaseName(), Self); diff --git a/ydb/core/tx/schemeshard/ut_export/ut_export.cpp b/ydb/core/tx/schemeshard/ut_export/ut_export.cpp index 4a8ad8b32170..67b7c2c204ce 100644 --- a/ydb/core/tx/schemeshard/ut_export/ut_export.cpp +++ b/ydb/core/tx/schemeshard/ut_export/ut_export.cpp @@ -1394,4 +1394,52 @@ partitioning_settings { TestGetExport(runtime, txId, "/MyRoot", Ydb::StatusIds::CANCELLED); } + + Y_UNIT_TEST(UidAsIdempotencyKey) { + TTestBasicRuntime runtime; + TTestEnv env(runtime); + ui64 txId = 100; + + TestCreateTable(runtime, ++txId, "/MyRoot", R"( + Name: "Table" + Columns { Name: "key" Type: "Utf8" } + Columns { Name: "value" Type: "Utf8" } + KeyColumnNames: ["key"] + )"); + env.TestWaitNotification(runtime, txId); + + TPortManager portManager; + const ui16 port = portManager.GetPort(); + + TS3Mock s3Mock({}, TS3Mock::TSettings(port)); + UNIT_ASSERT(s3Mock.Start()); + + const auto request = Sprintf(R"( + OperationParams { + labels { + key: "uid" + value: "foo" + } + } + ExportToS3Settings { + endpoint: "localhost:%d" + scheme: HTTP + items { + source_path: "/MyRoot/Table" + destination_prefix: "" + } + } + )", port); + + // create operation + TestExport(runtime, ++txId, "/MyRoot", request); + const ui64 exportId = txId; + // create operation again with same uid + TestExport(runtime, ++txId, "/MyRoot", request); + // new operation was not created + TestGetExport(runtime, txId, "/MyRoot", Ydb::StatusIds::NOT_FOUND); + // check previous operation + TestGetExport(runtime, exportId, "/MyRoot"); + env.TestWaitNotification(runtime, exportId); + } } diff --git a/ydb/core/tx/schemeshard/ut_restore/ut_restore.cpp b/ydb/core/tx/schemeshard/ut_restore/ut_restore.cpp index 19b00dba18d3..4e8effd31bf9 100644 --- a/ydb/core/tx/schemeshard/ut_restore/ut_restore.cpp +++ b/ydb/core/tx/schemeshard/ut_restore/ut_restore.cpp @@ -2451,6 +2451,59 @@ Y_UNIT_TEST_SUITE(TImportTests) { Run(runtime, env, ConvertTestData(data), request, Ydb::StatusIds::PRECONDITION_FAILED); Run(runtime, env, ConvertTestData(data), request, Ydb::StatusIds::SUCCESS, "/MyRoot", false, userSID); } + + Y_UNIT_TEST(UidAsIdempotencyKey) { + TTestBasicRuntime runtime; + TTestEnv env(runtime, TTestEnvOptions()); + ui64 txId = 100; + + const auto data = GenerateTestData(R"( + columns { + name: "key" + type { optional_type { item { type_id: UTF8 } } } + } + columns { + name: "value" + type { optional_type { item { type_id: UTF8 } } } + } + primary_key: "key" + )", {{"a", 1}}); + + TPortManager portManager; + const ui16 port = portManager.GetPort(); + + TS3Mock s3Mock(ConvertTestData(data), TS3Mock::TSettings(port)); + UNIT_ASSERT(s3Mock.Start()); + + const auto request = Sprintf(R"( + OperationParams { + labels { + key: "uid" + value: "foo" + } + } + ImportFromS3Settings { + endpoint: "localhost:%d" + scheme: HTTP + items { + source_prefix: "" + destination_path: "/MyRoot/Table" + } + } + )", port); + + // create operation + TestImport(runtime, ++txId, "/MyRoot", request); + const ui64 importId = txId; + // create operation again with same uid + TestImport(runtime, ++txId, "/MyRoot", request); + // new operation was not created + TestGetImport(runtime, txId, "/MyRoot", Ydb::StatusIds::NOT_FOUND); + // check previous operation + TestGetImport(runtime, importId, "/MyRoot"); + env.TestWaitNotification(runtime, importId); + } + } Y_UNIT_TEST_SUITE(TImportWithRebootsTests) { From cfdbc778a604f5e70ff0cd418e33ac186ef148a5 Mon Sep 17 00:00:00 2001 From: Vasily Gerasimov Date: Mon, 19 Feb 2024 16:38:26 +0200 Subject: [PATCH 026/117] Enable DDL in ExecuteScript. Allow not to specify TxControl in QueryService queries (#1603) (#1815) --- .../query/rpc_execute_script.cpp | 4 -- .../kqp/session_actor/kqp_query_state.cpp | 38 +++++++++++++++++ ydb/core/kqp/session_actor/kqp_query_state.h | 2 + .../kqp/session_actor/kqp_session_actor.cpp | 18 ++++++-- ydb/core/kqp/ut/service/kqp_qs_queries_ut.cpp | 41 ++++++++++++++++++- ydb/core/kqp/ut/service/kqp_qs_scripts_ut.cpp | 2 +- 6 files changed, 96 insertions(+), 9 deletions(-) diff --git a/ydb/core/grpc_services/query/rpc_execute_script.cpp b/ydb/core/grpc_services/query/rpc_execute_script.cpp index 86cd942d3290..a1de6537e7d2 100644 --- a/ydb/core/grpc_services/query/rpc_execute_script.cpp +++ b/ydb/core/grpc_services/query/rpc_execute_script.cpp @@ -59,10 +59,6 @@ std::tuple FillKqpRequest( kqpRequest.MutableRequest()->SetType(NKikimrKqp::QUERY_TYPE_SQL_GENERIC_SCRIPT); kqpRequest.MutableRequest()->SetKeepSession(false); - // TODO: Avoid explicit tx_control for script queries. - kqpRequest.MutableRequest()->MutableTxControl()->mutable_begin_tx()->mutable_serializable_read_write(); - kqpRequest.MutableRequest()->MutableTxControl()->set_commit_tx(true); - kqpRequest.MutableRequest()->SetCancelAfterMs(GetDuration(req.operation_params().cancel_after()).MilliSeconds()); kqpRequest.MutableRequest()->SetTimeoutMs(GetDuration(req.operation_params().operation_timeout()).MilliSeconds()); diff --git a/ydb/core/kqp/session_actor/kqp_query_state.cpp b/ydb/core/kqp/session_actor/kqp_query_state.cpp index 74571ae2f8cc..7ea7dfa77bfe 100644 --- a/ydb/core/kqp/session_actor/kqp_query_state.cpp +++ b/ydb/core/kqp/session_actor/kqp_query_state.cpp @@ -306,4 +306,42 @@ bool TKqpQueryState::HasErrors(const NSchemeCache::TSchemeCacheNavigate& respons return true; } +bool TKqpQueryState::HasImpliedTx() const { + if (HasTxControl()) { + return false; + } + + const NKikimrKqp::EQueryAction action = RequestEv->GetAction(); + if (action != NKikimrKqp::QUERY_ACTION_EXECUTE && + action != NKikimrKqp::QUERY_ACTION_EXECUTE_PREPARED) + { + return false; + } + + const NKikimrKqp::EQueryType queryType = RequestEv->GetType(); + if (queryType != NKikimrKqp::QUERY_TYPE_SQL_GENERIC_QUERY && + queryType != NKikimrKqp::QUERY_TYPE_SQL_GENERIC_SCRIPT && + queryType != NKikimrKqp::QUERY_TYPE_SQL_GENERIC_CONCURRENT_QUERY) + { + return false; + } + + for (const auto& transactionPtr : PreparedQuery->GetTransactions()) { + switch (transactionPtr->GetType()) { + case NKqpProto::TKqpPhyTx::TYPE_GENERIC: // data transaction + return true; + case NKqpProto::TKqpPhyTx::TYPE_UNSPECIFIED: + case NKqpProto::TKqpPhyTx::TYPE_COMPUTE: + case NKqpProto::TKqpPhyTx::TYPE_DATA: // data transaction, but not in QueryService API + case NKqpProto::TKqpPhyTx::TYPE_SCAN: + case NKqpProto::TKqpPhyTx::TYPE_SCHEME: + case NKqpProto::TKqpPhyTx_EType_TKqpPhyTx_EType_INT_MIN_SENTINEL_DO_NOT_USE_: + case NKqpProto::TKqpPhyTx_EType_TKqpPhyTx_EType_INT_MAX_SENTINEL_DO_NOT_USE_: + break; + } + } + + return false; +} + } diff --git a/ydb/core/kqp/session_actor/kqp_query_state.h b/ydb/core/kqp/session_actor/kqp_query_state.h index 4bcc4cc47fee..7766ddd70116 100644 --- a/ydb/core/kqp/session_actor/kqp_query_state.h +++ b/ydb/core/kqp/session_actor/kqp_query_state.h @@ -362,6 +362,8 @@ class TKqpQueryState : public TNonCopyable { return RequestEv->HasTxControl(); } + bool HasImpliedTx() const; // (only for QueryService API) user has not specified TxControl in the request. In this case we behave like Begin/Commit was specified. + const ::Ydb::Table::TransactionControl& GetTxControl() const { return RequestEv->GetTxControl(); } diff --git a/ydb/core/kqp/session_actor/kqp_session_actor.cpp b/ydb/core/kqp/session_actor/kqp_session_actor.cpp index 00bb19061486..e9735f3bc723 100644 --- a/ydb/core/kqp/session_actor/kqp_session_actor.cpp +++ b/ydb/core/kqp/session_actor/kqp_session_actor.cpp @@ -636,9 +636,21 @@ class TKqpSessionActor : public TActorBootstrapped { Counters->ReportBeginTransaction(Settings.DbCounters, Transactions.EvictedTx, Transactions.Size(), Transactions.ToBeAbortedSize()); } + static const Ydb::Table::TransactionControl& GetImpliedTxControl() { + auto create = []() -> Ydb::Table::TransactionControl { + Ydb::Table::TransactionControl control; + control.mutable_begin_tx()->mutable_serializable_read_write(); + control.set_commit_tx(true); + return control; + }; + static const Ydb::Table::TransactionControl control = create(); + return control; + } + bool PrepareQueryTransaction() { - if (QueryState->HasTxControl()) { - const auto& txControl = QueryState->GetTxControl(); + const bool hasTxControl = QueryState->HasTxControl(); + if (hasTxControl || QueryState->HasImpliedTx()) { + const auto& txControl = hasTxControl ? QueryState->GetTxControl() : GetImpliedTxControl(); QueryState->Commit = txControl.commit_tx(); switch (txControl.tx_selector_case()) { @@ -941,7 +953,7 @@ class TKqpSessionActor : public TActorBootstrapped { case NKqpProto::TKqpPhyTx::TYPE_SCHEME: YQL_ENSURE(tx->StagesSize() == 0); - if (QueryState->TxCtx->EffectiveIsolationLevel != NKikimrKqp::ISOLATION_LEVEL_UNDEFINED) { + if (QueryState->HasTxControl() && QueryState->TxCtx->EffectiveIsolationLevel != NKikimrKqp::ISOLATION_LEVEL_UNDEFINED) { ReplyQueryError(Ydb::StatusIds::PRECONDITION_FAILED, "Scheme operations cannot be executed inside transaction"); return true; diff --git a/ydb/core/kqp/ut/service/kqp_qs_queries_ut.cpp b/ydb/core/kqp/ut/service/kqp_qs_queries_ut.cpp index 460fa094bef0..e6665f5947c7 100644 --- a/ydb/core/kqp/ut/service/kqp_qs_queries_ut.cpp +++ b/ydb/core/kqp/ut/service/kqp_qs_queries_ut.cpp @@ -1321,6 +1321,45 @@ Y_UNIT_TEST_SUITE(KqpQueryService) { UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::PRECONDITION_FAILED, result.GetIssues().ToString()); } + Y_UNIT_TEST(DdlExecuteScript) { + NKikimrConfig::TAppConfig appConfig; + appConfig.MutableTableServiceConfig()->SetEnablePreparedDdl(true); + auto setting = NKikimrKqp::TKqpSetting(); + auto serverSettings = TKikimrSettings() + .SetAppConfig(appConfig) + .SetKqpSettings({setting}) + .SetEnableScriptExecutionOperations(true); + + TKikimrRunner kikimr(serverSettings); + auto db = kikimr.GetQueryClient(); + + const TString sql = R"sql( + CREATE TABLE TestDdlExecuteScript ( + Key Uint64, + Value String, + PRIMARY KEY (Key) + ); + )sql"; + + auto scriptExecutionOperation = db.ExecuteScript(sql).ExtractValueSync(); + UNIT_ASSERT_VALUES_EQUAL_C(scriptExecutionOperation.Status().GetStatus(), EStatus::SUCCESS, scriptExecutionOperation.Status().GetIssues().ToString()); + UNIT_ASSERT(scriptExecutionOperation.Metadata().ExecutionId); + + NYdb::NOperation::TOperationClient client(kikimr.GetDriver()); + TMaybe readyOp; + while (true) { + auto op = client.Get(scriptExecutionOperation.Id()).GetValueSync(); + if (op.Ready()) { + readyOp = std::move(op); + break; + } + UNIT_ASSERT_C(op.Status().IsSuccess(), TStringBuilder() << op.Status().GetStatus() << ":" << op.Status().GetIssues().ToString()); + Sleep(TDuration::MilliSeconds(10)); + } + UNIT_ASSERT_C(readyOp->Status().IsSuccess(), readyOp->Status().GetIssues().ToString()); + UNIT_ASSERT_EQUAL_C(readyOp->Metadata().ExecStatus, EExecStatus::Completed, readyOp->Status().GetIssues().ToString()); + } + Y_UNIT_TEST(DdlMixedDml) { NKikimrConfig::TAppConfig appConfig; appConfig.MutableTableServiceConfig()->SetEnablePreparedDdl(true); @@ -1353,7 +1392,7 @@ Y_UNIT_TEST_SUITE(KqpQueryService) { UPSERT INTO KeyValue (Key, Value) VALUES (3, "Three"); SELECT * FROM KeyValue; )", TTxControl::NoTx()).ExtractValueSync(); - UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::PRECONDITION_FAILED, result.GetIssues().ToString()); + UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, result.GetIssues().ToString()); } Y_UNIT_TEST(Tcl) { diff --git a/ydb/core/kqp/ut/service/kqp_qs_scripts_ut.cpp b/ydb/core/kqp/ut/service/kqp_qs_scripts_ut.cpp index a91c4e4d3504..5fdb3ed11809 100644 --- a/ydb/core/kqp/ut/service/kqp_qs_scripts_ut.cpp +++ b/ydb/core/kqp/ut/service/kqp_qs_scripts_ut.cpp @@ -203,7 +203,7 @@ Y_UNIT_TEST_SUITE(KqpQueryServiceScripts) { } - void ExecuteScriptWithStatsMode (Ydb::Query::StatsMode statsMode) { + void ExecuteScriptWithStatsMode(Ydb::Query::StatsMode statsMode) { auto kikimr = DefaultKikimrRunner(); auto db = kikimr.GetQueryClient(); From 782ac23e6f971d90d70df1f2695ec53d049a3ea4 Mon Sep 17 00:00:00 2001 From: Aleksei Borzenkov Date: Mon, 19 Feb 2024 17:42:06 +0300 Subject: [PATCH 027/117] Fix lost coordinator steps during mediator reconnect race (#2037) (#2056) --- .../coordinator/coordinator_volatile_ut.cpp | 99 +++++++++++++++++++ ydb/core/tx/coordinator/mediator_queue.cpp | 3 +- 2 files changed, 101 insertions(+), 1 deletion(-) diff --git a/ydb/core/tx/coordinator/coordinator_volatile_ut.cpp b/ydb/core/tx/coordinator/coordinator_volatile_ut.cpp index bc148f7d8ba2..8d75974813aa 100644 --- a/ydb/core/tx/coordinator/coordinator_volatile_ut.cpp +++ b/ydb/core/tx/coordinator/coordinator_volatile_ut.cpp @@ -1,4 +1,5 @@ #include +#include #include #include #include @@ -258,6 +259,104 @@ namespace NKikimr::NFlatTxCoordinator::NTest { observedSteps.clear(); } + Y_UNIT_TEST(MediatorReconnectPlanRace) { + TPortManager pm; + TServerSettings serverSettings(pm.GetPort(2134)); + serverSettings.SetDomainName("Root") + .SetNodeCount(1) + .SetUseRealThreads(false); + + Tests::TServer::TPtr server = new TServer(serverSettings); + + auto &runtime = *server->GetRuntime(); + runtime.SetLogPriority(NKikimrServices::TX_COORDINATOR, NActors::NLog::PRI_DEBUG); + runtime.SetLogPriority(NKikimrServices::BOOTSTRAPPER, NActors::NLog::PRI_DEBUG); + + auto sender = runtime.AllocateEdgeActor(); + ui64 coordinatorId = ChangeStateStorage(Coordinator, server->GetSettings().Domain); + ui64 mediatorId = ChangeStateStorage(Mediator, server->GetSettings().Domain); + ui64 tabletId = ChangeStateStorage(TTestTxConfig::TxTablet0, server->GetSettings().Domain); + + CreateTestBootstrapper(runtime, + CreateTestTabletInfo(tabletId, TTabletTypes::Dummy), + [](const TActorId& tablet, TTabletStorageInfo* info) { + return new TPlanTargetTablet(tablet, info); + }); + + { + TDispatchOptions options; + options.FinalEvents.push_back(TDispatchOptions::TFinalEventCondition(TEvTablet::EvBoot, 1)); + runtime.DispatchEvents(options); + } + + TActorId mediatorQueue; + std::vector> mediatorQueueSteps; + auto blockMediatorQueueSteps = runtime.AddObserver([&](TEvMediatorQueueStep::TPtr& ev) { + mediatorQueue = ev->GetRecipientRewrite(); + mediatorQueueSteps.emplace_back(ev.Release()); + Cerr << "... blocked TEvMediatorQueueStep for " << mediatorQueue << Endl; + }); + + std::vector observedSteps; + auto stepsObserver = runtime.AddObserver([&](TEvTxProcessing::TEvPlanStep::TPtr& ev) { + auto* msg = ev->Get(); + observedSteps.push_back(msg->Record.GetStep()); + }); + + auto waitFor = [&](const auto& condition, const TString& description) { + for (int i = 0; i < 5 && !condition(); ++i) { + Cerr << "... waiting for " << description << Endl; + TDispatchOptions options; + options.CustomFinalCondition = [&]() { + return condition(); + }; + runtime.DispatchEvents(options); + } + UNIT_ASSERT_C(condition(), "... failed to wait for " << description); + }; + + ui64 txId = 12345678; + if (auto propose = std::make_unique(coordinatorId, txId, 0, Min(), Max())) { + auto* tx = propose->Record.MutableTransaction(); + // Not necessary, but we test volatile transactions here + tx->SetFlags(TEvTxProxy::TEvProposeTransaction::FlagVolatile); + auto* affected = tx->AddAffectedSet(); + affected->SetTabletId(tabletId); + affected->SetFlags(TEvTxProxy::TEvProposeTransaction::AffectedWrite); + + runtime.SendToPipe(coordinatorId, sender, propose.release()); + } + + waitFor([&]{ return mediatorQueueSteps.size() > 0; }, "TEvMediatorQueueStep"); + UNIT_ASSERT_VALUES_EQUAL(mediatorQueueSteps.size(), 1u); + + // We shouldn't see any steps yet + UNIT_ASSERT_VALUES_EQUAL(observedSteps.size(), 0u); + + auto injectMediatorQueueStep = runtime.AddObserver([&](TEvTabletPipe::TEvClientDestroyed::TPtr& ev) { + if (ev->GetRecipientRewrite() == mediatorQueue) { + Cerr << "... found pipe disconnect at " << mediatorQueue << Endl; + // Stop blocking mediator queue steps + // This seems to be safe, since we remove someone else from std::list + blockMediatorQueueSteps.Remove(); + // Inject blocked mediator steps into queue mailbox, they will be handled after the disconnect + for (auto& ev : mediatorQueueSteps) { + runtime.Send(ev.release(), 0, true); + } + mediatorQueueSteps.clear(); + } + }); + + Cerr << "... rebooting mediator" << Endl; + RebootTablet(runtime, mediatorId, sender); + + waitFor([&]{ return mediatorQueueSteps.empty(); }, "injected mediator steps"); + + // We must observe the plan step soon + runtime.SimulateSleep(TDuration::Seconds(2)); + UNIT_ASSERT_VALUES_EQUAL(observedSteps.size(), 1u); + } + } // Y_UNIT_TEST_SUITE(CoordinatorVolatile) } // namespace NKikimr::NFlatTxCoordinator::NTest diff --git a/ydb/core/tx/coordinator/mediator_queue.cpp b/ydb/core/tx/coordinator/mediator_queue.cpp index c7a4eecbd255..8cb7557d80aa 100644 --- a/ydb/core/tx/coordinator/mediator_queue.cpp +++ b/ydb/core/tx/coordinator/mediator_queue.cpp @@ -284,6 +284,7 @@ class TTxCoordinatorMediatorQueue : public TActorBootstrappedGetTypeRewrite()) { + HFunc(TEvMediatorQueueStep, Handle); HFunc(TEvTxProcessing::TEvPlanStepAck, Handle); HFunc(TEvTxCoordinator::TEvCoordinatorSyncResult, Handle); HFunc(TEvTabletPipe::TEvClientConnected, Handle); @@ -294,8 +295,8 @@ class TTxCoordinatorMediatorQueue : public TActorBootstrappedGetTypeRewrite()) { - HFunc(TEvTxProcessing::TEvPlanStepAck, Handle); HFunc(TEvMediatorQueueStep, Handle); + HFunc(TEvTxProcessing::TEvPlanStepAck, Handle); HFunc(TEvTabletPipe::TEvClientDestroyed, Handle); CFunc(TEvents::TSystem::PoisonPill, Die) } From c1a933bc8031cb95e1dc642cbab88085e3750329 Mon Sep 17 00:00:00 2001 From: Pavel Velikhov Date: Mon, 19 Feb 2024 21:08:54 +0300 Subject: [PATCH 028/117] Cannonized two plans (#1773) (#2081) --- .../query_4.plan | 22 ++++++--------- .../query_5.plan | 28 ++++++++----------- 2 files changed, 19 insertions(+), 31 deletions(-) diff --git a/ydb/tests/functional/suite_tests/canondata/test_postgres.TestPGSQL.test_sql_suite_plan-jointest_join3.test_/query_4.plan b/ydb/tests/functional/suite_tests/canondata/test_postgres.TestPGSQL.test_sql_suite_plan-jointest_join3.test_/query_4.plan index 4e79bd2696d3..8280179fba4a 100644 --- a/ydb/tests/functional/suite_tests/canondata/test_postgres.TestPGSQL.test_sql_suite_plan-jointest_join3.test_/query_4.plan +++ b/ydb/tests/functional/suite_tests/canondata/test_postgres.TestPGSQL.test_sql_suite_plan-jointest_join3.test_/query_4.plan @@ -175,26 +175,20 @@ "PlanNodeType": "Connection", "Plans": [ { - "CTE Name": "precompute_0_0", - "Node Type": "TablePointLookup-ConstantExpr", + "Node Type": "TableRangeScan", "Operators": [ { - "Inputs": [ - { - "InternalOperatorId": 1 - } - ], - "Name": "TablePointLookup", + "Inputs": [], + "Name": "TableRangeScan", "ReadColumns": [ "k", "pd" ], + "ReadRangesExpectedSize": 1, + "ReadRangesKeys": [ + "k" + ], "Table": "postgres_jointest/join3.test_plan/parent" - }, - { - "Inputs": [], - "Iterator": "precompute_0_0", - "Name": "Iterator" } ], "PlanNodeId": 1, @@ -235,7 +229,7 @@ "k", "pd" ], - "type": "Lookup" + "type": "Scan" } ] } diff --git a/ydb/tests/functional/suite_tests/canondata/test_postgres.TestPGSQL.test_sql_suite_plan-jointest_join3.test_/query_5.plan b/ydb/tests/functional/suite_tests/canondata/test_postgres.TestPGSQL.test_sql_suite_plan-jointest_join3.test_/query_5.plan index 587d33bcc4a8..5263099b2605 100644 --- a/ydb/tests/functional/suite_tests/canondata/test_postgres.TestPGSQL.test_sql_suite_plan-jointest_join3.test_/query_5.plan +++ b/ydb/tests/functional/suite_tests/canondata/test_postgres.TestPGSQL.test_sql_suite_plan-jointest_join3.test_/query_5.plan @@ -271,26 +271,20 @@ "PlanNodeType": "Connection", "Plans": [ { - "CTE Name": "precompute_0_0", - "Node Type": "TablePointLookup-ConstantExpr", + "Node Type": "TableRangeScan", "Operators": [ { - "Inputs": [ - { - "InternalOperatorId": 1 - } - ], - "Name": "TablePointLookup", + "Inputs": [], + "Name": "TableRangeScan", "ReadColumns": [ "k", "pd" ], + "ReadRangesExpectedSize": 1, + "ReadRangesKeys": [ + "k" + ], "Table": "postgres_jointest/join3.test_plan/parent" - }, - { - "Inputs": [], - "Iterator": "precompute_0_0", - "Name": "Iterator" } ], "PlanNodeId": 1, @@ -328,14 +322,14 @@ "reads": [ { "columns": [ - "k" + "k", + "pd" ], - "type": "Lookup" + "type": "Scan" }, { "columns": [ - "k", - "pd" + "k" ], "type": "Lookup" } From 321f6837de0ecc4bd7bce10a02fb02f1e457a74d Mon Sep 17 00:00:00 2001 From: Alexey Efimov Date: Wed, 21 Feb 2024 11:16:37 +0400 Subject: [PATCH 029/117] fix iam monitoring (#2061) (#2113) --- ydb/core/mon/mon.cpp | 12 ++++++++---- 1 file changed, 8 insertions(+), 4 deletions(-) diff --git a/ydb/core/mon/mon.cpp b/ydb/core/mon/mon.cpp index 4d31af077a91..8acaa51baf8b 100644 --- a/ydb/core/mon/mon.cpp +++ b/ydb/core/mon/mon.cpp @@ -6,15 +6,19 @@ namespace NActors { using namespace NMonitoring; +using namespace NKikimr; namespace { const std::vector& GetEntries(const TString& ticket) { if (ticket.StartsWith("Bearer")) { - static std::vector entries = { - {NKikimr::TEvTicketParser::TEvAuthorizeTicket::ToPermissions({"ydb.developerApi.get", "ydb.developerApi.update"}), {{"gizmo_id", "gizmo"}}} - }; - return entries; + if (AppData()->AuthConfig.GetUseAccessService() + && (AppData()->DomainsConfig.GetSecurityConfig().ViewerAllowedSIDsSize() > 0 || AppData()->DomainsConfig.GetSecurityConfig().MonitoringAllowedSIDsSize() > 0)) { + static std::vector entries = { + {NKikimr::TEvTicketParser::TEvAuthorizeTicket::ToPermissions({"ydb.developerApi.get", "ydb.developerApi.update"}), {{"gizmo_id", "gizmo"}}} + }; + return entries; + } } static std::vector emptyEntries = {}; return emptyEntries; From 09dbd42bf9aa82042d19cb426d1bf5c1b9256ad4 Mon Sep 17 00:00:00 2001 From: Vitalii Gridnev Date: Wed, 21 Feb 2024 18:18:30 +0300 Subject: [PATCH 030/117] correctly fix memlimit exception problem (#2135) --- .../kqp/executer_actor/kqp_data_executer.cpp | 12 +++ .../kqp/executer_actor/kqp_executer_impl.h | 8 ++ .../executer_actor/kqp_literal_executer.cpp | 18 ----- .../kqp/executer_actor/kqp_scan_executer.cpp | 4 + .../kqp/session_actor/kqp_session_actor.cpp | 53 +++++++++++- .../kqp/session_actor/kqp_session_actor.h | 16 +++- ydb/core/kqp/ut/query/kqp_limits_ut.cpp | 81 +++++++++++++++++++ 7 files changed, 168 insertions(+), 24 deletions(-) diff --git a/ydb/core/kqp/executer_actor/kqp_data_executer.cpp b/ydb/core/kqp/executer_actor/kqp_data_executer.cpp index a6fdcac9a80d..b8dd4a1824ba 100644 --- a/ydb/core/kqp/executer_actor/kqp_data_executer.cpp +++ b/ydb/core/kqp/executer_actor/kqp_data_executer.cpp @@ -312,6 +312,8 @@ class TKqpDataExecuter : public TKqpExecuterBase { return TActorBootstrapped::SelfId(); } + TString BuildMemoryLimitExceptionMessage() const { + if (Request.TxAlloc) { + return TStringBuilder() << "Memory limit exception at " << CurrentStateFuncName() + << ", current limit is " << Request.TxAlloc->Alloc.GetLimit() << " bytes."; + } + return TStringBuilder() << "Memory limit exception at " << CurrentStateFuncName(); + } + void ReportEventElapsedTime() { if (Stats) { ui64 elapsedMicros = TlsActivationContext->GetCurrentEventTicksAsSeconds() * 1'000'000; diff --git a/ydb/core/kqp/executer_actor/kqp_literal_executer.cpp b/ydb/core/kqp/executer_actor/kqp_literal_executer.cpp index 3d1383bf0810..6c2df7106680 100644 --- a/ydb/core/kqp/executer_actor/kqp_literal_executer.cpp +++ b/ydb/core/kqp/executer_actor/kqp_literal_executer.cpp @@ -146,24 +146,6 @@ class TKqpLiteralExecuter { return; } - ui64 mkqlMemoryLimit = Request.MkqlMemoryLimit > 0 - ? Request.MkqlMemoryLimit - : 1_GB; - - auto& alloc = Request.TxAlloc->Alloc; - auto rmConfig = GetKqpResourceManager()->GetConfig(); - ui64 mkqlInitialLimit = std::min(mkqlMemoryLimit, rmConfig.GetMkqlLightProgramMemoryLimit()); - ui64 mkqlMaxLimit = std::max(mkqlMemoryLimit, rmConfig.GetMkqlLightProgramMemoryLimit()); - alloc.SetLimit(mkqlInitialLimit); - - // TODO: KIKIMR-15350 - alloc.Ref().SetIncreaseMemoryLimitCallback([this, &alloc, mkqlMaxLimit](ui64 currentLimit, ui64 required) { - if (required < mkqlMaxLimit) { - LOG_D("Increase memory limit from " << currentLimit << " to " << required); - alloc.SetLimit(required); - } - }); - // task runner settings ComputeCtx = std::make_unique(); RunnerContext = CreateTaskRunnerContext(ComputeCtx.get(), &Request.TxAlloc->TypeEnv); diff --git a/ydb/core/kqp/executer_actor/kqp_scan_executer.cpp b/ydb/core/kqp/executer_actor/kqp_scan_executer.cpp index d6f6f1e9813b..62d799717d20 100644 --- a/ydb/core/kqp/executer_actor/kqp_scan_executer.cpp +++ b/ydb/core/kqp/executer_actor/kqp_scan_executer.cpp @@ -90,6 +90,8 @@ class TKqpScanExecuter : public TKqpExecuterBase #include #include +#include #include #include @@ -619,6 +620,23 @@ class TKqpSessionActor : public TActorBootstrapped { QueryState->TxId = UlidGen.Next(); QueryState->TxCtx = MakeIntrusive(false, AppData()->FunctionRegistry, AppData()->TimeProvider, AppData()->RandomProvider, Config->EnableKqpImmediateEffects); + + auto& alloc = QueryState->TxCtx->TxAlloc; + ui64 mkqlInitialLimit = Settings.MkqlInitialMemoryLimit; + + const auto& queryLimitsProto = Settings.TableService.GetQueryLimits(); + const auto& phaseLimitsProto = queryLimitsProto.GetPhaseLimits(); + ui64 mkqlMaxLimit = phaseLimitsProto.GetComputeNodeMemoryLimitBytes(); + mkqlMaxLimit = mkqlMaxLimit ? mkqlMaxLimit : ui64(Settings.MkqlMaxMemoryLimit); + + alloc->Alloc.SetLimit(mkqlInitialLimit); + alloc->Alloc.Ref().SetIncreaseMemoryLimitCallback([this, &alloc, mkqlMaxLimit](ui64 currentLimit, ui64 required) { + if (required < mkqlMaxLimit) { + LOG_D("Increase memory limit from " << currentLimit << " to " << required); + alloc->Alloc.SetLimit(required); + } + }); + QueryState->QueryData = std::make_shared(QueryState->TxCtx->TxAlloc); QueryState->TxCtx->SetIsolationLevel(settings); QueryState->TxCtx->OnBeginQuery(); @@ -748,6 +766,8 @@ class TKqpSessionActor : public TActorBootstrapped { } } catch(const yexception& ex) { ythrow TRequestFail(Ydb::StatusIds::BAD_REQUEST) << ex.what(); + } catch(const TMemoryLimitExceededException&) { + ythrow TRequestFail(Ydb::StatusIds::BAD_REQUEST) << BuildMemoryLimitExceptionMessage(); } return true; } @@ -2051,6 +2071,9 @@ class TKqpSessionActor : public TActorBootstrapped { ReplyQueryError(ex.Status, ex.what(), ex.Issues); } catch (const yexception& ex) { InternalError(ex.what()); + } catch (const TMemoryLimitExceededException&) { + ReplyQueryError(Ydb::StatusIds::INTERNAL_ERROR, + BuildMemoryLimitExceptionMessage()); } } @@ -2090,6 +2113,9 @@ class TKqpSessionActor : public TActorBootstrapped { ReplyQueryError(ex.Status, ex.what(), ex.Issues); } catch (const yexception& ex) { InternalError(ex.what()); + } catch (const TMemoryLimitExceededException&) { + ReplyQueryError(Ydb::StatusIds::UNDETERMINED, + BuildMemoryLimitExceptionMessage()); } } @@ -2125,14 +2151,24 @@ class TKqpSessionActor : public TActorBootstrapped { } } catch (const yexception& ex) { InternalError(ex.what()); + } catch (const TMemoryLimitExceededException&) { + ReplyQueryError(Ydb::StatusIds::INTERNAL_ERROR, + BuildMemoryLimitExceptionMessage()); } } STATEFN(FinalCleanupState) { - switch (ev->GetTypeRewrite()) { - hFunc(TEvents::TEvGone, HandleFinalCleanup); - hFunc(TEvents::TEvUndelivered, HandleNoop); - hFunc(TEvKqpSnapshot::TEvCreateSnapshotResponse, Handle); + try { + switch (ev->GetTypeRewrite()) { + hFunc(TEvents::TEvGone, HandleFinalCleanup); + hFunc(TEvents::TEvUndelivered, HandleNoop); + hFunc(TEvKqpSnapshot::TEvCreateSnapshotResponse, Handle); + } + } catch (const yexception& ex) { + InternalError(ex.what()); + } catch (const TMemoryLimitExceededException&) { + ReplyQueryError(Ydb::StatusIds::INTERNAL_ERROR, + BuildMemoryLimitExceptionMessage()); } } @@ -2165,6 +2201,15 @@ class TKqpSessionActor : public TActorBootstrapped { } } + TString BuildMemoryLimitExceptionMessage() const { + if (QueryState && QueryState->TxCtx) { + return TStringBuilder() << "Memory limit exception at " << CurrentStateFuncName() + << ", current limit is " << QueryState->TxCtx->TxAlloc->Alloc.GetLimit() << " bytes."; + } else { + return TStringBuilder() << "Memory limit exception at " << CurrentStateFuncName(); + } + } + void ProcessTopicOps(TEvTxProxySchemeCache::TEvNavigateKeySetResult::TPtr& ev) { YQL_ENSURE(ev->Get()->Request); if (ev->Get()->Request->Cookie < QueryId) { diff --git a/ydb/core/kqp/session_actor/kqp_session_actor.h b/ydb/core/kqp/session_actor/kqp_session_actor.h index 763e43de343d..3dc392551620 100644 --- a/ydb/core/kqp/session_actor/kqp_session_actor.h +++ b/ydb/core/kqp/session_actor/kqp_session_actor.h @@ -7,6 +7,7 @@ #include #include +#include #include namespace NKikimr::NKqp { @@ -19,9 +20,12 @@ struct TKqpWorkerSettings { NKikimrConfig::TTableServiceConfig TableService; NKikimrConfig::TQueryServiceConfig QueryService; + TControlWrapper MkqlInitialMemoryLimit; + TControlWrapper MkqlMaxMemoryLimit; + TKqpDbCountersPtr DbCounters; - TKqpWorkerSettings(const TString& cluster, const TString& database, + explicit TKqpWorkerSettings(const TString& cluster, const TString& database, const NKikimrConfig::TTableServiceConfig& tableServiceConfig, const NKikimrConfig::TQueryServiceConfig& queryServiceConfig, TKqpDbCountersPtr dbCounters) @@ -29,7 +33,15 @@ struct TKqpWorkerSettings { , Database(database) , TableService(tableServiceConfig) , QueryService(queryServiceConfig) - , DbCounters(dbCounters) {} + , MkqlInitialMemoryLimit(2097152, 1, Max()) + , MkqlMaxMemoryLimit(1073741824, 1, Max()) + , DbCounters(dbCounters) + { + AppData()->Icb->RegisterSharedControl( + MkqlInitialMemoryLimit, "KqpSession.MkqlInitialMemoryLimit"); + AppData()->Icb->RegisterSharedControl( + MkqlMaxMemoryLimit, "KqpSession.MkqlMaxMemoryLimit"); + } }; IActor* CreateKqpSessionActor(const TActorId& owner, const TString& sessionId, diff --git a/ydb/core/kqp/ut/query/kqp_limits_ut.cpp b/ydb/core/kqp/ut/query/kqp_limits_ut.cpp index 2c7f85a4854f..2b0218e43e7b 100644 --- a/ydb/core/kqp/ut/query/kqp_limits_ut.cpp +++ b/ydb/core/kqp/ut/query/kqp_limits_ut.cpp @@ -17,6 +17,87 @@ namespace { } Y_UNIT_TEST_SUITE(KqpLimits) { + Y_UNIT_TEST(KqpMkqlMemoryLimitException) { + TKikimrRunner kikimr; + CreateLargeTable(kikimr, 10, 10, 1'000'000, 1); + + kikimr.GetTestServer().GetRuntime()->SetLogPriority(NKikimrServices::KQP_SLOW_LOG, NActors::NLog::PRI_ERROR); + + TControlWrapper mkqlInitialMemoryLimit; + TControlWrapper mkqlMaxMemoryLimit; + + mkqlInitialMemoryLimit = kikimr.GetTestServer().GetRuntime()->GetAppData().Icb->RegisterSharedControl( + mkqlInitialMemoryLimit, "KqpSession.MkqlInitialMemoryLimit"); + mkqlMaxMemoryLimit = kikimr.GetTestServer().GetRuntime()->GetAppData().Icb->RegisterSharedControl( + mkqlMaxMemoryLimit, "KqpSession.MkqlMaxMemoryLimit"); + + mkqlInitialMemoryLimit = 1_KB; + mkqlMaxMemoryLimit = 1_KB; + + auto db = kikimr.GetTableClient(); + auto session = db.CreateSession().GetValueSync().GetSession(); + + auto result = session.ExecuteDataQuery(Q1_(R"( + SELECT * FROM `/Root/LargeTable`; + )"), TTxControl::BeginTx().CommitTx()).ExtractValueSync(); + result.GetIssues().PrintTo(Cerr); + UNIT_ASSERT_VALUES_EQUAL(result.GetStatus(), EStatus::PRECONDITION_FAILED); + } + + Y_UNIT_TEST(LargeParametersAndMkqlFailure) { + auto app = NKikimrConfig::TAppConfig(); + app.MutableTableServiceConfig()->MutableResourceManager()->SetMkqlLightProgramMemoryLimit(1'000'000'000); + + TKikimrRunner kikimr(app); + CreateLargeTable(kikimr, 0, 0, 0); + + kikimr.GetTestServer().GetRuntime()->SetLogPriority(NKikimrServices::KQP_SLOW_LOG, NActors::NLog::PRI_ERROR); + + auto db = kikimr.GetTableClient(); + auto session = db.CreateSession().GetValueSync().GetSession(); + + TControlWrapper mkqlInitialMemoryLimit; + TControlWrapper mkqlMaxMemoryLimit; + + mkqlInitialMemoryLimit = kikimr.GetTestServer().GetRuntime()->GetAppData().Icb->RegisterSharedControl( + mkqlInitialMemoryLimit, "KqpSession.MkqlInitialMemoryLimit"); + mkqlMaxMemoryLimit = kikimr.GetTestServer().GetRuntime()->GetAppData().Icb->RegisterSharedControl( + mkqlMaxMemoryLimit, "KqpSession.MkqlMaxMemoryLimit"); + + + mkqlInitialMemoryLimit = 1_KB; + mkqlMaxMemoryLimit = 1_KB; + + auto paramsBuilder = db.GetParamsBuilder(); + auto& rowsParam = paramsBuilder.AddParam("$rows"); + + rowsParam.BeginList(); + for (ui32 i = 0; i < 100; ++i) { + rowsParam.AddListItem() + .BeginStruct() + .AddMember("Key") + .OptionalUint64(i) + .AddMember("KeyText") + .OptionalString(TString(5000, '0' + i % 10)) + .AddMember("Data") + .OptionalInt64(i) + .AddMember("DataText") + .OptionalString(TString(16, '0' + (i + 1) % 10)) + .EndStruct(); + } + rowsParam.EndList(); + rowsParam.Build(); + + auto result = session.ExecuteDataQuery(Q1_(R"( + DECLARE $rows AS List>; + + UPSERT INTO `/Root/LargeTable` + SELECT * FROM AS_TABLE($rows); + )"), TTxControl::BeginTx().CommitTx(), paramsBuilder.Build()).ExtractValueSync(); + result.GetIssues().PrintTo(Cerr); + UNIT_ASSERT_VALUES_EQUAL(result.GetStatus(), EStatus::BAD_REQUEST); + } + Y_UNIT_TEST(DatashardProgramSize) { auto app = NKikimrConfig::TAppConfig(); app.MutableTableServiceConfig()->MutableResourceManager()->SetMkqlLightProgramMemoryLimit(1'000'000'000); From 5e91e287d27d8364cfb37d2f77b41adc3f77b04a Mon Sep 17 00:00:00 2001 From: Alexander Rutkovsky Date: Wed, 21 Feb 2024 21:13:45 +0300 Subject: [PATCH 031/117] Disable distconf in 24-1 (#2147) --- ydb/core/blobstorage/nodewarden/node_warden_impl.cpp | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/ydb/core/blobstorage/nodewarden/node_warden_impl.cpp b/ydb/core/blobstorage/nodewarden/node_warden_impl.cpp index 66c6f1e0e2b4..ae71ba2387a1 100644 --- a/ydb/core/blobstorage/nodewarden/node_warden_impl.cpp +++ b/ydb/core/blobstorage/nodewarden/node_warden_impl.cpp @@ -231,7 +231,7 @@ void TNodeWarden::Bootstrap() { StartInvalidGroupProxy(); - StartDistributedConfigKeeper(); + // StartDistributedConfigKeeper(); // disabled in 24-1 } void TNodeWarden::HandleReadCache() { From 08728786f61fc3b74cf3c87b4fcc86a5765b9d49 Mon Sep 17 00:00:00 2001 From: Nikolay Shumkov <153636981+shnikd@users.noreply.github.com> Date: Wed, 21 Feb 2024 21:43:04 +0300 Subject: [PATCH 032/117] KIKIMR-20082: TableStore/ColumnTable with QueryService (#1377) (#1647) --- .../executer_actor/kqp_scheme_executer.cpp | 30 ++ ydb/core/kqp/gateway/kqp_ic_gateway.cpp | 276 ++-------------- ydb/core/kqp/host/kqp_gateway_proxy.cpp | 299 +++++++++++++++++- ydb/core/kqp/provider/yql_kikimr_exec.cpp | 7 +- ydb/core/kqp/provider/yql_kikimr_gateway.h | 9 +- ydb/core/kqp/ut/service/kqp_qs_queries_ut.cpp | 142 +++++++++ ydb/core/protos/kqp_physical.proto | 5 + 7 files changed, 501 insertions(+), 267 deletions(-) diff --git a/ydb/core/kqp/executer_actor/kqp_scheme_executer.cpp b/ydb/core/kqp/executer_actor/kqp_scheme_executer.cpp index 780bc7b85b0b..26dc514af23b 100644 --- a/ydb/core/kqp/executer_actor/kqp_scheme_executer.cpp +++ b/ydb/core/kqp/executer_actor/kqp_scheme_executer.cpp @@ -203,6 +203,36 @@ class TKqpSchemeExecuter : public TActorBootstrapped { break; } + case NKqpProto::TKqpSchemeOperation::kCreateColumnTable: { + const auto& modifyScheme = schemeOp.GetCreateColumnTable(); + ev->Record.MutableTransaction()->MutableModifyScheme()->CopyFrom(modifyScheme); + break; + } + + case NKqpProto::TKqpSchemeOperation::kAlterColumnTable: { + const auto& modifyScheme = schemeOp.GetAlterColumnTable(); + ev->Record.MutableTransaction()->MutableModifyScheme()->CopyFrom(modifyScheme); + break; + } + + case NKqpProto::TKqpSchemeOperation::kCreateTableStore: { + const auto& modifyScheme = schemeOp.GetCreateTableStore(); + ev->Record.MutableTransaction()->MutableModifyScheme()->CopyFrom(modifyScheme); + break; + } + + case NKqpProto::TKqpSchemeOperation::kAlterTableStore: { + const auto& modifyScheme = schemeOp.GetAlterTableStore(); + ev->Record.MutableTransaction()->MutableModifyScheme()->CopyFrom(modifyScheme); + break; + } + + case NKqpProto::TKqpSchemeOperation::kDropTableStore: { + const auto& modifyScheme = schemeOp.GetDropTableStore(); + ev->Record.MutableTransaction()->MutableModifyScheme()->CopyFrom(modifyScheme); + break; + } + default: InternalError(TStringBuilder() << "Unexpected scheme operation: " << (ui32) schemeOp.GetOperationCase()); diff --git a/ydb/core/kqp/gateway/kqp_ic_gateway.cpp b/ydb/core/kqp/gateway/kqp_ic_gateway.cpp index 72b65ebeacd9..763470536966 100644 --- a/ydb/core/kqp/gateway/kqp_ic_gateway.cpp +++ b/ydb/core/kqp/gateway/kqp_ic_gateway.cpp @@ -877,51 +877,12 @@ class TKikimrIcGateway : public IKqpGateway { return tablePromise.GetFuture(); } - TFuture CreateColumnTable(NYql::TKikimrTableMetadataPtr metadata, bool createDir) override { - using TRequest = TEvTxUserProxy::TEvProposeTransaction; - - try { - if (!CheckCluster(metadata->Cluster)) { - return InvalidCluster(metadata->Cluster); - } - - std::pair pathPair; - { - TString error; - if (!GetPathPair(metadata->Name, pathPair, error, createDir)) { - return MakeFuture(ResultFromError(error)); - } - } - - auto ev = MakeHolder(); - ev->Record.SetDatabaseName(Database); - if (UserToken) { - ev->Record.SetUserToken(UserToken->GetSerializedToken()); - } - auto& schemeTx = *ev->Record.MutableTransaction()->MutableModifyScheme(); - schemeTx.SetWorkingDir(pathPair.first); - - Ydb::StatusIds::StatusCode code; - TString error; - - schemeTx.SetOperationType(NKikimrSchemeOp::ESchemeOpCreateColumnTable); - NKikimrSchemeOp::TColumnTableDescription* tableDesc = schemeTx.MutableCreateColumnTable(); - - tableDesc->SetName(pathPair.second); - FillColumnTableSchema(*tableDesc->MutableSchema(), *metadata); - - if (!FillCreateColumnTableDesc(metadata, *tableDesc, code, error)) { - IKqpGateway::TGenericResult errResult; - errResult.AddIssue(NYql::TIssue(error)); - errResult.SetStatus(NYql::YqlStatusFromYdbStatus(code)); - return MakeFuture(std::move(errResult)); - } - - return SendSchemeRequest(ev.Release()); - } - catch (yexception& e) { - return MakeFuture(ResultFromException(e)); - } + TFuture CreateColumnTable(NYql::TKikimrTableMetadataPtr metadata, + bool createDir, bool existingOk) override { + Y_UNUSED(metadata); + Y_UNUSED(createDir); + Y_UNUSED(existingOk); + return NotImplemented(); } TFuture AlterTable(const TString&, Ydb::Table::AlterTableRequest&&, const TMaybe&, ui64, NKikimrIndexBuilder::TIndexBuildSettings&&) override @@ -1035,150 +996,33 @@ class TKikimrIcGateway : public IKqpGateway { TFuture AlterColumnTable(const TString& cluster, const NYql::TAlterColumnTableSettings& settings) override { - using TRequest = TEvTxUserProxy::TEvProposeTransaction; - - try { - if (!CheckCluster(cluster)) { - return InvalidCluster(cluster); - } - - std::pair pathPair; - { - TString error; - if (!GetPathPair(settings.Table, pathPair, error, false)) { - return MakeFuture(ResultFromError(error)); - } - } - - auto ev = MakeHolder(); - ev->Record.SetDatabaseName(Database); - if (UserToken) { - ev->Record.SetUserToken(UserToken->GetSerializedToken()); - } - auto& schemeTx = *ev->Record.MutableTransaction()->MutableModifyScheme(); - schemeTx.SetWorkingDir(pathPair.first); - - schemeTx.SetOperationType(NKikimrSchemeOp::ESchemeOpAlterColumnTable); - NKikimrSchemeOp::TAlterColumnTable* alter = schemeTx.MutableAlterColumnTable(); - alter->SetName(settings.Table); - - return SendSchemeRequest(ev.Release()); - } - catch (yexception& e) { - return MakeFuture(ResultFromException(e)); - } + Y_UNUSED(cluster); + Y_UNUSED(settings); + return NotImplemented(); } TFuture CreateTableStore(const TString& cluster, - const NYql::TCreateTableStoreSettings& settings) override { - using TRequest = TEvTxUserProxy::TEvProposeTransaction; - - try { - if (!CheckCluster(cluster)) { - return InvalidCluster(cluster); - } - - std::pair pathPair; - { - TString error; - if (!GetPathPair(settings.TableStore, pathPair, error, false)) { - return MakeFuture(ResultFromError(error)); - } - } - - auto ev = MakeHolder(); - ev->Record.SetDatabaseName(Database); - if (UserToken) { - ev->Record.SetUserToken(UserToken->GetSerializedToken()); - } - auto& schemeTx = *ev->Record.MutableTransaction()->MutableModifyScheme(); - schemeTx.SetWorkingDir(pathPair.first); - - schemeTx.SetOperationType(NKikimrSchemeOp::ESchemeOpCreateColumnStore); - NKikimrSchemeOp::TColumnStoreDescription* storeDesc = schemeTx.MutableCreateColumnStore(); - storeDesc->SetName(pathPair.second); - storeDesc->SetColumnShardCount(settings.ShardsCount); - - NKikimrSchemeOp::TColumnTableSchemaPreset* schemaPreset = storeDesc->AddSchemaPresets(); - schemaPreset->SetName("default"); - FillColumnTableSchema(*schemaPreset->MutableSchema(), settings); - - return SendSchemeRequest(ev.Release()); - } - catch (yexception& e) { - return MakeFuture(ResultFromException(e)); - } + const NYql::TCreateTableStoreSettings& settings, + bool existingOk) override { + Y_UNUSED(cluster); + Y_UNUSED(settings); + Y_UNUSED(existingOk); + return NotImplemented(); } TFuture AlterTableStore(const TString& cluster, const NYql::TAlterTableStoreSettings& settings) override { - using TRequest = TEvTxUserProxy::TEvProposeTransaction; - - try { - if (!CheckCluster(cluster)) { - return InvalidCluster(cluster); - } - - std::pair pathPair; - { - TString error; - if (!GetPathPair(settings.TableStore, pathPair, error, false)) { - return MakeFuture(ResultFromError(error)); - } - } - - auto ev = MakeHolder(); - ev->Record.SetDatabaseName(Database); - if (UserToken) { - ev->Record.SetUserToken(UserToken->GetSerializedToken()); - } - auto& schemeTx = *ev->Record.MutableTransaction()->MutableModifyScheme(); - schemeTx.SetWorkingDir(pathPair.first); - - schemeTx.SetOperationType(NKikimrSchemeOp::ESchemeOpAlterColumnStore); - NKikimrSchemeOp::TAlterColumnStore* alter = schemeTx.MutableAlterColumnStore(); - alter->SetName(pathPair.second); - - return SendSchemeRequest(ev.Release()); - } - catch (yexception& e) { - return MakeFuture(ResultFromException(e)); - } + Y_UNUSED(cluster); + Y_UNUSED(settings); + return NotImplemented(); } TFuture DropTableStore(const TString& cluster, - const NYql::TDropTableStoreSettings& settings) override { - using TRequest = TEvTxUserProxy::TEvProposeTransaction; - - try { - if (!CheckCluster(cluster)) { - return InvalidCluster(cluster); - } - - std::pair pathPair; - { - TString error; - if (!GetPathPair(settings.TableStore, pathPair, error, false)) { - return MakeFuture(ResultFromError(error)); - } - } - - auto ev = MakeHolder(); - ev->Record.SetDatabaseName(Database); - if (UserToken) { - ev->Record.SetUserToken(UserToken->GetSerializedToken()); - } - auto& schemeTx = *ev->Record.MutableTransaction()->MutableModifyScheme(); - schemeTx.SetWorkingDir(pathPair.first); - - schemeTx.SetOperationType(NKikimrSchemeOp::ESchemeOpDropColumnStore); - NKikimrSchemeOp::TDrop* drop = schemeTx.MutableDrop(); - drop->SetName(pathPair.second); - return SendSchemeRequest(ev.Release()); - } - catch (yexception& e) { - return MakeFuture(ResultFromException(e)); - } + const NYql::TDropTableStoreSettings& settings, bool missingOk) override { + Y_UNUSED(cluster); + Y_UNUSED(settings); + Y_UNUSED(missingOk); + return NotImplemented(); } TFuture CreateExternalTable(const TString& cluster, @@ -2328,27 +2172,6 @@ class TKikimrIcGateway : public IKqpGateway { return result; } - template - static void FillColumnTableSchema(NKikimrSchemeOp::TColumnTableSchema& schema, const T& metadata) - { - Y_ENSURE(metadata.ColumnOrder.size() == metadata.Columns.size()); - for (const auto& name : metadata.ColumnOrder) { - auto columnIt = metadata.Columns.find(name); - Y_ENSURE(columnIt != metadata.Columns.end()); - - TOlapColumnDescription& columnDesc = *schema.AddColumns(); - columnDesc.SetName(columnIt->second.Name); - columnDesc.SetType(columnIt->second.Type); - columnDesc.SetNotNull(columnIt->second.NotNull); - } - - for (const auto& keyColumn : metadata.KeyColumnNames) { - schema.AddKeyColumnNames(keyColumn); - } - - schema.SetEngine(NKikimrSchemeOp::EColumnTableEngine::COLUMN_ENGINE_REPLACING_TIMESERIES); - } - static void FillParameters(TQueryData::TPtr params, ::google::protobuf::Map, Ydb::TypedValue>* output) { if (!params) { return; @@ -2358,59 +2181,6 @@ class TKikimrIcGateway : public IKqpGateway { output->insert(paramsMap.begin(), paramsMap.end()); } - static bool FillCreateColumnTableDesc(NYql::TKikimrTableMetadataPtr metadata, - NKikimrSchemeOp::TColumnTableDescription& tableDesc, Ydb::StatusIds::StatusCode& code, TString& error) - { - if (metadata->Columns.empty()) { - tableDesc.SetSchemaPresetName("default"); - } - - auto& hashSharding = *tableDesc.MutableSharding()->MutableHashSharding(); - - for (const TString& column : metadata->TableSettings.PartitionBy) { - if (!metadata->Columns.count(column)) { - code = Ydb::StatusIds::BAD_REQUEST; - error = TStringBuilder() << "Unknown column '" << column << "' in partition by key"; - return false; - } - - hashSharding.AddColumns(column); - } - - if (metadata->TableSettings.PartitionByHashFunction) { - if (to_lower(metadata->TableSettings.PartitionByHashFunction.GetRef()) == "cloud_logs") { - hashSharding.SetFunction(NKikimrSchemeOp::TColumnTableSharding::THashSharding::HASH_FUNCTION_CLOUD_LOGS); - } else if (to_lower(metadata->TableSettings.PartitionByHashFunction.GetRef()) == "consistency_hash_64") { - hashSharding.SetFunction(NKikimrSchemeOp::TColumnTableSharding::THashSharding::HASH_FUNCTION_CONSISTENCY_64); - } else if (to_lower(metadata->TableSettings.PartitionByHashFunction.GetRef()) == "modulo_n") { - hashSharding.SetFunction(NKikimrSchemeOp::TColumnTableSharding::THashSharding::HASH_FUNCTION_MODULO_N); - } else { - code = Ydb::StatusIds::BAD_REQUEST; - error = TStringBuilder() << "Unknown hash function '" - << metadata->TableSettings.PartitionByHashFunction.GetRef() << "' to partition by"; - return false; - } - } else { - hashSharding.SetFunction(NKikimrSchemeOp::TColumnTableSharding::THashSharding::HASH_FUNCTION_CONSISTENCY_64); - } - - if (metadata->TableSettings.MinPartitions) { - tableDesc.SetColumnShardCount(*metadata->TableSettings.MinPartitions); - } - - if (metadata->TableSettings.TtlSettings.Defined() && metadata->TableSettings.TtlSettings.IsSet()) { - const auto& inputSettings = metadata->TableSettings.TtlSettings.GetValueSet(); - auto& resultSettings = *tableDesc.MutableTtlSettings(); - resultSettings.MutableEnabled()->SetColumnName(inputSettings.ColumnName); - resultSettings.MutableEnabled()->SetExpireAfterSeconds(inputSettings.ExpireAfter.Seconds()); - if (inputSettings.ColumnUnit) { - resultSettings.MutableEnabled()->SetColumnUnit(static_cast(*inputSettings.ColumnUnit)); - } - } - - return true; - } - private: TString Cluster; const NKikimrKqp::EQueryType QueryType; diff --git a/ydb/core/kqp/host/kqp_gateway_proxy.cpp b/ydb/core/kqp/host/kqp_gateway_proxy.cpp index c153f18b27a1..c545e7b62e23 100644 --- a/ydb/core/kqp/host/kqp_gateway_proxy.cpp +++ b/ydb/core/kqp/host/kqp_gateway_proxy.cpp @@ -354,6 +354,80 @@ bool FillCreateTableDesc(NYql::TKikimrTableMetadataPtr metadata, NKikimrSchemeOp return true; } +template +void FillColumnTableSchema(NKikimrSchemeOp::TColumnTableSchema& schema, const T& metadata) +{ + Y_ENSURE(metadata.ColumnOrder.size() == metadata.Columns.size()); + for (const auto& name : metadata.ColumnOrder) { + auto columnIt = metadata.Columns.find(name); + Y_ENSURE(columnIt != metadata.Columns.end()); + + NKikimrSchemeOp::TOlapColumnDescription& columnDesc = *schema.AddColumns(); + columnDesc.SetName(columnIt->second.Name); + columnDesc.SetType(columnIt->second.Type); + columnDesc.SetNotNull(columnIt->second.NotNull); + } + + for (const auto& keyColumn : metadata.KeyColumnNames) { + schema.AddKeyColumnNames(keyColumn); + } + + schema.SetEngine(NKikimrSchemeOp::EColumnTableEngine::COLUMN_ENGINE_REPLACING_TIMESERIES); +} + +bool FillCreateColumnTableDesc(NYql::TKikimrTableMetadataPtr metadata, + NKikimrSchemeOp::TColumnTableDescription& tableDesc, Ydb::StatusIds::StatusCode& code, TString& error) +{ + if (metadata->Columns.empty()) { + tableDesc.SetSchemaPresetName("default"); + } + + auto& hashSharding = *tableDesc.MutableSharding()->MutableHashSharding(); + + for (const TString& column : metadata->TableSettings.PartitionBy) { + if (!metadata->Columns.count(column)) { + code = Ydb::StatusIds::BAD_REQUEST; + error = TStringBuilder() << "Unknown column '" << column << "' in partition by key"; + return false; + } + + hashSharding.AddColumns(column); + } + + if (metadata->TableSettings.PartitionByHashFunction) { + if (to_lower(metadata->TableSettings.PartitionByHashFunction.GetRef()) == "cloud_logs") { + hashSharding.SetFunction(NKikimrSchemeOp::TColumnTableSharding::THashSharding::HASH_FUNCTION_CLOUD_LOGS); + } else if (to_lower(metadata->TableSettings.PartitionByHashFunction.GetRef()) == "consistency_hash_64") { + hashSharding.SetFunction(NKikimrSchemeOp::TColumnTableSharding::THashSharding::HASH_FUNCTION_CONSISTENCY_64); + } else if (to_lower(metadata->TableSettings.PartitionByHashFunction.GetRef()) == "modulo_n") { + hashSharding.SetFunction(NKikimrSchemeOp::TColumnTableSharding::THashSharding::HASH_FUNCTION_MODULO_N); + } else { + code = Ydb::StatusIds::BAD_REQUEST; + error = TStringBuilder() << "Unknown hash function '" + << metadata->TableSettings.PartitionByHashFunction.GetRef() << "' to partition by"; + return false; + } + } else { + hashSharding.SetFunction(NKikimrSchemeOp::TColumnTableSharding::THashSharding::HASH_FUNCTION_CONSISTENCY_64); + } + + if (metadata->TableSettings.MinPartitions) { + tableDesc.SetColumnShardCount(*metadata->TableSettings.MinPartitions); + } + + if (metadata->TableSettings.TtlSettings.Defined() && metadata->TableSettings.TtlSettings.IsSet()) { + const auto& inputSettings = metadata->TableSettings.TtlSettings.GetValueSet(); + auto& resultSettings = *tableDesc.MutableTtlSettings(); + resultSettings.MutableEnabled()->SetColumnName(inputSettings.ColumnName); + resultSettings.MutableEnabled()->SetExpireAfterSeconds(inputSettings.ExpireAfter.Seconds()); + if (inputSettings.ColumnUnit) { + resultSettings.MutableEnabled()->SetColumnUnit(static_cast(*inputSettings.ColumnUnit)); + } + } + + return true; +} + template static TFuture PrepareUnsupported(const char* name) { TResult result; @@ -1215,32 +1289,241 @@ class TKqpGatewayProxy : public IKikimrGateway { } } - TFuture CreateColumnTable(TKikimrTableMetadataPtr metadata, bool createDir) override { - FORWARD_ENSURE_NO_PREPARE(CreateColumnTable, metadata, createDir); + TFuture CreateColumnTable(TKikimrTableMetadataPtr metadata, + bool createDir, bool existingOk) override { + CHECK_PREPARED_DDL(CreateColumnTable); + + try { + const auto& cluster = metadata->Cluster; + + if (cluster != SessionCtx->GetCluster()) { + return MakeFuture(ResultFromError("Invalid cluster: " + cluster)); + } + + std::pair pathPair; + { + TString error; + if (!NSchemeHelpers::SplitTablePath(metadata->Name, GetDatabase(), pathPair, error, createDir)) { + return MakeFuture(ResultFromError(error)); + } + } + + NKikimrSchemeOp::TModifyScheme schemeTx; + schemeTx.SetWorkingDir(pathPair.first); + + Ydb::StatusIds::StatusCode code; + TString error; + + schemeTx.SetOperationType(NKikimrSchemeOp::ESchemeOpCreateColumnTable); + schemeTx.SetFailedOnAlreadyExists(!existingOk); + + NKikimrSchemeOp::TColumnTableDescription* tableDesc = schemeTx.MutableCreateColumnTable(); + + tableDesc->SetName(pathPair.second); + FillColumnTableSchema(*tableDesc->MutableSchema(), *metadata); + + if (!FillCreateColumnTableDesc(metadata, *tableDesc, code, error)) { + IKqpGateway::TGenericResult errResult; + errResult.AddIssue(NYql::TIssue(error)); + errResult.SetStatus(NYql::YqlStatusFromYdbStatus(code)); + return MakeFuture(std::move(errResult)); + } + + if (IsPrepare()) { + auto& phyQuery = *SessionCtx->Query().PreparingQuery->MutablePhysicalQuery(); + auto& phyTx = *phyQuery.AddTransactions(); + phyTx.SetType(NKqpProto::TKqpPhyTx::TYPE_SCHEME); + phyTx.MutableSchemeOperation()->MutableCreateTable()->Swap(&schemeTx); + + TGenericResult result; + result.SetSuccess(); + return MakeFuture(result); + } else { + return Gateway->ModifyScheme(std::move(schemeTx)); + } + } + catch (yexception& e) { + return MakeFuture(ResultFromException(e)); + } } TFuture AlterColumnTable(const TString& cluster, const TAlterColumnTableSettings& settings) override { - FORWARD_ENSURE_NO_PREPARE(AlterColumnTable, cluster, settings); + CHECK_PREPARED_DDL(AlterColumnTable); + + try { + if (cluster != SessionCtx->GetCluster()) { + return MakeFuture(ResultFromError("Invalid cluster: " + cluster)); + } + + std::pair pathPair; + { + TString error; + if (!NSchemeHelpers::SplitTablePath(settings.Table, GetDatabase(), pathPair, error, false)) { + return MakeFuture(ResultFromError(error)); + } + } + + NKikimrSchemeOp::TModifyScheme schemeTx; + schemeTx.SetWorkingDir(pathPair.first); + + schemeTx.SetOperationType(NKikimrSchemeOp::ESchemeOpAlterColumnTable); + NKikimrSchemeOp::TAlterColumnTable* alter = schemeTx.MutableAlterColumnTable(); + alter->SetName(settings.Table); + + if (IsPrepare()) { + auto& phyQuery = *SessionCtx->Query().PreparingQuery->MutablePhysicalQuery(); + auto& phyTx = *phyQuery.AddTransactions(); + phyTx.SetType(NKqpProto::TKqpPhyTx::TYPE_SCHEME); + phyTx.MutableSchemeOperation()->MutableAlterColumnTable()->Swap(&schemeTx); + + TGenericResult result; + result.SetSuccess(); + return MakeFuture(result); + } else { + return Gateway->ModifyScheme(std::move(schemeTx)); + } + } + catch (yexception& e) { + return MakeFuture(ResultFromException(e)); + } } TFuture CreateTableStore(const TString& cluster, - const TCreateTableStoreSettings& settings) override + const TCreateTableStoreSettings& settings, bool existingOk) override { - FORWARD_ENSURE_NO_PREPARE(CreateTableStore, cluster, settings); + CHECK_PREPARED_DDL(CreateTableStore); + + try { + if (cluster != SessionCtx->GetCluster()) { + return MakeFuture(ResultFromError("Invalid cluster: " + cluster)); + } + + std::pair pathPair; + { + TString error; + if (!NSchemeHelpers::SplitTablePath(settings.TableStore, GetDatabase(), pathPair, error, false)) { + return MakeFuture(ResultFromError(error)); + } + } + + NKikimrSchemeOp::TModifyScheme schemeTx; + schemeTx.SetWorkingDir(pathPair.first); + + schemeTx.SetOperationType(NKikimrSchemeOp::ESchemeOpCreateColumnStore); + schemeTx.SetFailedOnAlreadyExists(!existingOk); + + NKikimrSchemeOp::TColumnStoreDescription* storeDesc = schemeTx.MutableCreateColumnStore(); + storeDesc->SetName(pathPair.second); + storeDesc->SetColumnShardCount(settings.ShardsCount); + + NKikimrSchemeOp::TColumnTableSchemaPreset* schemaPreset = storeDesc->AddSchemaPresets(); + schemaPreset->SetName("default"); + FillColumnTableSchema(*schemaPreset->MutableSchema(), settings); + + if (IsPrepare()) { + auto& phyQuery = *SessionCtx->Query().PreparingQuery->MutablePhysicalQuery(); + auto& phyTx = *phyQuery.AddTransactions(); + phyTx.SetType(NKqpProto::TKqpPhyTx::TYPE_SCHEME); + phyTx.MutableSchemeOperation()->MutableCreateTableStore()->Swap(&schemeTx); + + TGenericResult result; + result.SetSuccess(); + return MakeFuture(result); + } else { + return Gateway->ModifyScheme(std::move(schemeTx)); + } + } + catch (yexception& e) { + return MakeFuture(ResultFromException(e)); + } } TFuture AlterTableStore(const TString& cluster, const TAlterTableStoreSettings& settings) override { - FORWARD_ENSURE_NO_PREPARE(AlterTableStore, cluster, settings); + CHECK_PREPARED_DDL(AlterTableStore); + + try { + if (cluster != SessionCtx->GetCluster()) { + return MakeFuture(ResultFromError("Invalid cluster: " + cluster)); + } + + std::pair pathPair; + { + TString error; + if (!NSchemeHelpers::SplitTablePath(settings.TableStore, GetDatabase(), pathPair, error, false)) { + return MakeFuture(ResultFromError(error)); + } + } + + NKikimrSchemeOp::TModifyScheme schemeTx; + schemeTx.SetWorkingDir(pathPair.first); + + schemeTx.SetOperationType(NKikimrSchemeOp::ESchemeOpAlterColumnStore); + NKikimrSchemeOp::TAlterColumnStore* alter = schemeTx.MutableAlterColumnStore(); + alter->SetName(pathPair.second); + + if (IsPrepare()) { + auto& phyQuery = *SessionCtx->Query().PreparingQuery->MutablePhysicalQuery(); + auto& phyTx = *phyQuery.AddTransactions(); + phyTx.SetType(NKqpProto::TKqpPhyTx::TYPE_SCHEME); + phyTx.MutableSchemeOperation()->MutableAlterTableStore()->Swap(&schemeTx); + + TGenericResult result; + result.SetSuccess(); + return MakeFuture(result); + } else { + return Gateway->ModifyScheme(std::move(schemeTx)); + } + } + catch (yexception& e) { + return MakeFuture(ResultFromException(e)); + } } TFuture DropTableStore(const TString& cluster, - const TDropTableStoreSettings& settings) override + const TDropTableStoreSettings& settings, bool missingOk) override { - FORWARD_ENSURE_NO_PREPARE(DropTableStore, cluster, settings); + CHECK_PREPARED_DDL(DropTableStore); + + try { + if (cluster != SessionCtx->GetCluster()) { + return MakeFuture(ResultFromError("Invalid cluster: " + cluster)); + } + + std::pair pathPair; + { + TString error; + if (!NSchemeHelpers::SplitTablePath(settings.TableStore, GetDatabase(), pathPair, error, false)) { + return MakeFuture(ResultFromError(error)); + } + } + + NKikimrSchemeOp::TModifyScheme schemeTx; + schemeTx.SetWorkingDir(pathPair.first); + schemeTx.SetSuccessOnNotExist(missingOk); + schemeTx.SetOperationType(NKikimrSchemeOp::ESchemeOpDropColumnStore); + NKikimrSchemeOp::TDrop* drop = schemeTx.MutableDrop(); + drop->SetName(pathPair.second); + + if (IsPrepare()) { + auto& phyQuery = *SessionCtx->Query().PreparingQuery->MutablePhysicalQuery(); + auto& phyTx = *phyQuery.AddTransactions(); + phyTx.SetType(NKqpProto::TKqpPhyTx::TYPE_SCHEME); + phyTx.MutableSchemeOperation()->MutableDropTableStore()->Swap(&schemeTx); + + TGenericResult result; + result.SetSuccess(); + return MakeFuture(result); + } else { + return Gateway->ModifyScheme(std::move(schemeTx)); + } + } + catch (yexception& e) { + return MakeFuture(ResultFromException(e)); + } } TFuture CreateExternalTable(const TString& cluster, const TCreateExternalTableSettings& settings, diff --git a/ydb/core/kqp/provider/yql_kikimr_exec.cpp b/ydb/core/kqp/provider/yql_kikimr_exec.cpp index 6940dc181627..cfb96efa16ab 100644 --- a/ydb/core/kqp/provider/yql_kikimr_exec.cpp +++ b/ydb/core/kqp/provider/yql_kikimr_exec.cpp @@ -948,12 +948,13 @@ class TKiSinkCallableExecutionTransformer : public TAsyncCallbackTransformerCreateTableStore(cluster, - ParseCreateTableStoreSettings(maybeCreate.Cast(), table.Metadata->TableSettings)); + ParseCreateTableStoreSettings(maybeCreate.Cast(), table.Metadata->TableSettings), existingOk); break; } case ETableType::Table: case ETableType::Unknown: { - future = isColumn ? Gateway->CreateColumnTable(table.Metadata, true) : Gateway->CreateTable(table.Metadata, true, existingOk); + future = isColumn ? Gateway->CreateColumnTable(table.Metadata, true, existingOk) + : Gateway->CreateTable(table.Metadata, true, existingOk); break; } } @@ -1017,7 +1018,7 @@ class TKiSinkCallableExecutionTransformer : public TAsyncCallbackTransformerDropTableStore(cluster, ParseDropTableStoreSettings(maybeDrop.Cast())); + future = Gateway->DropTableStore(cluster, ParseDropTableStoreSettings(maybeDrop.Cast()), missingOk); break; case ETableType::ExternalTable: future = Gateway->DropExternalTable(cluster, ParseDropExternalTableSettings(maybeDrop.Cast()), missingOk); diff --git a/ydb/core/kqp/provider/yql_kikimr_gateway.h b/ydb/core/kqp/provider/yql_kikimr_gateway.h index 8d79563400f0..ddd2d76e80d1 100644 --- a/ydb/core/kqp/provider/yql_kikimr_gateway.h +++ b/ydb/core/kqp/provider/yql_kikimr_gateway.h @@ -833,15 +833,18 @@ class IKikimrGateway : public TThrRefBase { virtual NThreading::TFuture DropGroup(const TString& cluster, const TDropGroupSettings& settings) = 0; - virtual NThreading::TFuture CreateColumnTable(TKikimrTableMetadataPtr metadata, bool createDir) = 0; + virtual NThreading::TFuture CreateColumnTable( + TKikimrTableMetadataPtr metadata, bool createDir, bool existingOk = false) = 0; virtual NThreading::TFuture AlterColumnTable(const TString& cluster, const TAlterColumnTableSettings& settings) = 0; - virtual NThreading::TFuture CreateTableStore(const TString& cluster, const TCreateTableStoreSettings& settings) = 0; + virtual NThreading::TFuture CreateTableStore(const TString& cluster, + const TCreateTableStoreSettings& settings, bool existingOk = false) = 0; virtual NThreading::TFuture AlterTableStore(const TString& cluster, const TAlterTableStoreSettings& settings) = 0; - virtual NThreading::TFuture DropTableStore(const TString& cluster, const TDropTableStoreSettings& settings) = 0; + virtual NThreading::TFuture DropTableStore(const TString& cluster, + const TDropTableStoreSettings& settings, bool missingOk) = 0; virtual NThreading::TFuture CreateExternalTable(const TString& cluster, const TCreateExternalTableSettings& settings, bool createDir, bool existingOk, bool replaceIfExists) = 0; diff --git a/ydb/core/kqp/ut/service/kqp_qs_queries_ut.cpp b/ydb/core/kqp/ut/service/kqp_qs_queries_ut.cpp index e6665f5947c7..506ddf7bd6d6 100644 --- a/ydb/core/kqp/ut/service/kqp_qs_queries_ut.cpp +++ b/ydb/core/kqp/ut/service/kqp_qs_queries_ut.cpp @@ -1,5 +1,7 @@ #include #include +#include +#include #include #include #include @@ -671,6 +673,146 @@ Y_UNIT_TEST_SUITE(KqpQueryService) { checkDrop(true, EEx::IfExists, 1); } + Y_UNIT_TEST(DdlColumnTable) { + const TVector schema = { + TTestHelper::TColumnSchema().SetName("Key").SetType(NScheme::NTypeIds::Uint64).SetNullable(false), + TTestHelper::TColumnSchema().SetName("Value").SetType(NScheme::NTypeIds::String) + }; + + NKikimrConfig::TAppConfig appConfig; + appConfig.MutableTableServiceConfig()->SetEnablePreparedDdl(true); + auto setting = NKikimrKqp::TKqpSetting(); + auto serverSettings = TKikimrSettings() + .SetAppConfig(appConfig) + .SetKqpSettings({setting}); + + TTestHelper testHelper(serverSettings); + auto& kikimr = testHelper.GetKikimr(); + + auto db = kikimr.GetQueryClient(); + + enum EEx { + Empty, + IfExists, + IfNotExists, + }; + + auto checkCreate = [&](bool expectSuccess, EEx exMode, const TString& objPath, bool isStore) { + UNIT_ASSERT_UNEQUAL(exMode, EEx::IfExists); + const TString ifNotExistsStatement = exMode == EEx::IfNotExists ? "IF NOT EXISTS" : ""; + const TString objType = isStore ? "TABLESTORE" : "TABLE"; + const TString hash = !isStore ? " PARTITION BY HASH(Key) " : ""; + auto sql = TStringBuilder() << R"( + --!syntax_v1 + CREATE )" << objType << " " << ifNotExistsStatement << " `" << objPath << R"(` ( + Key Uint64 NOT NULL, + Value String, + PRIMARY KEY (Key) + ))" << hash << R"( + WITH ( + STORE = COLUMN, + AUTO_PARTITIONING_MIN_PARTITIONS_COUNT = 10 + );)"; + + auto result = db.ExecuteQuery(sql, TTxControl::NoTx()).ExtractValueSync(); + if (expectSuccess) { + UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, result.GetIssues().ToString()); + } else { + UNIT_ASSERT_VALUES_UNEQUAL_C(result.GetStatus(), EStatus::SUCCESS, result.GetIssues().ToString()); + } + UNIT_ASSERT(result.GetResultSets().empty()); + }; + + auto checkAlter = [&](const TString& objPath, bool isStore) { + const TString objType = isStore ? "TABLESTORE" : "TABLE"; + { + auto sql = TStringBuilder() << R"( + --!syntax_v1 + ALTER )" << objType << " `" << objPath << R"(` + ADD COLUMN NewColumn Uint64; + ;)"; + + auto result = db.ExecuteQuery(sql, TTxControl::NoTx()).ExtractValueSync(); + UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, result.GetIssues().ToString()); + } + { + auto sql = TStringBuilder() << R"( + --!syntax_v1 + ALTER )" << objType << " `" << objPath << R"(` + DROP COLUMN NewColumn; + ;)"; + + auto result = db.ExecuteQuery(sql, TTxControl::NoTx()).ExtractValueSync(); + UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, result.GetIssues().ToString()); + } + }; + + auto checkDrop = [&](bool expectSuccess, EEx exMode, + const TString& objPath, bool isStore) { + UNIT_ASSERT_UNEQUAL(exMode, EEx::IfNotExists); + const TString ifExistsStatement = exMode == EEx::IfExists ? "IF EXISTS" : ""; + const TString objType = isStore ? "TABLESTORE" : "TABLE"; + auto sql = TStringBuilder() << R"( + --!syntax_v1 + DROP )" << objType << " " << ifExistsStatement << " `" << objPath << R"(`;)"; + + auto result = db.ExecuteQuery(sql, TTxControl::NoTx()).ExtractValueSync(); + if (expectSuccess) { + UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, result.GetIssues().ToString()); + } else { + UNIT_ASSERT_VALUES_UNEQUAL_C(result.GetStatus(), EStatus::SUCCESS, result.GetIssues().ToString()); + } + UNIT_ASSERT(result.GetResultSets().empty()); + }; + + auto checkAddRow = [&](const TString& objPath) { + const size_t inserted_rows = 5; + TTestHelper::TColumnTable testTable; + testTable.SetName(objPath) + .SetPrimaryKey({"Key"}) + .SetSharding({"Key"}) + .SetSchema(schema); + { + TTestHelper::TUpdatesBuilder tableInserter(testTable.GetArrowSchema(schema)); + for (size_t i = 0; i < inserted_rows; i++) { + tableInserter.AddRow().Add(i).Add("test_res_" + std::to_string(i)); + } + testHelper.BulkUpsert(testTable, tableInserter); + } + + Sleep(TDuration::Seconds(100)); + + auto sql = TStringBuilder() << R"( + SELECT Value FROM `)" << objPath << R"(` WHERE Key=1)"; + + testHelper.ReadData(sql, "[[[\"test_res_1\"]]]"); + }; + + checkCreate(true, EEx::Empty, "/Root/TableStoreTest", true); + checkCreate(false, EEx::Empty, "/Root/TableStoreTest", true); + checkCreate(true, EEx::IfNotExists, "/Root/TableStoreTest", true); + checkDrop(true, EEx::Empty, "/Root/TableStoreTest", true); + checkDrop(true, EEx::IfExists, "/Root/TableStoreTest", true); + checkDrop(false, EEx::Empty, "/Root/TableStoreTest", true); + + checkCreate(true, EEx::IfNotExists, "/Root/TableStoreTest", true); + checkCreate(false, EEx::Empty, "/Root/TableStoreTest", true); + checkDrop(true, EEx::IfExists, "/Root/TableStoreTest", true); + checkDrop(false, EEx::Empty, "/Root/TableStoreTest", true); + + checkCreate(true, EEx::IfNotExists, "/Root/ColumnTable", false); + checkAlter("/Root/ColumnTable", false); + checkDrop(true, EEx::IfExists, "/Root/ColumnTable", false); + + checkCreate(true, EEx::Empty, "/Root/ColumnTable", false); + checkCreate(false, EEx::Empty, "/Root/ColumnTable", false); + checkCreate(true, EEx::IfNotExists, "/Root/ColumnTable", false); + checkAddRow("/Root/ColumnTable"); + checkDrop(true, EEx::IfExists, "/Root/ColumnTable", false); + checkDrop(false, EEx::Empty, "/Root/ColumnTable", false); + checkDrop(true, EEx::IfExists, "/Root/ColumnTable", false); + } + Y_UNIT_TEST(DdlUser) { NKikimrConfig::TAppConfig appConfig; appConfig.MutableTableServiceConfig()->SetEnablePreparedDdl(true); diff --git a/ydb/core/protos/kqp_physical.proto b/ydb/core/protos/kqp_physical.proto index 53da436f29e6..7be29de58da6 100644 --- a/ydb/core/protos/kqp_physical.proto +++ b/ydb/core/protos/kqp_physical.proto @@ -430,6 +430,11 @@ message TKqpSchemeOperation { TKqpPhyMetadataOperation UpsertObject = 24; TKqpPhyMetadataOperation AlterObject = 25; TKqpPhyMetadataOperation DropObject = 26; + NKikimrSchemeOp.TModifyScheme CreateColumnTable = 27; + NKikimrSchemeOp.TModifyScheme AlterColumnTable = 28; + NKikimrSchemeOp.TModifyScheme CreateTableStore = 29; + NKikimrSchemeOp.TModifyScheme DropTableStore = 30; + NKikimrSchemeOp.TModifyScheme AlterTableStore = 31; } } From 08d5b07a418de07563a24d9861ba9c03541f58f2 Mon Sep 17 00:00:00 2001 From: Nikolay Shumkov <153636981+shnikd@users.noreply.github.com> Date: Wed, 21 Feb 2024 21:44:25 +0300 Subject: [PATCH 033/117] Support temp tables in yql (#2141) --- ydb/core/kqp/ut/service/kqp_qs_queries_ut.cpp | 131 ++++++++++++++++++ ydb/library/yql/sql/v1/SQLv1.g.in | 2 +- .../yql/sql/v1/format/sql_format_ut.cpp | 4 +- ydb/library/yql/sql/v1/node.h | 1 + ydb/library/yql/sql/v1/query.cpp | 4 + ydb/library/yql/sql/v1/sql_query.cpp | 6 +- ydb/library/yql/sql/v1/sql_ut.cpp | 34 +++++ 7 files changed, 179 insertions(+), 3 deletions(-) diff --git a/ydb/core/kqp/ut/service/kqp_qs_queries_ut.cpp b/ydb/core/kqp/ut/service/kqp_qs_queries_ut.cpp index 506ddf7bd6d6..dbcc2dcf8b09 100644 --- a/ydb/core/kqp/ut/service/kqp_qs_queries_ut.cpp +++ b/ydb/core/kqp/ut/service/kqp_qs_queries_ut.cpp @@ -860,6 +860,137 @@ Y_UNIT_TEST_SUITE(KqpQueryService) { UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, result.GetIssues().ToString()); } + Y_UNIT_TEST(CreateTempTable) { + NKikimrConfig::TAppConfig appConfig; + appConfig.MutableTableServiceConfig()->SetEnablePreparedDdl(true); + auto setting = NKikimrKqp::TKqpSetting(); + auto serverSettings = TKikimrSettings() + .SetAppConfig(appConfig) + .SetKqpSettings({setting}); + TKikimrRunner kikimr( + serverSettings.SetWithSampleTables(false).SetEnableTempTables(true)); + auto clientConfig = NGRpcProxy::TGRpcClientConfig(kikimr.GetEndpoint()); + auto client = kikimr.GetQueryClient(); + { + auto session = client.GetSession().GetValueSync().GetSession(); + auto id = session.GetId(); + + const auto queryCreate = Q_(R"( + --!syntax_v1 + CREATE TEMP TABLE Temp ( + Key Uint64 NOT NULL, + Value String, + PRIMARY KEY (Key) + );)"); + + auto resultCreate = session.ExecuteQuery(queryCreate, NYdb::NQuery::TTxControl::NoTx()).ExtractValueSync(); + UNIT_ASSERT_C(resultCreate.IsSuccess(), resultCreate.GetIssues().ToString()); + + const auto querySelect = Q_(R"( + --!syntax_v1 + SELECT * FROM Temp; + )"); + + auto resultSelect = session.ExecuteQuery( + querySelect, NYdb::NQuery::TTxControl::BeginTx().CommitTx()).ExtractValueSync(); + UNIT_ASSERT_C(resultSelect.IsSuccess(), resultSelect.GetIssues().ToString()); + + bool allDoneOk = true; + NTestHelpers::CheckDelete(clientConfig, id, Ydb::StatusIds::SUCCESS, allDoneOk); + + UNIT_ASSERT(allDoneOk); + } + + { + const auto querySelect = Q_(R"( + --!syntax_v1 + SELECT * FROM Temp; + )"); + + auto resultSelect = client.ExecuteQuery( + querySelect, NYdb::NQuery::TTxControl::BeginTx().CommitTx()).ExtractValueSync(); + UNIT_ASSERT(!resultSelect.IsSuccess()); + } + } + + Y_UNIT_TEST(TempTablesDrop) { + NKikimrConfig::TAppConfig appConfig; + appConfig.MutableTableServiceConfig()->SetEnablePreparedDdl(true); + auto setting = NKikimrKqp::TKqpSetting(); + auto serverSettings = TKikimrSettings() + .SetAppConfig(appConfig) + .SetKqpSettings({setting}); + TKikimrRunner kikimr( + serverSettings.SetWithSampleTables(false).SetEnableTempTables(true)); + auto clientConfig = NGRpcProxy::TGRpcClientConfig(kikimr.GetEndpoint()); + auto client = kikimr.GetQueryClient(); + + auto session = client.GetSession().GetValueSync().GetSession(); + auto id = session.GetId(); + + const auto queryCreate = Q_(R"( + --!syntax_v1 + CREATE TEMPORARY TABLE Temp ( + Key Uint64 NOT NULL, + Value String, + PRIMARY KEY (Key) + );)"); + + auto resultCreate = session.ExecuteQuery(queryCreate, NYdb::NQuery::TTxControl::NoTx()).ExtractValueSync(); + UNIT_ASSERT_C(resultCreate.IsSuccess(), resultCreate.GetIssues().ToString()); + + { + const auto querySelect = Q_(R"( + --!syntax_v1 + SELECT * FROM Temp; + )"); + + auto resultSelect = session.ExecuteQuery( + querySelect, NYdb::NQuery::TTxControl::BeginTx().CommitTx()).ExtractValueSync(); + UNIT_ASSERT_C(resultSelect.IsSuccess(), resultSelect.GetIssues().ToString()); + } + + const auto queryDrop = Q_(R"( + --!syntax_v1 + DROP TABLE Temp; + )"); + + auto resultDrop = session.ExecuteQuery( + queryDrop, NYdb::NQuery::TTxControl::NoTx()).ExtractValueSync(); + UNIT_ASSERT_C(resultDrop.IsSuccess(), resultDrop.GetIssues().ToString()); + + { + const auto querySelect = Q_(R"( + --!syntax_v1 + SELECT * FROM Temp; + )"); + + auto resultSelect = session.ExecuteQuery( + querySelect, NYdb::NQuery::TTxControl::BeginTx().CommitTx()).ExtractValueSync(); + UNIT_ASSERT(!resultSelect.IsSuccess()); + } + + bool allDoneOk = true; + NTestHelpers::CheckDelete(clientConfig, id, Ydb::StatusIds::SUCCESS, allDoneOk); + + UNIT_ASSERT(allDoneOk); + + auto sessionAnother = client.GetSession().GetValueSync().GetSession(); + auto idAnother = sessionAnother.GetId(); + UNIT_ASSERT(id != idAnother); + + { + const auto querySelect = Q_(R"( + --!syntax_v1 + SELECT * FROM Temp; + )"); + + auto resultSelect = sessionAnother.ExecuteQuery( + querySelect, NYdb::NQuery::TTxControl::BeginTx().CommitTx()).ExtractValueSync(); + UNIT_ASSERT(!resultSelect.IsSuccess()); + } + } + Y_UNIT_TEST(DdlGroup) { NKikimrConfig::TAppConfig appConfig; appConfig.MutableTableServiceConfig()->SetEnablePreparedDdl(true); diff --git a/ydb/library/yql/sql/v1/SQLv1.g.in b/ydb/library/yql/sql/v1/SQLv1.g.in index 9be5921ef070..e58e33c584b5 100644 --- a/ydb/library/yql/sql/v1/SQLv1.g.in +++ b/ydb/library/yql/sql/v1/SQLv1.g.in @@ -623,7 +623,7 @@ object_features: object_feature | LPAREN object_feature (COMMA object_feature)* object_type_ref: an_id_or_type; -create_table_stmt: CREATE (OR REPLACE)? (TABLE | TABLESTORE | EXTERNAL TABLE) (IF NOT EXISTS)? simple_table_ref LPAREN create_table_entry (COMMA create_table_entry)* COMMA? RPAREN +create_table_stmt: CREATE (OR REPLACE)? (TABLE | TABLESTORE | EXTERNAL TABLE | TEMP TABLE | TEMPORARY TABLE) (IF NOT EXISTS)? simple_table_ref LPAREN create_table_entry (COMMA create_table_entry)* COMMA? RPAREN table_inherits? table_partition_by? with_table_settings? diff --git a/ydb/library/yql/sql/v1/format/sql_format_ut.cpp b/ydb/library/yql/sql/v1/format/sql_format_ut.cpp index cef8e235cc83..4952be3413b0 100644 --- a/ydb/library/yql/sql/v1/format/sql_format_ut.cpp +++ b/ydb/library/yql/sql/v1/format/sql_format_ut.cpp @@ -307,7 +307,9 @@ Y_UNIT_TEST_SUITE(CheckSqlFormatter) { ")\n" "PARTITION BY HASH (a, b, hash)\n" "WITH (tiering = 'some');\n"}, - {"create table if not exists user(user int32)", "CREATE TABLE IF NOT EXISTS user (\n\tuser int32\n);\n"} + {"create table if not exists user(user int32)", "CREATE TABLE IF NOT EXISTS user (\n\tuser int32\n);\n"}, + {"create temp table user(user int32)", "CREATE TEMP TABLE user (\n\tuser int32\n);\n"}, + {"create temporary table user(user int32)", "CREATE TEMPORARY TABLE user (\n\tuser int32\n);\n"} }; TSetup setup; diff --git a/ydb/library/yql/sql/v1/node.h b/ydb/library/yql/sql/v1/node.h index 8bb0ba2030bd..26c0d1d30aff 100644 --- a/ydb/library/yql/sql/v1/node.h +++ b/ydb/library/yql/sql/v1/node.h @@ -1046,6 +1046,7 @@ namespace NSQLTranslationV1 { TVector Changefeeds; TTableSettings TableSettings; ETableType TableType = ETableType::Table; + bool Temporary = false; }; struct TAlterTableParameters { diff --git a/ydb/library/yql/sql/v1/query.cpp b/ydb/library/yql/sql/v1/query.cpp index 4ea558ead15c..a9185ddf3413 100644 --- a/ydb/library/yql/sql/v1/query.cpp +++ b/ydb/library/yql/sql/v1/query.cpp @@ -1140,6 +1140,10 @@ class TCreateTableNode final: public TAstListNode { break; } + if (Params.Temporary) { + opts = L(opts, Q(Y(Q("temporary")))); + } + Add("block", Q(Y( Y("let", "sink", Y("DataSink", BuildQuotedAtom(Pos, Table.Service), Scoped->WrapCluster(Table.Cluster, ctx))), Y("let", "world", Y(TString(WriteName), "world", "sink", keys, Y("Void"), Q(opts))), diff --git a/ydb/library/yql/sql/v1/sql_query.cpp b/ydb/library/yql/sql/v1/sql_query.cpp index 79f9c3469644..ac6859afeb34 100644 --- a/ydb/library/yql/sql/v1/sql_query.cpp +++ b/ydb/library/yql/sql/v1/sql_query.cpp @@ -166,10 +166,14 @@ bool TSqlQuery::Statement(TVector& blocks, const TRule_sql_stmt_core& const auto& block = rule.GetBlock3(); ETableType tableType = ETableType::Table; + bool temporary = false; if (block.HasAlt2() && block.GetAlt2().GetToken1().GetId() == SQLv1LexerTokens::TOKEN_TABLESTORE) { tableType = ETableType::TableStore; } else if (block.HasAlt3() && block.GetAlt3().GetToken1().GetId() == SQLv1LexerTokens::TOKEN_EXTERNAL) { tableType = ETableType::ExternalTable; + } else if (block.HasAlt4() && block.GetAlt4().GetToken1().GetId() == SQLv1LexerTokens::TOKEN_TEMP || + block.HasAlt5() && block.GetAlt5().GetToken1().GetId() == SQLv1LexerTokens::TOKEN_TEMPORARY) { + temporary = true; } bool existingOk = false; @@ -193,7 +197,7 @@ bool TSqlQuery::Statement(TVector& blocks, const TRule_sql_stmt_core& return false; } - TCreateTableParameters params{.TableType=tableType}; + TCreateTableParameters params{.TableType=tableType, .Temporary=temporary}; if (!CreateTableEntry(rule.GetRule_create_table_entry7(), params)) { return false; } diff --git a/ydb/library/yql/sql/v1/sql_ut.cpp b/ydb/library/yql/sql/v1/sql_ut.cpp index 6da68c791bf7..ee7420fcef41 100644 --- a/ydb/library/yql/sql/v1/sql_ut.cpp +++ b/ydb/library/yql/sql/v1/sql_ut.cpp @@ -1007,6 +1007,40 @@ Y_UNIT_TEST_SUITE(SqlParsingOnly) { UNIT_ASSERT_VALUES_EQUAL(1, elementStat["Write!"]); } + Y_UNIT_TEST(CreateTempTable) { + NYql::TAstParseResult res = SqlToYql("USE plato; CREATE TEMP TABLE t (a int32, primary key(a));"); + UNIT_ASSERT(res.Root); + + TVerifyLineFunc verifyLine = [](const TString& word, const TString& line) { + if (word == "Write!") { + UNIT_ASSERT_VALUES_UNEQUAL_C(TString::npos, + line.find(R"__((Write! world sink (Key '('tablescheme (String '"t"))) (Void) '('('mode 'create) '('columns '('('"a" (AsOptionalType (DataType 'Int32)) '('columnConstrains '()) '()))) '('primarykey '('"a")) '('temporary))))__"), line); + } + }; + + TWordCountHive elementStat = {{TString("Write!"), 0}}; + VerifyProgram(res, elementStat, verifyLine); + + UNIT_ASSERT_VALUES_EQUAL(1, elementStat["Write!"]); + } + + Y_UNIT_TEST(CreateTemporaryTable) { + NYql::TAstParseResult res = SqlToYql("USE plato; CREATE TEMPORARY TABLE t (a int32, primary key(a));"); + UNIT_ASSERT(res.Root); + + TVerifyLineFunc verifyLine = [](const TString& word, const TString& line) { + if (word == "Write!") { + UNIT_ASSERT_VALUES_UNEQUAL_C(TString::npos, + line.find(R"__((Write! world sink (Key '('tablescheme (String '"t"))) (Void) '('('mode 'create) '('columns '('('"a" (AsOptionalType (DataType 'Int32)) '('columnConstrains '()) '()))) '('primarykey '('"a")) '('temporary))))__"), line); + } + }; + + TWordCountHive elementStat = {{TString("Write!"), 0}}; + VerifyProgram(res, elementStat, verifyLine); + + UNIT_ASSERT_VALUES_EQUAL(1, elementStat["Write!"]); + } + Y_UNIT_TEST(CreateTableDuplicatedPkColumnsFail) { NYql::TAstParseResult res = SqlToYql("USE plato; CREATE TABLE t (a int32 not null, primary key(a, a));"); UNIT_ASSERT(!res.Root); From 7d8916296ca7a800e4df36a0f1357712641e49a3 Mon Sep 17 00:00:00 2001 From: ivanmorozov333 <111685085+ivanmorozov333@users.noreply.github.com> Date: Thu, 22 Feb 2024 07:34:07 +0300 Subject: [PATCH 034/117] Stable-24-1 cs patch 2 (#2145) Co-authored-by: nsofya --- ydb/core/tx/columnshard/normalizer/abstract/abstract.h | 2 +- ydb/core/tx/columnshard/splitter/batch_slice.h | 6 +++++- 2 files changed, 6 insertions(+), 2 deletions(-) diff --git a/ydb/core/tx/columnshard/normalizer/abstract/abstract.h b/ydb/core/tx/columnshard/normalizer/abstract/abstract.h index 89e75a67e091..538e1a1d44f0 100644 --- a/ydb/core/tx/columnshard/normalizer/abstract/abstract.h +++ b/ydb/core/tx/columnshard/normalizer/abstract/abstract.h @@ -101,7 +101,7 @@ namespace NKikimr::NOlap { public: TNormalizationController(std::shared_ptr storagesManager, const std::shared_ptr& counters) : StoragesManager(storagesManager) - , TaskSubscription("CS:NORMALIZER", counters) {} + , TaskSubscription("CS::NORMALIZER", counters) {} const NOlap::NResourceBroker::NSubscribe::TTaskContext& GetTaskSubscription() const { return TaskSubscription; diff --git a/ydb/core/tx/columnshard/splitter/batch_slice.h b/ydb/core/tx/columnshard/splitter/batch_slice.h index a97a1e1770e7..0c0aca979feb 100644 --- a/ydb/core/tx/columnshard/splitter/batch_slice.h +++ b/ydb/core/tx/columnshard/splitter/batch_slice.h @@ -73,7 +73,11 @@ class TDefaultSchemaDetails: public ISchemaDetailInfo { } virtual std::optional GetColumnSerializationStats(const ui32 columnId) const override { - return Stats->GetColumnInfo(columnId); + auto stats = Stats->GetColumnInfo(columnId); + if (stats && stats->GetRecordsCount() != 0) { + return stats; + } + return std::nullopt; } virtual std::optional GetBatchSerializationStats(const std::shared_ptr& rb) const override { return Stats->GetStatsForRecordBatch(rb); From fd4ca58fbdc40d37063fe6ba46f14f80f3de6f0e Mon Sep 17 00:00:00 2001 From: Vitalii Gridnev Date: Thu, 22 Feb 2024 12:09:29 +0300 Subject: [PATCH 035/117] Merge default values for columns fixes and changes to stable 24 1 (#2140) Co-authored-by: Nikolay Shumkov <153636981+shnikd@users.noreply.github.com> --- ydb/core/kqp/common/kqp_resolve.h | 10 +- ydb/core/kqp/gateway/kqp_metadata_loader.cpp | 3 +- ydb/core/kqp/opt/kqp_opt_kql.cpp | 4 +- ydb/core/kqp/provider/yql_kikimr_datasink.cpp | 47 ++++- .../kqp/provider/yql_kikimr_expr_nodes.cpp | 2 +- ydb/core/kqp/provider/yql_kikimr_gateway.h | 6 +- ydb/core/kqp/provider/yql_kikimr_provider.cpp | 6 +- .../kqp/provider/yql_kikimr_provider_impl.h | 2 +- ydb/core/kqp/provider/yql_kikimr_type_ann.cpp | 63 +++++-- .../kqp/query_compiler/kqp_query_compiler.cpp | 1 + ydb/core/kqp/ut/pg/kqp_pg_ut.cpp | 43 +++++ ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp | 175 ++++++++++++++++++ ydb/core/protos/flat_scheme_op.proto | 3 + ydb/core/protos/flat_tx_scheme.proto | 1 + ydb/core/protos/kqp.proto | 3 + ydb/core/protos/kqp_physical.proto | 3 + ydb/core/tx/datashard/sys_tables.h | 4 +- ydb/core/tx/scheme_board/cache.cpp | 1 + ydb/core/tx/schemeshard/schemeshard__init.cpp | 9 +- .../tx/schemeshard/schemeshard__init_root.cpp | 3 +- ...eshard__operation_finalize_build_index.cpp | 18 ++ ...hemeshard__operation_upgrade_subdomain.cpp | 1 + .../schemeshard_build_index__progress.cpp | 5 +- ydb/core/tx/schemeshard/schemeshard_impl.cpp | 27 ++- ydb/core/tx/schemeshard/schemeshard_impl.h | 1 + .../tx/schemeshard/schemeshard_info_types.cpp | 1 + .../tx/schemeshard/schemeshard_info_types.h | 1 + .../schemeshard_path_describer.cpp | 4 +- ydb/core/tx/schemeshard/schemeshard_schema.h | 12 +- .../tx/schemeshard/ut_export/ut_export.cpp | 66 ++++++- .../tx/schemeshard/ut_restore/ut_restore.cpp | 148 +++++++++++++++ ydb/core/tx/sharding/unboxed_reader.h | 1 + ydb/core/ydb_convert/table_description.cpp | 61 +++++- ydb/library/yql/sql/pg/pg_sql.cpp | 4 +- .../yql/sql/pg/pg_sql_autoparam_ut.cpp | 40 ++-- .../yql/sql/settings/translation_settings.h | 3 +- ydb/public/api/protos/ydb_table.proto | 4 + .../flat_schemeshard.schema | 32 +++- 38 files changed, 741 insertions(+), 77 deletions(-) diff --git a/ydb/core/kqp/common/kqp_resolve.h b/ydb/core/kqp/common/kqp_resolve.h index 701e7d0dd95c..b8a36a6aa885 100644 --- a/ydb/core/kqp/common/kqp_resolve.h +++ b/ydb/core/kqp/common/kqp_resolve.h @@ -33,6 +33,7 @@ struct TTableConstInfo : public TAtomicRefCount { ETableKind TableKind = ETableKind::Unknown; THashMap Sequences; THashMap DefaultFromLiteral; + bool IsBuildInProgress = false; TTableConstInfo() {} TTableConstInfo(const TString& path) : Path(path) {} @@ -52,6 +53,7 @@ struct TTableConstInfo : public TAtomicRefCount { NPg::TypeDescFromPgTypeName(phyColumn.GetPgTypeName())); } column.NotNull = phyColumn.GetNotNull(); + column.IsBuildInProgress = phyColumn.GetIsBuildInProgress(); Columns.emplace(phyColumn.GetId().GetName(), std::move(column)); if (!phyColumn.GetDefaultFromSequence().empty()) { @@ -144,19 +146,19 @@ class TKqpTableKeys { const TMap& GetColumns() const { return TableConstInfo->Columns; } - + const TVector& GetKeyColumns() const { return TableConstInfo->KeyColumns; } - + const TVector& GetKeyColumnTypes() const { return TableConstInfo->KeyColumnTypes; } - + const ETableKind& GetTableKind() const { return TableConstInfo->TableKind; } - + const THashMap& GetSequences() const { return TableConstInfo->Sequences; } diff --git a/ydb/core/kqp/gateway/kqp_metadata_loader.cpp b/ydb/core/kqp/gateway/kqp_metadata_loader.cpp index 58a942d41246..cf0c76f3546d 100644 --- a/ydb/core/kqp/gateway/kqp_metadata_loader.cpp +++ b/ydb/core/kqp/gateway/kqp_metadata_loader.cpp @@ -192,7 +192,8 @@ TTableMetadataResult GetTableMetadataResult(const NSchemeCache::TSchemeCacheNavi columnDesc.Name, columnDesc.Id, typeName, notNull, columnDesc.PType, columnDesc.PTypeMod, columnDesc.DefaultFromSequence, defaultKind, - columnDesc.DefaultFromLiteral + columnDesc.DefaultFromLiteral, + columnDesc.IsBuildInProgress ) ); if (columnDesc.KeyOrder >= 0) { diff --git a/ydb/core/kqp/opt/kqp_opt_kql.cpp b/ydb/core/kqp/opt/kqp_opt_kql.cpp index 90db2d10ccc9..4aee267bfe23 100644 --- a/ydb/core/kqp/opt/kqp_opt_kql.cpp +++ b/ydb/core/kqp/opt/kqp_opt_kql.cpp @@ -445,7 +445,7 @@ TExprBase BuildRowsToDelete(const TKikimrTableDescription& tableData, bool withS const TPositionHandle pos, TExprContext& ctx, const TIntrusivePtr& kqpCtx) { const auto tableMeta = BuildTableMeta(tableData, pos, ctx); - const auto tableColumns = BuildColumnsList(tableData, pos, ctx, withSystemColumns); + const auto tableColumns = BuildColumnsList(tableData, pos, ctx, withSystemColumns, true /*ignoreWriteOnlyColumns*/); const auto allRows = BuildReadTable(tableColumns, pos, tableData, false, ctx, kqpCtx); @@ -517,7 +517,7 @@ TExprBase BuildDeleteTableWithIndex(const TKiDeleteTable& del, const TKikimrTabl TExprBase BuildRowsToUpdate(const TKikimrTableDescription& tableData, bool withSystemColumns, const TCoLambda& filter, const TPositionHandle pos, TExprContext& ctx, const TIntrusivePtr& kqpCtx) { - auto kqlReadTable = BuildReadTable(BuildColumnsList(tableData, pos, ctx, withSystemColumns), pos, tableData, false, ctx, kqpCtx); + auto kqlReadTable = BuildReadTable(BuildColumnsList(tableData, pos, ctx, withSystemColumns, true /*ignoreWriteOnlyColumns*/), pos, tableData, false, ctx, kqpCtx); return Build(ctx, pos) .Input(kqlReadTable) diff --git a/ydb/core/kqp/provider/yql_kikimr_datasink.cpp b/ydb/core/kqp/provider/yql_kikimr_datasink.cpp index 9c6243f35c64..b035743a5a31 100644 --- a/ydb/core/kqp/provider/yql_kikimr_datasink.cpp +++ b/ydb/core/kqp/provider/yql_kikimr_datasink.cpp @@ -671,7 +671,7 @@ class TKikimrDataSink : public TDataProviderBase TString(dataSink.Cluster()), key.GetTablePath(), node->Pos(), ctx); - returningColumns = BuildColumnsList(*table, node->Pos(), ctx, sysColumnsEnabled); + returningColumns = BuildColumnsList(*table, node->Pos(), ctx, sysColumnsEnabled, true /*ignoreWriteOnlyColumns*/); break; } else { @@ -787,7 +787,7 @@ class TKikimrDataSink : public TDataProviderBase auto replaceIfExists = (settings.Mode.Cast().Value() == "create_or_replace"); auto existringOk = (settings.Mode.Cast().Value() == "create_if_not_exists"); - return Build(ctx, node->Pos()) + auto createTable = Build(ctx, node->Pos()) .World(node->Child(0)) .DataSink(node->Child(1)) .Table().Build(key.GetTablePath()) @@ -807,8 +807,47 @@ class TKikimrDataSink : public TDataProviderBase .ExistingOk() .Value(existringOk) .Build() - .Done() - .Ptr(); + .Done(); + + bool exprEvalNeeded = false; + + for(auto item: createTable.Cast().Columns()) { + auto columnTuple = item.Cast(); + if (columnTuple.Size() > 2) { + const auto& columnConstraints = columnTuple.Item(2).Cast(); + for(const auto& constraint: columnConstraints.Value().Cast()) { + if (constraint.Name().Value() != "default") + continue; + + YQL_ENSURE(constraint.Value().IsValid()); + bool shouldEvaluate = ( + constraint.Value().Cast().Ptr()->IsCallable() && + (constraint.Value().Cast().Ptr()->Content() == "PgCast") && + (constraint.Value().Cast().Ptr()->ChildrenSize() >= 1) && + (constraint.Value().Cast().Ptr()->Child(0)->IsCallable()) && + (constraint.Value().Cast().Ptr()->Child(0)->Content() == "PgConst") + ); + + if (shouldEvaluate) { + auto evaluatedExpr = ctx.Builder(constraint.Value().Cast().Ptr()->Pos()) + .Callable("EvaluateExpr") + .Add(0, constraint.Value().Cast().Ptr()) + .Seal() + .Build(); + + constraint.Ptr()->ChildRef(TCoNameValueTuple::idx_Value) = evaluatedExpr; + exprEvalNeeded = true; + } + } + } + } + + if (exprEvalNeeded) { + ctx.Step.Repeat(TExprStep::ExprEval); + } + + return createTable.Ptr(); + } else if (mode == "alter") { for (auto setting : settings.Other) { if (setting.Name().Value() == "intent") { diff --git a/ydb/core/kqp/provider/yql_kikimr_expr_nodes.cpp b/ydb/core/kqp/provider/yql_kikimr_expr_nodes.cpp index cbe44c3a9d84..1763f15e1f08 100644 --- a/ydb/core/kqp/provider/yql_kikimr_expr_nodes.cpp +++ b/ydb/core/kqp/provider/yql_kikimr_expr_nodes.cpp @@ -17,7 +17,7 @@ TCoAtomList TKiReadTable::GetSelectColumns(TExprContext& ctx, const TKikimrTable bool withSystemColumns) const { if (Select().Maybe()) { - return BuildColumnsList(tableData, Pos(), ctx, withSystemColumns); + return BuildColumnsList(tableData, Pos(), ctx, withSystemColumns, true /*ignoreWriteOnlyColumns*/); } return Select().Cast(); diff --git a/ydb/core/kqp/provider/yql_kikimr_gateway.h b/ydb/core/kqp/provider/yql_kikimr_gateway.h index ddd2d76e80d1..3c9b541eee70 100644 --- a/ydb/core/kqp/provider/yql_kikimr_gateway.h +++ b/ydb/core/kqp/provider/yql_kikimr_gateway.h @@ -215,13 +215,14 @@ struct TKikimrColumnMetadata { NKikimrKqp::TKqpColumnMetadataProto::EDefaultKind DefaultKind = NKikimrKqp::TKqpColumnMetadataProto::DEFAULT_KIND_UNSPECIFIED; TString DefaultFromSequence; Ydb::TypedValue DefaultFromLiteral; + bool IsBuildInProgress = false; TKikimrColumnMetadata() = default; TKikimrColumnMetadata(const TString& name, ui32 id, const TString& type, bool notNull, NKikimr::NScheme::TTypeInfo typeInfo = {}, const TString& typeMod = {}, const TString& defaultFromSequence = {}, NKikimrKqp::TKqpColumnMetadataProto::EDefaultKind defaultKind = NKikimrKqp::TKqpColumnMetadataProto::DEFAULT_KIND_UNSPECIFIED, - const Ydb::TypedValue& defaultFromLiteral = {}) + const Ydb::TypedValue& defaultFromLiteral = {}, bool isBuildInProgress = false) : Name(name) , Id(id) , Type(type) @@ -231,6 +232,7 @@ struct TKikimrColumnMetadata { , DefaultKind(defaultKind) , DefaultFromSequence(defaultFromSequence) , DefaultFromLiteral(defaultFromLiteral) + , IsBuildInProgress(isBuildInProgress) {} explicit TKikimrColumnMetadata(const NKikimrKqp::TKqpColumnMetadataProto* message) @@ -242,6 +244,7 @@ struct TKikimrColumnMetadata { , DefaultKind(message->GetDefaultKind()) , DefaultFromSequence(message->GetDefaultFromSequence()) , DefaultFromLiteral(message->GetDefaultFromLiteral()) + , IsBuildInProgress(message->GetIsBuildInProgress()) { auto typeInfoMod = NKikimr::NScheme::TypeInfoModFromProtoColumnType(message->GetTypeId(), message->HasTypeInfo() ? &message->GetTypeInfo() : nullptr); @@ -279,6 +282,7 @@ struct TKikimrColumnMetadata { message->SetDefaultFromSequence(DefaultFromSequence); message->SetDefaultKind(DefaultKind); message->MutableDefaultFromLiteral()->CopyFrom(DefaultFromLiteral); + message->SetIsBuildInProgress(IsBuildInProgress); if (columnType.TypeInfo) { *message->MutableTypeInfo() = *columnType.TypeInfo; } diff --git a/ydb/core/kqp/provider/yql_kikimr_provider.cpp b/ydb/core/kqp/provider/yql_kikimr_provider.cpp index 28965c15b825..bbc5a9f534f0 100644 --- a/ydb/core/kqp/provider/yql_kikimr_provider.cpp +++ b/ydb/core/kqp/provider/yql_kikimr_provider.cpp @@ -463,10 +463,14 @@ bool TKikimrKey::Extract(const TExprNode& key) { } TCoAtomList BuildColumnsList(const TKikimrTableDescription& table, TPositionHandle pos, - TExprContext& ctx, bool withSystemColumns) + TExprContext& ctx, bool withSystemColumns, bool ignoreWriteOnlyColumns) { TVector columnsToSelect; for (const auto& pair : table.Metadata->Columns) { + if (pair.second.IsBuildInProgress && ignoreWriteOnlyColumns) { + continue; + } + auto atom = Build(ctx, pos) .Value(pair.second.Name) .Done(); diff --git a/ydb/core/kqp/provider/yql_kikimr_provider_impl.h b/ydb/core/kqp/provider/yql_kikimr_provider_impl.h index 725c74d8465a..71781fd89c0a 100644 --- a/ydb/core/kqp/provider/yql_kikimr_provider_impl.h +++ b/ydb/core/kqp/provider/yql_kikimr_provider_impl.h @@ -209,7 +209,7 @@ TAutoPtr CreateKiSinkCallableExecutionTransformer( TAutoPtr CreateKiSinkPlanInfoTransformer(TIntrusivePtr queryExecutor); NNodes::TCoAtomList BuildColumnsList(const TKikimrTableDescription& table, TPositionHandle pos, - TExprContext& ctx, bool withSystemColumns); + TExprContext& ctx, bool withSystemColumns, bool ignoreWriteOnlyColumns); const TTypeAnnotationNode* GetReadTableRowType(TExprContext& ctx, const TKikimrTablesData& tablesData, const TString& cluster, const TString& table, NNodes::TCoAtomList select, bool withSystemColumns = false); diff --git a/ydb/core/kqp/provider/yql_kikimr_type_ann.cpp b/ydb/core/kqp/provider/yql_kikimr_type_ann.cpp index e2bbc5db7cb1..12eaf9cd1432 100644 --- a/ydb/core/kqp/provider/yql_kikimr_type_ann.cpp +++ b/ydb/core/kqp/provider/yql_kikimr_type_ann.cpp @@ -418,6 +418,13 @@ class TKiSinkTypeAnnotationTransformer : public TKiSinkVisitorTransformer THashSet generateColumnsIfInsertColumnsSet; for(const auto& [name, info] : table->Metadata->Columns) { + if (info.IsBuildInProgress && rowType->FindItem(name)) { + ctx.AddError(YqlIssue(pos, TIssuesIds::KIKIMR_BAD_REQUEST, TStringBuilder() + << "Column is under build operation, write operation is not allowed to column: " << name + << " for table: " << table->Metadata->Name)); + return TStatus::Error; + } + if (rowType->FindItem(name)) { continue; } @@ -431,7 +438,7 @@ class TKiSinkTypeAnnotationTransformer : public TKiSinkVisitorTransformer } if (info.IsDefaultKindDefined()) { - if (op == TYdbOperation::Upsert) { + if (op == TYdbOperation::Upsert && !info.IsBuildInProgress) { generateColumnsIfInsertColumnsSet.emplace(name); } @@ -625,6 +632,13 @@ class TKiSinkTypeAnnotationTransformer : public TKiSinkVisitorTransformer << "Column '" << item->GetName() << "' does not exist in table '" << node.Table().Value() << "'.")); return TStatus::Error; } + + if (column->IsBuildInProgress) { + ctx.AddError(YqlIssue(ctx.GetPosition(node.Pos()), TIssuesIds::KIKIMR_BAD_REQUEST, TStringBuilder() + << "Column '" << item->GetName() << "' is under the build operation '" << node.Table().Value() << "'.")); + return TStatus::Error; + } + if (column->NotNull && item->HasOptionalOrNull()) { if (item->GetItemType()->GetKind() == ETypeAnnotationKind::Pg) { //no type-level notnull check for pg types. @@ -636,6 +650,8 @@ class TKiSinkTypeAnnotationTransformer : public TKiSinkVisitorTransformer } } + + if (!node.ReturningColumns().Empty()) { ctx.AddError(TIssue(ctx.GetPosition(node.Pos()), TStringBuilder() << "It is not allowed to use returning")); @@ -808,7 +824,13 @@ virtual TStatus HandleCreateTable(TKiCreateTable create, TExprContext& ctx) over columnMeta.SetDefaultFromLiteral(); - if (auto pgConst = constraint.Value().Maybe()) { + YQL_ENSURE(constraint.Value().IsValid()); + const auto& constrValue = constraint.Value().Cast(); + bool isPgNull = constrValue.Ptr()->IsCallable() && + constrValue.Ptr()->Content() == "PgCast" && constrValue.Ptr()->ChildrenSize() >= 1 && + constrValue.Ptr()->Child(0)->IsCallable() && constrValue.Ptr()->Child(0)->Content() == "Null"; + + if (constrValue.Maybe() || isPgNull) { auto actualPgType = actualType->Cast(); YQL_ENSURE(actualPgType); @@ -819,25 +841,38 @@ virtual TStatus HandleCreateTable(TKiCreateTable create, TExprContext& ctx) over return TStatus::Error; } - TString content = TString(pgConst.Cast().Value().Value()); - auto parseResult = NKikimr::NPg::PgNativeBinaryFromNativeText(content, typeDesc); - if (parseResult.Error) { - ctx.AddError(TIssue(ctx.GetPosition(constraint.Pos()), - TStringBuilder() << "Failed to parse default expr for typename " << actualPgType->GetName() - << ", error reason: " << *parseResult.Error)); - return TStatus::Error; + if (isPgNull) { + if (columnMeta.NotNull) { + ctx.AddError(TIssue(ctx.GetPosition(constraint.Pos()), TStringBuilder() << "Default expr " << columnName + << " is nullable or optional, but column has not null constraint. ")); + return TStatus::Error; + } + + columnMeta.DefaultFromLiteral.mutable_value()->set_null_flag_value(NProtoBuf::NULL_VALUE); + + } else { + YQL_ENSURE(constrValue.Maybe()); + auto pgConst = constrValue.Cast(); + TString content = TString(pgConst.Value().Value()); + auto parseResult = NKikimr::NPg::PgNativeBinaryFromNativeText(content, typeDesc); + if (parseResult.Error) { + ctx.AddError(TIssue(ctx.GetPosition(constraint.Pos()), + TStringBuilder() << "Failed to parse default expr for typename " << actualPgType->GetName() + << ", error reason: " << *parseResult.Error)); + return TStatus::Error; + } + + columnMeta.DefaultFromLiteral.mutable_value()->set_bytes_value(parseResult.Str); } - columnMeta.DefaultFromLiteral.mutable_value()->set_bytes_value(parseResult.Str); auto* pg = columnMeta.DefaultFromLiteral.mutable_type()->mutable_pg_type(); - pg->set_type_name(NKikimr::NPg::PgTypeNameFromTypeDesc(typeDesc)); pg->set_oid(NKikimr::NPg::PgTypeIdFromTypeDesc(typeDesc)); - } else if (auto literal = constraint.Value().Maybe()) { - FillLiteralProto(constraint.Value().Cast(), columnMeta.DefaultFromLiteral); + } else if (auto literal = constrValue.Maybe()) { + FillLiteralProto(literal.Cast(), columnMeta.DefaultFromLiteral); } else { ctx.AddError(TIssue(ctx.GetPosition(constraint.Pos()), - TStringBuilder() << "Unsupported type of default value " << constraint.Value().Cast().Ptr()->Content())); + TStringBuilder() << "Unsupported type of default value")); return TStatus::Error; } diff --git a/ydb/core/kqp/query_compiler/kqp_query_compiler.cpp b/ydb/core/kqp/query_compiler/kqp_query_compiler.cpp index eb485955fd45..3e75c1b9ba42 100644 --- a/ydb/core/kqp/query_compiler/kqp_query_compiler.cpp +++ b/ydb/core/kqp/query_compiler/kqp_query_compiler.cpp @@ -174,6 +174,7 @@ void FillTable(const TKikimrTableMetadata& tableMeta, THashSet&& col phyColumn.MutableId()->SetId(column->Id); phyColumn.MutableId()->SetName(column->Name); phyColumn.SetTypeId(column->TypeInfo.GetTypeId()); + phyColumn.SetIsBuildInProgress(column->IsBuildInProgress); if (column->IsDefaultFromSequence()) { phyColumn.SetDefaultFromSequence(column->DefaultFromSequence); } else if (column->IsDefaultFromLiteral()) { diff --git a/ydb/core/kqp/ut/pg/kqp_pg_ut.cpp b/ydb/core/kqp/ut/pg/kqp_pg_ut.cpp index 86e34adf31d2..bffc9729ee24 100644 --- a/ydb/core/kqp/ut/pg/kqp_pg_ut.cpp +++ b/ydb/core/kqp/ut/pg/kqp_pg_ut.cpp @@ -3403,7 +3403,50 @@ Y_UNIT_TEST_SUITE(KqpPg) { )", FormatResultSetYson(result.GetResultSet(0))); } } +/* + Y_UNIT_TEST(InsertValuesFromTableWithDefaultAndCast) { + NKikimrConfig::TAppConfig appConfig; + appConfig.MutableTableServiceConfig()->SetEnablePreparedDdl(true); + auto setting = NKikimrKqp::TKqpSetting(); + auto serverSettings = TKikimrSettings() + .SetAppConfig(appConfig) + .SetKqpSettings({setting}); + TKikimrRunner kikimr(serverSettings.SetWithSampleTables(false)); + auto db = kikimr.GetQueryClient(); + auto settings = NYdb::NQuery::TExecuteQuerySettings().Syntax(NYdb::NQuery::ESyntax::Pg); + { + auto result = db.ExecuteQuery(R"( + CREATE TABLE t ( + a INT, + b int DEFAULT 5::int4, + c int DEFAULT '7'::int4, + d varchar(20) DEFAULT 'foo'::varchar(2), + e int DEFAULT NULL, + f bit varying(5) DEFAULT '1001', + PRIMARY KEY(a) + ); + )", NYdb::NQuery::TTxControl::NoTx(), settings).ExtractValueSync(); + UNIT_ASSERT_C(result.IsSuccess(), result.GetIssues().ToString()); + } + { + auto result = db.ExecuteQuery(R"( + INSERT INTO t VALUES(1); + )", NYdb::NQuery::TTxControl::BeginTx().CommitTx(), settings).ExtractValueSync(); + UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, result.GetIssues().ToString()); + } + { + auto result = db.ExecuteQuery(R"( + SELECT * FROM t; + )", NYdb::NQuery::TTxControl::BeginTx().CommitTx(), settings).ExtractValueSync(); + UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, result.GetIssues().ToString()); + UNIT_ASSERT_C(!result.GetResultSets().empty(), "results are empty"); + CompareYson(R"( + [["1";"5";"7";"fo";#;"1001"]] + )", FormatResultSetYson(result.GetResultSet(0))); + } + } +*/ Y_UNIT_TEST(InsertValuesFromTableWithDefaultBool) { NKikimrConfig::TAppConfig appConfig; appConfig.MutableTableServiceConfig()->SetEnablePreparedDdl(true); diff --git a/ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp b/ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp index d3326432c2d0..b2bad6ad8ac2 100644 --- a/ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp +++ b/ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp @@ -584,6 +584,181 @@ Y_UNIT_TEST_SUITE(KqpConstraints) { } + Y_UNIT_TEST(AddNonColumnDoesnotReturnInternalError) { + + NKikimrConfig::TAppConfig appConfig; + appConfig.MutableTableServiceConfig()->SetEnableSequences(false); + appConfig.MutableTableServiceConfig()->SetEnableColumnsWithDefault(true); + appConfig.MutableFeatureFlags()->SetEnableAddColumsWithDefaults(true); + + TKikimrRunner kikimr(TKikimrSettings().SetUseRealThreads(false).SetPQConfig(DefaultPQConfig()).SetAppConfig(appConfig)); + auto db = kikimr.RunCall([&] { return kikimr.GetTableClient(); } ); + auto session = kikimr.RunCall([&] { return db.CreateSession().GetValueSync().GetSession(); } ); + auto querySession = kikimr.RunCall([&] { return db.CreateSession().GetValueSync().GetSession(); } ); + + auto& runtime = *kikimr.GetTestServer().GetRuntime(); + + { + auto query = R"( + --!syntax_v1 + CREATE TABLE `/Root/AddNonColumnDoesnotReturnInternalError` ( + Key Uint32 NOT NULL, + Value String NOT NULL, + Value2 String NOT NULL DEFAULT "text", + PRIMARY KEY (Key) + ); + )"; + + auto result = kikimr.RunCall([&]{ return session.ExecuteSchemeQuery(query).GetValueSync(); }); + UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, + result.GetIssues().ToString()); + } + + auto fQuery = [&](TString query) -> TString { + NYdb::NTable::TExecDataQuerySettings execSettings; + execSettings.KeepInQueryCache(true); + execSettings.CollectQueryStats(ECollectQueryStatsMode::Basic); + + auto result = kikimr.RunCall([&] { + return querySession + .ExecuteDataQuery(query, TTxControl::BeginTx().CommitTx(), + execSettings) + .ExtractValueSync(); } ); + + if (result.GetStatus() == EStatus::SUCCESS) { + UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, + result.GetIssues().ToString()); + if (result.GetResultSets().size() > 0) + return NYdb::FormatResultSetYson(result.GetResultSet(0)); + return ""; + } else { + return TStringBuilder() << result.GetStatus() << ": " << result.GetIssues().ToString(); + } + }; + + fQuery(R"( + UPSERT INTO `/Root/AddNonColumnDoesnotReturnInternalError` (Key, Value) VALUES (1, "Old"); + )"); + + fQuery(R"( + UPDATE `/Root/AddNonColumnDoesnotReturnInternalError` SET Value2="Updated" WHERE Key=1; + )"); + + auto fCompareTable = [&](TString expected) { + TString query = R"( + SELECT * FROM `/Root/AddNonColumnDoesnotReturnInternalError` ORDER BY Key; + )"; + CompareYson(expected, fQuery(query)); + }; + + fCompareTable(R"( + [ + [1u;"Old";"Updated"] + ] + )"); + + auto alterQuery = R"( + --!syntax_v1 + ALTER TABLE `/Root/AddNonColumnDoesnotReturnInternalError` ADD COLUMN Value3 Int32 NOT NULL DEFAULT 7; + )"; + + bool enabledCapture = true; + TVector> delayedUpsertRows; + auto grab = [&delayedUpsertRows, &enabledCapture](TAutoPtr& ev) -> auto { + if (enabledCapture && ev->GetTypeRewrite() == NKikimr::TEvDataShard::TEvUploadRowsRequest::EventType) { + delayedUpsertRows.emplace_back(ev.Release()); + return TTestActorRuntime::EEventAction::DROP; + } + + return TTestActorRuntime::EEventAction::PROCESS; + }; + + TDispatchOptions opts; + opts.FinalEvents.emplace_back([&delayedUpsertRows](IEventHandle&) { + return delayedUpsertRows.size() > 0; + }); + + runtime.SetObserverFunc(grab); + + auto alterFuture = kikimr.RunInThreadPool([&] { return session.ExecuteSchemeQuery(alterQuery).GetValueSync(); }); + + runtime.DispatchEvents(opts); + Y_VERIFY_S(delayedUpsertRows.size() > 0, "no upload rows requests"); + + fQuery(R"( + UPSERT INTO `/Root/AddNonColumnDoesnotReturnInternalError` + (Key, Value) VALUES (2, "New"); + )"); + + fQuery(R"( + UPSERT INTO `/Root/AddNonColumnDoesnotReturnInternalError` + (Key, Value) VALUES (1, "Changed"); + )"); + + { + + TString result = fQuery(R"( + SELECT Key, Value2, Value3 FROM `/Root/AddNonColumnDoesnotReturnInternalError`; + )"); + + Cerr << result << Endl; + UNIT_ASSERT_STRING_CONTAINS(result, "GENERIC_ERROR"); + UNIT_ASSERT_STRING_CONTAINS(result, "Member not found: Value3. Did you mean Value"); + } + + { + TString result = fQuery(R"( + UPSERT INTO `/Root/AddNonColumnDoesnotReturnInternalError` + (Key, Value, Value2, Value3) VALUES (1, "4", "four", 1); + )"); + + Cerr << result << Endl; + UNIT_ASSERT_STRING_CONTAINS(result, "BAD_REQUEST"); + UNIT_ASSERT_STRING_CONTAINS(result, "is under build operation"); + } + + { + TString result = fQuery(R"( + UPDATE `/Root/AddNonColumnDoesnotReturnInternalError` SET Value3=1 WHERE Key=1; + )"); + + Cerr << result << Endl; + UNIT_ASSERT_STRING_CONTAINS(result, "BAD_REQUEST"); + UNIT_ASSERT_STRING_CONTAINS(result, "is under the build operation"); + } + + { + TString result = fQuery(R"( + DELETE FROM `/Root/AddNonColumnDoesnotReturnInternalError` WHERE Value3=7; + )"); + + Cerr << result << Endl; + UNIT_ASSERT_STRING_CONTAINS(result, "GENERIC_ERROR"); + UNIT_ASSERT_STRING_CONTAINS(result, "Member not found"); + } + + fCompareTable(R"( + [ + [1u;"Changed";"Updated"]; + [2u;"New";"text"] + ] + )"); + + enabledCapture = false; + for (const auto& ev: delayedUpsertRows) { + runtime.Send(ev); + } + + auto result = runtime.WaitFuture(alterFuture); + + fCompareTable(R"( + [ + [1u;"Changed";"Updated";7]; + [2u;"New";"text";7] + ] + )"); + } + Y_UNIT_TEST(IndexedTableAndNotNullColumnAddNotNullColumn) { NKikimrConfig::TAppConfig appConfig; diff --git a/ydb/core/protos/flat_scheme_op.proto b/ydb/core/protos/flat_scheme_op.proto index 895e1240cbdc..22f15326b990 100644 --- a/ydb/core/protos/flat_scheme_op.proto +++ b/ydb/core/protos/flat_scheme_op.proto @@ -89,6 +89,9 @@ message TColumnDescription { Ydb.TypedValue DefaultFromLiteral = 10; // Literal default value } optional bool NotNull = 8; + // flag that indicates that column is currently under the build + // operation. + optional bool IsBuildInProgress = 11 [default = false]; } message TStorageSettings { diff --git a/ydb/core/protos/flat_tx_scheme.proto b/ydb/core/protos/flat_tx_scheme.proto index 6972e9f44cae..0ee8122cd057 100644 --- a/ydb/core/protos/flat_tx_scheme.proto +++ b/ydb/core/protos/flat_tx_scheme.proto @@ -263,6 +263,7 @@ message TMigrateColumn { optional uint32 DefaultKind = 8; optional bytes DefaultValue = 9; optional bool NotNull = 10; + optional bool IsBuildInProgress = 12; } message TMigratePartition { diff --git a/ydb/core/protos/kqp.proto b/ydb/core/protos/kqp.proto index bcfc0f9f499f..37b7e8834450 100644 --- a/ydb/core/protos/kqp.proto +++ b/ydb/core/protos/kqp.proto @@ -144,6 +144,9 @@ message TKqpColumnMetadataProto { optional string DefaultFromSequence = 8; optional EDefaultKind DefaultKind = 9; optional Ydb.TypedValue DefaultFromLiteral = 10; + // flag that indicates that column is currently under the build + // operation. + optional bool IsBuildInProgress = 11 [default = false]; }; message TKqpTableMetadataProto { diff --git a/ydb/core/protos/kqp_physical.proto b/ydb/core/protos/kqp_physical.proto index 7be29de58da6..9ee7b069ed04 100644 --- a/ydb/core/protos/kqp_physical.proto +++ b/ydb/core/protos/kqp_physical.proto @@ -69,6 +69,9 @@ message TKqpPhyColumn { Ydb.TypedValue DefaultFromLiteral = 5; } bool NotNull = 6; + // flag that indicates that column is currently under the build + // operation. + optional bool IsBuildInProgress = 7; } enum EKqpPhyTableKind { diff --git a/ydb/core/tx/datashard/sys_tables.h b/ydb/core/tx/datashard/sys_tables.h index de3715000ffd..a1ac25c0a841 100644 --- a/ydb/core/tx/datashard/sys_tables.h +++ b/ydb/core/tx/datashard/sys_tables.h @@ -30,6 +30,7 @@ struct TSysTables { TString DefaultFromSequence; EDefaultKind DefaultKind; Ydb::TypedValue DefaultFromLiteral; + bool IsBuildInProgress = false; TTableColumnInfo() = default; @@ -53,7 +54,7 @@ struct TSysTables { const TString& typeMod = {}, i32 keyOrder = -1, const TString& defaultFromSequence = {}, EDefaultKind defaultKind = EDefaultKind::DEFAULT_UNDEFINED, - const Ydb::TypedValue& defaultFromLiteral = {}) + const Ydb::TypedValue& defaultFromLiteral = {}, bool isBuildInProgress = false) : Name(name) , Id(colId) , PType(type) @@ -62,6 +63,7 @@ struct TSysTables { , DefaultFromSequence(defaultFromSequence) , DefaultKind(defaultKind) , DefaultFromLiteral(defaultFromLiteral) + , IsBuildInProgress(isBuildInProgress) {} }; diff --git a/ydb/core/tx/scheme_board/cache.cpp b/ydb/core/tx/scheme_board/cache.cpp index c02f74e8f567..8692568da184 100644 --- a/ydb/core/tx/scheme_board/cache.cpp +++ b/ydb/core/tx/scheme_board/cache.cpp @@ -774,6 +774,7 @@ class TSchemeCache: public TMonitorableActor { columnDesc.HasTypeInfo() ? &columnDesc.GetTypeInfo() : nullptr); column.PType = typeInfoMod.TypeInfo; column.PTypeMod = typeInfoMod.TypeMod; + column.IsBuildInProgress = columnDesc.GetIsBuildInProgress(); if (columnDesc.HasDefaultFromSequence()) { column.SetDefaultFromSequence(); diff --git a/ydb/core/tx/schemeshard/schemeshard__init.cpp b/ydb/core/tx/schemeshard/schemeshard__init.cpp index df556221b43d..6e499e0676a0 100644 --- a/ydb/core/tx/schemeshard/schemeshard__init.cpp +++ b/ydb/core/tx/schemeshard/schemeshard__init.cpp @@ -358,7 +358,7 @@ struct TSchemeShard::TTxInit : public TTransactionBase { return true; } - typedef std::tuple TColumnRec; + typedef std::tuple TColumnRec; typedef TDeque TColumnRows; template @@ -385,7 +385,8 @@ struct TSchemeShard::TTxInit : public TTransactionBase { rowSet.template GetValueOrDefault(0), rowSet.template GetValue(), rowSet.template GetValue(), - rowSet.template GetValueOrDefault(false) + rowSet.template GetValueOrDefault(false), + rowSet.template GetValueOrDefault(false) ); } @@ -1934,6 +1935,7 @@ struct TSchemeShard::TTxInit : public TTransactionBase { auto defaultKind = std::get<9>(rec); auto defaultValue = std::get<10>(rec); auto notNull = std::get<11>(rec); + auto isBuildInProgress = std::get<12>(rec); Y_VERIFY_S(Self->PathsById.contains(pathId), "Path doesn't exist, pathId: " << pathId); Y_VERIFY_S(Self->PathsById.at(pathId)->IsTable() || Self->PathsById.at(pathId)->IsExternalTable(), "Path is not a table or external table, pathId: " << pathId); @@ -1947,6 +1949,7 @@ struct TSchemeShard::TTxInit : public TTransactionBase { colInfo.DefaultKind = defaultKind; colInfo.DefaultValue = defaultValue; colInfo.NotNull = notNull; + colInfo.IsBuildInProgress = isBuildInProgress; if (auto it = Self->Tables.find(pathId); it != Self->Tables.end()) { TTableInfo::TPtr tableInfo = it->second; @@ -1992,6 +1995,7 @@ struct TSchemeShard::TTxInit : public TTransactionBase { auto defaultKind = std::get<9>(rec); auto defaultValue = std::get<10>(rec); auto notNull = std::get<11>(rec); + auto isBuildInProgress = std::get<12>(rec); Y_VERIFY_S(Self->PathsById.contains(pathId), "Path doesn't exist, pathId: " << pathId); Y_VERIFY_S(Self->PathsById.at(pathId)->IsTable(), "Path is not a table, pathId: " << pathId); @@ -2012,6 +2016,7 @@ struct TSchemeShard::TTxInit : public TTransactionBase { colInfo.DefaultKind = defaultKind; colInfo.DefaultValue = defaultValue; colInfo.NotNull = notNull; + colInfo.IsBuildInProgress = isBuildInProgress; tableInfo->AlterData->Columns[colId] = colInfo; } } diff --git a/ydb/core/tx/schemeshard/schemeshard__init_root.cpp b/ydb/core/tx/schemeshard/schemeshard__init_root.cpp index 908784e3f2c7..2575fb98ec5a 100644 --- a/ydb/core/tx/schemeshard/schemeshard__init_root.cpp +++ b/ydb/core/tx/schemeshard/schemeshard__init_root.cpp @@ -706,7 +706,8 @@ struct TSchemeShard::TTxMigrate : public TSchemeShard::TRwTxBase { NIceDb::TUpdate(colDescr.GetFamily()), NIceDb::TUpdate(ETableColumnDefaultKind(colDescr.GetDefaultKind())), NIceDb::TUpdate(colDescr.GetDefaultValue()), - NIceDb::TUpdate(colDescr.GetNotNull())); + NIceDb::TUpdate(colDescr.GetNotNull()), + NIceDb::TUpdate(colDescr.GetIsBuildInProgress())); } for (const NKikimrScheme::TMigratePartition& partDescr: tableDescr.GetPartitions()) { diff --git a/ydb/core/tx/schemeshard/schemeshard__operation_finalize_build_index.cpp b/ydb/core/tx/schemeshard/schemeshard__operation_finalize_build_index.cpp index d14760f29d93..df9e154bf648 100644 --- a/ydb/core/tx/schemeshard/schemeshard__operation_finalize_build_index.cpp +++ b/ydb/core/tx/schemeshard/schemeshard__operation_finalize_build_index.cpp @@ -156,6 +156,24 @@ class TPropose: public TSubOperationState { const TTableInfo::TPtr tableInfo = context.SS->Tables.at(txState->TargetPathId); tableInfo->AlterVersion += 1; + + for(auto& column: tableInfo->Columns) { + if (column.second.IsDropped()) + continue; + + if (!column.second.IsBuildInProgress) + continue; + + LOG_INFO_S(context.Ctx, NKikimrServices::FLAT_TX_SCHEMESHARD, + DebugHint() << " HandleReply ProgressState" + << " at tablet: " << ssId + << " terminating build column process at column " + << column.second.Name); + + column.second.IsBuildInProgress = false; + context.SS->PersistTableFinishColumnBuilding(db, txState->TargetPathId, tableInfo, column.first); + } + context.SS->PersistTableAlterVersion(db, txState->TargetPathId, tableInfo); context.SS->TabletCounters->Simple()[COUNTER_SNAPSHOTS_COUNT].Sub(1); diff --git a/ydb/core/tx/schemeshard/schemeshard__operation_upgrade_subdomain.cpp b/ydb/core/tx/schemeshard/schemeshard__operation_upgrade_subdomain.cpp index 5a1a466e020a..0f958b237e8a 100644 --- a/ydb/core/tx/schemeshard/schemeshard__operation_upgrade_subdomain.cpp +++ b/ydb/core/tx/schemeshard/schemeshard__operation_upgrade_subdomain.cpp @@ -230,6 +230,7 @@ class TConfigure: public TSubOperationState { colDescr->SetDeleteVersion(column.DeleteVersion); colDescr->SetFamily(column.Family); colDescr->SetNotNull(column.NotNull); + colDescr->SetIsBuildInProgress(column.IsBuildInProgress); if (column.DefaultKind != ETableColumnDefaultKind::None) { colDescr->SetDefaultKind(ui32(column.DefaultKind)); colDescr->SetDefaultValue(column.DefaultValue); diff --git a/ydb/core/tx/schemeshard/schemeshard_build_index__progress.cpp b/ydb/core/tx/schemeshard/schemeshard_build_index__progress.cpp index 37c0a91e8cfa..08dbd2b9c593 100644 --- a/ydb/core/tx/schemeshard/schemeshard_build_index__progress.cpp +++ b/ydb/core/tx/schemeshard/schemeshard_build_index__progress.cpp @@ -98,6 +98,7 @@ THolder AlterMainTablePropose( col->SetType(NScheme::TypeName(typeInfo, typeMod)); col->SetName(colInfo.ColumnName); col->MutableDefaultFromLiteral()->CopyFrom(colInfo.DefaultFromLiteral); + col->SetIsBuildInProgress(true); if (!colInfo.FamilyName.empty()) { col->SetFamilyName(colInfo.FamilyName); @@ -1057,7 +1058,7 @@ struct TSchemeShard::TIndexBuilder::TTxReply: public TSchemeShard::TIndexBuilder } ReplyOnCreation(buildInfo, statusCode); - break; + break; } case TIndexBuildInfo::EState::Locking: @@ -1296,7 +1297,7 @@ struct TSchemeShard::TIndexBuilder::TTxReply: public TSchemeShard::TIndexBuilder buildInfo->AlterMainTableTxId = txId; NIceDb::TNiceDb db(txc.DB); Self->PersistBuildIndexAlterMainTableTxId(db, buildInfo); - + } break; diff --git a/ydb/core/tx/schemeshard/schemeshard_impl.cpp b/ydb/core/tx/schemeshard/schemeshard_impl.cpp index c55bca5942fe..fad1fc55ae99 100644 --- a/ydb/core/tx/schemeshard/schemeshard_impl.cpp +++ b/ydb/core/tx/schemeshard/schemeshard_impl.cpp @@ -2504,6 +2504,18 @@ void TSchemeShard::PersistTableAlterVersion(NIceDb::TNiceDb& db, const TPathId p } } +void TSchemeShard::PersistTableFinishColumnBuilding(NIceDb::TNiceDb& db, const TPathId pathId, const TTableInfo::TPtr tableInfo, ui64 colId) { + const auto& cinfo = tableInfo->Columns.at(colId); + if (pathId.OwnerId == TabletID()) { + db.Table().Key(pathId.LocalPathId, colId).Update( + NIceDb::TUpdate(cinfo.IsBuildInProgress)); + + } else { + db.Table().Key(pathId.OwnerId, pathId.LocalPathId, colId).Update( + NIceDb::TUpdate(cinfo.IsBuildInProgress)); + } +} + void TSchemeShard::PersistTableAltered(NIceDb::TNiceDb& db, const TPathId pathId, const TTableInfo::TPtr tableInfo) { TString partitionConfig; Y_PROTOBUF_SUPPRESS_NODISCARD tableInfo->PartitionConfig().SerializeToString(&partitionConfig); @@ -2562,7 +2574,8 @@ void TSchemeShard::PersistTableAltered(NIceDb::TNiceDb& db, const TPathId pathId NIceDb::TUpdate(cinfo.Family), NIceDb::TUpdate(cinfo.DefaultKind), NIceDb::TUpdate(cinfo.DefaultValue), - NIceDb::TUpdate(cinfo.NotNull)); + NIceDb::TUpdate(cinfo.NotNull), + NIceDb::TUpdate(cinfo.IsBuildInProgress)); db.Table().Key(pathId.LocalPathId, colId).Delete(); } else { @@ -2576,7 +2589,8 @@ void TSchemeShard::PersistTableAltered(NIceDb::TNiceDb& db, const TPathId pathId NIceDb::TUpdate(cinfo.Family), NIceDb::TUpdate(cinfo.DefaultKind), NIceDb::TUpdate(cinfo.DefaultValue), - NIceDb::TUpdate(cinfo.NotNull)); + NIceDb::TUpdate(cinfo.NotNull), + NIceDb::TUpdate(cinfo.IsBuildInProgress)); } db.Table().Key(pathId.OwnerId, pathId.LocalPathId, colId).Delete(); } @@ -2620,7 +2634,8 @@ void TSchemeShard::PersistAddAlterTable(NIceDb::TNiceDb& db, TPathId pathId, con NIceDb::TUpdate(cinfo.Family), NIceDb::TUpdate(cinfo.DefaultKind), NIceDb::TUpdate(cinfo.DefaultValue), - NIceDb::TUpdate(cinfo.NotNull)); + NIceDb::TUpdate(cinfo.NotNull), + NIceDb::TUpdate(cinfo.IsBuildInProgress)); } else { db.Table().Key(pathId.OwnerId, pathId.LocalPathId, colId).Update( NIceDb::TUpdate(cinfo.Name), @@ -2632,7 +2647,8 @@ void TSchemeShard::PersistAddAlterTable(NIceDb::TNiceDb& db, TPathId pathId, con NIceDb::TUpdate(cinfo.Family), NIceDb::TUpdate(cinfo.DefaultKind), NIceDb::TUpdate(cinfo.DefaultValue), - NIceDb::TUpdate(cinfo.NotNull)); + NIceDb::TUpdate(cinfo.NotNull), + NIceDb::TUpdate(cinfo.IsBuildInProgress)); } } } @@ -2771,7 +2787,8 @@ void TSchemeShard::PersistExternalTable(NIceDb::TNiceDb &db, TPathId pathId, con NIceDb::TUpdate(cinfo.Family), NIceDb::TUpdate(cinfo.DefaultKind), NIceDb::TUpdate(cinfo.DefaultValue), - NIceDb::TUpdate(cinfo.NotNull)); + NIceDb::TUpdate(cinfo.NotNull), + NIceDb::TUpdate(cinfo.IsBuildInProgress)); } } diff --git a/ydb/core/tx/schemeshard/schemeshard_impl.h b/ydb/core/tx/schemeshard/schemeshard_impl.h index 2c1a2e6db0b8..ae4a7e2c3151 100644 --- a/ydb/core/tx/schemeshard/schemeshard_impl.h +++ b/ydb/core/tx/schemeshard/schemeshard_impl.h @@ -649,6 +649,7 @@ class TSchemeShard void PersistTablePartitionStats(NIceDb::TNiceDb& db, const TPathId& tableId, const TTableInfo::TPtr tableInfo); void PersistTableCreated(NIceDb::TNiceDb& db, const TPathId tableId); void PersistTableAlterVersion(NIceDb::TNiceDb &db, const TPathId pathId, const TTableInfo::TPtr tableInfo); + void PersistTableFinishColumnBuilding(NIceDb::TNiceDb& db, const TPathId pathId, const TTableInfo::TPtr tableInfo, ui64 colId); void PersistTableAltered(NIceDb::TNiceDb &db, const TPathId pathId, const TTableInfo::TPtr tableInfo); void PersistAddAlterTable(NIceDb::TNiceDb& db, TPathId pathId, const TTableInfo::TAlterDataPtr alter); void PersistPersQueueGroup(NIceDb::TNiceDb &db, TPathId pathId, const TTopicInfo::TPtr); diff --git a/ydb/core/tx/schemeshard/schemeshard_info_types.cpp b/ydb/core/tx/schemeshard/schemeshard_info_types.cpp index 830b726d913a..fb0fdc3c3ba7 100644 --- a/ydb/core/tx/schemeshard/schemeshard_info_types.cpp +++ b/ydb/core/tx/schemeshard/schemeshard_info_types.cpp @@ -190,6 +190,7 @@ TTableInfo::TAlterDataPtr TTableInfo::CreateAlterData( TTableInfo::TColumn& column = alterData->Columns[colId]; column = TTableInfo::TColumn(colName, colId, typeInfo, typeMod, col.GetNotNull()); column.Family = columnFamily ? columnFamily->GetId() : 0; + column.IsBuildInProgress = col.GetIsBuildInProgress(); if (source) column.CreateVersion = alterData->AlterVersion; if (col.HasDefaultFromSequence()) { diff --git a/ydb/core/tx/schemeshard/schemeshard_info_types.h b/ydb/core/tx/schemeshard/schemeshard_info_types.h index 265d620a8201..d0c0e7a604f6 100644 --- a/ydb/core/tx/schemeshard/schemeshard_info_types.h +++ b/ydb/core/tx/schemeshard/schemeshard_info_types.h @@ -321,6 +321,7 @@ struct TTableInfo : public TSimpleRefCount { ui64 DeleteVersion; ETableColumnDefaultKind DefaultKind = ETableColumnDefaultKind::None; TString DefaultValue; + bool IsBuildInProgress = false; TColumn(const TString& name, ui32 id, NScheme::TTypeInfo type, const TString& typeMod, bool notNull) : NTable::TScheme::TColumn(name, id, type, typeMod, notNull) diff --git a/ydb/core/tx/schemeshard/schemeshard_path_describer.cpp b/ydb/core/tx/schemeshard/schemeshard_path_describer.cpp index 876fe8a7296b..943844615294 100644 --- a/ydb/core/tx/schemeshard/schemeshard_path_describer.cpp +++ b/ydb/core/tx/schemeshard/schemeshard_path_describer.cpp @@ -725,7 +725,7 @@ void TPathDescriber::DescribeDomainRoot(TPathElement::TPtr pathEl) { if (const auto& serverlessComputeResourcesMode = subDomainInfo->GetServerlessComputeResourcesMode()) { entry->SetServerlessComputeResourcesMode(*serverlessComputeResourcesMode); } - + if (TTabletId sharedHive = subDomainInfo->GetSharedHive()) { entry->SetSharedHive(sharedHive.GetValue()); } @@ -1119,6 +1119,8 @@ void TSchemeShard::DescribeTable(const TTableInfo::TPtr tableInfo, const NScheme } } + colDescr->SetIsBuildInProgress(cinfo.IsBuildInProgress); + switch (cinfo.DefaultKind) { case ETableColumnDefaultKind::None: break; diff --git a/ydb/core/tx/schemeshard/schemeshard_schema.h b/ydb/core/tx/schemeshard/schemeshard_schema.h index 929f8a4e07ae..8f6c4ef6281b 100644 --- a/ydb/core/tx/schemeshard/schemeshard_schema.h +++ b/ydb/core/tx/schemeshard/schemeshard_schema.h @@ -185,10 +185,11 @@ struct Schema : NIceDb::Schema { struct DefaultKind : Column<9, NScheme::NTypeIds::Uint32> { using Type = ETableColumnDefaultKind; static constexpr Type Default = Type::None; }; struct DefaultValue : Column<10, NScheme::NTypeIds::String> {}; struct NotNull : Column<11, NScheme::NTypeIds::Bool> {}; + struct IsBuildInProgress : Column<13, NScheme::NTypeIds::Bool> {}; using TKey = TableKey; using TColumns = TableColumns; + CreateVersion, DeleteVersion, Family, DefaultKind, DefaultValue, NotNull, ColTypeData, IsBuildInProgress>; }; struct MigratedColumns : Table<55> { @@ -206,10 +207,11 @@ struct Schema : NIceDb::Schema { struct DefaultKind : Column<10, NScheme::NTypeIds::Uint32> { using Type = ETableColumnDefaultKind; static constexpr Type Default = Type::None; }; struct DefaultValue : Column<11, NScheme::NTypeIds::String> {}; struct NotNull : Column<12, NScheme::NTypeIds::Bool> {}; + struct IsBuildInProgress : Column<14, NScheme::NTypeIds::Bool> {}; using TKey = TableKey; using TColumns = TableColumns; + CreateVersion, DeleteVersion, Family, DefaultKind, DefaultValue, NotNull, ColTypeData, IsBuildInProgress>; }; struct ColumnAlters : Table<13> { @@ -225,10 +227,11 @@ struct Schema : NIceDb::Schema { struct DefaultKind : Column<9, NScheme::NTypeIds::Uint32> { using Type = ETableColumnDefaultKind; static constexpr Type Default = Type::None; }; struct DefaultValue : Column<10, NScheme::NTypeIds::String> {}; struct NotNull : Column<11, NScheme::NTypeIds::Bool> {}; + struct IsBuildInProgress : Column<13, NScheme::NTypeIds::Bool> {}; using TKey = TableKey; using TColumns = TableColumns; + CreateVersion, DeleteVersion, Family, DefaultKind, DefaultValue, NotNull, ColTypeData, IsBuildInProgress>; }; struct MigratedColumnAlters : Table<63> { @@ -246,10 +249,11 @@ struct Schema : NIceDb::Schema { struct DefaultKind : Column<10, NScheme::NTypeIds::Uint32> { using Type = ETableColumnDefaultKind; static constexpr Type Default = Type::None; }; struct DefaultValue : Column<11, NScheme::NTypeIds::String> {}; struct NotNull : Column<12, NScheme::NTypeIds::Bool> {}; + struct IsBuildInProgress : Column<14, NScheme::NTypeIds::Bool> {}; using TKey = TableKey; using TColumns = TableColumns; + CreateVersion, DeleteVersion, Family, DefaultKind, DefaultValue, NotNull, ColTypeData, IsBuildInProgress>; }; struct Shards : Table<7> { diff --git a/ydb/core/tx/schemeshard/ut_export/ut_export.cpp b/ydb/core/tx/schemeshard/ut_export/ut_export.cpp index 67b7c2c204ce..ef35341e5769 100644 --- a/ydb/core/tx/schemeshard/ut_export/ut_export.cpp +++ b/ydb/core/tx/schemeshard/ut_export/ut_export.cpp @@ -281,8 +281,42 @@ Y_UNIT_TEST_SUITE(TExportToS3Tests) { const TVector tables = {R"( Name: "Table" - Columns { Name: "key" Type: "Utf8" } - Columns { Name: "value" Type: "Utf8" } + Columns { + Name: "key" + Type: "Utf8" + DefaultFromLiteral { + type { + optional_type { + item { + type_id: UTF8 + } + } + } + value { + items { + text_value: "b" + } + } + } + } + Columns { + Name: "value" + Type: "Utf8" + DefaultFromLiteral { + type { + optional_type { + item { + type_id: UTF8 + } + } + } + value { + items { + text_value: "a" + } + } + } + } KeyColumnNames: ["key"] PartitionConfig { ColumnFamilies { @@ -331,6 +365,20 @@ Y_UNIT_TEST_SUITE(TExportToS3Tests) { } } not_null: false + from_literal { + type { + optional_type { + item { + type_id: UTF8 + } + } + } + value { + items { + text_value: "b" + } + } + } } columns { name: "value" @@ -342,6 +390,20 @@ columns { } } not_null: false + from_literal { + type { + optional_type { + item { + type_id: UTF8 + } + } + } + value { + items { + text_value: "a" + } + } + } } primary_key: "key" storage_settings { diff --git a/ydb/core/tx/schemeshard/ut_restore/ut_restore.cpp b/ydb/core/tx/schemeshard/ut_restore/ut_restore.cpp index 4e8effd31bf9..f033b17d3ffc 100644 --- a/ydb/core/tx/schemeshard/ut_restore/ut_restore.cpp +++ b/ydb/core/tx/schemeshard/ut_restore/ut_restore.cpp @@ -373,6 +373,79 @@ Y_UNIT_TEST_SUITE(TRestoreTests) { NKqp::CompareYson(data.YsonStr, content); } + bool CheckDefaultFromLiteral(const NKikimrSchemeOp::TTableDescription& desc) { + for (const auto& column: desc.GetColumns()) { + if (column.GetName() == "value") { + switch (column.GetDefaultValueCase()) { + case NKikimrSchemeOp::TColumnDescription::kDefaultFromLiteral: { + const auto& fromLiteral = column.GetDefaultFromLiteral(); + + TString str; + google::protobuf::TextFormat::PrintToString(fromLiteral, &str); + + TString result = R"(type { + optional_type { + item { + type_id: UTF8 + } + } +} +value { + items { + text_value: "value1" + } +} +)"; + return str == result; + } + default: break; + } + break; + } + } + return false; + } + + Y_UNIT_TEST_WITH_COMPRESSION(ShouldSucceedWithDefaultFromLiteral) { + TTestBasicRuntime runtime; + + const auto data = GenerateTestData(Codec, "a", 1); + + Restore(runtime, R"( + Name: "Table" + Columns { Name: "key" Type: "Utf8" } + Columns { + Name: "value" + Type: "Utf8" + DefaultFromLiteral { + type { + optional_type { + item { + type_id: UTF8 + } + } + } + value { + items { + text_value: "value1" + } + } + } + } + KeyColumnNames: ["key"] + )", {data}); + + auto content = ReadTable(runtime, TTestTxConfig::FakeHiveTablets); + NKqp::CompareYson(data.YsonStr, content); + + const auto desc = DescribePath(runtime, "/MyRoot/Table", true, true); + UNIT_ASSERT_VALUES_EQUAL(desc.GetStatus(), NKikimrScheme::StatusSuccess); + + const auto& table = desc.GetPathDescription().GetTable(); + + UNIT_ASSERT_C(CheckDefaultFromLiteral(table), "Invalid default value"); + } + Y_UNIT_TEST_WITH_COMPRESSION(ShouldSucceedOnMultiShardTable) { TTestBasicRuntime runtime; @@ -729,6 +802,81 @@ Y_UNIT_TEST_SUITE(TRestoreTests) { TestGetImport(runtime, txId, "/MyRoot"); } + Y_UNIT_TEST(ShouldRestoreDefaultValuesFromLiteral) { + TPortManager portManager; + const ui16 port = portManager.GetPort(); + + TS3Mock s3Mock({}, TS3Mock::TSettings(port)); + UNIT_ASSERT(s3Mock.Start()); + + TTestBasicRuntime runtime; + TTestEnv env(runtime); + ui64 txId = 100; + + runtime.SetLogPriority(NKikimrServices::DATASHARD_BACKUP, NActors::NLog::PRI_TRACE); + runtime.SetLogPriority(NKikimrServices::DATASHARD_RESTORE, NActors::NLog::PRI_TRACE); + runtime.SetLogPriority(NKikimrServices::EXPORT, NActors::NLog::PRI_TRACE); + runtime.SetLogPriority(NKikimrServices::IMPORT, NActors::NLog::PRI_TRACE); + + TestCreateTable(runtime, ++txId, "/MyRoot", R"( + Name: "Original" + Columns { Name: "key" Type: "Utf8" } + Columns { + Name: "value" + Type: "Utf8" + DefaultFromLiteral { + type { + optional_type { + item { + type_id: UTF8 + } + } + } + value { + items { + text_value: "value1" + } + } + } + } + KeyColumnNames: ["key"] + )"); + env.TestWaitNotification(runtime, txId); + + TestExport(runtime, ++txId, "/MyRoot", Sprintf(R"( + ExportToS3Settings { + endpoint: "localhost:%d" + scheme: HTTP + items { + source_path: "/MyRoot/Original" + destination_prefix: "" + } + } + )", port)); + env.TestWaitNotification(runtime, txId); + TestGetExport(runtime, txId, "/MyRoot"); + + TestImport(runtime, ++txId, "/MyRoot", Sprintf(R"( + ImportFromS3Settings { + endpoint: "localhost:%d" + scheme: HTTP + items { + source_prefix: "" + destination_path: "/MyRoot/Restored" + } + } + )", port)); + env.TestWaitNotification(runtime, txId); + TestGetImport(runtime, txId, "/MyRoot"); + + const auto desc = DescribePath(runtime, "/MyRoot/Restored", true, true); + UNIT_ASSERT_VALUES_EQUAL(desc.GetStatus(), NKikimrScheme::StatusSuccess); + + const auto& table = desc.GetPathDescription().GetTable(); + + UNIT_ASSERT_C(CheckDefaultFromLiteral(table), "Invalid default value"); + } + Y_UNIT_TEST(ExportImportPg) { TTestBasicRuntime runtime; TTestEnv env(runtime, TTestEnvOptions().EnableTablePgTypes(true)); diff --git a/ydb/core/tx/sharding/unboxed_reader.h b/ydb/core/tx/sharding/unboxed_reader.h index e6c59a58db5d..fed3e972e2b9 100644 --- a/ydb/core/tx/sharding/unboxed_reader.h +++ b/ydb/core/tx/sharding/unboxed_reader.h @@ -17,6 +17,7 @@ struct TExternalTableColumn { NScheme::TTypeInfo Type; TString TypeMod; bool NotNull; + bool IsBuildInProgress = false; }; struct TColumnUnboxedPlaceInfo: public TExternalTableColumn { diff --git a/ydb/core/ydb_convert/table_description.cpp b/ydb/core/ydb_convert/table_description.cpp index ad283f387571..7912606b9214 100644 --- a/ydb/core/ydb_convert/table_description.cpp +++ b/ydb/core/ydb_convert/table_description.cpp @@ -151,11 +151,11 @@ bool BuildAlterTableAddIndexRequest(const Ydb::Table::AlterTableRequest* req, NK if (flags & NKqpProto::TKqpSchemeOperation::FLAG_PG_MODE) { settings->set_pg_mode(true); } - + if (flags & NKqpProto::TKqpSchemeOperation::FLAG_IF_NOT_EXISTS) { settings->set_if_not_exist(true); } - + settings->set_source_path(req->path()); auto tableIndex = settings->mutable_index(); tableIndex->CopyFrom(req->add_indexes(0)); @@ -390,6 +390,54 @@ static Ydb::Type* AddColumn(Ydb::Table::ColumnMeta* newColumn, const TColumn& co } } newColumn->set_not_null(column.GetNotNull()); + return columnType; +} + +template <> +Ydb::Type* AddColumn(Ydb::Table::ColumnMeta* newColumn, const NKikimrSchemeOp::TColumnDescription& column) { + newColumn->set_name(column.GetName()); + + Ydb::Type* columnType = nullptr; + auto* typeDesc = NPg::TypeDescFromPgTypeName(column.GetType()); + if (typeDesc) { + columnType = newColumn->mutable_type(); + auto* pg = columnType->mutable_pg_type(); + pg->set_type_name(NPg::PgTypeNameFromTypeDesc(typeDesc)); + pg->set_type_modifier(NPg::TypeModFromPgTypeName(column.GetType())); + pg->set_oid(NPg::PgTypeIdFromTypeDesc(typeDesc)); + pg->set_typlen(0); + pg->set_typmod(0); + } else { + NYql::NProto::TypeIds protoType; + if (!NYql::NProto::TypeIds_Parse(column.GetType(), &protoType)) { + throw NYql::TErrorException(NKikimrIssues::TIssuesIds::DEFAULT_ERROR) + << "Got invalid type: " << column.GetType() << " for column: " << column.GetName(); + } + + if (column.GetNotNull()) { + columnType = newColumn->mutable_type(); + } else { + columnType = newColumn->mutable_type()->mutable_optional_type()->mutable_item(); + } + Y_ENSURE(columnType); + if (protoType == NYql::NProto::TypeIds::Decimal) { + auto typeParams = columnType->mutable_decimal_type(); + // TODO: Change TEvDescribeSchemeResult to return decimal params + typeParams->set_precision(22); + typeParams->set_scale(9); + } else { + NMiniKQL::ExportPrimitiveTypeToProto(protoType, *columnType); + } + } + newColumn->set_not_null(column.GetNotNull()); + switch (column.GetDefaultValueCase()) { + case NKikimrSchemeOp::TColumnDescription::kDefaultFromLiteral: { + auto fromLiteral = newColumn->mutable_from_literal(); + *fromLiteral = column.GetDefaultFromLiteral(); + break; + } + default: break; + } return columnType; } @@ -607,6 +655,15 @@ bool FillColumnDescription(NKikimrSchemeOp::TTableDescription& out, if (!column.family().empty()) { cd->SetFamilyName(column.family()); } + + switch (column.default_value_case()) { + case Ydb::Table::ColumnMeta::kFromLiteral: { + auto fromLiteral = cd->MutableDefaultFromLiteral(); + *fromLiteral = column.from_literal(); + break; + } + default: break; + } } return true; diff --git a/ydb/library/yql/sql/pg/pg_sql.cpp b/ydb/library/yql/sql/pg/pg_sql.cpp index 723b77ab518d..013cd63ec3e1 100644 --- a/ydb/library/yql/sql/pg/pg_sql.cpp +++ b/ydb/library/yql/sql/pg/pg_sql.cpp @@ -222,6 +222,7 @@ class TConverter : public IPGParseEvents { bool AllowOver = false; bool AllowReturnSet = false; bool AllowSubLinks = false; + bool AutoParametrizeEnabled = true; TVector* WindowItems = nullptr; TString Scope; }; @@ -1702,6 +1703,7 @@ class TConverter : public IPGParseEvents { TExprSettings settings; settings.AllowColumns = false; settings.Scope = "DEFAULT"; + settings.AutoParametrizeEnabled = false; cinfo.Default = ParseExpr(constraintNode->raw_expr, settings); if (!cinfo.Default) { return false; @@ -3094,7 +3096,7 @@ class TConverter : public IPGParseEvents { ? L(A("PgType"), QA(TPgConst::ToString(valueNType->type))) : L(A("PgType"), QA("unknown")); - if (Settings.AutoParametrizeEnabled && !Settings.AutoParametrizeExprDisabledScopes.contains(settings.Scope)) { + if (Settings.AutoParametrizeEnabled && settings.AutoParametrizeEnabled) { return AutoParametrizeConst(std::move(valueNType.GetRef()), pgTypeNode); } diff --git a/ydb/library/yql/sql/pg/pg_sql_autoparam_ut.cpp b/ydb/library/yql/sql/pg/pg_sql_autoparam_ut.cpp index 1de71ead7df9..01d674db3ec5 100644 --- a/ydb/library/yql/sql/pg/pg_sql_autoparam_ut.cpp +++ b/ydb/library/yql/sql/pg/pg_sql_autoparam_ut.cpp @@ -13,14 +13,13 @@ Y_UNIT_TEST_SUITE(PgSqlParsingAutoparam) { UNIT_ASSERT_C(res.Issues.Empty(), "Failed to parse statement, issues: " + res.Issues.ToString()); UNIT_ASSERT_C(res.PgAutoParamValues.Empty(), "Expected no auto parametrization"); } - - Y_UNIT_TEST(AutoParamValues_DifferentTypes) { + + Y_UNIT_TEST(AutoParamValues_NoParametersWithDefaults) { TTranslationSettings settings; settings.AutoParametrizeEnabled = true; settings.AutoParametrizeValuesStmt = true; - settings.AutoParametrizeExprDisabledScopes = {"VALUES"}; auto res = SqlToYqlWithMode( - R"(insert into plato.Output values (1,2,3), (1,2.0,3))", + R"(CREATE TABLE t (a int PRIMARY KEY, b int DEFAULT 0))", NSQLTranslation::ESqlMode::QUERY, 10, {}, @@ -33,10 +32,10 @@ Y_UNIT_TEST_SUITE(PgSqlParsingAutoparam) { } using TUsedParamsGetter = std::function&, const NYql::TAstNode& node)>; - + void GetUsedParamsInValues(TSet& usedParams, const NYql::TAstNode& node) { - const bool isPgSetItem = - node.IsListOfSize(2) && node.GetChild(0)->IsAtom() + const bool isPgSetItem = + node.IsListOfSize(2) && node.GetChild(0)->IsAtom() && node.GetChild(0)->GetContent() == "PgSetItem"; if (!isPgSetItem) { return; @@ -45,7 +44,7 @@ Y_UNIT_TEST_SUITE(PgSqlParsingAutoparam) { for (const auto* pgOption : pgSetItemOptions->GetChildren()) { const bool isQuotedList = - pgOption->IsListOfSize(2) && pgOption->GetChild(0)->IsAtom() + pgOption->IsListOfSize(2) && pgOption->GetChild(0)->IsAtom() && pgOption->GetChild(0)->GetContent() == "quote"; if (!isQuotedList) { continue; @@ -54,7 +53,7 @@ Y_UNIT_TEST_SUITE(PgSqlParsingAutoparam) { const auto* option = pgOption->GetChild(1); const auto* optionName = option->GetChild(0); - const bool isValuesNode = + const bool isValuesNode = optionName->IsListOfSize(2) && optionName->GetChild(0)->IsAtom() && optionName->GetChild(0)->GetContent() == "quote" && optionName->GetChild(1)->GetContent() == "values"; @@ -68,11 +67,10 @@ Y_UNIT_TEST_SUITE(PgSqlParsingAutoparam) { } } - void TestAutoParam(const TString& query, const THashMap& expectedParamNameToJsonYdbVal, const TMap& expectedParamTypes, TUsedParamsGetter usedParamsGetter, THashSet disabledParametrizeScopes = {}) { + void TestAutoParam(const TString& query, const THashMap& expectedParamNameToJsonYdbVal, const TMap& expectedParamTypes, TUsedParamsGetter usedParamsGetter) { TTranslationSettings settings; settings.AutoParametrizeEnabled = true; settings.AutoParametrizeValuesStmt = true; - settings.AutoParametrizeExprDisabledScopes = disabledParametrizeScopes; auto res = SqlToYqlWithMode( query, NSQLTranslation::ESqlMode::QUERY, @@ -87,9 +85,9 @@ Y_UNIT_TEST_SUITE(PgSqlParsingAutoparam) { TSet declaredParams; TMap actualParamTypes; VisitAstNodes(*res.Root, [&declaredParams, &actualParamTypes] (const NYql::TAstNode& node) { - const bool isDeclareNode = - node.IsList() && node.GetChildrenCount() > 0 - && node.GetChild(0)->IsAtom() + const bool isDeclareNode = + node.IsList() && node.GetChildrenCount() > 0 + && node.GetChild(0)->IsAtom() && node.GetChild(0)->GetContent() == "declare"; if (isDeclareNode) { UNIT_ASSERT_VALUES_EQUAL(node.GetChildrenCount(), 3); @@ -114,7 +112,7 @@ Y_UNIT_TEST_SUITE(PgSqlParsingAutoparam) { auto actualParam = res.PgAutoParamValues.GetRef()[expectedParamName]; UNIT_ASSERT_STRINGS_EQUAL(expectedParam.ShortUtf8DebugString(), actualParam.ShortUtf8DebugString()); - UNIT_ASSERT_C(declaredParams.contains(expectedParamName), + UNIT_ASSERT_C(declaredParams.contains(expectedParamName), "Declared params don't contain expected param name: " << expectedParamName); } @@ -184,7 +182,7 @@ Y_UNIT_TEST_SUITE(PgSqlParsingAutoparam) { TString type = "(ListType (TupleType (PgType 'unknown) (PgType 'int4)))"; TestAutoParam(query, {{"a0", expectedParamJson}}, {{"a0", type}}, GetUsedParamsInValues); } - + Y_UNIT_TEST(AutoParamConsts_Where) { TString query = R"( select * from plato.Output where key > 1 @@ -201,8 +199,8 @@ Y_UNIT_TEST_SUITE(PgSqlParsingAutoparam) { return; } const auto quotedVal = maybeQuote.GetRef(); - const bool isWhere = - quotedVal->IsListOfSize(2) && quotedVal->GetChild(1)->IsListOfSize(3) + const bool isWhere = + quotedVal->IsListOfSize(2) && quotedVal->GetChild(1)->IsListOfSize(3) && quotedVal->GetChild(1)->IsListOfSize(3) && quotedVal->GetChild(1)->GetChild(0)->IsAtom() && quotedVal->GetChild(1)->GetChild(0)->GetContent() == "PgWhere"; @@ -224,7 +222,7 @@ Y_UNIT_TEST_SUITE(PgSqlParsingAutoparam) { TString type = "(PgType 'int4)"; TestAutoParam(query, {{"a0", expectedParamJson}}, {{"a0", type}}, usedInWhereComp); } - + Y_UNIT_TEST(AutoParamConsts_Select) { TString query = R"( select 1, 'test', B'10001' @@ -250,7 +248,7 @@ Y_UNIT_TEST_SUITE(PgSqlParsingAutoparam) { {"a2", "(PgType 'bit)"}, }; TestAutoParam(query, { - {"a0", expectedParamJsonInt4}, + {"a0", expectedParamJsonInt4}, {"a1", expectedParamJsonText}, {"a2", expectedParamJsonBit}, }, expectedParamTypes, dummyGetter); @@ -270,7 +268,7 @@ Y_UNIT_TEST_SUITE(PgSqlParsingAutoparam) { const TUsedParamsGetter dummyGetter = [] (TSet& usedParams, const NYql::TAstNode&) { usedParams = {"a0", "a1"}; }; - TestAutoParam(query, {{"a0", expectedParamJsonInt4}, {"a1", expectedParamJsonText}}, paramToType, dummyGetter, {}); + TestAutoParam(query, {{"a0", expectedParamJsonInt4}, {"a1", expectedParamJsonText}}, paramToType, dummyGetter); } } diff --git a/ydb/library/yql/sql/settings/translation_settings.h b/ydb/library/yql/sql/settings/translation_settings.h index 2dad2e646dda..4626b47ed653 100644 --- a/ydb/library/yql/sql/settings/translation_settings.h +++ b/ydb/library/yql/sql/settings/translation_settings.h @@ -27,7 +27,7 @@ namespace NSQLTranslation { }; enum class EBindingsMode { - // raise error + // raise error DISABLED, // classic support for bindings ENABLED, @@ -111,7 +111,6 @@ namespace NSQLTranslation { TVector PgParameterTypeOids; bool AutoParametrizeEnabled = false; bool AutoParametrizeValuesStmt = false; - THashSet AutoParametrizeExprDisabledScopes = {}; TGUCSettings::TPtr GUCSettings = std::make_shared(); }; diff --git a/ydb/public/api/protos/ydb_table.proto b/ydb/public/api/protos/ydb_table.proto index a5d1abcb483c..e878cb5bdf17 100644 --- a/ydb/public/api/protos/ydb_table.proto +++ b/ydb/public/api/protos/ydb_table.proto @@ -342,6 +342,10 @@ message ColumnMeta { string family = 3; // Column nullability optional bool not_null = 4; + // Column default value option + oneof default_value { + TypedValue from_literal = 5; + } } message DateTypeColumnModeSettings { diff --git a/ydb/tests/functional/scheme_tests/canondata/tablet_scheme_tests.TestTabletSchemes.test_tablet_schemes_flat_schemeshard_/flat_schemeshard.schema b/ydb/tests/functional/scheme_tests/canondata/tablet_scheme_tests.TestTabletSchemes.test_tablet_schemes_flat_schemeshard_/flat_schemeshard.schema index ac60dcdd47f0..de5abd702456 100644 --- a/ydb/tests/functional/scheme_tests/canondata/tablet_scheme_tests.TestTabletSchemes.test_tablet_schemes_flat_schemeshard_/flat_schemeshard.schema +++ b/ydb/tests/functional/scheme_tests/canondata/tablet_scheme_tests.TestTabletSchemes.test_tablet_schemes_flat_schemeshard_/flat_schemeshard.schema @@ -458,6 +458,11 @@ "ColumnId": 12, "ColumnName": "ColTypeData", "ColumnType": "String" + }, + { + "ColumnId": 13, + "ColumnName": "IsBuildInProgress", + "ColumnType": "Bool" } ], "ColumnsDropped": [], @@ -475,7 +480,8 @@ 9, 10, 11, - 12 + 12, + 13 ], "RoomID": 0, "Codec": 0, @@ -971,6 +977,11 @@ "ColumnId": 12, "ColumnName": "ColTypeData", "ColumnType": "String" + }, + { + "ColumnId": 13, + "ColumnName": "IsBuildInProgress", + "ColumnType": "Bool" } ], "ColumnsDropped": [], @@ -988,7 +999,8 @@ 9, 10, 11, - 12 + 12, + 13 ], "RoomID": 0, "Codec": 0, @@ -3664,6 +3676,11 @@ "ColumnId": 13, "ColumnName": "ColTypeData", "ColumnType": "String" + }, + { + "ColumnId": 14, + "ColumnName": "IsBuildInProgress", + "ColumnType": "Bool" } ], "ColumnsDropped": [], @@ -3682,7 +3699,8 @@ 10, 11, 12, - 13 + 13, + 14 ], "RoomID": 0, "Codec": 0, @@ -4157,6 +4175,11 @@ "ColumnId": 13, "ColumnName": "ColTypeData", "ColumnType": "String" + }, + { + "ColumnId": 14, + "ColumnName": "IsBuildInProgress", + "ColumnType": "Bool" } ], "ColumnsDropped": [], @@ -4175,7 +4198,8 @@ 10, 11, 12, - 13 + 13, + 14 ], "RoomID": 0, "Codec": 0, From 288a80b1fe0d97f4f386f232f79ded431f5eb8bf Mon Sep 17 00:00:00 2001 From: ivanmorozov333 <111685085+ivanmorozov333@users.noreply.github.com> Date: Thu, 22 Feb 2024 17:30:42 +0300 Subject: [PATCH 036/117] Stable-24-1 patch for cs (#2142) --- ydb/core/formats/arrow/arrow_filter.cpp | 10 +- ydb/core/formats/arrow/arrow_filter.h | 1 + ydb/core/formats/arrow/arrow_helpers.cpp | 37 +++- ydb/core/formats/arrow/arrow_helpers.h | 2 + .../compression/CMakeLists.darwin-arm64.txt | 23 --- .../compression/CMakeLists.darwin-x86_64.txt | 23 --- .../compression/CMakeLists.linux-aarch64.txt | 24 --- .../compression/CMakeLists.linux-x86_64.txt | 24 --- .../formats/arrow/compression/CMakeLists.txt | 19 -- .../compression/CMakeLists.windows-x86_64.txt | 23 --- ydb/core/formats/arrow/compression/diff.cpp | 77 -------- ydb/core/formats/arrow/compression/diff.h | 34 ---- ydb/core/formats/arrow/compression/object.cpp | 70 ------- ydb/core/formats/arrow/compression/object.h | 39 ---- ydb/core/formats/arrow/compression/ya.make | 16 -- ydb/core/formats/arrow/permutations.cpp | 31 ++- ydb/core/formats/arrow/program.cpp | 30 +-- .../formats/arrow/serializer/abstract.cpp | 25 ++- ydb/core/formats/arrow/serializer/abstract.h | 90 +++++++-- .../formats/arrow/serializer/batch_only.cpp | 58 ------ .../formats/arrow/serializer/batch_only.h | 38 ---- ydb/core/formats/arrow/serializer/full.cpp | 54 ----- ydb/core/formats/arrow/serializer/full.h | 38 ---- ydb/core/formats/arrow/serializer/native.cpp | 185 ++++++++++++++++++ ydb/core/formats/arrow/serializer/native.h | 72 +++++++ .../{compression => serializer}/parsing.cpp | 0 .../{compression => serializer}/parsing.h | 0 ydb/core/formats/arrow/serializer/ya.make | 5 +- ydb/core/formats/arrow/special_keys.cpp | 6 +- ydb/core/formats/arrow/ut/ut_dictionary.cpp | 15 +- ydb/core/formats/arrow/ut/ut_size_calcer.cpp | 2 - ydb/core/grpc_services/rpc_log_store.cpp | 10 +- ydb/core/grpc_services/rpc_long_tx.cpp | 1 - .../kqp/compute_actor/kqp_compute_events.h | 1 - .../tablestore/operations/alter_column.cpp | 10 +- .../tablestore/operations/alter_column.h | 4 +- .../behaviour/tablestore/operations/ya.make | 2 +- ydb/core/kqp/ut/common/columnshard.cpp | 1 - ydb/core/kqp/ut/olap/kqp_olap_ut.cpp | 9 +- ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp | 1 - ydb/core/kqp/ut/scheme/kqp_scheme_ut.cpp | 1 - ydb/core/protos/config.proto | 1 + ydb/core/protos/flat_scheme_op.proto | 19 +- ydb/core/tablet/resource_broker.cpp | 12 ++ .../blobs_action/counters/storage.cpp | 6 +- .../blobs_action/counters/storage.h | 1 - .../tx/columnshard/blobs_action/tier/gc.cpp | 4 +- .../columnshard/blobs_action/tier/write.cpp | 9 +- .../tx/columnshard/blobs_action/tier/write.h | 4 +- .../blobs_action/transaction/tx_write.cpp | 2 +- .../transaction/tx_write_index.cpp | 7 + .../blobs_action/transaction/tx_write_index.h | 1 + .../tx/columnshard/blobs_reader/actor.cpp | 2 +- ydb/core/tx/columnshard/columnshard.cpp | 2 +- .../tx/columnshard/columnshard__write.cpp | 60 ++++-- ydb/core/tx/columnshard/columnshard_impl.cpp | 15 +- ydb/core/tx/columnshard/columnshard_impl.h | 20 +- .../tx/columnshard/columnshard_ut_common.cpp | 4 +- .../tx/columnshard/columnshard_ut_common.h | 4 +- ydb/core/tx/columnshard/common/limits.cpp | 4 + ydb/core/tx/columnshard/common/limits.h | 9 + .../columnshard/common/protos/snapshot.proto | 6 + ydb/core/tx/columnshard/common/protos/ya.make | 10 + ydb/core/tx/columnshard/common/snapshot.cpp | 7 + ydb/core/tx/columnshard/common/snapshot.h | 32 +++ ydb/core/tx/columnshard/common/ya.make | 2 + .../tx/columnshard/counters/columnshard.cpp | 25 ++- .../tx/columnshard/counters/columnshard.h | 82 +++++--- .../tx/columnshard/counters/common/owner.h | 3 + ydb/core/tx/columnshard/counters/ya.make | 2 + .../engines/changes/abstract/abstract.h | 6 + .../engines/changes/general_compaction.h | 6 - .../engines/changes/indexation.cpp | 5 +- .../tx/columnshard/engines/changes/ttl.cpp | 14 +- ydb/core/tx/columnshard/engines/changes/ttl.h | 21 +- .../engines/changes/with_appended.cpp | 10 - .../engines/changes/with_appended.h | 5 +- .../tx/columnshard/engines/column_engine.h | 4 +- .../engines/column_engine_logs.cpp | 73 ++++--- .../columnshard/engines/column_engine_logs.h | 42 +++- ydb/core/tx/columnshard/engines/defs.h | 1 - ydb/core/tx/columnshard/engines/filter.h | 1 + .../columnshard/engines/insert_table/data.h | 1 + .../tx/columnshard/engines/portions/meta.cpp | 2 +- .../tx/columnshard/engines/portions/meta.h | 4 + .../engines/portions/portion_info.cpp | 4 + .../engines/portions/portion_info.h | 5 + .../columnshard/engines/predicate/filter.cpp | 9 + .../tx/columnshard/engines/predicate/filter.h | 1 + .../columnshard/engines/predicate/range.cpp | 31 +++ .../tx/columnshard/engines/predicate/range.h | 1 + .../engines/reader/plain_reader/columns_set.h | 9 + .../engines/reader/plain_reader/context.cpp | 52 +++-- .../engines/reader/plain_reader/context.h | 8 +- .../reader/plain_reader/fetched_data.h | 14 +- .../engines/reader/plain_reader/fetching.cpp | 6 + .../reader/plain_reader/plain_read_data.cpp | 9 +- .../engines/reader/plain_reader/source.cpp | 1 - .../engines/reader/plain_reader/source.h | 26 ++- .../engines/reader/read_metadata.cpp | 2 +- .../engines/scheme/abstract_scheme.h | 1 + .../engines/scheme/column_features.cpp | 41 ++-- .../engines/scheme/column_features.h | 45 ++--- .../columnshard/engines/scheme/index_info.cpp | 41 ++-- .../columnshard/engines/scheme/index_info.h | 2 +- .../engines/scheme/indexes/abstract/meta.cpp | 9 +- .../engines/scheme/indexes/bloom/checker.cpp | 4 +- .../tx/columnshard/engines/scheme/tier_info.h | 17 +- .../storage/optimizer/lbuckets/optimizer.h | 13 +- .../columnshard/engines/storage/storage.cpp | 5 +- .../tx/columnshard/engines/storage/storage.h | 2 +- ydb/core/tx/columnshard/engines/ut/helper.cpp | 11 ++ ydb/core/tx/columnshard/engines/ut/helper.h | 11 ++ .../engines/{ => ut}/ut_insert_table.cpp | 13 +- .../engines/{ => ut}/ut_logs_engine.cpp | 22 ++- .../engines/{ => ut}/ut_program.cpp | 2 +- ydb/core/tx/columnshard/engines/ut/ya.make | 1 + .../writer/indexed_blob_constructor.cpp | 35 +++- .../engines/writer/indexed_blob_constructor.h | 19 +- .../engines/writer/write_controller.h | 13 ++ ydb/core/tx/columnshard/engines/ya.make | 1 - .../columnshard/splitter/ut/ut_splitter.cpp | 7 +- ydb/core/tx/columnshard/splitter/ut/ya.make | 1 - ydb/core/tx/columnshard/tables_manager.cpp | 4 +- ydb/core/tx/data_events/write_data.h | 3 + .../tx/schemeshard/olap/columns/update.cpp | 35 ++-- ydb/core/tx/schemeshard/olap/columns/update.h | 15 +- ydb/core/tx/schemeshard/olap/columns/ya.make | 3 +- ydb/core/tx/schemeshard/olap/common/ya.make | 1 + ydb/core/tx/schemeshard/ya.make | 1 - ydb/core/tx/tiering/manager.cpp | 22 ++- ydb/core/tx/tiering/manager.h | 5 +- ydb/core/tx/tiering/rule/object.h | 3 +- ydb/core/tx/tiering/rule/ya.make | 1 + ydb/core/wrappers/s3_storage_config.cpp | 4 + ydb/library/conclusion/result.h | 14 ++ .../libcpp/ut_helpers/connector_client_mock.h | 6 +- .../generic/connector/libcpp/utils.cpp | 7 +- ydb/services/bg_tasks/abstract/interface.h | 16 +- .../metadata/abstract/request_features.h | 1 + ydb/services/metadata/abstract/ya.make | 1 - 141 files changed, 1262 insertions(+), 1035 deletions(-) delete mode 100644 ydb/core/formats/arrow/compression/CMakeLists.darwin-arm64.txt delete mode 100644 ydb/core/formats/arrow/compression/CMakeLists.darwin-x86_64.txt delete mode 100644 ydb/core/formats/arrow/compression/CMakeLists.linux-aarch64.txt delete mode 100644 ydb/core/formats/arrow/compression/CMakeLists.linux-x86_64.txt delete mode 100644 ydb/core/formats/arrow/compression/CMakeLists.txt delete mode 100644 ydb/core/formats/arrow/compression/CMakeLists.windows-x86_64.txt delete mode 100644 ydb/core/formats/arrow/compression/diff.cpp delete mode 100644 ydb/core/formats/arrow/compression/diff.h delete mode 100644 ydb/core/formats/arrow/compression/object.cpp delete mode 100644 ydb/core/formats/arrow/compression/object.h delete mode 100644 ydb/core/formats/arrow/compression/ya.make delete mode 100644 ydb/core/formats/arrow/serializer/batch_only.cpp delete mode 100644 ydb/core/formats/arrow/serializer/batch_only.h delete mode 100644 ydb/core/formats/arrow/serializer/full.cpp delete mode 100644 ydb/core/formats/arrow/serializer/full.h create mode 100644 ydb/core/formats/arrow/serializer/native.cpp create mode 100644 ydb/core/formats/arrow/serializer/native.h rename ydb/core/formats/arrow/{compression => serializer}/parsing.cpp (100%) rename ydb/core/formats/arrow/{compression => serializer}/parsing.h (100%) create mode 100644 ydb/core/tx/columnshard/common/limits.cpp create mode 100644 ydb/core/tx/columnshard/common/limits.h create mode 100644 ydb/core/tx/columnshard/common/protos/snapshot.proto create mode 100644 ydb/core/tx/columnshard/common/protos/ya.make create mode 100644 ydb/core/tx/columnshard/engines/ut/helper.cpp create mode 100644 ydb/core/tx/columnshard/engines/ut/helper.h rename ydb/core/tx/columnshard/engines/{ => ut}/ut_insert_table.cpp (89%) rename ydb/core/tx/columnshard/engines/{ => ut}/ut_logs_engine.cpp (98%) rename ydb/core/tx/columnshard/engines/{ => ut}/ut_program.cpp (99%) diff --git a/ydb/core/formats/arrow/arrow_filter.cpp b/ydb/core/formats/arrow/arrow_filter.cpp index bdfb8d0355f1..162bbb37b540 100644 --- a/ydb/core/formats/arrow/arrow_filter.cpp +++ b/ydb/core/formats/arrow/arrow_filter.cpp @@ -569,7 +569,7 @@ TColumnFilter TColumnFilter::CombineSequentialAnd(const TColumnFilter& extFilter ++itExt; } } - Y_ABORT_UNLESS(itSelf == Filter.end() && itExt == extFilter.Filter.cend()); + AFL_VERIFY(itSelf == Filter.end() && itExt == extFilter.Filter.cend()); TColumnFilter result = TColumnFilter::BuildAllowFilter(); std::swap(resultFilter, result.Filter); std::swap(curCurrent, result.LastValue); @@ -611,4 +611,12 @@ std::optional TColumnFilter::GetFilteredCount() const { return *FilteredCount; } +void TColumnFilter::Append(const TColumnFilter& filter) { + bool currentVal = filter.GetStartValue(); + for (auto&& i : filter.Filter) { + Add(currentVal, i); + currentVal = !currentVal; + } +} + } diff --git a/ydb/core/formats/arrow/arrow_filter.h b/ydb/core/formats/arrow/arrow_filter.h index b33b9a13707e..80e449ef05c1 100644 --- a/ydb/core/formats/arrow/arrow_filter.h +++ b/ydb/core/formats/arrow/arrow_filter.h @@ -52,6 +52,7 @@ class TColumnFilter { FilteredCount.reset(); } public: + void Append(const TColumnFilter& filter); void Add(const bool value, const ui32 count = 1); std::optional GetFilteredCount() const; const std::vector& BuildSimpleFilter() const; diff --git a/ydb/core/formats/arrow/arrow_helpers.cpp b/ydb/core/formats/arrow/arrow_helpers.cpp index eac6a6670e00..a49cf23e686e 100644 --- a/ydb/core/formats/arrow/arrow_helpers.cpp +++ b/ydb/core/formats/arrow/arrow_helpers.cpp @@ -4,7 +4,7 @@ #include "common/validation.h" #include "merging_sorted_input_stream.h" #include "permutations.h" -#include "serializer/batch_only.h" +#include "serializer/native.h" #include "serializer/abstract.h" #include "serializer/stream.h" #include "simple_arrays_cache.h" @@ -106,7 +106,7 @@ std::shared_ptr DeserializeSchema(const TString& str) { } TString SerializeBatch(const std::shared_ptr& batch, const arrow::ipc::IpcWriteOptions& options) { - return NSerialization::TBatchPayloadSerializer(options).Serialize(batch); + return NSerialization::TNativeSerializer(options).SerializePayload(batch); } TString SerializeBatchNoCompression(const std::shared_ptr& batch) { @@ -117,7 +117,7 @@ TString SerializeBatchNoCompression(const std::shared_ptr& b std::shared_ptr DeserializeBatch(const TString& blob, const std::shared_ptr& schema) { - auto result = NSerialization::TBatchPayloadDeserializer(schema).Deserialize(blob); + auto result = NSerialization::TNativeSerializer().Deserialize(blob, schema); if (result.ok()) { return *result; } else { @@ -977,4 +977,35 @@ std::shared_ptr MergeColumns(const std::vector> SliceToRecordBatches(const std::shared_ptr& t) { + std::set splitPositions; + const ui32 numRows = t->num_rows(); + for (auto&& i : t->columns()) { + ui32 pos = 0; + for (auto&& arr : i->chunks()) { + splitPositions.emplace(pos); + pos += arr->length(); + } + AFL_VERIFY(pos == t->num_rows()); + } + std::vector>> slicedData; + slicedData.resize(splitPositions.size()); + std::vector positions(splitPositions.begin(), splitPositions.end()); + for (auto&& i : t->columns()) { + for (ui32 idx = 0; idx < positions.size(); ++idx) { + auto slice = i->Slice(positions[idx], ((idx + 1 == positions.size()) ? numRows : positions[idx + 1]) - positions[idx]); + AFL_VERIFY(slice->num_chunks() == 1); + slicedData[idx].emplace_back(slice->chunks().front()); + } + } + std::vector> result; + ui32 count = 0; + for (auto&& i : slicedData) { + result.emplace_back(arrow::RecordBatch::Make(t->schema(), i.front()->length(), i)); + count += result.back()->num_rows(); + } + AFL_VERIFY(count == t->num_rows())("count", count)("t", t->num_rows()); + return result; +} + } diff --git a/ydb/core/formats/arrow/arrow_helpers.h b/ydb/core/formats/arrow/arrow_helpers.h index 84aba485fa7e..efa064ee71a3 100644 --- a/ydb/core/formats/arrow/arrow_helpers.h +++ b/ydb/core/formats/arrow/arrow_helpers.h @@ -128,6 +128,8 @@ inline bool HasNulls(const std::shared_ptr& column) { return column->null_bitmap_data(); } +std::vector> SliceToRecordBatches(const std::shared_ptr& t); + bool ArrayScalarsEqual(const std::shared_ptr& lhs, const std::shared_ptr& rhs); std::shared_ptr BoolVecToArray(const std::vector& vec); diff --git a/ydb/core/formats/arrow/compression/CMakeLists.darwin-arm64.txt b/ydb/core/formats/arrow/compression/CMakeLists.darwin-arm64.txt deleted file mode 100644 index 0f1b4b72adce..000000000000 --- a/ydb/core/formats/arrow/compression/CMakeLists.darwin-arm64.txt +++ /dev/null @@ -1,23 +0,0 @@ - -# This file was generated by the build system used internally in the Yandex monorepo. -# Only simple modifications are allowed (adding source-files to targets, adding simple properties -# like target_include_directories). These modifications will be ported to original -# ya.make files by maintainers. Any complex modifications which can't be ported back to the -# original buildsystem will not be accepted. - - - -add_library(formats-arrow-compression) -target_link_libraries(formats-arrow-compression PUBLIC - contrib-libs-cxxsupp - yutil - libs-apache-arrow - ydb-core-protos - core-formats-arrow - ydb-library-conclusion -) -target_sources(formats-arrow-compression PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/compression/diff.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/compression/object.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/compression/parsing.cpp -) diff --git a/ydb/core/formats/arrow/compression/CMakeLists.darwin-x86_64.txt b/ydb/core/formats/arrow/compression/CMakeLists.darwin-x86_64.txt deleted file mode 100644 index 0f1b4b72adce..000000000000 --- a/ydb/core/formats/arrow/compression/CMakeLists.darwin-x86_64.txt +++ /dev/null @@ -1,23 +0,0 @@ - -# This file was generated by the build system used internally in the Yandex monorepo. -# Only simple modifications are allowed (adding source-files to targets, adding simple properties -# like target_include_directories). These modifications will be ported to original -# ya.make files by maintainers. Any complex modifications which can't be ported back to the -# original buildsystem will not be accepted. - - - -add_library(formats-arrow-compression) -target_link_libraries(formats-arrow-compression PUBLIC - contrib-libs-cxxsupp - yutil - libs-apache-arrow - ydb-core-protos - core-formats-arrow - ydb-library-conclusion -) -target_sources(formats-arrow-compression PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/compression/diff.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/compression/object.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/compression/parsing.cpp -) diff --git a/ydb/core/formats/arrow/compression/CMakeLists.linux-aarch64.txt b/ydb/core/formats/arrow/compression/CMakeLists.linux-aarch64.txt deleted file mode 100644 index 80620e94bb4b..000000000000 --- a/ydb/core/formats/arrow/compression/CMakeLists.linux-aarch64.txt +++ /dev/null @@ -1,24 +0,0 @@ - -# This file was generated by the build system used internally in the Yandex monorepo. -# Only simple modifications are allowed (adding source-files to targets, adding simple properties -# like target_include_directories). These modifications will be ported to original -# ya.make files by maintainers. Any complex modifications which can't be ported back to the -# original buildsystem will not be accepted. - - - -add_library(formats-arrow-compression) -target_link_libraries(formats-arrow-compression PUBLIC - contrib-libs-linux-headers - contrib-libs-cxxsupp - yutil - libs-apache-arrow - ydb-core-protos - core-formats-arrow - ydb-library-conclusion -) -target_sources(formats-arrow-compression PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/compression/diff.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/compression/object.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/compression/parsing.cpp -) diff --git a/ydb/core/formats/arrow/compression/CMakeLists.linux-x86_64.txt b/ydb/core/formats/arrow/compression/CMakeLists.linux-x86_64.txt deleted file mode 100644 index 80620e94bb4b..000000000000 --- a/ydb/core/formats/arrow/compression/CMakeLists.linux-x86_64.txt +++ /dev/null @@ -1,24 +0,0 @@ - -# This file was generated by the build system used internally in the Yandex monorepo. -# Only simple modifications are allowed (adding source-files to targets, adding simple properties -# like target_include_directories). These modifications will be ported to original -# ya.make files by maintainers. Any complex modifications which can't be ported back to the -# original buildsystem will not be accepted. - - - -add_library(formats-arrow-compression) -target_link_libraries(formats-arrow-compression PUBLIC - contrib-libs-linux-headers - contrib-libs-cxxsupp - yutil - libs-apache-arrow - ydb-core-protos - core-formats-arrow - ydb-library-conclusion -) -target_sources(formats-arrow-compression PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/compression/diff.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/compression/object.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/compression/parsing.cpp -) diff --git a/ydb/core/formats/arrow/compression/CMakeLists.txt b/ydb/core/formats/arrow/compression/CMakeLists.txt deleted file mode 100644 index d863ebd18067..000000000000 --- a/ydb/core/formats/arrow/compression/CMakeLists.txt +++ /dev/null @@ -1,19 +0,0 @@ - -# This file was generated by the build system used internally in the Yandex monorepo. -# Only simple modifications are allowed (adding source-files to targets, adding simple properties -# like target_include_directories). These modifications will be ported to original -# ya.make files by maintainers. Any complex modifications which can't be ported back to the -# original buildsystem will not be accepted. - - -if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) - include(CMakeLists.linux-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) - include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) -endif() diff --git a/ydb/core/formats/arrow/compression/CMakeLists.windows-x86_64.txt b/ydb/core/formats/arrow/compression/CMakeLists.windows-x86_64.txt deleted file mode 100644 index 0f1b4b72adce..000000000000 --- a/ydb/core/formats/arrow/compression/CMakeLists.windows-x86_64.txt +++ /dev/null @@ -1,23 +0,0 @@ - -# This file was generated by the build system used internally in the Yandex monorepo. -# Only simple modifications are allowed (adding source-files to targets, adding simple properties -# like target_include_directories). These modifications will be ported to original -# ya.make files by maintainers. Any complex modifications which can't be ported back to the -# original buildsystem will not be accepted. - - - -add_library(formats-arrow-compression) -target_link_libraries(formats-arrow-compression PUBLIC - contrib-libs-cxxsupp - yutil - libs-apache-arrow - ydb-core-protos - core-formats-arrow - ydb-library-conclusion -) -target_sources(formats-arrow-compression PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/compression/diff.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/compression/object.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/compression/parsing.cpp -) diff --git a/ydb/core/formats/arrow/compression/diff.cpp b/ydb/core/formats/arrow/compression/diff.cpp deleted file mode 100644 index 0659cba5e2ab..000000000000 --- a/ydb/core/formats/arrow/compression/diff.cpp +++ /dev/null @@ -1,77 +0,0 @@ -#include "diff.h" -#include "object.h" -#include "parsing.h" -#include - -namespace NKikimr::NArrow { - -NKikimrSchemeOp::TCompressionOptions TCompressionDiff::SerializeToProto() const { - NKikimrSchemeOp::TCompressionOptions result; - if (Level) { - result.SetCompressionLevel(*Level); - } - if (Codec) { - result.SetCompressionCodec(CompressionToProto(*Codec)); - } - return result; -} - -TConclusionStatus TCompressionDiff::DeserializeFromRequestFeatures(NYql::TFeaturesExtractor& features) { - { - auto fValue = features.Extract("COMPRESSION.TYPE"); - if (fValue) { - Codec = NArrow::CompressionFromString(*fValue); - if (!Codec) { - return TConclusionStatus::Fail("cannot parse COMPRESSION.TYPE as arrow::Compression"); - } - } - } - { - auto fValue = features.Extract("COMPRESSION.LEVEL"); - if (fValue) { - ui32 level; - if (!TryFromString(*fValue, level)) { - return TConclusionStatus::Fail("cannot parse COMPRESSION.LEVEL as ui32"); - } - Level = level; - } - } - return TConclusionStatus::Success(); -} - -bool TCompressionDiff::DeserializeFromProto(const NKikimrSchemeOp::TCompressionOptions& proto) { - if (proto.HasCompressionLevel()) { - Level = proto.GetCompressionLevel(); - } - if (proto.HasCompressionCodec()) { - Codec = CompressionFromProto(proto.GetCompressionCodec()); - if (!Codec) { - return false; - } - } - return true; -} - -NKikimr::TConclusionStatus TCompressionDiff::Apply(std::optional& settings) const { - if (IsEmpty()) { - return TConclusionStatus::Success(); - } - TCompression merged; - if (!!settings) { - merged = *settings; - } - if (Codec) { - merged.Codec = *Codec; - } - if (Level) { - merged.Level = *Level; - } - auto validation = merged.Validate(); - if (!validation) { - return validation; - } - settings = merged; - return TConclusionStatus::Success(); -} - -} diff --git a/ydb/core/formats/arrow/compression/diff.h b/ydb/core/formats/arrow/compression/diff.h deleted file mode 100644 index 53cdd5bae788..000000000000 --- a/ydb/core/formats/arrow/compression/diff.h +++ /dev/null @@ -1,34 +0,0 @@ -#pragma once - -#include -#include -#include -#include -#include -#include -#include - -namespace NKikimr::NArrow { - -class TCompression; - -class TCompressionDiff { -private: - std::optional Codec; - std::optional Level; - bool IsEmpty() const { - return !Level && !Codec; - } -public: - NKikimrSchemeOp::TCompressionOptions SerializeToProto() const; - bool DeserializeFromProto(const NKikimrSchemeOp::TCompressionOptions& proto); - TConclusionStatus DeserializeFromRequestFeatures(NYql::TFeaturesExtractor& features); - const std::optional& GetCodec() const { - return Codec; - } - const std::optional& GetLevel() const { - return Level; - } - TConclusionStatus Apply(std::optional& settings) const; -}; -} diff --git a/ydb/core/formats/arrow/compression/object.cpp b/ydb/core/formats/arrow/compression/object.cpp deleted file mode 100644 index 7f58d2618e90..000000000000 --- a/ydb/core/formats/arrow/compression/object.cpp +++ /dev/null @@ -1,70 +0,0 @@ -#include "object.h" -#include "parsing.h" -#include -#include - -namespace NKikimr::NArrow { - -TConclusionStatus NKikimr::NArrow::TCompression::Validate() const { - if (Level) { - auto codec = TStatusValidator::GetValid(arrow::util::Codec::Create(Codec)); - const int levelMin = codec->minimum_compression_level(); - const int levelMax = codec->maximum_compression_level(); - if (Level && (*Level < levelMin || levelMax < *Level)) { - return TConclusionStatus::Fail( - TStringBuilder() << "incorrect level for codec. have to be: [" << levelMin << ":" << levelMax << "]" - ); - } - } - return TConclusionStatus::Success(); -} - -TConclusionStatus TCompression::DeserializeFromProto(const NKikimrSchemeOp::TCompressionOptions& compression) { - if (compression.HasCompressionCodec()) { - auto codecOpt = NArrow::CompressionFromProto(compression.GetCompressionCodec()); - if (!codecOpt) { - return TConclusionStatus::Fail("cannot parse codec type from proto"); - } - Codec = *codecOpt; - } - if (compression.HasCompressionLevel()) { - Level = compression.GetCompressionLevel(); - } - return Validate(); -} - -NKikimrSchemeOp::TCompressionOptions TCompression::SerializeToProto() const { - NKikimrSchemeOp::TCompressionOptions result; - result.SetCompressionCodec(NArrow::CompressionToProto(Codec)); - if (Level) { - result.SetCompressionLevel(*Level); - } - return result; -} - -TString TCompression::DebugString() const { - TStringBuilder sb; - sb << arrow::util::Codec::GetCodecAsString(Codec) << ":" << Level.value_or(arrow::util::kUseDefaultCompressionLevel); - return sb; -} - -std::unique_ptr TCompression::BuildArrowCodec() const { - return NArrow::TStatusValidator::GetValid( - arrow::util::Codec::Create( - Codec, Level.value_or(arrow::util::kUseDefaultCompressionLevel))); -} - -NKikimr::TConclusion TCompression::BuildFromProto(const NKikimrSchemeOp::TCompressionOptions& compression) { - TCompression result; - auto resultStatus = result.DeserializeFromProto(compression); - if (!resultStatus) { - return resultStatus; - } - return result; -} - -std::unique_ptr TCompression::BuildDefaultCodec() { - return *arrow::util::Codec::Create(arrow::Compression::LZ4_FRAME); -} - -} diff --git a/ydb/core/formats/arrow/compression/object.h b/ydb/core/formats/arrow/compression/object.h deleted file mode 100644 index 18c32b592212..000000000000 --- a/ydb/core/formats/arrow/compression/object.h +++ /dev/null @@ -1,39 +0,0 @@ -#pragma once - -#include -#include -#include "diff.h" - -namespace NKikimr::NArrow { - -class TCompression { -private: - arrow::Compression::type Codec = arrow::Compression::LZ4_FRAME; - std::optional Level; - TCompression() = default; - - TConclusionStatus Validate() const; - friend class TCompressionDiff; -public: - - static std::unique_ptr BuildDefaultCodec(); - - TConclusionStatus DeserializeFromProto(const NKikimrSchemeOp::TCompressionOptions& compression); - - NKikimrSchemeOp::TCompressionOptions SerializeToProto() const; - - static TConclusion BuildFromProto(const NKikimrSchemeOp::TCompressionOptions& compression); - - explicit TCompression(const arrow::Compression::type codec, std::optional level = {}) - : Codec(codec) - , Level(level) - { - - } - - TString DebugString() const; - std::unique_ptr BuildArrowCodec() const; - -}; - -} diff --git a/ydb/core/formats/arrow/compression/ya.make b/ydb/core/formats/arrow/compression/ya.make deleted file mode 100644 index 420b028e3f29..000000000000 --- a/ydb/core/formats/arrow/compression/ya.make +++ /dev/null @@ -1,16 +0,0 @@ -LIBRARY() - -SRCS( - diff.cpp - object.cpp - parsing.cpp -) - -PEERDIR( - contrib/libs/apache/arrow - ydb/core/protos - ydb/core/formats/arrow - ydb/library/conclusion -) - -END() diff --git a/ydb/core/formats/arrow/permutations.cpp b/ydb/core/formats/arrow/permutations.cpp index 6f38f9fb0050..f1a68600bb70 100644 --- a/ydb/core/formats/arrow/permutations.cpp +++ b/ydb/core/formats/arrow/permutations.cpp @@ -15,34 +15,24 @@ namespace NKikimr::NArrow { std::shared_ptr MakePermutation(const int size, const bool reverse) { - if (size < 1) { - return {}; - } - arrow::UInt64Builder builder; - if (!builder.Reserve(size).ok()) { - return {}; - } + TStatusValidator::Validate(builder.Reserve(size)); - if (reverse) { - ui64 value = size - 1; - for (i64 i = 0; i < size; ++i, --value) { - if (!builder.Append(value).ok()) { - return {}; + if (size) { + if (reverse) { + ui64 value = size - 1; + for (i64 i = 0; i < size; ++i, --value) { + TStatusValidator::Validate(builder.Append(value)); } - } - } else { - for (i64 i = 0; i < size; ++i) { - if (!builder.Append(i).ok()) { - return {}; + } else { + for (i64 i = 0; i < size; ++i) { + TStatusValidator::Validate(builder.Append(i)); } } } std::shared_ptr out; - if (!builder.Finish(&out).ok()) { - return {}; - } + TStatusValidator::Validate(builder.Finish(&out)); return out; } @@ -287,6 +277,7 @@ std::shared_ptr TShardingSplitIndex::BuildPermutation() cons } std::shared_ptr ReverseRecords(const std::shared_ptr& batch) { + AFL_VERIFY(batch); auto permutation = NArrow::MakePermutation(batch->num_rows(), true); return NArrow::TStatusValidator::GetValid(arrow::compute::Take(batch, permutation)).record_batch(); } diff --git a/ydb/core/formats/arrow/program.cpp b/ydb/core/formats/arrow/program.cpp index fadd6bbf76b4..6523d12b2c38 100644 --- a/ydb/core/formats/arrow/program.cpp +++ b/ydb/core/formats/arrow/program.cpp @@ -139,18 +139,20 @@ class TKernelFunction : public IStepFunction { TKernelFunction(const TFunctionPtr kernelsFunction, arrow::compute::ExecContext* ctx) : TBase(ctx) , Function(kernelsFunction) - {} + { + AFL_VERIFY(Function); + } arrow::Result Call(const TAssignObject& assign, const TDatumBatch& batch) const override { auto arguments = TBase::BuildArgs(batch, assign.GetArguments()); if (!arguments) { return arrow::Status::Invalid("Error parsing args."); } - try { +// try { return Function->Execute(*arguments, assign.GetOptions(), TBase::Ctx); - } catch (const std::exception& ex) { - return arrow::Status::ExecutionError(ex.what()); - } +// } catch (const std::exception& ex) { +// return arrow::Status::ExecutionError(ex.what()); +// } } }; @@ -865,12 +867,18 @@ std::shared_ptr TProgramStep::BuildFilter(const std::shar if (Filters.empty()) { return nullptr; } - auto datumBatch = TDatumBatch::FromTable(t); - - NArrow::TStatusValidator::Validate(ApplyAssignes(*datumBatch, NArrow::GetCustomExecContext())); - NArrow::TColumnFilter local = NArrow::TColumnFilter::BuildAllowFilter(); - NArrow::TStatusValidator::Validate(MakeCombinedFilter(*datumBatch, local)); - return std::make_shared(std::move(local)); + std::vector> batches = NArrow::SliceToRecordBatches(t); + NArrow::TColumnFilter fullLocal = NArrow::TColumnFilter::BuildAllowFilter(); + for (auto&& rb : batches) { + auto datumBatch = TDatumBatch::FromRecordBatch(rb); + NArrow::TStatusValidator::Validate(ApplyAssignes(*datumBatch, NArrow::GetCustomExecContext())); + NArrow::TColumnFilter local = NArrow::TColumnFilter::BuildAllowFilter(); + NArrow::TStatusValidator::Validate(MakeCombinedFilter(*datumBatch, local)); + AFL_VERIFY(local.Size() == datumBatch->Rows)("local", local.Size())("datum", datumBatch->Rows); + fullLocal.Append(local); + } + AFL_VERIFY(fullLocal.Size() == t->num_rows())("filter", fullLocal.Size())("t", t->num_rows()); + return std::make_shared(std::move(fullLocal)); } const std::set& TProgramStep::GetFilterOriginalColumnIds() const { diff --git a/ydb/core/formats/arrow/serializer/abstract.cpp b/ydb/core/formats/arrow/serializer/abstract.cpp index 13ee3d731bb6..6347cd765b9b 100644 --- a/ydb/core/formats/arrow/serializer/abstract.cpp +++ b/ydb/core/formats/arrow/serializer/abstract.cpp @@ -1,11 +1,28 @@ #include "abstract.h" +#include "native.h" namespace NKikimr::NArrow::NSerialization { -arrow::Result> IDeserializer::Deserialize(const TString& data) const { - if (!data) { - return nullptr; +NKikimr::TConclusionStatus TSerializerContainer::DeserializeFromProto(const NKikimrSchemeOp::TCompressionOptions& proto) { + NKikimrSchemeOp::TOlapColumn::TSerializer serializerProto; + serializerProto.SetClassName(NArrow::NSerialization::TNativeSerializer::GetClassNameStatic()); + *serializerProto.MutableArrowCompression() = proto; + AFL_VERIFY(Initialize(NArrow::NSerialization::TNativeSerializer::GetClassNameStatic(), true)); + return GetObjectPtr()->DeserializeFromProto(serializerProto); +} + +NKikimr::TConclusionStatus TSerializerContainer::DeserializeFromRequest(NYql::TFeaturesExtractor& features) { + const std::optional className = features.Extract("SERIALIZER.CLASS_NAME"); + if (!className) { + return TConclusionStatus::Success(); + } + if (!TBase::Initialize(*className)) { + return TConclusionStatus::Fail("dont know anything about class_name=" + *className); } - return DoDeserialize(data); + return TBase::GetObjectPtr()->DeserializeFromRequest(features); +} + +std::shared_ptr TSerializerContainer::GetDefaultSerializer() { + return std::make_shared(); } } diff --git a/ydb/core/formats/arrow/serializer/abstract.h b/ydb/core/formats/arrow/serializer/abstract.h index f21ac1d58f74..6051f9fc90ce 100644 --- a/ydb/core/formats/arrow/serializer/abstract.h +++ b/ydb/core/formats/arrow/serializer/abstract.h @@ -1,38 +1,106 @@ #pragma once +#include +#include +#include +#include + #include #include #include +#include namespace NKikimr::NArrow::NSerialization { class ISerializer { protected: - virtual TString DoSerialize(const std::shared_ptr& batch) const = 0; + virtual TString DoSerializeFull(const std::shared_ptr& batch) const = 0; + virtual TString DoSerializePayload(const std::shared_ptr& batch) const = 0; + virtual arrow::Result> DoDeserialize(const TString& data) const = 0; + virtual arrow::Result> DoDeserialize(const TString& data, const std::shared_ptr& schema) const = 0; + virtual TString DoDebugString() const { + return ""; + } + + virtual TConclusionStatus DoDeserializeFromRequest(NYql::TFeaturesExtractor& features) = 0; + + virtual TConclusionStatus DoDeserializeFromProto(const NKikimrSchemeOp::TOlapColumn::TSerializer& proto) = 0; + virtual void DoSerializeToProto(NKikimrSchemeOp::TOlapColumn::TSerializer& proto) const = 0; public: using TPtr = std::shared_ptr; + using TFactory = NObjectFactory::TObjectFactory; + using TProto = NKikimrSchemeOp::TOlapColumn::TSerializer; virtual ~ISerializer() = default; - TString Serialize(const std::shared_ptr& batch) const { - return DoSerialize(batch); + TConclusionStatus DeserializeFromRequest(NYql::TFeaturesExtractor& features) { + return DoDeserializeFromRequest(features); + } + + TString DebugString() const { + return TStringBuilder() << "{class_name=" << GetClassName() << ";details={" << DoDebugString() << "}}"; + } + + TConclusionStatus DeserializeFromProto(const NKikimrSchemeOp::TOlapColumn::TSerializer& proto) { + return DoDeserializeFromProto(proto); + } + + void SerializeToProto(NKikimrSchemeOp::TOlapColumn::TSerializer& proto) const { + return DoSerializeToProto(proto); + } + + TString SerializeFull(const std::shared_ptr& batch) const { + return DoSerializeFull(batch); + } + + TString SerializePayload(const std::shared_ptr& batch) const { + return DoSerializePayload(batch); + } + + arrow::Result> Deserialize(const TString& data) const { + if (!data) { + return nullptr; + } + return DoDeserialize(data); + } + + arrow::Result> Deserialize(const TString& data, const std::shared_ptr& schema) const { + if (!data) { + return nullptr; + } + return DoDeserialize(data, schema); } virtual bool IsHardPacker() const = 0; + + virtual TString GetClassName() const = 0; }; -class IDeserializer { -protected: - virtual arrow::Result> DoDeserialize(const TString& data) const = 0; - virtual TString DoDebugString() const = 0; +class TSerializerContainer: public NBackgroundTasks::TInterfaceProtoContainer { +private: + using TBase = NBackgroundTasks::TInterfaceProtoContainer; public: - using TPtr = std::shared_ptr; - virtual ~IDeserializer() = default; + using TBase::TBase; + + TSerializerContainer(const std::shared_ptr& object) + : TBase(object) + { + + } TString DebugString() const { - return DoDebugString(); + if (GetObjectPtr()) { + return GetObjectPtr()->DebugString(); + } else { + return "NO_OBJECT"; + } } + using TBase::DeserializeFromProto; + + static std::shared_ptr GetDefaultSerializer(); + + TConclusionStatus DeserializeFromProto(const NKikimrSchemeOp::TCompressionOptions& proto); - arrow::Result> Deserialize(const TString& data) const; + TConclusionStatus DeserializeFromRequest(NYql::TFeaturesExtractor& features); }; } diff --git a/ydb/core/formats/arrow/serializer/batch_only.cpp b/ydb/core/formats/arrow/serializer/batch_only.cpp deleted file mode 100644 index c93f97b3f559..000000000000 --- a/ydb/core/formats/arrow/serializer/batch_only.cpp +++ /dev/null @@ -1,58 +0,0 @@ -#include "batch_only.h" -#include "stream.h" -#include -#include -#include -#include -#include -#include -#include -#include -namespace NKikimr::NArrow::NSerialization { - -arrow::Result> TBatchPayloadDeserializer::DoDeserialize(const TString& data) const { - arrow::ipc::DictionaryMemo dictMemo; - auto options = arrow::ipc::IpcReadOptions::Defaults(); - options.use_threads = false; - - std::shared_ptr buffer(std::make_shared(data)); - arrow::io::BufferReader reader(buffer); - AFL_TRACE(NKikimrServices::ARROW_HELPER)("event", "parsing")("size", data.size())("columns", Schema->num_fields()); - auto batchResult = arrow::ipc::ReadRecordBatch(Schema, &dictMemo, options, &reader); - if (!batchResult.ok()) { - return batchResult; - } - std::shared_ptr batch = *batchResult; - if (!batch) { - return arrow::Status(arrow::StatusCode::SerializationError, "empty batch"); - } - auto validation = batch->Validate(); - if (!validation.ok()) { - return arrow::Status(arrow::StatusCode::SerializationError, "batch is not valid: " + validation.ToString()); - } - return batch; -} - -TString TBatchPayloadSerializer::DoSerialize(const std::shared_ptr& batch) const { - arrow::ipc::IpcPayload payload; - // Build payload. Compression if set up performed here. - TStatusValidator::Validate(arrow::ipc::GetRecordBatchPayload(*batch, Options, &payload)); - - int32_t metadata_length = 0; - arrow::io::MockOutputStream mock; - // Process prepared payload through mock stream. Fast and efficient. - TStatusValidator::Validate(arrow::ipc::WriteIpcPayload(payload, Options, &mock, &metadata_length)); - - TString str; - str.resize(mock.GetExtentBytesWritten()); - - TFixedStringOutputStream out(&str); - // Write prepared payload into the resultant string. No extra allocation will be made. - TStatusValidator::Validate(arrow::ipc::WriteIpcPayload(payload, Options, &out, &metadata_length)); - Y_ABORT_UNLESS(out.GetPosition() == str.size()); - Y_DEBUG_ABORT_UNLESS(TBatchPayloadDeserializer(batch->schema()).Deserialize(str).ok()); - AFL_DEBUG(NKikimrServices::ARROW_HELPER)("event", "serialize")("size", str.size())("columns", batch->schema()->num_fields()); - return str; -} - -} diff --git a/ydb/core/formats/arrow/serializer/batch_only.h b/ydb/core/formats/arrow/serializer/batch_only.h deleted file mode 100644 index b3dfda9e7ffb..000000000000 --- a/ydb/core/formats/arrow/serializer/batch_only.h +++ /dev/null @@ -1,38 +0,0 @@ -#pragma once -#include "abstract.h" -#include -#include - -namespace NKikimr::NArrow::NSerialization { - -class TBatchPayloadSerializer: public ISerializer { -private: - const arrow::ipc::IpcWriteOptions Options; -protected: - virtual TString DoSerialize(const std::shared_ptr& batch) const override; -public: - virtual bool IsHardPacker() const override { - return Options.codec && Options.codec->compression_type() == arrow::Compression::ZSTD && Options.codec->compression_level() > 3; - } - TBatchPayloadSerializer(const arrow::ipc::IpcWriteOptions& options) - : Options(options) { - - } -}; - -class TBatchPayloadDeserializer: public IDeserializer { -private: - const std::shared_ptr Schema; -protected: - virtual arrow::Result> DoDeserialize(const TString& data) const override; - virtual TString DoDebugString() const override { - return "type=BATCH_PAYLOAD;"; - } -public: - TBatchPayloadDeserializer(const std::shared_ptr schema) - : Schema(schema) { - - } -}; - -} diff --git a/ydb/core/formats/arrow/serializer/full.cpp b/ydb/core/formats/arrow/serializer/full.cpp deleted file mode 100644 index 9f830c3662cb..000000000000 --- a/ydb/core/formats/arrow/serializer/full.cpp +++ /dev/null @@ -1,54 +0,0 @@ -#include "full.h" -#include "stream.h" -#include -#include -#include -#include -#include -#include -#include -namespace NKikimr::NArrow::NSerialization { - -arrow::Result> TFullDataDeserializer::DoDeserialize(const TString& data) const { - arrow::ipc::DictionaryMemo dictMemo; - auto options = arrow::ipc::IpcReadOptions::Defaults(); - options.use_threads = false; - - std::shared_ptr buffer(std::make_shared(data)); - arrow::io::BufferReader readerStream(buffer); - auto reader = TStatusValidator::GetValid(arrow::ipc::RecordBatchStreamReader::Open(&readerStream)); - - std::shared_ptr batch; - auto readResult = reader->ReadNext(&batch); - if (!readResult.ok()) { - return readResult; - } - if (!batch) { - return arrow::Status(arrow::StatusCode::SerializationError, "null batch"); - } - auto validation = batch->Validate(); - if (!validation.ok()) { - return arrow::Status(arrow::StatusCode::SerializationError, "validation error: " + validation.ToString()); - } - return batch; -} - -TString TFullDataSerializer::DoSerialize(const std::shared_ptr& batch) const { - TString result; - { - arrow::io::MockOutputStream mock; - auto writer = TStatusValidator::GetValid(arrow::ipc::MakeStreamWriter(&mock, batch->schema(), Options)); - TStatusValidator::Validate(writer->WriteRecordBatch(*batch)); - result.reserve(mock.GetExtentBytesWritten()); - } - { - TStringOutputStream stream(&result); - auto writer = TStatusValidator::GetValid(arrow::ipc::MakeStreamWriter(&stream, batch->schema(), Options)); - TStatusValidator::Validate(writer->WriteRecordBatch(*batch)); - TStatusValidator::Validate(writer->Close()); - Y_ABORT_UNLESS(stream.GetPosition() == result.size()); - } - return result; -} - -} diff --git a/ydb/core/formats/arrow/serializer/full.h b/ydb/core/formats/arrow/serializer/full.h deleted file mode 100644 index 56761a3d752e..000000000000 --- a/ydb/core/formats/arrow/serializer/full.h +++ /dev/null @@ -1,38 +0,0 @@ -#pragma once - -#include "abstract.h" -#include -#include -#include - -namespace NKikimr::NArrow::NSerialization { - -class TFullDataSerializer: public ISerializer { -private: - const arrow::ipc::IpcWriteOptions Options; -protected: - virtual TString DoSerialize(const std::shared_ptr& batch) const override; -public: - virtual bool IsHardPacker() const override { - return Options.codec && Options.codec->compression_type() == arrow::Compression::ZSTD && Options.codec->compression_level() > 3; - } - - TFullDataSerializer(const arrow::ipc::IpcWriteOptions& options) - : Options(options) { - - } -}; - -class TFullDataDeserializer: public IDeserializer { -protected: - virtual arrow::Result> DoDeserialize(const TString& data) const override; - virtual TString DoDebugString() const override { - return "type=FULL_DATA;"; - } -public: - TFullDataDeserializer() { - - } -}; - -} diff --git a/ydb/core/formats/arrow/serializer/native.cpp b/ydb/core/formats/arrow/serializer/native.cpp new file mode 100644 index 000000000000..5a6819ee270a --- /dev/null +++ b/ydb/core/formats/arrow/serializer/native.cpp @@ -0,0 +1,185 @@ +#include "native.h" +#include "stream.h" +#include "parsing.h" +#include +#include + +#include +#include + +#include +#include +#include +#include +#include + +namespace NKikimr::NArrow::NSerialization { + +arrow::Result> TNativeSerializer::DoDeserialize(const TString& data) const { + arrow::ipc::DictionaryMemo dictMemo; + auto options = arrow::ipc::IpcReadOptions::Defaults(); + options.use_threads = false; + + std::shared_ptr buffer(std::make_shared(data)); + arrow::io::BufferReader readerStream(buffer); + auto reader = TStatusValidator::GetValid(arrow::ipc::RecordBatchStreamReader::Open(&readerStream)); + + std::shared_ptr batch; + auto readResult = reader->ReadNext(&batch); + if (!readResult.ok()) { + return readResult; + } + if (!batch) { + return arrow::Status(arrow::StatusCode::SerializationError, "null batch"); + } + auto validation = batch->Validate(); + if (!validation.ok()) { + return arrow::Status(arrow::StatusCode::SerializationError, "validation error: " + validation.ToString()); + } + return batch; +} + +TString TNativeSerializer::DoSerializeFull(const std::shared_ptr& batch) const { + TString result; + { + arrow::io::MockOutputStream mock; + auto writer = TStatusValidator::GetValid(arrow::ipc::MakeStreamWriter(&mock, batch->schema(), Options)); + TStatusValidator::Validate(writer->WriteRecordBatch(*batch)); + result.reserve(mock.GetExtentBytesWritten()); + } + { + TStringOutputStream stream(&result); + auto writer = TStatusValidator::GetValid(arrow::ipc::MakeStreamWriter(&stream, batch->schema(), Options)); + TStatusValidator::Validate(writer->WriteRecordBatch(*batch)); + TStatusValidator::Validate(writer->Close()); + Y_ABORT_UNLESS(stream.GetPosition() == result.size()); + } + return result; +} + +arrow::Result> TNativeSerializer::DoDeserialize(const TString& data, const std::shared_ptr& schema) const { + arrow::ipc::DictionaryMemo dictMemo; + auto options = arrow::ipc::IpcReadOptions::Defaults(); + options.use_threads = false; + + std::shared_ptr buffer(std::make_shared(data)); + arrow::io::BufferReader reader(buffer); + AFL_TRACE(NKikimrServices::ARROW_HELPER)("event", "parsing")("size", data.size())("columns", schema->num_fields()); + auto batchResult = arrow::ipc::ReadRecordBatch(schema, &dictMemo, options, &reader); + if (!batchResult.ok()) { + return batchResult; + } + std::shared_ptr batch = *batchResult; + if (!batch) { + return arrow::Status(arrow::StatusCode::SerializationError, "empty batch"); + } + auto validation = batch->Validate(); + if (!validation.ok()) { + return arrow::Status(arrow::StatusCode::SerializationError, "batch is not valid: " + validation.ToString()); + } + return batch; +} + +TString TNativeSerializer::DoSerializePayload(const std::shared_ptr& batch) const { + arrow::ipc::IpcPayload payload; + // Build payload. Compression if set up performed here. + TStatusValidator::Validate(arrow::ipc::GetRecordBatchPayload(*batch, Options, &payload)); + + int32_t metadata_length = 0; + arrow::io::MockOutputStream mock; + // Process prepared payload through mock stream. Fast and efficient. + TStatusValidator::Validate(arrow::ipc::WriteIpcPayload(payload, Options, &mock, &metadata_length)); + + TString str; + str.resize(mock.GetExtentBytesWritten()); + + TFixedStringOutputStream out(&str); + // Write prepared payload into the resultant string. No extra allocation will be made. + TStatusValidator::Validate(arrow::ipc::WriteIpcPayload(payload, Options, &out, &metadata_length)); + Y_ABORT_UNLESS(out.GetPosition() == str.size()); + Y_DEBUG_ABORT_UNLESS(Deserialize(str, batch->schema()).ok()); + AFL_DEBUG(NKikimrServices::ARROW_HELPER)("event", "serialize")("size", str.size())("columns", batch->schema()->num_fields()); + return str; +} + +NKikimr::TConclusion> TNativeSerializer::BuildCodec(const arrow::Compression::type& cType, const std::optional level) const { + auto codec = NArrow::TStatusValidator::GetValid(arrow::util::Codec::Create(cType)); + if (!codec) { + return std::shared_ptr(); + } + const int levelDef = level.value_or(codec->default_compression_level()); + const int levelMin = codec->minimum_compression_level(); + const int levelMax = codec->maximum_compression_level(); + if (levelDef < levelMin || levelMax < levelDef) { + return TConclusionStatus::Fail( + TStringBuilder() << "incorrect level for codec. have to be: [" << levelMin << ":" << levelMax << "]" + ); + } + std::shared_ptr codecPtr = std::move(NArrow::TStatusValidator::GetValid(arrow::util::Codec::Create(cType, levelDef))); + return codecPtr; +} + +NKikimr::TConclusionStatus TNativeSerializer::DoDeserializeFromRequest(NYql::TFeaturesExtractor& features) { + std::optional codec; + std::optional level; + { + auto fValue = features.Extract("COMPRESSION.TYPE"); + if (!fValue) { + return TConclusionStatus::Fail("not defined COMPRESSION.TYPE as arrow::Compression"); + } + codec = NArrow::CompressionFromString(*fValue); + if (!codec) { + return TConclusionStatus::Fail("cannot parse COMPRESSION.TYPE as arrow::Compression"); + } + } + { + auto fValue = features.Extract("COMPRESSION.LEVEL"); + if (fValue) { + ui32 levelLocal; + if (!TryFromString(*fValue, levelLocal)) { + return TConclusionStatus::Fail("cannot parse COMPRESSION.LEVEL as ui32"); + } + level = levelLocal; + } + } + auto codecPtrStatus = BuildCodec(codec.value_or(Options.codec->compression_type()), level); + if (!codecPtrStatus) { + return codecPtrStatus.GetError(); + } + Options.codec = *codecPtrStatus; + return TConclusionStatus::Success(); +} + +NKikimr::TConclusionStatus TNativeSerializer::DoDeserializeFromProto(const NKikimrSchemeOp::TOlapColumn::TSerializer& proto) { + if (!proto.HasArrowCompression()) { + return TConclusionStatus::Fail("no arrow serializer data in proto"); + } + auto compression = proto.GetArrowCompression(); + if (!compression.HasCodec()) { + Options = GetDefaultOptions(); + return TConclusionStatus::Success(); + } + std::optional codec = NArrow::CompressionFromProto(compression.GetCodec()); + if (!codec) { + return TConclusionStatus::Fail("cannot parse codec type from proto"); + } + std::optional level; + if (compression.HasLevel()) { + level = compression.GetLevel(); + } + + Options.use_threads = false; + auto result = BuildCodec(*codec, level); + if (!result) { + return result.GetError(); + } + Options.codec = *result; + return TConclusionStatus::Success(); +} + +void TNativeSerializer::DoSerializeToProto(NKikimrSchemeOp::TOlapColumn::TSerializer& proto) const { + proto.MutableArrowCompression()->SetCodec(NArrow::CompressionToProto(Options.codec->compression_type())); + proto.MutableArrowCompression()->SetLevel(Options.codec->compression_level()); +} + +} diff --git a/ydb/core/formats/arrow/serializer/native.h b/ydb/core/formats/arrow/serializer/native.h new file mode 100644 index 000000000000..ece3e9e34fc9 --- /dev/null +++ b/ydb/core/formats/arrow/serializer/native.h @@ -0,0 +1,72 @@ +#pragma once + +#include "abstract.h" + +#include + +#include +#include + +#include +#include + +namespace NKikimr::NArrow::NSerialization { + +class TNativeSerializer: public ISerializer { +public: + static TString GetClassNameStatic() { + return "ARROW_SERIALIZER"; + } +private: + arrow::ipc::IpcWriteOptions Options; + + TConclusion> BuildCodec(const arrow::Compression::type& cType, const std::optional level) const; + static const inline TFactory::TRegistrator Registrator = TFactory::TRegistrator(GetClassNameStatic()); +protected: + virtual TString DoSerializeFull(const std::shared_ptr& batch) const override; + virtual TString DoSerializePayload(const std::shared_ptr& batch) const override; + virtual arrow::Result> DoDeserialize(const TString& data) const override; + virtual arrow::Result> DoDeserialize(const TString& data, const std::shared_ptr& schema) const override; + + virtual TConclusionStatus DoDeserializeFromRequest(NYql::TFeaturesExtractor& features) override; + + static arrow::ipc::IpcOptions BuildDefaultOptions() { + arrow::ipc::IpcWriteOptions options; + options.use_threads = false; + options.codec = *arrow::util::Codec::Create(arrow::Compression::LZ4_FRAME); + return options; + } + + virtual TConclusionStatus DoDeserializeFromProto(const NKikimrSchemeOp::TOlapColumn::TSerializer& proto) override; + + virtual void DoSerializeToProto(NKikimrSchemeOp::TOlapColumn::TSerializer& proto) const override; + +public: + virtual TString GetClassName() const override { + return GetClassNameStatic(); + } + + virtual bool IsHardPacker() const override { + return Options.codec && Options.codec->compression_type() == arrow::Compression::ZSTD && Options.codec->compression_level() > 3; + } + + static arrow::ipc::IpcOptions GetDefaultOptions() { + static arrow::ipc::IpcWriteOptions options = BuildDefaultOptions(); + return options; + } + + TNativeSerializer(const arrow::Compression::type compressionType) { + Options.use_threads = false; + auto r = arrow::util::Codec::Create(compressionType); + AFL_VERIFY(r.ok()); + Options.codec = std::move(*r); + } + + TNativeSerializer(const arrow::ipc::IpcWriteOptions& options = GetDefaultOptions()) + : Options(options) { + Options.use_threads = false; + + } +}; + +} diff --git a/ydb/core/formats/arrow/compression/parsing.cpp b/ydb/core/formats/arrow/serializer/parsing.cpp similarity index 100% rename from ydb/core/formats/arrow/compression/parsing.cpp rename to ydb/core/formats/arrow/serializer/parsing.cpp diff --git a/ydb/core/formats/arrow/compression/parsing.h b/ydb/core/formats/arrow/serializer/parsing.h similarity index 100% rename from ydb/core/formats/arrow/compression/parsing.h rename to ydb/core/formats/arrow/serializer/parsing.h diff --git a/ydb/core/formats/arrow/serializer/ya.make b/ydb/core/formats/arrow/serializer/ya.make index 558825873a2c..bf7e091ab4bf 100644 --- a/ydb/core/formats/arrow/serializer/ya.make +++ b/ydb/core/formats/arrow/serializer/ya.make @@ -3,15 +3,16 @@ LIBRARY() PEERDIR( contrib/libs/apache/arrow ydb/core/formats/arrow/common + ydb/services/metadata/abstract ydb/library/actors/core ydb/core/protos ) SRCS( abstract.cpp - full.cpp - batch_only.cpp + GLOBAL native.cpp stream.cpp + parsing.cpp ) END() diff --git a/ydb/core/formats/arrow/special_keys.cpp b/ydb/core/formats/arrow/special_keys.cpp index 0006b339464a..b84fa44799c6 100644 --- a/ydb/core/formats/arrow/special_keys.cpp +++ b/ydb/core/formats/arrow/special_keys.cpp @@ -1,7 +1,7 @@ #include "special_keys.h" #include "permutations.h" #include "reader/read_filter_merger.h" -#include +#include #include #include @@ -11,7 +11,7 @@ bool TSpecialKeys::DeserializeFromString(const TString& data) { if (!data) { return false; } - Data = NArrow::TStatusValidator::GetValid(NArrow::NSerialization::TFullDataDeserializer().Deserialize(data)); + Data = NArrow::TStatusValidator::GetValid(NArrow::NSerialization::TSerializerContainer::GetDefaultSerializer()->Deserialize(data)); return !!Data; } @@ -25,7 +25,7 @@ NKikimr::NArrow::TReplaceKey TSpecialKeys::GetKeyByIndex(const ui32 position, co } TString TSpecialKeys::SerializeToString() const { - return NArrow::NSerialization::TFullDataSerializer(arrow::ipc::IpcWriteOptions::Defaults()).Serialize(Data); + return NArrow::NSerialization::TSerializerContainer::GetDefaultSerializer()->SerializeFull(Data); } TString TSpecialKeys::SerializeToStringDataOnlyNoCompression() const { diff --git a/ydb/core/formats/arrow/ut/ut_dictionary.cpp b/ydb/core/formats/arrow/ut/ut_dictionary.cpp index c723eb1957c6..c3df2c6a30f0 100644 --- a/ydb/core/formats/arrow/ut/ut_dictionary.cpp +++ b/ydb/core/formats/arrow/ut/ut_dictionary.cpp @@ -1,7 +1,6 @@ #include #include -#include -#include +#include #include #include #include @@ -13,13 +12,13 @@ Y_UNIT_TEST_SUITE(Dictionary) { ui64 Test(NConstruction::IArrayBuilder::TPtr column, const arrow::ipc::IpcWriteOptions& options, const ui32 bSize) { std::shared_ptr batch = NConstruction::TRecordBatchConstructor({ column }).BuildBatch(bSize); - const TString data = NSerialization::TFullDataSerializer(options).Serialize(batch); - auto deserializedBatch = *NSerialization::TFullDataDeserializer().Deserialize(data); + const TString data = NSerialization::TNativeSerializer(options).SerializeFull(batch); + auto deserializedBatch = *NSerialization::TNativeSerializer().Deserialize(data); Y_ABORT_UNLESS(!!deserializedBatch); auto originalBatchTransformed = DictionaryToArray(batch); auto roundBatchTransformed = DictionaryToArray(deserializedBatch); - const TString roundUnpacked = NSerialization::TFullDataSerializer(options).Serialize(roundBatchTransformed); - const TString roundTransformed = NSerialization::TFullDataSerializer(options).Serialize(originalBatchTransformed); + const TString roundUnpacked = NSerialization::TNativeSerializer(options).SerializeFull(roundBatchTransformed); + const TString roundTransformed = NSerialization::TNativeSerializer(options).SerializeFull(originalBatchTransformed); Y_ABORT_UNLESS(roundBatchTransformed->num_rows() == originalBatchTransformed->num_rows()); Y_ABORT_UNLESS(roundUnpacked == roundTransformed); return data.size(); @@ -154,8 +153,8 @@ Y_UNIT_TEST_SUITE(Dictionary) { "field", NConstruction::TStringPoolFiller(pSize, strLen) ); std::shared_ptr batch = NConstruction::TRecordBatchConstructor({ column }).BuildBatch(bSize); - const TString dataFull = NSerialization::TFullDataSerializer(options).Serialize(batch); - const TString dataPayload = NSerialization::TBatchPayloadSerializer(options).Serialize(batch); + const TString dataFull = NSerialization::TNativeSerializer(options).SerializeFull(batch); + const TString dataPayload = NSerialization::TNativeSerializer(options).SerializePayload(batch); bytesFull = dataFull.size(); bytesPayload = dataPayload.size(); } diff --git a/ydb/core/formats/arrow/ut/ut_size_calcer.cpp b/ydb/core/formats/arrow/ut/ut_size_calcer.cpp index 4a8413dcd5fc..24d2c52d9217 100644 --- a/ydb/core/formats/arrow/ut/ut_size_calcer.cpp +++ b/ydb/core/formats/arrow/ut/ut_size_calcer.cpp @@ -1,7 +1,5 @@ #include #include -#include -#include #include #include #include diff --git a/ydb/core/grpc_services/rpc_log_store.cpp b/ydb/core/grpc_services/rpc_log_store.cpp index 2e3453d5df96..10d9ac929f5f 100644 --- a/ydb/core/grpc_services/rpc_log_store.cpp +++ b/ydb/core/grpc_services/rpc_log_store.cpp @@ -42,16 +42,16 @@ bool ConvertCompressionFromPublicToInternal(const Ydb::LogStore::Compression& fr error = "LogStores with no compression are disabled."; return false; case Ydb::LogStore::Compression::CODEC_LZ4: - to.SetCompressionCodec(NKikimrSchemeOp::ColumnCodecLZ4); + to.SetCodec(NKikimrSchemeOp::ColumnCodecLZ4); break; case Ydb::LogStore::Compression::CODEC_ZSTD: - to.SetCompressionCodec(NKikimrSchemeOp::ColumnCodecZSTD); + to.SetCodec(NKikimrSchemeOp::ColumnCodecZSTD); break; default: break; } if (from.compression_level()) { - to.SetCompressionLevel(from.compression_level()); + to.SetLevel(from.compression_level()); } return true; } @@ -60,7 +60,7 @@ void ConvertCompressionFromInternalToPublic(const NKikimrSchemeOp::TCompressionO Ydb::LogStore::Compression& to) { to.set_compression_codec(Ydb::LogStore::Compression::CODEC_LZ4); // LZ4 if not set - switch (from.GetCompressionCodec()) { + switch (from.GetCodec()) { case NKikimrSchemeOp::ColumnCodecPlain: to.set_compression_codec(Ydb::LogStore::Compression::CODEC_PLAIN); break; @@ -73,7 +73,7 @@ void ConvertCompressionFromInternalToPublic(const NKikimrSchemeOp::TCompressionO default: break; } - to.set_compression_level(from.GetCompressionLevel()); + to.set_compression_level(from.GetLevel()); } bool ConvertSchemaFromPublicToInternal(const Ydb::LogStore::Schema& from, NKikimrSchemeOp::TColumnTableSchema& to, diff --git a/ydb/core/grpc_services/rpc_long_tx.cpp b/ydb/core/grpc_services/rpc_long_tx.cpp index 59dc26c2990d..38a29ce77520 100644 --- a/ydb/core/grpc_services/rpc_long_tx.cpp +++ b/ydb/core/grpc_services/rpc_long_tx.cpp @@ -6,7 +6,6 @@ #include #include #include -#include #include #include #include diff --git a/ydb/core/kqp/compute_actor/kqp_compute_events.h b/ydb/core/kqp/compute_actor/kqp_compute_events.h index 5d57f94fa409..f31f946d28fd 100644 --- a/ydb/core/kqp/compute_actor/kqp_compute_events.h +++ b/ydb/core/kqp/compute_actor/kqp_compute_events.h @@ -6,7 +6,6 @@ #include #include -#include namespace NKikimr::NKqp { diff --git a/ydb/core/kqp/gateway/behaviour/tablestore/operations/alter_column.cpp b/ydb/core/kqp/gateway/behaviour/tablestore/operations/alter_column.cpp index e7706d1093c0..c3b65e981194 100644 --- a/ydb/core/kqp/gateway/behaviour/tablestore/operations/alter_column.cpp +++ b/ydb/core/kqp/gateway/behaviour/tablestore/operations/alter_column.cpp @@ -17,9 +17,9 @@ TConclusionStatus TAlterColumnOperation::DoDeserialize(NYql::TObjectSettingsImpl } } { - auto result = CompressionDiff.DeserializeFromRequestFeatures(features); - if (!result) { - return TConclusionStatus::Fail(result.GetErrorMessage()); + auto status = Serializer.DeserializeFromRequest(features); + if (!status) { + return status; } } return TConclusionStatus::Success(); @@ -28,7 +28,9 @@ TConclusionStatus TAlterColumnOperation::DoDeserialize(NYql::TObjectSettingsImpl void TAlterColumnOperation::DoSerializeScheme(NKikimrSchemeOp::TAlterColumnTableSchema& schemaData) const { auto* column = schemaData.AddAlterColumns(); column->SetName(ColumnName); - *column->MutableCompression() = CompressionDiff.SerializeToProto(); + if (!!Serializer) { + Serializer.SerializeToProto(*column->MutableSerializer()); + } *column->MutableDictionaryEncoding() = DictionaryEncodingDiff.SerializeToProto(); } diff --git a/ydb/core/kqp/gateway/behaviour/tablestore/operations/alter_column.h b/ydb/core/kqp/gateway/behaviour/tablestore/operations/alter_column.h index 803ffd5464f9..81c0e362be3d 100644 --- a/ydb/core/kqp/gateway/behaviour/tablestore/operations/alter_column.h +++ b/ydb/core/kqp/gateway/behaviour/tablestore/operations/alter_column.h @@ -1,5 +1,5 @@ #include "abstract.h" -#include +#include #include namespace NKikimr::NKqp::NColumnshard { @@ -14,7 +14,7 @@ class TAlterColumnOperation : public ITableStoreOperation { TString ColumnName; - NArrow::TCompressionDiff CompressionDiff; + NArrow::NSerialization::TSerializerContainer Serializer; NArrow::NDictionary::TEncodingDiff DictionaryEncodingDiff; public: TConclusionStatus DoDeserialize(NYql::TObjectSettingsImpl::TFeaturesExtractor& features) override; diff --git a/ydb/core/kqp/gateway/behaviour/tablestore/operations/ya.make b/ydb/core/kqp/gateway/behaviour/tablestore/operations/ya.make index 08467f55d565..3301f543b8f6 100644 --- a/ydb/core/kqp/gateway/behaviour/tablestore/operations/ya.make +++ b/ydb/core/kqp/gateway/behaviour/tablestore/operations/ya.make @@ -11,7 +11,7 @@ SRCS( PEERDIR( ydb/services/metadata/manager - ydb/core/formats/arrow/compression + ydb/core/formats/arrow/serializer ydb/core/kqp/gateway/utils ydb/core/protos ) diff --git a/ydb/core/kqp/ut/common/columnshard.cpp b/ydb/core/kqp/ut/common/columnshard.cpp index 99a10e26ecad..085415d36c59 100644 --- a/ydb/core/kqp/ut/common/columnshard.cpp +++ b/ydb/core/kqp/ut/common/columnshard.cpp @@ -1,5 +1,4 @@ #include "columnshard.h" -#include #include namespace NKikimr { diff --git a/ydb/core/kqp/ut/olap/kqp_olap_ut.cpp b/ydb/core/kqp/ut/olap/kqp_olap_ut.cpp index 76a94877e767..417ba6527433 100644 --- a/ydb/core/kqp/ut/olap/kqp_olap_ut.cpp +++ b/ydb/core/kqp/ut/olap/kqp_olap_ut.cpp @@ -29,7 +29,6 @@ #include #include -#include namespace NKikimr { namespace NKqp { @@ -1367,7 +1366,7 @@ Y_UNIT_TEST_SUITE(KqpOlap) { CompareYson(result, R"([[1u;]])"); } - AFL_VERIFY(csController->GetIndexesApprovedOnSelect().Val() < 0.15 * csController->GetIndexesSkippingOnSelect().Val()); + AFL_VERIFY(csController->GetIndexesApprovedOnSelect().Val() < 0.20 * csController->GetIndexesSkippingOnSelect().Val()); } @@ -3797,6 +3796,12 @@ Y_UNIT_TEST_SUITE(KqpOlap) { Y_ABORT_UNLESS(d.GetMaxCount() - d.GetMinCount() <= 2); } } + { + auto alterQuery = TStringBuilder() << "ALTER OBJECT `/Root/olapStore` (TYPE TABLESTORE) SET (ACTION=ALTER_COLUMN, NAME=field, `SERIALIZER.CLASS_NAME`=`ARROW_SERIALIZER`, `COMPRESSION.TYPE`=`zstd`);"; + auto session = tableClient.CreateSession().GetValueSync().GetSession(); + auto alterResult = session.ExecuteSchemeQuery(alterQuery).GetValueSync(); + UNIT_ASSERT_VALUES_EQUAL_C(alterResult.GetStatus(), EStatus::SUCCESS, alterResult.GetIssues().ToString()); + } } const ui64 rawBytesUnpack = rawBytesUnpack1PK - rawBytesPK1; const ui64 bytesUnpack = bytesUnpack1PK - bytesPK1; diff --git a/ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp b/ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp index b2bad6ad8ac2..e0ab76506b08 100644 --- a/ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp +++ b/ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp @@ -7,7 +7,6 @@ #include #include #include -#include #include diff --git a/ydb/core/kqp/ut/scheme/kqp_scheme_ut.cpp b/ydb/core/kqp/ut/scheme/kqp_scheme_ut.cpp index 1f53b50a8337..3c13d8c27b4d 100644 --- a/ydb/core/kqp/ut/scheme/kqp_scheme_ut.cpp +++ b/ydb/core/kqp/ut/scheme/kqp_scheme_ut.cpp @@ -7,7 +7,6 @@ #include #include #include -#include #include #include diff --git a/ydb/core/protos/config.proto b/ydb/core/protos/config.proto index 9f0f5a1e52a7..b5a2f5e034fe 100644 --- a/ydb/core/protos/config.proto +++ b/ydb/core/protos/config.proto @@ -1489,6 +1489,7 @@ message TColumnShardConfig { optional uint32 WritingBufferDurationMs = 8 [default = 0]; optional bool UseChunkedMergeOnCompaction = 9 [default = true]; optional uint64 CompactionMemoryLimit = 10 [default = 536870912]; + optional uint64 TieringsMemoryLimit = 11 [default = 536870912]; } message TSchemeShardConfig { diff --git a/ydb/core/protos/flat_scheme_op.proto b/ydb/core/protos/flat_scheme_op.proto index 22f15326b990..ba7772bcca9c 100644 --- a/ydb/core/protos/flat_scheme_op.proto +++ b/ydb/core/protos/flat_scheme_op.proto @@ -400,14 +400,24 @@ message TDictionaryEncodingSettings { } message TCompressionOptions { - optional EColumnCodec CompressionCodec = 2; // LZ4 (in arrow LZ4_FRAME variant) if not set - optional int32 CompressionLevel = 3; // Use default compression level if not set (0 != not set) + optional EColumnCodec Codec = 2; // LZ4 (in arrow LZ4_FRAME variant) if not set + optional int32 Level = 3; // Use default compression level if not set (0 != not set) +} + +message TOlapColumn { + + message TSerializer { + optional string ClassName = 1; + oneof Implementation { + TCompressionOptions ArrowCompression = 40; + } + } } message TOlapColumnDiff { optional string Name = 1; - optional TCompressionOptions Compression = 2; optional TDictionaryEncodingSettings DictionaryEncoding = 4; + optional TOlapColumn.TSerializer Serializer = 5; } message TOlapColumnDescription { @@ -422,8 +432,9 @@ message TOlapColumnDescription { optional NKikimrProto.TTypeInfo TypeInfo = 6; optional bool NotNull = 7; - optional TCompressionOptions Compression = 8; + optional TCompressionOptions Compression = 8[deprecated = true]; optional TDictionaryEncodingSettings DictionaryEncoding = 9; + optional TOlapColumn.TSerializer Serializer = 10; } message TRequestedBloomFilter { diff --git a/ydb/core/tablet/resource_broker.cpp b/ydb/core/tablet/resource_broker.cpp index 5583ff718686..700a04135197 100644 --- a/ydb/core/tablet/resource_broker.cpp +++ b/ydb/core/tablet/resource_broker.cpp @@ -1269,6 +1269,7 @@ NKikimrResourceBroker::TResourceBrokerConfig MakeDefaultConfig() const ui64 KqpRmQueueCPU = 4; const ui64 KqpRmQueueMemory = 10ULL << 30; + const ui64 CSTTLCompactionMemoryLimit = 1ULL << 30; const ui64 CSInsertCompactionMemoryLimit = 1ULL << 30; const ui64 CSGeneralCompactionMemoryLimit = 3ULL << 30; const ui64 CSScanMemoryLimit = 3ULL << 30; @@ -1314,6 +1315,12 @@ NKikimrResourceBroker::TResourceBrokerConfig MakeDefaultConfig() queue->MutableLimit()->SetCpu(3); queue->MutableLimit()->SetMemory(CSInsertCompactionMemoryLimit); + queue = config.AddQueues(); + queue->SetName("queue_cs_ttl"); + queue->SetWeight(100); + queue->MutableLimit()->SetCpu(3); + queue->MutableLimit()->SetMemory(CSTTLCompactionMemoryLimit); + queue = config.AddQueues(); queue->SetName("queue_cs_general"); queue->SetWeight(100); @@ -1413,6 +1420,11 @@ NKikimrResourceBroker::TResourceBrokerConfig MakeDefaultConfig() task->SetQueueName("queue_compaction_borrowed"); task->SetDefaultDuration(TDuration::Minutes(10).GetValue()); + task = config.AddTasks(); + task->SetName("CS::TTL"); + task->SetQueueName("queue_cs_ttl"); + task->SetDefaultDuration(TDuration::Minutes(10).GetValue()); + task = config.AddTasks(); task->SetName("CS::INDEXATION"); task->SetQueueName("queue_cs_indexation"); diff --git a/ydb/core/tx/columnshard/blobs_action/counters/storage.cpp b/ydb/core/tx/columnshard/blobs_action/counters/storage.cpp index e7c30dc5ee4f..8d8d9733e40f 100644 --- a/ydb/core/tx/columnshard/blobs_action/counters/storage.cpp +++ b/ydb/core/tx/columnshard/blobs_action/counters/storage.cpp @@ -9,11 +9,7 @@ TStorageCounters::TStorageCounters(const TString& storageId) } std::shared_ptr TStorageCounters::GetConsumerCounter(const TString& consumerId) { - auto it = ConsumerCounters.find(consumerId); - if (it == ConsumerCounters.end()) { - it = ConsumerCounters.emplace(consumerId, std::make_shared(consumerId, *this)).first; - } - return it->second; + return std::make_shared(consumerId, *this); } TConsumerCounters::TConsumerCounters(const TString& consumerId, const TStorageCounters& parent) diff --git a/ydb/core/tx/columnshard/blobs_action/counters/storage.h b/ydb/core/tx/columnshard/blobs_action/counters/storage.h index e92ca28bda20..902766af1545 100644 --- a/ydb/core/tx/columnshard/blobs_action/counters/storage.h +++ b/ydb/core/tx/columnshard/blobs_action/counters/storage.h @@ -25,7 +25,6 @@ class TConsumerCounters: public NColumnShard::TCommonCountersOwner { class TStorageCounters: public NColumnShard::TCommonCountersOwner { private: using TBase = NColumnShard::TCommonCountersOwner; - THashMap> ConsumerCounters; public: TStorageCounters(const TString& storageId); diff --git a/ydb/core/tx/columnshard/blobs_action/tier/gc.cpp b/ydb/core/tx/columnshard/blobs_action/tier/gc.cpp index d1b509cbef0c..b44019f880ae 100644 --- a/ydb/core/tx/columnshard/blobs_action/tier/gc.cpp +++ b/ydb/core/tx/columnshard/blobs_action/tier/gc.cpp @@ -9,12 +9,12 @@ void TGCTask::DoOnExecuteTxAfterCleaning(NColumnShard::TColumnShard& /*self*/, N size_t numBlobs = 0; for (; DraftBlobIds.size() && numBlobs < NColumnShard::TLimits::MAX_BLOBS_TO_DELETE; ++numBlobs) { - dbBlobs.EraseBlobToKeep(DraftBlobIds.front()); + dbBlobs.RemoveTierDraftBlobId(GetStorageId(), DraftBlobIds.front()); DraftBlobIds.pop_front(); } for (; DeleteBlobIds.size() && numBlobs < NColumnShard::TLimits::MAX_BLOBS_TO_DELETE; ++numBlobs) { - dbBlobs.EraseBlobToDelete(DeleteBlobIds.front()); + dbBlobs.RemoveTierBlobToDelete(GetStorageId(), DeleteBlobIds.front()); DeleteBlobIds.pop_front(); } } diff --git a/ydb/core/tx/columnshard/blobs_action/tier/write.cpp b/ydb/core/tx/columnshard/blobs_action/tier/write.cpp index fa54aa75fadf..9620f8d37e55 100644 --- a/ydb/core/tx/columnshard/blobs_action/tier/write.cpp +++ b/ydb/core/tx/columnshard/blobs_action/tier/write.cpp @@ -24,7 +24,6 @@ void TWriteAction::DoOnExecuteTxAfterWrite(NColumnShard::TColumnShard& /*self*/, for (auto&& i : GetBlobsForWrite()) { dbBlobs.RemoveTierDraftBlobId(GetStorageId(), i.first); dbBlobs.AddTierBlobToDelete(GetStorageId(), i.first); - GCInfo->MutableBlobsToDelete().emplace_back(i.first); } } } @@ -41,4 +40,12 @@ NKikimr::NOlap::TUnifiedBlobId TWriteAction::AllocateNextBlobId(const TString& d return TUnifiedBlobId(Max(), TLogoBlobID(TabletId, now.GetValue() >> 32, now.GetValue() & Max(), TLogoBlobID::MaxChannel, data.size(), AtomicIncrement(Counter) % TLogoBlobID::MaxCookie, 1)); } +void TWriteAction::DoOnCompleteTxAfterWrite(NColumnShard::TColumnShard& /*self*/, const bool blobsWroteSuccessfully) { + if (!blobsWroteSuccessfully) { + for (auto&& i : GetBlobsForWrite()) { + GCInfo->MutableBlobsToDelete().emplace_back(i.first); + } + } +} + } diff --git a/ydb/core/tx/columnshard/blobs_action/tier/write.h b/ydb/core/tx/columnshard/blobs_action/tier/write.h index 9d65f971ce6c..425cabc27d51 100644 --- a/ydb/core/tx/columnshard/blobs_action/tier/write.h +++ b/ydb/core/tx/columnshard/blobs_action/tier/write.h @@ -27,9 +27,7 @@ class TWriteAction: public IBlobsWritingAction { } virtual void DoOnExecuteTxAfterWrite(NColumnShard::TColumnShard& self, NColumnShard::TBlobManagerDb& dbBlobs, const bool blobsWroteSuccessfully) override; - virtual void DoOnCompleteTxAfterWrite(NColumnShard::TColumnShard& /*self*/, const bool /*blobsWroteSuccessfully*/) override { - - } + virtual void DoOnCompleteTxAfterWrite(NColumnShard::TColumnShard& /*self*/, const bool blobsWroteSuccessfully) override; public: virtual bool NeedDraftTransaction() const override { return true; diff --git a/ydb/core/tx/columnshard/blobs_action/transaction/tx_write.cpp b/ydb/core/tx/columnshard/blobs_action/transaction/tx_write.cpp index 4d080a3f930b..1701f5ae6a5a 100644 --- a/ydb/core/tx/columnshard/blobs_action/transaction/tx_write.cpp +++ b/ydb/core/tx/columnshard/blobs_action/transaction/tx_write.cpp @@ -111,7 +111,7 @@ void TTxWrite::Complete(const TActorContext& ctx) { for (ui32 i = 0; i < buffer.GetAggregations().size(); ++i) { const auto& writeMeta = buffer.GetAggregations()[i]->GetWriteData()->GetWriteMeta(); ctx.Send(writeMeta.GetSource(), Results[i].release()); - Self->CSCounters.OnWriteTxComplete((now - writeMeta.GetWriteStartInstant()).MilliSeconds()); + Self->CSCounters.OnWriteTxComplete(now - writeMeta.GetWriteStartInstant()); Self->CSCounters.OnSuccessWriteResponse(); } diff --git a/ydb/core/tx/columnshard/blobs_action/transaction/tx_write_index.cpp b/ydb/core/tx/columnshard/blobs_action/transaction/tx_write_index.cpp index cd48f921478b..429696ac9951 100644 --- a/ydb/core/tx/columnshard/blobs_action/transaction/tx_write_index.cpp +++ b/ydb/core/tx/columnshard/blobs_action/transaction/tx_write_index.cpp @@ -85,4 +85,11 @@ TTxWriteIndex::TTxWriteIndex(TColumnShard* self, TEvPrivate::TEvWriteIndex::TPtr Y_ABORT_UNLESS(Ev && Ev->Get()->IndexChanges); } +void TTxWriteIndex::Describe(IOutputStream& out) const noexcept { + out << TypeName(*this); + if (Ev->Get()->IndexChanges) { + out << ": " << Ev->Get()->IndexChanges->DebugString(); + } +} + } diff --git a/ydb/core/tx/columnshard/blobs_action/transaction/tx_write_index.h b/ydb/core/tx/columnshard/blobs_action/transaction/tx_write_index.h index 09922121d15a..5c20461c402a 100644 --- a/ydb/core/tx/columnshard/blobs_action/transaction/tx_write_index.h +++ b/ydb/core/tx/columnshard/blobs_action/transaction/tx_write_index.h @@ -16,6 +16,7 @@ class TTxWriteIndex: public TTransactionBase { bool Execute(TTransactionContext& txc, const TActorContext& ctx) override; void Complete(const TActorContext& ctx) override; TTxType GetTxType() const override { return TXTYPE_WRITE_INDEX; } + virtual void Describe(IOutputStream& out) const noexcept override; private: diff --git a/ydb/core/tx/columnshard/blobs_reader/actor.cpp b/ydb/core/tx/columnshard/blobs_reader/actor.cpp index 6112a82e2633..0ba5d774d2a9 100644 --- a/ydb/core/tx/columnshard/blobs_reader/actor.cpp +++ b/ydb/core/tx/columnshard/blobs_reader/actor.cpp @@ -15,7 +15,7 @@ void TActor::Handle(NBlobCache::TEvBlobCache::TEvReadBlobRangeResult::TPtr& ev) bool aborted = false; if (event.Status != NKikimrProto::EReplyStatus::OK) { WaitingBlobsCount.Sub(Task->GetWaitingCount()); - if (!Task->AddError(event.BlobRange, IBlobsReadingAction::TErrorStatus::Fail(event.Status, "cannot get blob"))) { + if (!Task->AddError(event.BlobRange, IBlobsReadingAction::TErrorStatus::Fail(event.Status, "cannot get blob: " + event.Data.substr(1024)))) { aborted = true; } } else { diff --git a/ydb/core/tx/columnshard/columnshard.cpp b/ydb/core/tx/columnshard/columnshard.cpp index 6923c4f35783..7af0a0e384ed 100644 --- a/ydb/core/tx/columnshard/columnshard.cpp +++ b/ydb/core/tx/columnshard/columnshard.cpp @@ -20,7 +20,7 @@ void TColumnShard::CleanupActors(const TActorContext& ctx) { StoragesManager->Stop(); if (Tiers) { - Tiers->Stop(); + Tiers->Stop(true); } } diff --git a/ydb/core/tx/columnshard/columnshard__write.cpp b/ydb/core/tx/columnshard/columnshard__write.cpp index 101d3a296f96..34c55c811cda 100644 --- a/ydb/core/tx/columnshard/columnshard__write.cpp +++ b/ydb/core/tx/columnshard/columnshard__write.cpp @@ -1,6 +1,7 @@ #include "columnshard_impl.h" #include "blobs_action/transaction/tx_write.h" #include "blobs_action/transaction/tx_draft.h" +#include "counters/columnshard.h" #include "operations/slice_builder.h" #include "operations/write_data.h" @@ -21,9 +22,17 @@ void TColumnShard::OverloadWriteFail(const EOverloadStatus overloadReason, const IncCounter(COUNTER_WRITE_OVERLOAD); CSCounters.OnOverloadInsertTable(writeData.GetSize()); break; - case EOverloadStatus::Shard: + case EOverloadStatus::ShardTxInFly: IncCounter(COUNTER_WRITE_OVERLOAD); - CSCounters.OnOverloadShard(writeData.GetSize()); + CSCounters.OnOverloadShardTx(writeData.GetSize()); + break; + case EOverloadStatus::ShardWritesInFly: + IncCounter(COUNTER_WRITE_OVERLOAD); + CSCounters.OnOverloadShardWrites(writeData.GetSize()); + break; + case EOverloadStatus::ShardWritesSizeInFly: + IncCounter(COUNTER_WRITE_OVERLOAD); + CSCounters.OnOverloadShardWritesSize(writeData.GetSize()); break; case EOverloadStatus::None: Y_ABORT("invalid function usage"); @@ -45,8 +54,20 @@ TColumnShard::EOverloadStatus TColumnShard::CheckOverloaded(const ui64 tableId) return EOverloadStatus::InsertTable; } - if (WritesMonitor.ShardOverloaded()) { - return EOverloadStatus::Shard; + ui64 txLimit = Settings.OverloadTxInFlight; + ui64 writesLimit = Settings.OverloadWritesInFlight; + ui64 writesSizeLimit = Settings.OverloadWritesSizeInFlight; + if (txLimit && Executor()->GetStats().TxInFly > txLimit) { + AFL_WARN(NKikimrServices::TX_COLUMNSHARD)("event", "shard_overload")("reason", "tx_in_fly")("sum", Executor()->GetStats().TxInFly)("limit", txLimit); + return EOverloadStatus::ShardTxInFly; + } + if (writesLimit && WritesMonitor.GetWritesInFlight() > writesLimit) { + AFL_WARN(NKikimrServices::TX_COLUMNSHARD)("event", "shard_overload")("reason", "writes_in_fly")("sum", WritesMonitor.GetWritesInFlight())("limit", writesLimit); + return EOverloadStatus::ShardWritesInFly; + } + if (writesSizeLimit && WritesMonitor.GetWritesSizeInFlight() > writesSizeLimit) { + AFL_WARN(NKikimrServices::TX_COLUMNSHARD)("event", "shard_overload")("reason", "writes_size_in_fly")("sum", WritesMonitor.GetWritesSizeInFlight())("limit", writesSizeLimit); + return EOverloadStatus::ShardWritesSizeInFly; } return EOverloadStatus::None; } @@ -57,7 +78,8 @@ void TColumnShard::Handle(TEvPrivate::TEvWriteBlobsResult::TPtr& ev, const TActo auto& putResult = ev->Get()->GetPutResult(); OnYellowChannels(putResult); NOlap::TWritingBuffer& wBuffer = ev->Get()->MutableWritesBuffer(); - auto& baseAggregations = wBuffer.GetAggregations(); + auto baseAggregations = wBuffer.GetAggregations(); + wBuffer.InitReplyReceived(TMonotonic::Now()); auto wg = WritesMonitor.FinishWrite(wBuffer.GetSumSize(), wBuffer.GetAggregations().size()); @@ -70,13 +92,13 @@ void TColumnShard::Handle(TEvPrivate::TEvWriteBlobsResult::TPtr& ev, const TActo auto result = std::make_unique(TabletID(), writeMeta, NKikimrTxColumnShard::EResultStatus::ERROR); ctx.Send(writeMeta.GetSource(), result.release()); - CSCounters.OnFailedWriteResponse(); + CSCounters.OnFailedWriteResponse(EWriteFailReason::NoTable); wBuffer.RemoveData(aggr, StoragesManager->GetInsertOperator()); continue; } if (putResult.GetPutStatus() != NKikimrProto::OK) { - CSCounters.OnWritePutBlobsFail((TMonotonic::Now() - writeMeta.GetWriteStartInstant()).MilliSeconds()); + CSCounters.OnWritePutBlobsFail(TMonotonic::Now() - writeMeta.GetWriteStartInstant()); IncCounter(COUNTER_WRITE_FAIL); auto errCode = NKikimrTxColumnShard::EResultStatus::STORAGE_ERROR; @@ -97,16 +119,17 @@ void TColumnShard::Handle(TEvPrivate::TEvWriteBlobsResult::TPtr& ev, const TActo auto result = NEvents::TDataEvents::TEvWriteResult::BuildError(TabletID(), operation->GetTxId(), NKikimrDataEvents::TEvWriteResult::STATUS_INTERNAL_ERROR, "put data fails"); ctx.Send(writeMeta.GetSource(), result.release()); } - CSCounters.OnFailedWriteResponse(); + CSCounters.OnFailedWriteResponse(EWriteFailReason::PutBlob); wBuffer.RemoveData(aggr, StoragesManager->GetInsertOperator()); } else { const TMonotonic now = TMonotonic::Now(); - CSCounters.OnWritePutBlobsSuccess((now - writeMeta.GetWriteStartInstant()).MilliSeconds()); - CSCounters.OnWriteMiddle1PutBlobsSuccess((now - writeMeta.GetWriteMiddle1StartInstant()).MilliSeconds()); - CSCounters.OnWriteMiddle2PutBlobsSuccess((now - writeMeta.GetWriteMiddle2StartInstant()).MilliSeconds()); - CSCounters.OnWriteMiddle3PutBlobsSuccess((now - writeMeta.GetWriteMiddle3StartInstant()).MilliSeconds()); - CSCounters.OnWriteMiddle4PutBlobsSuccess((now - writeMeta.GetWriteMiddle4StartInstant()).MilliSeconds()); - CSCounters.OnWriteMiddle5PutBlobsSuccess((now - writeMeta.GetWriteMiddle5StartInstant()).MilliSeconds()); + CSCounters.OnWritePutBlobsSuccess(now - writeMeta.GetWriteStartInstant()); + CSCounters.OnWriteMiddle1PutBlobsSuccess(now - writeMeta.GetWriteMiddle1StartInstant()); + CSCounters.OnWriteMiddle2PutBlobsSuccess(now - writeMeta.GetWriteMiddle2StartInstant()); + CSCounters.OnWriteMiddle3PutBlobsSuccess(now - writeMeta.GetWriteMiddle3StartInstant()); + CSCounters.OnWriteMiddle4PutBlobsSuccess(now - writeMeta.GetWriteMiddle4StartInstant()); + CSCounters.OnWriteMiddle5PutBlobsSuccess(now - writeMeta.GetWriteMiddle5StartInstant()); + CSCounters.OnWriteMiddle6PutBlobsSuccess(now - writeMeta.GetWriteMiddle6StartInstant()); LOG_S_DEBUG("Write (record) into pathId " << writeMeta.GetTableId() << (writeMeta.GetWriteId() ? (" writeId " + ToString(writeMeta.GetWriteId())).c_str() : "") << " at tablet " << TabletID()); @@ -139,18 +162,20 @@ void TColumnShard::Handle(TEvColumnShard::TEvWrite::TPtr& ev, const TActorContex IncCounter(signalIndex); ctx.Send(source, std::make_unique(TabletID(), writeMeta, NKikimrTxColumnShard::EResultStatus::ERROR)); - CSCounters.OnFailedWriteResponse(); return; }; if (!AppDataVerified().ColumnShardConfig.GetWritingEnabled()) { AFL_WARN(NKikimrServices::TX_COLUMNSHARD)("event", "skip_writing")("reason", "disabled"); + CSCounters.OnFailedWriteResponse(EWriteFailReason::Disabled); return returnFail(COUNTER_WRITE_FAIL); } if (!TablesManager.IsReadyForWrite(tableId)) { LOG_S_NOTICE("Write (fail) into pathId:" << writeMeta.GetTableId() << (TablesManager.HasPrimaryIndex()? "": " no index") << " at tablet " << TabletID()); + + CSCounters.OnFailedWriteResponse(EWriteFailReason::NoTable); return returnFail(COUNTER_WRITE_FAIL); } @@ -159,6 +184,7 @@ void TColumnShard::Handle(TEvColumnShard::TEvWrite::TPtr& ev, const TActorContex if (!arrowData->ParseFromProto(record)) { LOG_S_ERROR("Write (fail) " << record.GetData().size() << " bytes into pathId " << writeMeta.GetTableId() << " at tablet " << TabletID()); + CSCounters.OnFailedWriteResponse(EWriteFailReason::IncorrectSchema); return returnFail(COUNTER_WRITE_FAIL); } @@ -167,7 +193,7 @@ void TColumnShard::Handle(TEvColumnShard::TEvWrite::TPtr& ev, const TActorContex if (overloadStatus != EOverloadStatus::None) { std::unique_ptr result = std::make_unique(TabletID(), writeData.GetWriteMeta(), NKikimrTxColumnShard::EResultStatus::OVERLOADED); OverloadWriteFail(overloadStatus, writeData, std::move(result), ctx); - CSCounters.OnFailedWriteResponse(); + CSCounters.OnFailedWriteResponse(EWriteFailReason::Overload); } else { if (ui64 writeId = (ui64)HasLongTxWrite(writeMeta.GetLongTxIdUnsafe(), writeMeta.GetWritePartId())) { LOG_S_DEBUG("Write (duplicate) into pathId " << writeMeta.GetTableId() @@ -179,7 +205,7 @@ void TColumnShard::Handle(TEvColumnShard::TEvWrite::TPtr& ev, const TActorContex auto result = std::make_unique( TabletID(), writeMeta, writeId, NKikimrTxColumnShard::EResultStatus::SUCCESS); ctx.Send(writeMeta.GetSource(), result.release()); - CSCounters.OnFailedWriteResponse(); + CSCounters.OnFailedWriteResponse(EWriteFailReason::LongTxDuplication); return; } diff --git a/ydb/core/tx/columnshard/columnshard_impl.cpp b/ydb/core/tx/columnshard/columnshard_impl.cpp index 5d5df25e8fe9..daa499e55488 100644 --- a/ydb/core/tx/columnshard/columnshard_impl.cpp +++ b/ydb/core/tx/columnshard/columnshard_impl.cpp @@ -89,6 +89,7 @@ TColumnShard::TColumnShard(TTabletStorageInfo* info, const TActorId& tablet) , SubscribeCounters(std::make_shared()) , InsertTaskSubscription(NOlap::TInsertColumnEngineChanges::StaticTypeName(), SubscribeCounters) , CompactTaskSubscription(NOlap::TCompactColumnEngineChanges::StaticTypeName(), SubscribeCounters) + , TTLTaskSubscription(NOlap::TTTLColumnEngineChanges::StaticTypeName(), SubscribeCounters) , ReadCounters("Read") , ScanCounters("Scan") , WritesMonitor(*this) @@ -295,6 +296,9 @@ void TColumnShard::TryAbortWrites(NIceDb::TNiceDb& db, NOlap::TDbWrapper& dbTabl failedAborts.push_back(writeId); } } + if (failedAborts.size()) { + AFL_ERROR(NKikimrServices::TX_COLUMNSHARD)("event", "failed_aborts")("count", failedAborts.size())("writes_count", writesToAbort.size()); + } for (auto& writeId : failedAborts) { writesToAbort.erase(writeId); } @@ -743,13 +747,15 @@ bool TColumnShard::SetupTtl(const THashMap& pathTtls, con } auto actualIndexInfo = TablesManager.GetPrimaryIndex()->GetVersionedIndex(); - std::shared_ptr indexChanges = TablesManager.MutablePrimaryIndex().StartTtl(eviction, BackgroundController.GetConflictTTLPortions()); + const ui64 memoryUsageLimit = HasAppData() ? AppDataVerified().ColumnShardConfig.GetTieringsMemoryLimit() : ((ui64)512 * 1024 * 1024); + std::shared_ptr indexChanges = TablesManager.MutablePrimaryIndex().StartTtl( + eviction, BackgroundController.GetConflictTTLPortions(), memoryUsageLimit); if (!indexChanges) { ACFL_DEBUG("background", "ttl")("skip_reason", "no_changes"); return false; } - + const TString externalTaskId = indexChanges->GetTaskIdentifier(); const bool needWrites = indexChanges->NeedConstruction(); ACFL_DEBUG("background", "ttl")("need_writes", needWrites); @@ -757,7 +763,9 @@ bool TColumnShard::SetupTtl(const THashMap& pathTtls, con auto ev = std::make_unique(std::move(actualIndexInfo), indexChanges, false); NYDBTest::TControllers::GetColumnShardController()->OnWriteIndexStart(TabletID(), indexChanges->TypeString()); if (needWrites) { - ActorContext().Register(new NOlap::NBlobOperations::NRead::TActor(std::make_shared(std::move(ev), SelfId(), TabletID(), CompactionCounters))); + NOlap::NResourceBroker::NSubscribe::ITask::StartResourceSubscription( + ResourceSubscribeActor, std::make_shared( + std::make_shared(std::move(ev), SelfId(), TabletID(), CompactionCounters), 0, indexChanges->CalcMemoryForUsage(), externalTaskId, TTLTaskSubscription)); } else { ev->SetPutStatus(NKikimrProto::OK); ActorContext().Send(SelfId(), std::move(ev)); @@ -807,6 +815,7 @@ void TColumnShard::SetupCleanupInsertTable() { if (!InsertTable->GetAborted().size() && !writeIdsToCleanup.size()) { return; } + AFL_INFO(NKikimrServices::TX_COLUMNSHARD)("event", "cleanup_started")("aborted", InsertTable->GetAborted().size())("to_cleanup", writeIdsToCleanup.size()); Execute(new TTxInsertTableCleanup(this, std::move(writeIdsToCleanup)), TActorContext::AsActorContext()); } diff --git a/ydb/core/tx/columnshard/columnshard_impl.h b/ydb/core/tx/columnshard/columnshard_impl.h index 00e72583c23a..126e163c8fe3 100644 --- a/ydb/core/tx/columnshard/columnshard_impl.h +++ b/ydb/core/tx/columnshard/columnshard_impl.h @@ -214,7 +214,9 @@ class TColumnShard void OnTieringModified(); public: enum class EOverloadStatus { - Shard /* "shard" */, + ShardTxInFly /* "shard_tx" */, + ShardWritesInFly /* "shard_writes" */, + ShardWritesSizeInFly /* "shard_writes_size" */, InsertTable /* "insert_table" */, Disk /* "disk" */, None /* "none" */ @@ -298,8 +300,8 @@ class TColumnShard class TWritesMonitor { private: TColumnShard& Owner; - ui64 WritesInFlight = 0; - ui64 WritesSizeInFlight = 0; + YDB_READONLY(ui64, WritesInFlight, 0); + YDB_READONLY(ui64, WritesSizeInFlight, 0); public: class TGuard: public TNonCopyable { @@ -335,17 +337,8 @@ class TColumnShard return TGuard(*this); } - bool ShardOverloaded() const { - ui64 txLimit = Owner.Settings.OverloadTxInFlight; - ui64 writesLimit = Owner.Settings.OverloadWritesInFlight; - ui64 writesSizeLimit = Owner.Settings.OverloadWritesSizeInFlight; - return (txLimit && Owner.Executor()->GetStats().TxInFly > txLimit) || - (writesLimit && WritesInFlight > writesLimit) || - (writesSizeLimit && WritesSizeInFlight > writesSizeLimit); - } - TString DebugString() const { - return TStringBuilder() << "TWritesMonitor: inflight " << WritesInFlight << " (" << WritesSizeInFlight << " bytes)"; + return TStringBuilder() << "{object=write_monitor;count=" << WritesInFlight << ";size=" << WritesSizeInFlight << "}"; } private: @@ -392,6 +385,7 @@ class TColumnShard std::shared_ptr SubscribeCounters; NOlap::NResourceBroker::NSubscribe::TTaskContext InsertTaskSubscription; NOlap::NResourceBroker::NSubscribe::TTaskContext CompactTaskSubscription; + NOlap::NResourceBroker::NSubscribe::TTaskContext TTLTaskSubscription; const TScanCounters ReadCounters; const TScanCounters ScanCounters; const TIndexationCounters CompactionCounters = TIndexationCounters("GeneralCompaction"); diff --git a/ydb/core/tx/columnshard/columnshard_ut_common.cpp b/ydb/core/tx/columnshard/columnshard_ut_common.cpp index 8df44d7df997..407aed03b43d 100644 --- a/ydb/core/tx/columnshard/columnshard_ut_common.cpp +++ b/ydb/core/tx/columnshard/columnshard_ut_common.cpp @@ -375,10 +375,10 @@ NMetadata::NFetcher::ISnapshot::TPtr TTestSchema::BuildSnapshot(const TTableSpec cProto.SetName(tier.Name); *cProto.MutableObjectStorage() = tier.S3; if (tier.Codec) { - cProto.MutableCompression()->SetCompressionCodec(tier.GetCodecId()); + cProto.MutableCompression()->SetCodec(tier.GetCodecId()); } if (tier.CompressionLevel) { - cProto.MutableCompression()->SetCompressionLevel(*tier.CompressionLevel); + cProto.MutableCompression()->SetLevel(*tier.CompressionLevel); } NColumnShard::NTiers::TTierConfig tConfig(tier.Name, cProto); cs->MutableTierConfigs().emplace(tConfig.GetTierName(), tConfig); diff --git a/ydb/core/tx/columnshard/columnshard_ut_common.h b/ydb/core/tx/columnshard/columnshard_ut_common.h index 0ea35595f338..58849aa342e1 100644 --- a/ydb/core/tx/columnshard/columnshard_ut_common.h +++ b/ydb/core/tx/columnshard/columnshard_ut_common.h @@ -236,10 +236,10 @@ struct TTestSchema { } if (specials.HasCodec()) { - schema->MutableDefaultCompression()->SetCompressionCodec(specials.GetCodecId()); + schema->MutableDefaultCompression()->SetCodec(specials.GetCodecId()); } if (specials.CompressionLevel) { - schema->MutableDefaultCompression()->SetCompressionLevel(*specials.CompressionLevel); + schema->MutableDefaultCompression()->SetLevel(*specials.CompressionLevel); } } diff --git a/ydb/core/tx/columnshard/common/limits.cpp b/ydb/core/tx/columnshard/common/limits.cpp new file mode 100644 index 000000000000..7bd45fa70d3b --- /dev/null +++ b/ydb/core/tx/columnshard/common/limits.cpp @@ -0,0 +1,4 @@ +#include "limits.h" + +namespace NKikimr::NColumnShard { +} \ No newline at end of file diff --git a/ydb/core/tx/columnshard/common/limits.h b/ydb/core/tx/columnshard/common/limits.h new file mode 100644 index 000000000000..04a5cb55128e --- /dev/null +++ b/ydb/core/tx/columnshard/common/limits.h @@ -0,0 +1,9 @@ +#pragma once +#include + +namespace NKikimr::NOlap { +class TGlobalLimits { +public: + static const inline ui64 TxWriteLimitBytes = 256 * 1024 * 1024; +}; +} \ No newline at end of file diff --git a/ydb/core/tx/columnshard/common/protos/snapshot.proto b/ydb/core/tx/columnshard/common/protos/snapshot.proto new file mode 100644 index 000000000000..becc25a219d2 --- /dev/null +++ b/ydb/core/tx/columnshard/common/protos/snapshot.proto @@ -0,0 +1,6 @@ +package NKikimrColumnShardProto; + +message TSnapshot { + optional uint64 PlanStep = 1; + optional uint64 TxId = 2; +} diff --git a/ydb/core/tx/columnshard/common/protos/ya.make b/ydb/core/tx/columnshard/common/protos/ya.make new file mode 100644 index 000000000000..500d562e466e --- /dev/null +++ b/ydb/core/tx/columnshard/common/protos/ya.make @@ -0,0 +1,10 @@ +PROTO_LIBRARY() + +SRCS( + snapshot.proto +) + +PEERDIR( +) + +END() diff --git a/ydb/core/tx/columnshard/common/snapshot.cpp b/ydb/core/tx/columnshard/common/snapshot.cpp index fb4ee00017f8..a38565ee3447 100644 --- a/ydb/core/tx/columnshard/common/snapshot.cpp +++ b/ydb/core/tx/columnshard/common/snapshot.cpp @@ -1,4 +1,5 @@ #include "snapshot.h" +#include #include namespace NKikimr::NOlap { @@ -7,4 +8,10 @@ TString TSnapshot::DebugString() const { return TStringBuilder() << "plan_step=" << PlanStep << ";tx_id=" << TxId << ";"; } +NKikimrColumnShardProto::TSnapshot TSnapshot::SerializeToProto() const { + NKikimrColumnShardProto::TSnapshot result; + SerializeToProto(result); + return result; +} + }; diff --git a/ydb/core/tx/columnshard/common/snapshot.h b/ydb/core/tx/columnshard/common/snapshot.h index 93b896be051e..389310cd528e 100644 --- a/ydb/core/tx/columnshard/common/snapshot.h +++ b/ydb/core/tx/columnshard/common/snapshot.h @@ -1,6 +1,13 @@ #pragma once +#include + #include #include +#include + +namespace NKikimrColumnShardProto { +class TSnapshot; +} namespace NKikimr::NOlap { @@ -15,6 +22,10 @@ class TSnapshot { , TxId(txId) { } + constexpr TInstant GetPlanInstant() const noexcept { + return TInstant::MilliSeconds(PlanStep); + } + constexpr ui64 GetPlanStep() const noexcept { return PlanStep; } @@ -47,6 +58,27 @@ class TSnapshot { return out << "{" << s.PlanStep << ':' << (s.TxId == std::numeric_limits::max() ? "max" : ::ToString(s.TxId)) << "}"; } + template + void SerializeToProto(TProto& result) const { + result.SetPlanStep(PlanStep); + result.SetTxId(TxId); + } + + NKikimrColumnShardProto::TSnapshot SerializeToProto() const; + + template + TConclusionStatus DeserializeFromProto(const TProto& proto) { + PlanStep = proto.GetPlanStep(); + TxId = proto.GetTxId(); + if (!PlanStep) { + return TConclusionStatus::Fail("incorrect planStep in proto"); + } + if (!TxId) { + return TConclusionStatus::Fail("incorrect txId in proto"); + } + return TConclusionStatus::Success(); + } + TString DebugString() const; }; diff --git a/ydb/core/tx/columnshard/common/ya.make b/ydb/core/tx/columnshard/common/ya.make index ac748e9ed9c7..a73340ea9681 100644 --- a/ydb/core/tx/columnshard/common/ya.make +++ b/ydb/core/tx/columnshard/common/ya.make @@ -1,6 +1,7 @@ LIBRARY() SRCS( + limits.h reverse_accessor.cpp scalars.cpp snapshot.cpp @@ -11,6 +12,7 @@ PEERDIR( ydb/core/protos contrib/libs/apache/arrow ydb/core/formats/arrow + ydb/core/tx/columnshard/common/protos ) GENERATE_ENUM_SERIALIZATION(portion.h) diff --git a/ydb/core/tx/columnshard/counters/columnshard.cpp b/ydb/core/tx/columnshard/counters/columnshard.cpp index 989deae6b9bc..e094fbbcd5ac 100644 --- a/ydb/core/tx/columnshard/counters/columnshard.cpp +++ b/ydb/core/tx/columnshard/counters/columnshard.cpp @@ -2,6 +2,8 @@ #include #include +#include + namespace NKikimr::NColumnShard { TCSCounters::TCSCounters() @@ -24,8 +26,12 @@ TCSCounters::TCSCounters() OverloadInsertTableBytes = TBase::GetDeriviative("OverloadInsertTable/Bytes"); OverloadInsertTableCount = TBase::GetDeriviative("OverloadInsertTable/Count"); - OverloadShardBytes = TBase::GetDeriviative("OverloadShard/Bytes"); - OverloadShardCount = TBase::GetDeriviative("OverloadShard/Count"); + OverloadShardTxBytes = TBase::GetDeriviative("OverloadShard/Tx/Bytes"); + OverloadShardTxCount = TBase::GetDeriviative("OverloadShard/Tx/Count"); + OverloadShardWritesBytes = TBase::GetDeriviative("OverloadShard/Writes/Bytes"); + OverloadShardWritesCount = TBase::GetDeriviative("OverloadShard/Writes/Count"); + OverloadShardWritesSizeBytes = TBase::GetDeriviative("OverloadShard/WritesSize/Bytes"); + OverloadShardWritesSizeCount = TBase::GetDeriviative("OverloadShard/WritesSize/Count"); InternalCompactionGranuleBytes = TBase::GetValueAutoAggregationsClient("InternalCompaction/Bytes"); InternalCompactionGranulePortionsCount = TBase::GetValueAutoAggregationsClient("InternalCompaction/PortionsCount"); @@ -39,12 +45,25 @@ TCSCounters::TCSCounters() HistogramSuccessWriteMiddle3PutBlobsDurationMs = TBase::GetHistogram("SuccessWriteMiddle3PutBlobsDurationMs", NMonitoring::ExponentialHistogram(18, 2, 5)); HistogramSuccessWriteMiddle4PutBlobsDurationMs = TBase::GetHistogram("SuccessWriteMiddle4PutBlobsDurationMs", NMonitoring::ExponentialHistogram(18, 2, 5)); HistogramSuccessWriteMiddle5PutBlobsDurationMs = TBase::GetHistogram("SuccessWriteMiddle5PutBlobsDurationMs", NMonitoring::ExponentialHistogram(18, 2, 5)); + HistogramSuccessWriteMiddle6PutBlobsDurationMs = TBase::GetHistogram("SuccessWriteMiddle6PutBlobsDurationMs", NMonitoring::ExponentialHistogram(18, 2, 5)); HistogramFailedWritePutBlobsDurationMs = TBase::GetHistogram("FailedWritePutBlobsDurationMs", NMonitoring::ExponentialHistogram(18, 2, 5)); HistogramWriteTxCompleteDurationMs = TBase::GetHistogram("WriteTxCompleteDurationMs", NMonitoring::ExponentialHistogram(18, 2, 5)); WritePutBlobsCount = TBase::GetValue("WritePutBlobs"); WriteRequests = TBase::GetValue("WriteRequests"); - FailedWriteRequests = TBase::GetDeriviative("FailedWriteRequests"); + + for (auto&& i : GetEnumAllValues()) { + auto sub = CreateSubGroup("reason", ::ToString(i)); + FailedWriteRequests.emplace(i, sub.GetDeriviative("FailedWriteRequests")); + } + SuccessWriteRequests = TBase::GetDeriviative("SuccessWriteRequests"); } +void TCSCounters::OnFailedWriteResponse(const EWriteFailReason reason) const { + WriteRequests->Sub(1); + auto it = FailedWriteRequests.find(reason); + AFL_VERIFY(it != FailedWriteRequests.end()); + it->second->Add(1); +} + } diff --git a/ydb/core/tx/columnshard/counters/columnshard.h b/ydb/core/tx/columnshard/counters/columnshard.h index ffe935c995c2..2441ca6fef3b 100644 --- a/ydb/core/tx/columnshard/counters/columnshard.h +++ b/ydb/core/tx/columnshard/counters/columnshard.h @@ -1,9 +1,21 @@ #pragma once -#include #include "common/owner.h" +#include + +#include + namespace NKikimr::NColumnShard { +enum class EWriteFailReason { + Disabled /* "disabled" */, + PutBlob /* "put_blob" */, + LongTxDuplication /* "long_tx_duplication" */, + NoTable /* "no_table" */, + IncorrectSchema /* "incorrect_schema" */, + Overload /* "overload" */ +}; + class TCSCounters: public TCommonCountersOwner { private: using TBase = TCommonCountersOwner; @@ -24,8 +36,12 @@ class TCSCounters: public TCommonCountersOwner { NMonitoring::TDynamicCounters::TCounterPtr OverloadInsertTableBytes; NMonitoring::TDynamicCounters::TCounterPtr OverloadInsertTableCount; - NMonitoring::TDynamicCounters::TCounterPtr OverloadShardBytes; - NMonitoring::TDynamicCounters::TCounterPtr OverloadShardCount; + NMonitoring::TDynamicCounters::TCounterPtr OverloadShardTxBytes; + NMonitoring::TDynamicCounters::TCounterPtr OverloadShardTxCount; + NMonitoring::TDynamicCounters::TCounterPtr OverloadShardWritesBytes; + NMonitoring::TDynamicCounters::TCounterPtr OverloadShardWritesCount; + NMonitoring::TDynamicCounters::TCounterPtr OverloadShardWritesSizeBytes; + NMonitoring::TDynamicCounters::TCounterPtr OverloadShardWritesSizeCount; std::shared_ptr InternalCompactionGranuleBytes; std::shared_ptr InternalCompactionGranulePortionsCount; @@ -39,54 +55,56 @@ class TCSCounters: public TCommonCountersOwner { NMonitoring::THistogramPtr HistogramSuccessWriteMiddle3PutBlobsDurationMs; NMonitoring::THistogramPtr HistogramSuccessWriteMiddle4PutBlobsDurationMs; NMonitoring::THistogramPtr HistogramSuccessWriteMiddle5PutBlobsDurationMs; + NMonitoring::THistogramPtr HistogramSuccessWriteMiddle6PutBlobsDurationMs; NMonitoring::THistogramPtr HistogramFailedWritePutBlobsDurationMs; NMonitoring::THistogramPtr HistogramWriteTxCompleteDurationMs; NMonitoring::TDynamicCounters::TCounterPtr WritePutBlobsCount; NMonitoring::TDynamicCounters::TCounterPtr WriteRequests; - NMonitoring::TDynamicCounters::TCounterPtr FailedWriteRequests; + THashMap FailedWriteRequests; NMonitoring::TDynamicCounters::TCounterPtr SuccessWriteRequests; public: void OnStartWriteRequest() const { WriteRequests->Add(1); } - void OnFailedWriteResponse() const { - WriteRequests->Sub(1); - FailedWriteRequests->Add(1); - } + void OnFailedWriteResponse(const EWriteFailReason reason) const; void OnSuccessWriteResponse() const { WriteRequests->Sub(1); SuccessWriteRequests->Add(1); } - void OnWritePutBlobsSuccess(const ui32 milliseconds) const { - HistogramSuccessWritePutBlobsDurationMs->Collect(milliseconds); + void OnWritePutBlobsSuccess(const TDuration d) const { + HistogramSuccessWritePutBlobsDurationMs->Collect(d.MilliSeconds()); WritePutBlobsCount->Sub(1); } - void OnWriteMiddle1PutBlobsSuccess(const ui32 milliseconds) const { - HistogramSuccessWriteMiddle1PutBlobsDurationMs->Collect(milliseconds); + void OnWriteMiddle1PutBlobsSuccess(const TDuration d) const { + HistogramSuccessWriteMiddle1PutBlobsDurationMs->Collect(d.MilliSeconds()); + } + + void OnWriteMiddle2PutBlobsSuccess(const TDuration d) const { + HistogramSuccessWriteMiddle2PutBlobsDurationMs->Collect(d.MilliSeconds()); } - void OnWriteMiddle2PutBlobsSuccess(const ui32 milliseconds) const { - HistogramSuccessWriteMiddle2PutBlobsDurationMs->Collect(milliseconds); + void OnWriteMiddle3PutBlobsSuccess(const TDuration d) const { + HistogramSuccessWriteMiddle3PutBlobsDurationMs->Collect(d.MilliSeconds()); } - void OnWriteMiddle3PutBlobsSuccess(const ui32 milliseconds) const { - HistogramSuccessWriteMiddle3PutBlobsDurationMs->Collect(milliseconds); + void OnWriteMiddle4PutBlobsSuccess(const TDuration d) const { + HistogramSuccessWriteMiddle4PutBlobsDurationMs->Collect(d.MilliSeconds()); } - void OnWriteMiddle4PutBlobsSuccess(const ui32 milliseconds) const { - HistogramSuccessWriteMiddle4PutBlobsDurationMs->Collect(milliseconds); + void OnWriteMiddle5PutBlobsSuccess(const TDuration d) const { + HistogramSuccessWriteMiddle5PutBlobsDurationMs->Collect(d.MilliSeconds()); } - void OnWriteMiddle5PutBlobsSuccess(const ui32 milliseconds) const { - HistogramSuccessWriteMiddle5PutBlobsDurationMs->Collect(milliseconds); + void OnWriteMiddle6PutBlobsSuccess(const TDuration d) const { + HistogramSuccessWriteMiddle6PutBlobsDurationMs->Collect(d.MilliSeconds()); } - void OnWritePutBlobsFail(const ui32 milliseconds) const { - HistogramFailedWritePutBlobsDurationMs->Collect(milliseconds); + void OnWritePutBlobsFail(const TDuration d) const { + HistogramFailedWritePutBlobsDurationMs->Collect(d.MilliSeconds()); WritePutBlobsCount->Sub(1); } @@ -94,8 +112,8 @@ class TCSCounters: public TCommonCountersOwner { WritePutBlobsCount->Add(1); } - void OnWriteTxComplete(const ui32 milliseconds) const { - HistogramWriteTxCompleteDurationMs->Collect(milliseconds); + void OnWriteTxComplete(const TDuration d) const { + HistogramWriteTxCompleteDurationMs->Collect(d.MilliSeconds()); } void OnInternalCompactionInfo(const ui64 bytes, const ui32 portionsCount) const { @@ -113,9 +131,19 @@ class TCSCounters: public TCommonCountersOwner { OverloadInsertTableCount->Add(1); } - void OnOverloadShard(const ui64 size) const { - OverloadShardBytes->Add(size); - OverloadShardCount->Add(1); + void OnOverloadShardTx(const ui64 size) const { + OverloadShardTxBytes->Add(size); + OverloadShardTxCount->Add(1); + } + + void OnOverloadShardWrites(const ui64 size) const { + OverloadShardWritesBytes->Add(size); + OverloadShardWritesCount->Add(1); + } + + void OnOverloadShardWritesSize(const ui64 size) const { + OverloadShardWritesSizeBytes->Add(size); + OverloadShardWritesSizeCount->Add(1); } void SkipIndexationInputDueToSplitCompaction(const ui64 size) const { diff --git a/ydb/core/tx/columnshard/counters/common/owner.h b/ydb/core/tx/columnshard/counters/common/owner.h index 1ea4bd513b7f..456699c80dc0 100644 --- a/ydb/core/tx/columnshard/counters/common/owner.h +++ b/ydb/core/tx/columnshard/counters/common/owner.h @@ -50,6 +50,9 @@ class TCommonCountersOwner { NMonitoring::TDynamicCounters::TCounterPtr GetDeriviative(const TString& name) const; void DeepSubGroup(const TString& id, const TString& value); void DeepSubGroup(const TString& componentName); + TCommonCountersOwner CreateSubGroup(const TString& param, const TString& value) const { + return TCommonCountersOwner(*this, param, value); + } NMonitoring::THistogramPtr GetHistogram(const TString& name, NMonitoring::IHistogramCollectorPtr&& hCollector) const; TCommonCountersOwner(const TString& module, TIntrusivePtr<::NMonitoring::TDynamicCounters> baseSignals = nullptr); diff --git a/ydb/core/tx/columnshard/counters/ya.make b/ydb/core/tx/columnshard/counters/ya.make index aed1f68de28b..5a0dbc7c3256 100644 --- a/ydb/core/tx/columnshard/counters/ya.make +++ b/ydb/core/tx/columnshard/counters/ya.make @@ -17,4 +17,6 @@ PEERDIR( ydb/core/base ) +GENERATE_ENUM_SERIALIZATION(columnshard.h) + END() diff --git a/ydb/core/tx/columnshard/engines/changes/abstract/abstract.h b/ydb/core/tx/columnshard/engines/changes/abstract/abstract.h index 8a5dacc48fac..dc5b3b2eb0f4 100644 --- a/ydb/core/tx/columnshard/engines/changes/abstract/abstract.h +++ b/ydb/core/tx/columnshard/engines/changes/abstract/abstract.h @@ -173,6 +173,12 @@ class TColumnEngineChanges { const TString TaskIdentifier = TGUID::Create().AsGuidString(); virtual ui64 DoCalcMemoryForUsage() const = 0; public: + class IMemoryPredictor { + public: + virtual ui64 AddPortion(const TPortionInfo& portionInfo) = 0; + virtual ~IMemoryPredictor() = default; + }; + ui64 CalcMemoryForUsage() const { return DoCalcMemoryForUsage(); } diff --git a/ydb/core/tx/columnshard/engines/changes/general_compaction.h b/ydb/core/tx/columnshard/engines/changes/general_compaction.h index 287ba34b37ae..e337d3cc3dbc 100644 --- a/ydb/core/tx/columnshard/engines/changes/general_compaction.h +++ b/ydb/core/tx/columnshard/engines/changes/general_compaction.h @@ -29,12 +29,6 @@ class TGeneralCompactColumnEngineChanges: public TCompactColumnEngineChanges { public: using TBase::TBase; - class IMemoryPredictor { - public: - virtual ui64 AddPortion(const TPortionInfo& portionInfo) = 0; - virtual ~IMemoryPredictor() = default; - }; - class TMemoryPredictorSimplePolicy: public IMemoryPredictor { private: ui64 SumMemory = 0; diff --git a/ydb/core/tx/columnshard/engines/changes/indexation.cpp b/ydb/core/tx/columnshard/engines/changes/indexation.cpp index c68100010934..f91fcb099f42 100644 --- a/ydb/core/tx/columnshard/engines/changes/indexation.cpp +++ b/ydb/core/tx/columnshard/engines/changes/indexation.cpp @@ -3,6 +3,7 @@ #include #include #include +#include namespace NKikimr::NOlap { @@ -116,9 +117,9 @@ TConclusionStatus TInsertColumnEngineChanges::DoConstructBlobs(TConstructionCont continue; } if (b->num_rows() < 100) { - SaverContext.SetExternalCompression(NArrow::TCompression(arrow::Compression::type::UNCOMPRESSED)); + SaverContext.SetExternalSerializer(NArrow::NSerialization::TSerializerContainer(std::make_shared(arrow::Compression::type::UNCOMPRESSED))); } else { - SaverContext.SetExternalCompression(NArrow::TCompression(arrow::Compression::type::LZ4_FRAME)); + SaverContext.SetExternalSerializer(NArrow::NSerialization::TSerializerContainer(std::make_shared(arrow::Compression::type::LZ4_FRAME))); } auto portions = MakeAppendedPortions(b, pathId, maxSnapshot, nullptr, context); Y_ABORT_UNLESS(portions.size()); diff --git a/ydb/core/tx/columnshard/engines/changes/ttl.cpp b/ydb/core/tx/columnshard/engines/changes/ttl.cpp index 80117f34f331..9a0ad102e54b 100644 --- a/ydb/core/tx/columnshard/engines/changes/ttl.cpp +++ b/ydb/core/tx/columnshard/engines/changes/ttl.cpp @@ -9,13 +9,7 @@ namespace NKikimr::NOlap { void TTTLColumnEngineChanges::DoDebugString(TStringOutput& out) const { TBase::DoDebugString(out); - if (PortionsToEvict.size()) { - out << "eviction=(count=" << PortionsToEvict.size() << ";portions=["; - for (auto& info : PortionsToEvict) { - out << info.GetPortionInfo() << ";to=" << info.GetFeatures().TargetTierName << ";"; - } - out << "];"; - } + out << "eviction=" << PortionsToEvict.size() << ";"; } void TTTLColumnEngineChanges::DoStart(NColumnShard::TColumnShard& self) { @@ -43,8 +37,8 @@ std::optional TTTLColumnEngineChanges::UpdateEvictedPorti auto* tiering = Tiering.FindPtr(evictFeatures.PathId); Y_ABORT_UNLESS(tiering); - auto compression = tiering->GetCompression(evictFeatures.TargetTierName); - if (!compression) { + auto serializer = tiering->GetSerializer(evictFeatures.TargetTierName); + if (!serializer) { // Nothing to recompress. We have no other kinds of evictions yet. evictFeatures.DataChanges = false; auto result = TPortionInfoWithBlobs::RestorePortion(portionInfo, srcBlobs); @@ -58,7 +52,7 @@ std::optional TTTLColumnEngineChanges::UpdateEvictedPorti AFL_DEBUG(NKikimrServices::TX_COLUMNSHARD)("portion_for_eviction", portionInfo.DebugString()); TSaverContext saverContext(evictFeatures.StorageOperator, SaverContext.GetStoragesManager()); - saverContext.SetTierName(evictFeatures.TargetTierName).SetExternalCompression(compression); + saverContext.SetTierName(evictFeatures.TargetTierName).SetExternalSerializer(*serializer); auto withBlobs = TPortionInfoWithBlobs::RestorePortion(portionInfo, srcBlobs); withBlobs.GetPortionInfo().InitOperator(evictFeatures.StorageOperator, true); withBlobs.GetPortionInfo().MutableMeta().SetTierName(evictFeatures.TargetTierName); diff --git a/ydb/core/tx/columnshard/engines/changes/ttl.h b/ydb/core/tx/columnshard/engines/changes/ttl.h index 5e19c69af8d8..5018d860bbb4 100644 --- a/ydb/core/tx/columnshard/engines/changes/ttl.h +++ b/ydb/core/tx/columnshard/engines/changes/ttl.h @@ -51,13 +51,32 @@ class TTTLColumnEngineChanges: public TChangesWithAppend { virtual TConclusionStatus DoConstructBlobs(TConstructionContext& context) noexcept override; virtual NColumnShard::ECumulativeCounters GetCounterIndex(const bool isSuccess) const override; virtual ui64 DoCalcMemoryForUsage() const override { + auto predictor = BuildMemoryPredictor(); ui64 result = 0; for (auto& p : PortionsToEvict) { - result += 2 * p.GetPortionInfo().GetBlobBytes(); + result = predictor->AddPortion(p.GetPortionInfo()); } return result; } public: + class TMemoryPredictorSimplePolicy: public IMemoryPredictor { + private: + ui64 SumBlobsMemory = 0; + ui64 MaxRawMemory = 0; + public: + virtual ui64 AddPortion(const TPortionInfo& portionInfo) override { + if (MaxRawMemory < portionInfo.GetRawBytes()) { + MaxRawMemory = portionInfo.GetRawBytes(); + } + SumBlobsMemory += portionInfo.GetBlobBytes(); + return SumBlobsMemory + MaxRawMemory; + } + }; + + static std::shared_ptr BuildMemoryPredictor() { + return std::make_shared(); + } + virtual bool NeedConstruction() const override { return PortionsToEvict.size(); } diff --git a/ydb/core/tx/columnshard/engines/changes/with_appended.cpp b/ydb/core/tx/columnshard/engines/changes/with_appended.cpp index 2ff9533af295..8b47d79ffb80 100644 --- a/ydb/core/tx/columnshard/engines/changes/with_appended.cpp +++ b/ydb/core/tx/columnshard/engines/changes/with_appended.cpp @@ -6,16 +6,6 @@ namespace NKikimr::NOlap { -void TChangesWithAppend::DoDebugString(TStringOutput& out) const { - if (ui32 added = AppendedPortions.size()) { - out << "portions_count:" << added << ";portions=("; - for (auto& portionInfo : AppendedPortions) { - out << portionInfo; - } - out << "); "; - } -} - void TChangesWithAppend::DoWriteIndex(NColumnShard::TColumnShard& self, TWriteIndexContext& /*context*/) { for (auto& portionInfo : AppendedPortions) { switch (portionInfo.GetPortionInfo().GetMeta().Produced) { diff --git a/ydb/core/tx/columnshard/engines/changes/with_appended.h b/ydb/core/tx/columnshard/engines/changes/with_appended.h index a398c61b005e..779a3ab8a14f 100644 --- a/ydb/core/tx/columnshard/engines/changes/with_appended.h +++ b/ydb/core/tx/columnshard/engines/changes/with_appended.h @@ -13,7 +13,6 @@ class TChangesWithAppend: public TColumnEngineChanges { protected: TSplitSettings SplitSettings; TSaverContext SaverContext; - virtual void DoDebugString(TStringOutput& out) const override; virtual void DoCompile(TFinalizationContext& context) override; virtual bool DoApplyChanges(TColumnEngineForLogs& self, TApplyChangesContext& context) override; virtual void DoWriteIndex(NColumnShard::TColumnShard& self, TWriteIndexContext& context) override; @@ -24,6 +23,10 @@ class TChangesWithAppend: public TColumnEngineChanges { std::vector MakeAppendedPortions(const std::shared_ptr batch, const ui64 granule, const TSnapshot& snapshot, const TGranuleMeta* granuleMeta, TConstructionContext& context) const; + virtual void DoDebugString(TStringOutput& out) const override { + out << "remove=" << PortionsToRemove.size() << ";append=" << AppendedPortions.size() << ";"; + } + public: const TSplitSettings& GetSplitSettings() const { return SplitSettings; diff --git a/ydb/core/tx/columnshard/engines/column_engine.h b/ydb/core/tx/columnshard/engines/column_engine.h index 29f7e74c2714..618b70a27c0c 100644 --- a/ydb/core/tx/columnshard/engines/column_engine.h +++ b/ydb/core/tx/columnshard/engines/column_engine.h @@ -375,8 +375,8 @@ class IColumnEngine { virtual std::shared_ptr StartCompaction(const TCompactionLimits& limits, const THashSet& busyPortions) noexcept = 0; virtual std::shared_ptr StartCleanup(const TSnapshot& snapshot, THashSet& pathsToDrop, ui32 maxRecords) noexcept = 0; - virtual std::shared_ptr StartTtl(const THashMap& pathEviction, const THashSet& busyPortions, - ui64 maxBytesToEvict = TCompactionLimits::DEFAULT_EVICTION_BYTES) noexcept = 0; + virtual std::shared_ptr StartTtl(const THashMap& pathEviction, + const THashSet& busyPortions, const ui64 memoryUsageLimit) noexcept = 0; virtual bool ApplyChanges(IDbWrapper& db, std::shared_ptr changes, const TSnapshot& snapshot) noexcept = 0; virtual void RegisterSchemaVersion(const TSnapshot& snapshot, TIndexInfo&& info) = 0; virtual const TMap>& GetStats() const = 0; diff --git a/ydb/core/tx/columnshard/engines/column_engine_logs.cpp b/ydb/core/tx/columnshard/engines/column_engine_logs.cpp index 39482ad60fdc..17833bc5a6e6 100644 --- a/ydb/core/tx/columnshard/engines/column_engine_logs.cpp +++ b/ydb/core/tx/columnshard/engines/column_engine_logs.cpp @@ -1,6 +1,7 @@ #include "column_engine_logs.h" #include "filter.h" +#include #include #include #include @@ -238,7 +239,11 @@ std::shared_ptr TColumnEngineForLogs::StartInsert(st } std::shared_ptr TColumnEngineForLogs::StartCompaction(const TCompactionLimits& limits, const THashSet& busyPortions) noexcept { - auto granule = GranulesStorage->GetGranuleForCompaction(Tables); + THashSet busyGranuleIds; + for (auto&& i : busyPortions) { + busyGranuleIds.emplace(i.GetPathId()); + } + auto granule = GranulesStorage->GetGranuleForCompaction(Tables, busyGranuleIds); if (!granule) { AFL_DEBUG(NKikimrServices::TX_COLUMNSHARD)("event", "no granules for start compaction"); return nullptr; @@ -253,14 +258,16 @@ std::shared_ptr TColumnEngineForLogs::StartCompaction(cons } std::shared_ptr TColumnEngineForLogs::StartCleanup(const TSnapshot& snapshot, - THashSet& pathsToDrop, ui32 maxRecords) noexcept { + THashSet& pathsToDrop, ui32 /*maxRecords*/) noexcept { AFL_DEBUG(NKikimrServices::TX_COLUMNSHARD)("event", "StartCleanup")("portions_count", CleanupPortions.size()); auto changes = std::make_shared(StoragesManager); - ui32 affectedRecords = 0; // Add all portions from dropped paths THashSet dropPortions; THashSet emptyPaths; + ui64 txSize = 0; + const ui64 txSizeLimit = TGlobalLimits::TxWriteLimitBytes / 4; + changes->NeedRepeat = false; for (ui64 pathId : pathsToDrop) { auto itTable = Tables.find(pathId); if (itTable == Tables.end()) { @@ -269,25 +276,21 @@ std::shared_ptr TColumnEngineForLogs::StartCleanup( } for (auto& [portion, info] : itTable->second->GetPortions()) { - affectedRecords += info->NumChunks(); - changes->PortionsToDrop.push_back(*info); - dropPortions.insert(portion); - - if (affectedRecords > maxRecords) { + if (txSize + info->GetTxVolume() < txSizeLimit || changes->PortionsToDrop.empty()) { + txSize += info->GetTxVolume(); + } else { + changes->NeedRepeat = true; break; } + changes->PortionsToDrop.push_back(*info); + dropPortions.insert(portion); } } for (ui64 pathId : emptyPaths) { pathsToDrop.erase(pathId); } - if (affectedRecords > maxRecords) { - AFL_DEBUG(NKikimrServices::TX_COLUMNSHARD)("event", "StartCleanup")("portions_count", CleanupPortions.size())("portions_prepared", changes->PortionsToDrop.size()); - return changes; - } - - while (CleanupPortions.size() && affectedRecords <= maxRecords) { + while (CleanupPortions.size() && !changes->NeedRepeat) { auto it = CleanupPortions.begin(); if (it->first >= snapshot) { AFL_DEBUG(NKikimrServices::TX_COLUMNSHARD)("event", "StartCleanupStop")("snapshot", snapshot.DebugString())("current_snapshot", it->first.DebugString()); @@ -295,12 +298,16 @@ std::shared_ptr TColumnEngineForLogs::StartCleanup( } for (auto&& i : it->second) { Y_ABORT_UNLESS(i.CheckForCleanup(snapshot)); - affectedRecords += i.NumChunks(); + if (txSize + i.GetTxVolume() < txSizeLimit || changes->PortionsToDrop.empty()) { + txSize += i.GetTxVolume(); + } else { + changes->NeedRepeat = true; + break; + } changes->PortionsToDrop.push_back(i); } CleanupPortions.erase(it); } - changes->NeedRepeat = affectedRecords > maxRecords; AFL_DEBUG(NKikimrServices::TX_COLUMNSHARD)("event", "StartCleanup")("portions_count", CleanupPortions.size())("portions_prepared", changes->PortionsToDrop.size()); if (changes->PortionsToDrop.empty()) { @@ -312,8 +319,6 @@ std::shared_ptr TColumnEngineForLogs::StartCleanup( TDuration TColumnEngineForLogs::ProcessTiering(const ui64 pathId, const TTiering& ttl, TTieringProcessContext& context) const { AFL_DEBUG(NKikimrServices::TX_COLUMNSHARD)("event", "ProcessTiering")("path_id", pathId)("ttl", ttl.GetDebugString()); - ui64 evictionSize = 0; - ui64 dropBlobs = 0; auto& indexInfo = VersionedIndex.GetLastSchema()->GetIndexInfo(); Y_ABORT_UNLESS(context.Changes->Tiering.emplace(pathId, ttl).second); @@ -331,6 +336,7 @@ TDuration TColumnEngineForLogs::ProcessTiering(const ui64 pathId, const TTiering auto ttlColumnNames = ttl.GetTtlColumns(); Y_ABORT_UNLESS(ttlColumnNames.size() == 1); // TODO: support different ttl columns ui32 ttlColumnId = indexInfo.GetColumnId(*ttlColumnNames.begin()); + const TInstant now = TInstant::Now(); for (auto& [portion, info] : itTable->second->GetPortions()) { if (info->HasRemoveSnapshot()) { continue; @@ -340,9 +346,7 @@ TDuration TColumnEngineForLogs::ProcessTiering(const ui64 pathId, const TTiering continue; } - context.AllowEviction = (evictionSize <= context.MaxEvictBytes); - context.AllowDrop = (dropBlobs <= TCompactionLimits::MAX_BLOBS_TO_DELETE); - const bool tryEvictPortion = context.AllowEviction && ttl.HasTiers(); + const bool tryEvictPortion = ttl.HasTiers() && context.HasLimitsForEviction(); if (auto max = info->MaxValue(ttlColumnId)) { bool keep = !expireTimestampOpt; @@ -358,10 +362,15 @@ TDuration TColumnEngineForLogs::ProcessTiering(const ui64 pathId, const TTiering } } - AFL_TRACE(NKikimrServices::TX_COLUMNSHARD)("event", "scalar_less_result")("keep", keep)("tryEvictPortion", tryEvictPortion)("allowDrop", context.AllowDrop); + AFL_TRACE(NKikimrServices::TX_COLUMNSHARD)("event", "scalar_less_result")("keep", keep)("tryEvictPortion", tryEvictPortion)("allowDrop", context.HasLimitsForTtl()); if (keep && tryEvictPortion) { const TString currentTierName = info->GetMeta().GetTierName() ? info->GetMeta().GetTierName() : IStoragesManager::DefaultStorageId; TString tierName = ""; + const TInstant maxChangePortionInstant = info->RecordSnapshotMax().GetPlanInstant(); + if (now - maxChangePortionInstant < TDuration::Minutes(60)) { + AFL_DEBUG(NKikimrServices::TX_COLUMNSHARD)("event", "skip_portion_to_evict")("reason", "too_fresh")("delta", now - maxChangePortionInstant); + continue; + } for (auto& tierRef : ttl.GetOrderedTiers()) { auto& tierInfo = tierRef.Get(); if (!indexInfo.AllowTtlOverColumn(tierInfo.GetEvictColumnName())) { @@ -390,23 +399,23 @@ TDuration TColumnEngineForLogs::ProcessTiering(const ui64 pathId, const TTiering } if (currentTierName != tierName) { AFL_DEBUG(NKikimrServices::TX_COLUMNSHARD)("event", "tiering switch detected")("from", currentTierName)("to", tierName); - evictionSize += info->BlobsSizes().first; context.Changes->AddPortionToEvict(*info, TPortionEvictionFeatures(tierName, pathId, StoragesManager->GetOperator(tierName))); + context.AppPortionForEvictionChecker(*info); SignalCounters.OnPortionToEvict(info->BlobsBytes()); } } - if (!keep && context.AllowDrop) { + if (!keep && context.HasLimitsForTtl()) { AFL_DEBUG(NKikimrServices::TX_COLUMNSHARD)("event", "portion_remove")("portion", info->DebugString()); - dropBlobs += info->NumBlobs(); AFL_VERIFY(context.Changes->PortionsToRemove.emplace(info->GetAddress(), *info).second); SignalCounters.OnPortionToDrop(info->BlobsBytes()); + context.AppPortionForTtlChecker(*info); } } else { AFL_DEBUG(NKikimrServices::TX_COLUMNSHARD)("event", "scalar_less_not_max"); SignalCounters.OnPortionNoBorder(info->BlobsBytes()); } } - if (dWaiting > TDuration::MilliSeconds(500) && (!context.AllowEviction || !context.AllowDrop)) { + if (dWaiting > TDuration::MilliSeconds(500) && (!context.HasLimitsForEviction() || !context.HasLimitsForTtl())) { dWaiting = TDuration::MilliSeconds(500); } Y_ABORT_UNLESS(!!dWaiting); @@ -447,7 +456,7 @@ bool TColumnEngineForLogs::DrainEvictionQueue(std::map TColumnEngineForLogs::StartTtl(const THashMap& pathEviction, const THashSet& busyPortions, ui64 maxEvictBytes) noexcept { +std::shared_ptr TColumnEngineForLogs::StartTtl(const THashMap& pathEviction, const THashSet& busyPortions, const ui64 memoryUsageLimit) noexcept { AFL_DEBUG(NKikimrServices::TX_COLUMNSHARD)("event", "StartTtl")("external", pathEviction.size()) ("internal", EvictionsController.MutableNextCheckInstantForTierings().size()) ; @@ -456,7 +465,7 @@ std::shared_ptr TColumnEngineForLogs::StartTtl(const TH auto changes = std::make_shared(TSplitSettings(), saverContext); - TTieringProcessContext context(maxEvictBytes, changes, busyPortions); + TTieringProcessContext context(memoryUsageLimit, changes, busyPortions, TTTLColumnEngineChanges::BuildMemoryPredictor()); bool hasExternalChanges = false; for (auto&& i : pathEviction) { context.DurationsForced[i.first] = ProcessTiering(i.first, i.second, context); @@ -575,9 +584,11 @@ void TColumnEngineForLogs::DoRegisterTable(const ui64 pathId) { AFL_VERIFY(Tables.emplace(pathId, std::make_shared(pathId, GranulesStorage, SignalCounters.RegisterGranuleDataCounters(), VersionedIndex)).second); } -TColumnEngineForLogs::TTieringProcessContext::TTieringProcessContext(const ui64 maxEvictBytes, std::shared_ptr changes, const THashSet& busyPortions) - : Now(TlsActivationContext ? AppData()->TimeProvider->Now() : TInstant::Now()) - , MaxEvictBytes(maxEvictBytes) +TColumnEngineForLogs::TTieringProcessContext::TTieringProcessContext(const ui64 memoryUsageLimit, + std::shared_ptr changes, const THashSet& busyPortions, const std::shared_ptr& memoryPredictor) + : MemoryUsageLimit(memoryUsageLimit) + , MemoryPredictor(memoryPredictor) + , Now(TlsActivationContext ? AppData()->TimeProvider->Now() : TInstant::Now()) , Changes(changes) , BusyPortions(busyPortions) { diff --git a/ydb/core/tx/columnshard/engines/column_engine_logs.h b/ydb/core/tx/columnshard/engines/column_engine_logs.h index 5ce93a914eca..c281d9b653f8 100644 --- a/ydb/core/tx/columnshard/engines/column_engine_logs.h +++ b/ydb/core/tx/columnshard/engines/column_engine_logs.h @@ -3,6 +3,7 @@ #include "defs.h" #include "column_engine.h" #include +#include #include #include #include "scheme/tier_info.h" @@ -84,20 +85,45 @@ class TColumnEngineForLogs : public IColumnEngine { std::shared_ptr StoragesManager; TEvictionsController EvictionsController; class TTieringProcessContext { + private: + const ui64 MemoryUsageLimit; + ui64 MemoryUsage = 0; + ui64 TxWriteVolume = 0; + std::shared_ptr MemoryPredictor; public: - bool AllowEviction = true; - bool AllowDrop = true; const TInstant Now; - const ui64 MaxEvictBytes; std::shared_ptr Changes; std::map DurationsForced; const THashSet& BusyPortions; - TTieringProcessContext(const ui64 maxEvictBytes, std::shared_ptr changes, const THashSet& busyPortions); + + void AppPortionForEvictionChecker(const TPortionInfo& info) { + MemoryUsage = MemoryPredictor->AddPortion(info); + TxWriteVolume += info.GetTxVolume(); + } + + void AppPortionForTtlChecker(const TPortionInfo& info) { + TxWriteVolume += info.GetTxVolume(); + } + + bool HasLimitsForEviction() const { + return MemoryUsage < MemoryUsageLimit && TxWriteVolume < TGlobalLimits::TxWriteLimitBytes; + } + + bool HasLimitsForTtl() const { + return TxWriteVolume < TGlobalLimits::TxWriteLimitBytes; + } + + TTieringProcessContext(const ui64 memoryUsageLimit, std::shared_ptr changes, + const THashSet& busyPortions, const std::shared_ptr& memoryPredictor); }; TDuration ProcessTiering(const ui64 pathId, const TTiering& tiering, TTieringProcessContext& context) const; bool DrainEvictionQueue(std::map>& evictionsQueue, TTieringProcessContext& context) const; public: + ui64* GetLastPortionPointer() { + return &LastPortion; + } + enum ETableIdx { GRANULES = 0, }; @@ -135,8 +161,8 @@ class TColumnEngineForLogs : public IColumnEngine { std::shared_ptr StartInsert(std::vector&& dataToIndex) noexcept override; std::shared_ptr StartCompaction(const TCompactionLimits& limits, const THashSet& busyPortions) noexcept override; std::shared_ptr StartCleanup(const TSnapshot& snapshot, THashSet& pathsToDrop, ui32 maxRecords) noexcept override; - std::shared_ptr StartTtl(const THashMap& pathEviction, const THashSet& busyPortions, - ui64 maxEvictBytes = TCompactionLimits::DEFAULT_EVICTION_BYTES) noexcept override; + std::shared_ptr StartTtl(const THashMap& pathEviction, + const THashSet& busyPortions, const ui64 memoryUsageLimit) noexcept override; bool ApplyChanges(IDbWrapper& db, std::shared_ptr indexChanges, const TSnapshot& snapshot) noexcept override; @@ -164,9 +190,7 @@ class TColumnEngineForLogs : public IColumnEngine { } const TGranuleMeta& GetGranuleVerified(const ui64 pathId) const { - auto it = Tables.find(pathId); - AFL_VERIFY(it != Tables.end())("path_id", pathId)("count", Tables.size()); - return *it->second; + return *GetGranulePtrVerified(pathId); } std::shared_ptr GetGranulePtrVerified(const ui64 pathId) const { diff --git a/ydb/core/tx/columnshard/engines/defs.h b/ydb/core/tx/columnshard/engines/defs.h index 6c4e0371d7a4..cb0ca8ee6ae7 100644 --- a/ydb/core/tx/columnshard/engines/defs.h +++ b/ydb/core/tx/columnshard/engines/defs.h @@ -3,7 +3,6 @@ #include #include #include -#include namespace NKikimr::NOlap { diff --git a/ydb/core/tx/columnshard/engines/filter.h b/ydb/core/tx/columnshard/engines/filter.h index 160a55e01d3f..22429208a8d0 100644 --- a/ydb/core/tx/columnshard/engines/filter.h +++ b/ydb/core/tx/columnshard/engines/filter.h @@ -3,6 +3,7 @@ #include "defs.h" #include #include +#include namespace NKikimr::NOlap { diff --git a/ydb/core/tx/columnshard/engines/insert_table/data.h b/ydb/core/tx/columnshard/engines/insert_table/data.h index 60361d2e27fc..ca726640b24d 100644 --- a/ydb/core/tx/columnshard/engines/insert_table/data.h +++ b/ydb/core/tx/columnshard/engines/insert_table/data.h @@ -2,6 +2,7 @@ #include "meta.h" #include #include +#include #include namespace NKikimr::NOlap { diff --git a/ydb/core/tx/columnshard/engines/portions/meta.cpp b/ydb/core/tx/columnshard/engines/portions/meta.cpp index 9f6a2c30823b..fde6d7135c35 100644 --- a/ydb/core/tx/columnshard/engines/portions/meta.cpp +++ b/ydb/core/tx/columnshard/engines/portions/meta.cpp @@ -69,7 +69,7 @@ bool TPortionMeta::DeserializeFromProto(const NKikimrTxColumnShard::TIndexPortio } std::optional TPortionMeta::SerializeToProto(const ui32 columnId, const ui32 chunk) const { - if (columnId != FirstPkColumn || chunk != 0) { + if (!IsChunkWithPortionInfo(columnId, chunk)) { return {}; } diff --git a/ydb/core/tx/columnshard/engines/portions/meta.h b/ydb/core/tx/columnshard/engines/portions/meta.h index 7acafc89a772..005021f7c457 100644 --- a/ydb/core/tx/columnshard/engines/portions/meta.h +++ b/ydb/core/tx/columnshard/engines/portions/meta.h @@ -26,6 +26,10 @@ struct TPortionMeta { EProduced Produced{EProduced::UNSPECIFIED}; ui32 FirstPkColumn = 0; + bool IsChunkWithPortionInfo(const ui32 columnId, const ui32 chunkIdx) const { + return columnId == FirstPkColumn && chunkIdx == 0; + } + bool DeserializeFromProto(const NKikimrTxColumnShard::TIndexPortionMeta& portionMeta, const TIndexInfo& indexInfo); std::optional SerializeToProto(const ui32 columnId, const ui32 chunk) const; diff --git a/ydb/core/tx/columnshard/engines/portions/portion_info.cpp b/ydb/core/tx/columnshard/engines/portions/portion_info.cpp index 3deb26a0a730..23b21564ab85 100644 --- a/ydb/core/tx/columnshard/engines/portions/portion_info.cpp +++ b/ydb/core/tx/columnshard/engines/portions/portion_info.cpp @@ -306,6 +306,10 @@ std::vector TPortionInfo::BuildPages() cons return pages; } +ui64 TPortionInfo::GetTxVolume() const { + return 1024 + Records.size() * 256 + Indexes.size() * 256; +} + std::shared_ptr TPortionInfo::TPreparedColumn::Assemble() const { Y_ABORT_UNLESS(!Blobs.empty()); diff --git a/ydb/core/tx/columnshard/engines/portions/portion_info.h b/ydb/core/tx/columnshard/engines/portions/portion_info.h index ffca573d8cce..d5a052ae52c6 100644 --- a/ydb/core/tx/columnshard/engines/portions/portion_info.h +++ b/ydb/core/tx/columnshard/engines/portions/portion_info.h @@ -30,6 +30,8 @@ class TPortionInfo { YDB_READONLY_DEF(std::vector, Indexes); public: + ui64 GetTxVolume() const; // fake-correct method for determ volume on rewrite this portion in transaction progress + class TPage { private: YDB_READONLY_DEF(std::vector, Records); @@ -364,6 +366,9 @@ class TPortionInfo { for (auto&& i : Records) { result.emplace(i.BlobRange.BlobId); } + for (auto&& i : Indexes) { + result.emplace(i.GetBlobRange().BlobId); + } return result; } diff --git a/ydb/core/tx/columnshard/engines/predicate/filter.cpp b/ydb/core/tx/columnshard/engines/predicate/filter.cpp index 77816507e0c1..10d66a832c1a 100644 --- a/ydb/core/tx/columnshard/engines/predicate/filter.cpp +++ b/ydb/core/tx/columnshard/engines/predicate/filter.cpp @@ -84,6 +84,15 @@ bool TPKRangesFilter::IsPortionInUsage(const TPortionInfo& info, const TIndexInf return SortedRanges.empty(); } +bool TPKRangesFilter::IsPortionInPartialUsage(const NArrow::TReplaceKey& start, const NArrow::TReplaceKey& end, const TIndexInfo& indexInfo) const { + for (auto&& i : SortedRanges) { + if (i.IsPortionInPartialUsage(start, end, indexInfo)) { + return true; + } + } + return false; +} + TPKRangesFilter::TPKRangesFilter(const bool reverse) : ReverseFlag(reverse) { diff --git a/ydb/core/tx/columnshard/engines/predicate/filter.h b/ydb/core/tx/columnshard/engines/predicate/filter.h index d9448d438081..6d30adfdc227 100644 --- a/ydb/core/tx/columnshard/engines/predicate/filter.h +++ b/ydb/core/tx/columnshard/engines/predicate/filter.h @@ -38,6 +38,7 @@ class TPKRangesFilter { } bool IsPortionInUsage(const TPortionInfo& info, const TIndexInfo& indexInfo) const; + bool IsPortionInPartialUsage(const NArrow::TReplaceKey& start, const NArrow::TReplaceKey& end, const TIndexInfo& indexInfo) const; NArrow::TColumnFilter BuildFilter(const arrow::Datum& data) const; diff --git a/ydb/core/tx/columnshard/engines/predicate/range.cpp b/ydb/core/tx/columnshard/engines/predicate/range.cpp index 53e10174b82d..1025fa055ca5 100644 --- a/ydb/core/tx/columnshard/engines/predicate/range.cpp +++ b/ydb/core/tx/columnshard/engines/predicate/range.cpp @@ -59,6 +59,37 @@ bool TPKRangeFilter::IsPortionInUsage(const TPortionInfo& info, const TIndexInfo return true; } +bool TPKRangeFilter::IsPortionInPartialUsage(const NArrow::TReplaceKey& start, const NArrow::TReplaceKey& end, const TIndexInfo& indexInfo) const { + bool startUsage = false; + bool endUsage = false; + if (auto from = PredicateFrom.ExtractKey(indexInfo.GetPrimaryKey())) { + AFL_VERIFY(from->Size() <= start.Size()); + if (PredicateFrom.IsInclude()) { + startUsage = std::is_lt(start.ComparePartNotNull(*from, from->Size())); + } else { + startUsage = std::is_lteq(start.ComparePartNotNull(*from, from->Size())); + } + } else { + startUsage = true; + } + + if (auto to = PredicateTo.ExtractKey(indexInfo.GetPrimaryKey())) { + AFL_VERIFY(to->Size() <= end.Size()); + if (PredicateTo.IsInclude()) { + endUsage = std::is_gt(end.ComparePartNotNull(*to, to->Size())); + } else { + endUsage = std::is_gteq(end.ComparePartNotNull(*to, to->Size())); + } + } else { + endUsage = true; + } + +// AFL_ERROR(NKikimrServices::TX_COLUMNSHARD)("start", start.DebugString())("end", end.DebugString())("from", PredicateFrom.DebugString())("to", PredicateTo.DebugString()) +// ("start_usage", startUsage)("end_usage", endUsage); + + return endUsage || startUsage; +} + std::optional TPKRangeFilter::Build(TPredicateContainer&& from, TPredicateContainer&& to) { if (!from.CrossRanges(to)) { AFL_DEBUG(NKikimrServices::TX_COLUMNSHARD_SCAN)("event", "cannot_build_predicate_range")("error", "predicates from/to not intersected"); diff --git a/ydb/core/tx/columnshard/engines/predicate/range.h b/ydb/core/tx/columnshard/engines/predicate/range.h index 7e23da4f13d6..ff84f35408a3 100644 --- a/ydb/core/tx/columnshard/engines/predicate/range.h +++ b/ydb/core/tx/columnshard/engines/predicate/range.h @@ -41,6 +41,7 @@ class TPKRangeFilter { NArrow::TColumnFilter BuildFilter(const arrow::Datum& data) const; bool IsPortionInUsage(const TPortionInfo& info, const TIndexInfo& indexInfo) const; + bool IsPortionInPartialUsage(const NArrow::TReplaceKey& start, const NArrow::TReplaceKey& end, const TIndexInfo& indexInfo) const; std::set GetColumnIds(const TIndexInfo& indexInfo) const; TString DebugString() const; diff --git a/ydb/core/tx/columnshard/engines/reader/plain_reader/columns_set.h b/ydb/core/tx/columnshard/engines/reader/plain_reader/columns_set.h index 97fef7f317eb..0bca398204e2 100644 --- a/ydb/core/tx/columnshard/engines/reader/plain_reader/columns_set.h +++ b/ydb/core/tx/columnshard/engines/reader/plain_reader/columns_set.h @@ -106,6 +106,15 @@ class TColumnsSet { return true; } + bool Cross(const TColumnsSet& columnsSet) const { + for (auto&& i : columnsSet.ColumnIds) { + if (ColumnIds.contains(i)) { + return true; + } + } + return false; + } + bool IsEqual(const TColumnsSet& columnsSet) const { if (columnsSet.GetColumnIds().size() != ColumnIds.size()) { return false; diff --git a/ydb/core/tx/columnshard/engines/reader/plain_reader/context.cpp b/ydb/core/tx/columnshard/engines/reader/plain_reader/context.cpp index cf07daf49f8f..930e91ad544d 100644 --- a/ydb/core/tx/columnshard/engines/reader/plain_reader/context.cpp +++ b/ydb/core/tx/columnshard/engines/reader/plain_reader/context.cpp @@ -19,21 +19,23 @@ ui64 TSpecialReadContext::GetMemoryForSources(const std::map TSpecialReadContext::GetColumnsFetchingPlan(const std::shared_ptr& source, const bool exclusiveSource) const { const bool needSnapshots = !exclusiveSource || ReadMetadata->GetSnapshot() < source->GetRecordSnapshotMax(); - auto result = CacheFetchingScripts[needSnapshots ? 1 : 0][exclusiveSource ? 1 : 0]; + const bool partialUsageByPK = ReadMetadata->GetPKRangesFilter().IsPortionInPartialUsage(source->GetStartReplaceKey(), source->GetFinishReplaceKey(), ReadMetadata->GetIndexInfo()); + auto result = CacheFetchingScripts[needSnapshots ? 1 : 0][exclusiveSource ? 1 : 0][partialUsageByPK ? 1 : 0]; if (!result) { return std::make_shared(source->GetRecordsCount(), "fake"); } return result; } -std::shared_ptr TSpecialReadContext::BuildColumnsFetchingPlan(const bool needSnapshots, const bool exclusiveSource) const { +std::shared_ptr TSpecialReadContext::BuildColumnsFetchingPlan(const bool needSnapshots, const bool exclusiveSource, const bool partialUsageByPredicateExt) const { std::shared_ptr result = std::make_shared(); std::shared_ptr current = result; + const bool partialUsageByPredicate = partialUsageByPredicateExt && PredicateColumns->GetColumnsCount(); if (!!IndexChecker) { current = current->AttachNext(std::make_shared(std::make_shared(IndexChecker->GetIndexIds()))); current = current->AttachNext(std::make_shared(IndexChecker)); } - if (!EFColumns->GetColumnsCount()) { + if (!EFColumns->GetColumnsCount() && !partialUsageByPredicate) { TColumnsSet columnsFetch = *FFColumns; if (needSnapshots) { columnsFetch = columnsFetch + *SpecColumns; @@ -49,20 +51,27 @@ std::shared_ptr TSpecialReadContext } } else if (exclusiveSource) { TColumnsSet columnsFetch = *EFColumns; - if (needSnapshots || FFColumns->Contains(SpecColumns)) { + if (needSnapshots || FFColumns->Cross(*SpecColumns)) { columnsFetch = columnsFetch + *SpecColumns; } + if (partialUsageByPredicate) { + columnsFetch = columnsFetch + *PredicateColumns; + } AFL_VERIFY(columnsFetch.GetColumnsCount()); current = current->AttachNext(std::make_shared(std::make_shared(columnsFetch), "ef")); - if (needSnapshots || FFColumns->Contains(SpecColumns)) { + if (needSnapshots || FFColumns->Cross(*SpecColumns)) { current = current->AttachNext(std::make_shared(SpecColumns)); current = current->AttachNext(std::make_shared()); columnsFetch = columnsFetch - *SpecColumns; } - current = current->AttachNext(std::make_shared(std::make_shared(columnsFetch))); - if (!ReadMetadata->GetPKRangesFilter().IsEmpty()) { + if (partialUsageByPredicate) { + current = current->AttachNext(std::make_shared(PredicateColumns)); current = current->AttachNext(std::make_shared()); + columnsFetch = columnsFetch - *PredicateColumns; + } + if (columnsFetch.GetColumnsCount()) { + current = current->AttachNext(std::make_shared(std::make_shared(columnsFetch))); } for (auto&& i : ReadMetadata->GetProgram().GetSteps()) { if (!i->IsFilterOnly()) { @@ -70,7 +79,10 @@ std::shared_ptr TSpecialReadContext } current = current->AttachNext(std::make_shared(i)); } - const TColumnsSet columnsAdditionalFetch = *FFColumns - *EFColumns - *SpecColumns; + TColumnsSet columnsAdditionalFetch = *FFColumns - *EFColumns - *SpecColumns; + if (partialUsageByPredicate) { + columnsAdditionalFetch = columnsAdditionalFetch - *PredicateColumns; + } if (columnsAdditionalFetch.GetColumnsCount()) { current = current->AttachNext(std::make_shared(std::make_shared(columnsAdditionalFetch))); current = current->AttachNext(std::make_shared(std::make_shared(columnsAdditionalFetch))); @@ -84,7 +96,7 @@ std::shared_ptr TSpecialReadContext current = current->AttachNext(std::make_shared()); } current = current->AttachNext(std::make_shared(PKColumns)); - if (!ReadMetadata->GetPKRangesFilter().IsEmpty()) { + if (partialUsageByPredicate) { current = current->AttachNext(std::make_shared()); } const TColumnsSet columnsFetchEF = columnsFetch - *SpecColumns - *PKColumns; @@ -95,7 +107,7 @@ std::shared_ptr TSpecialReadContext } current = current->AttachNext(std::make_shared(i)); } - const TColumnsSet columnsAdditionalFetch = *FFColumns - *EFColumns - *SpecColumns - *PKColumns; + const TColumnsSet columnsAdditionalFetch = *FFColumns - *EFColumns - *SpecColumns - *PKColumns - *PredicateColumns; if (columnsAdditionalFetch.GetColumnsCount()) { current = current->AttachNext(std::make_shared(std::make_shared(columnsAdditionalFetch))); current = current->AttachNext(std::make_shared(std::make_shared(columnsAdditionalFetch))); @@ -114,6 +126,14 @@ TSpecialReadContext::TSpecialReadContext(const std::shared_ptr& co auto readSchema = ReadMetadata->GetLoadSchema(ReadMetadata->GetSnapshot()); SpecColumns = std::make_shared(TIndexInfo::GetSpecialColumnIdsSet(), ReadMetadata->GetIndexInfo(), readSchema); IndexChecker = ReadMetadata->GetProgram().GetIndexChecker(); + { + auto predicateColumns = ReadMetadata->GetPKRangesFilter().GetColumnIds(ReadMetadata->GetIndexInfo()); + if (predicateColumns.size()) { + PredicateColumns = std::make_shared(predicateColumns, ReadMetadata->GetIndexInfo(), readSchema); + } else { + PredicateColumns = std::make_shared(); + } + } { auto efColumns = ReadMetadata->GetEarlyFilterColumnIds(); if (efColumns.size()) { @@ -144,10 +164,14 @@ TSpecialReadContext::TSpecialReadContext(const std::shared_ptr& co MergeColumns = std::make_shared(*PKColumns + *SpecColumns); AFL_DEBUG(NKikimrServices::TX_COLUMNSHARD_SCAN)("columns_context_info", DebugString()); - CacheFetchingScripts[0][0] = BuildColumnsFetchingPlan(false, false); - CacheFetchingScripts[0][1] = BuildColumnsFetchingPlan(false, true); - CacheFetchingScripts[1][0] = BuildColumnsFetchingPlan(true, false); - CacheFetchingScripts[1][1] = BuildColumnsFetchingPlan(true, true); + CacheFetchingScripts[0][0][0] = BuildColumnsFetchingPlan(false, false, false); + CacheFetchingScripts[0][1][0] = BuildColumnsFetchingPlan(false, true, false); + CacheFetchingScripts[1][0][0] = BuildColumnsFetchingPlan(true, false, false); + CacheFetchingScripts[1][1][0] = BuildColumnsFetchingPlan(true, true, false); + CacheFetchingScripts[0][0][1] = BuildColumnsFetchingPlan(false, false, true); + CacheFetchingScripts[0][1][1] = BuildColumnsFetchingPlan(false, true, true); + CacheFetchingScripts[1][0][1] = BuildColumnsFetchingPlan(true, false, true); + CacheFetchingScripts[1][1][1] = BuildColumnsFetchingPlan(true, true, true); } } diff --git a/ydb/core/tx/columnshard/engines/reader/plain_reader/context.h b/ydb/core/tx/columnshard/engines/reader/plain_reader/context.h index a8b727a5385a..ff6f17216642 100644 --- a/ydb/core/tx/columnshard/engines/reader/plain_reader/context.h +++ b/ydb/core/tx/columnshard/engines/reader/plain_reader/context.h @@ -15,6 +15,7 @@ class TSpecialReadContext { YDB_READONLY_DEF(std::shared_ptr, SpecColumns); YDB_READONLY_DEF(std::shared_ptr, MergeColumns); YDB_READONLY_DEF(std::shared_ptr, EFColumns); + YDB_READONLY_DEF(std::shared_ptr, PredicateColumns); YDB_READONLY_DEF(std::shared_ptr, PKColumns); YDB_READONLY_DEF(std::shared_ptr, FFColumns); YDB_READONLY_DEF(std::shared_ptr, ProgramInputColumns); @@ -22,11 +23,8 @@ class TSpecialReadContext { NIndexes::TIndexCheckerContainer IndexChecker; TReadMetadata::TConstPtr ReadMetadata; std::shared_ptr EmptyColumns = std::make_shared(); - std::shared_ptr PKFFColumns; - std::shared_ptr EFPKColumns; - std::shared_ptr FFMinusEFColumns; - std::shared_ptr BuildColumnsFetchingPlan(const bool needSnapshotsFilter, const bool exclusiveSource) const; - std::array, 2>, 2> CacheFetchingScripts; + std::shared_ptr BuildColumnsFetchingPlan(const bool needSnapshotsFilter, const bool exclusiveSource, const bool partialUsageByPredicate) const; + std::array, 2>, 2>, 2> CacheFetchingScripts; public: ui64 GetMemoryForSources(const std::map>& sources, const bool isExclusive); diff --git a/ydb/core/tx/columnshard/engines/reader/plain_reader/fetched_data.h b/ydb/core/tx/columnshard/engines/reader/plain_reader/fetched_data.h index 62d3c1fcb3b2..e31f51bd0dac 100644 --- a/ydb/core/tx/columnshard/engines/reader/plain_reader/fetched_data.h +++ b/ydb/core/tx/columnshard/engines/reader/plain_reader/fetched_data.h @@ -63,14 +63,10 @@ class TFetchedData { } void AddFilter(const std::shared_ptr& filter) { - if (UseFilter && Table && filter) { - AFL_VERIFY(filter->Apply(Table)); - } - if (!Filter) { - Filter = filter; - } else if (filter) { - *Filter = Filter->CombineSequentialAnd(*filter); + if (!filter) { + return; } + return AddFilter(*filter); } void AddFilter(const NArrow::TColumnFilter& filter) { @@ -79,8 +75,10 @@ class TFetchedData { } if (!Filter) { Filter = std::make_shared(filter); - } else { + } else if (UseFilter) { *Filter = Filter->CombineSequentialAnd(filter); + } else { + *Filter = Filter->And(filter); } } diff --git a/ydb/core/tx/columnshard/engines/reader/plain_reader/fetching.cpp b/ydb/core/tx/columnshard/engines/reader/plain_reader/fetching.cpp index 96923fed2a2f..7f38c7dfc000 100644 --- a/ydb/core/tx/columnshard/engines/reader/plain_reader/fetching.cpp +++ b/ydb/core/tx/columnshard/engines/reader/plain_reader/fetching.cpp @@ -3,6 +3,8 @@ #include #include +#include + namespace NKikimr::NOlap::NPlainReader { bool TStepAction::DoApply(IDataReader& /*owner*/) const { @@ -14,6 +16,7 @@ bool TStepAction::DoApply(IDataReader& /*owner*/) const { } bool TStepAction::DoExecute() { + NMiniKQL::TThrowingBindTerminator bind; while (Step) { if (Source->IsEmptyData()) { Source->Finalize(); @@ -58,6 +61,9 @@ bool TAssemblerStep::DoExecuteInplace(const std::shared_ptr& source } bool TFilterProgramStep::DoExecuteInplace(const std::shared_ptr& source, const std::shared_ptr& /*step*/) const { + AFL_VERIFY(source); + AFL_VERIFY(Step); + AFL_VERIFY(source->GetStageData().GetTable()); auto filter = Step->BuildFilter(source->GetStageData().GetTable()); source->MutableStageData().AddFilter(filter); return true; diff --git a/ydb/core/tx/columnshard/engines/reader/plain_reader/plain_read_data.cpp b/ydb/core/tx/columnshard/engines/reader/plain_reader/plain_read_data.cpp index 0720416cddb2..26b397fe2e36 100644 --- a/ydb/core/tx/columnshard/engines/reader/plain_reader/plain_read_data.cpp +++ b/ydb/core/tx/columnshard/engines/reader/plain_reader/plain_read_data.cpp @@ -33,15 +33,10 @@ TPlainReadData::TPlainReadData(const std::shared_ptr& conte } else { insertedPortionsBytes += (*itPortion)->BlobsBytes(); } - auto start = GetReadMetadata()->BuildSortedPosition((*itPortion)->IndexKeyStart()); - auto finish = GetReadMetadata()->BuildSortedPosition((*itPortion)->IndexKeyEnd()); - AFL_DEBUG(NKikimrServices::TX_COLUMNSHARD_SCAN)("event", "portions_for_merge")("start", start.DebugJson())("finish", finish.DebugJson()); - sources.emplace_back(std::make_shared(sourceIdx++, *itPortion, SpecialReadContext, start, finish)); + sources.emplace_back(std::make_shared(sourceIdx++, *itPortion, SpecialReadContext, (*itPortion)->IndexKeyStart(), (*itPortion)->IndexKeyEnd())); ++itPortion; } else { - auto start = GetReadMetadata()->BuildSortedPosition(itCommitted->GetFirstVerified()); - auto finish = GetReadMetadata()->BuildSortedPosition(itCommitted->GetLastVerified()); - sources.emplace_back(std::make_shared(sourceIdx++, *itCommitted, SpecialReadContext, start, finish)); + sources.emplace_back(std::make_shared(sourceIdx++, *itCommitted, SpecialReadContext, itCommitted->GetFirstVerified(), itCommitted->GetLastVerified())); committedPortionsBytes += itCommitted->GetSize(); ++itCommitted; } diff --git a/ydb/core/tx/columnshard/engines/reader/plain_reader/source.cpp b/ydb/core/tx/columnshard/engines/reader/plain_reader/source.cpp index e52f769a8172..3ba21e93aef1 100644 --- a/ydb/core/tx/columnshard/engines/reader/plain_reader/source.cpp +++ b/ydb/core/tx/columnshard/engines/reader/plain_reader/source.cpp @@ -3,7 +3,6 @@ #include "fetched_data.h" #include "plain_read_data.h" #include "constructor.h" -#include #include #include #include diff --git a/ydb/core/tx/columnshard/engines/reader/plain_reader/source.h b/ydb/core/tx/columnshard/engines/reader/plain_reader/source.h index f339312ecfd7..3cce8e16eef7 100644 --- a/ydb/core/tx/columnshard/engines/reader/plain_reader/source.h +++ b/ydb/core/tx/columnshard/engines/reader/plain_reader/source.h @@ -26,6 +26,8 @@ class IDataSource { YDB_READONLY(ui32, SourceIdx, 0); YDB_READONLY_DEF(NIndexedReader::TSortableBatchPosition, Start); YDB_READONLY_DEF(NIndexedReader::TSortableBatchPosition, Finish); + NArrow::TReplaceKey StartReplaceKey; + NArrow::TReplaceKey FinishReplaceKey; YDB_READONLY_DEF(std::shared_ptr, Context); YDB_READONLY(TSnapshot, RecordSnapshotMax, TSnapshot::Zero()); std::optional RecordsCount; @@ -52,6 +54,13 @@ class IDataSource { virtual void DoAbort() = 0; virtual void DoApplyIndex(const NIndexes::TIndexCheckerContainer& indexMeta) = 0; public: + const NArrow::TReplaceKey& GetStartReplaceKey() const { + return StartReplaceKey; + } + const NArrow::TReplaceKey& GetFinishReplaceKey() const { + return FinishReplaceKey; + } + const TFetchedResult& GetStageResult() const { AFL_VERIFY(!!StageResult); return *StageResult; @@ -147,16 +156,19 @@ class IDataSource { void RegisterInterval(TFetchingInterval& interval); IDataSource(const ui32 sourceIdx, const std::shared_ptr& context, - const NIndexedReader::TSortableBatchPosition& start, const NIndexedReader::TSortableBatchPosition& finish, + const NArrow::TReplaceKey& start, const NArrow::TReplaceKey& finish, const TSnapshot& recordSnapshotMax, const std::optional recordsCount ) : SourceIdx(sourceIdx) - , Start(start) - , Finish(finish) + , Start(context->GetReadMetadata()->BuildSortedPosition(start)) + , Finish(context->GetReadMetadata()->BuildSortedPosition(finish)) + , StartReplaceKey(start) + , FinishReplaceKey(finish) , Context(context) , RecordSnapshotMax(recordSnapshotMax) , RecordsCount(recordsCount) { + AFL_DEBUG(NKikimrServices::TX_COLUMNSHARD_SCAN)("event", "portions_for_merge")("start", Start.DebugJson())("finish", Finish.DebugJson()); if (Start.IsReverseSort()) { std::swap(Start, Finish); } @@ -210,10 +222,10 @@ class TPortionDataSource: public IDataSource { } TPortionDataSource(const ui32 sourceIdx, const std::shared_ptr& portion, const std::shared_ptr& context, - const NIndexedReader::TSortableBatchPosition& start, const NIndexedReader::TSortableBatchPosition& finish) + const NArrow::TReplaceKey& start, const NArrow::TReplaceKey& finish) : TBase(sourceIdx, context, start, finish, portion->RecordSnapshotMax(), portion->GetRecordsCount()) - , Portion(portion) { - + , Portion(portion) + { } }; @@ -256,7 +268,7 @@ class TCommittedDataSource: public IDataSource { } TCommittedDataSource(const ui32 sourceIdx, const TCommittedBlob& committed, const std::shared_ptr& context, - const NIndexedReader::TSortableBatchPosition& start, const NIndexedReader::TSortableBatchPosition& finish) + const NArrow::TReplaceKey& start, const NArrow::TReplaceKey& finish) : TBase(sourceIdx, context, start, finish, committed.GetSnapshot(), {}) , CommittedBlob(committed) { diff --git a/ydb/core/tx/columnshard/engines/reader/read_metadata.cpp b/ydb/core/tx/columnshard/engines/reader/read_metadata.cpp index 988d6553b327..e9a9e804977c 100644 --- a/ydb/core/tx/columnshard/engines/reader/read_metadata.cpp +++ b/ydb/core/tx/columnshard/engines/reader/read_metadata.cpp @@ -48,7 +48,7 @@ bool TReadMetadata::Init(const TReadDescription& readDescription, const TDataSto std::set TReadMetadata::GetEarlyFilterColumnIds() const { auto& indexInfo = ResultIndexSchema->GetIndexInfo(); - std::set result = GetPKRangesFilter().GetColumnIds(indexInfo); + std::set result; for (auto&& i : GetProgram().GetEarlyFilterColumns()) { auto id = indexInfo.GetColumnIdOptional(i); if (id) { diff --git a/ydb/core/tx/columnshard/engines/scheme/abstract_scheme.h b/ydb/core/tx/columnshard/engines/scheme/abstract_scheme.h index b063ba7d02ef..bde8318423ee 100644 --- a/ydb/core/tx/columnshard/engines/scheme/abstract_scheme.h +++ b/ydb/core/tx/columnshard/engines/scheme/abstract_scheme.h @@ -1,5 +1,6 @@ #pragma once +#include #include #include diff --git a/ydb/core/tx/columnshard/engines/scheme/column_features.cpp b/ydb/core/tx/columnshard/engines/scheme/column_features.cpp index a416509e4878..72d5059c0053 100644 --- a/ydb/core/tx/columnshard/engines/scheme/column_features.cpp +++ b/ydb/core/tx/columnshard/engines/scheme/column_features.cpp @@ -1,7 +1,6 @@ #include "column_features.h" #include "index_info.h" -#include -#include +#include #include namespace NKikimr::NOlap { @@ -23,26 +22,17 @@ NArrow::NTransformation::ITransformer::TPtr TColumnFeatures::GetLoadTransformer( } void TColumnFeatures::InitLoader(const TIndexInfo& info) { - NArrow::NTransformation::ITransformer::TPtr transformer = GetLoadTransformer(); auto schema = info.GetColumnSchema(ColumnId); - if (!transformer) { - Loader = std::make_shared(transformer, - std::make_shared(schema), - schema, ColumnId); - } else { - Loader = std::make_shared(transformer, - std::make_shared(), - schema, ColumnId); - } + Loader = std::make_shared(GetLoadTransformer(), Serializer, schema, ColumnId); } std::optional TColumnFeatures::BuildFromProto(const NKikimrSchemeOp::TOlapColumnDescription& columnInfo, const TIndexInfo& indexInfo) { const ui32 columnId = columnInfo.GetId(); TColumnFeatures result(columnId); - if (columnInfo.HasCompression()) { - auto settings = NArrow::TCompression::BuildFromProto(columnInfo.GetCompression()); - Y_ABORT_UNLESS(settings.IsSuccess()); - result.Compression = *settings; + if (columnInfo.HasSerializer()) { + AFL_VERIFY(result.Serializer.DeserializeFromProto(columnInfo.GetSerializer())); + } else if (columnInfo.HasCompression()) { + AFL_VERIFY(result.Serializer.DeserializeFromProto(columnInfo.GetCompression())); } if (columnInfo.HasDictionaryEncoding()) { auto settings = NArrow::NDictionary::TEncodingSettings::BuildFromProto(columnInfo.GetDictionaryEncoding()); @@ -53,20 +43,19 @@ std::optional TColumnFeatures::BuildFromProto(c return result; } -std::unique_ptr TColumnFeatures::GetCompressionCodec() const { - if (Compression) { - return Compression->BuildArrowCodec(); - } else { - return nullptr; - } -} - NKikimr::NOlap::TColumnFeatures TColumnFeatures::BuildFromIndexInfo(const ui32 columnId, const TIndexInfo& indexInfo) { TColumnFeatures result(columnId); result.InitLoader(indexInfo); return result; } +TColumnFeatures::TColumnFeatures(const ui32 columnId) + : ColumnId(columnId) + , Serializer(NArrow::NSerialization::TSerializerContainer::GetDefaultSerializer()) +{ + +} + TString TColumnLoader::DebugString() const { TStringBuilder result; if (ExpectedSchema) { @@ -75,8 +64,8 @@ TString TColumnLoader::DebugString() const { if (Transformer) { result << "transformer:" << Transformer->DebugString() << ";"; } - if (Deserializer) { - result << "deserializer:" << Deserializer->DebugString() << ";"; + if (Serializer) { + result << "serializer:" << Serializer->DebugString() << ";"; } return result; } diff --git a/ydb/core/tx/columnshard/engines/scheme/column_features.h b/ydb/core/tx/columnshard/engines/scheme/column_features.h index 11415ecc20de..7e99af80eb72 100644 --- a/ydb/core/tx/columnshard/engines/scheme/column_features.h +++ b/ydb/core/tx/columnshard/engines/scheme/column_features.h @@ -1,5 +1,4 @@ #pragma once -#include #include #include #include @@ -14,7 +13,7 @@ namespace NKikimr::NOlap { class TSaverContext { private: TString TierName; - std::optional ExternalCompression; + std::optional ExternalSerializer; YDB_READONLY_DEF(std::shared_ptr, StorageOperator); YDB_READONLY_DEF(std::shared_ptr, StoragesManager); public: @@ -24,11 +23,12 @@ class TSaverContext { } - const std::optional& GetExternalCompression() const { - return ExternalCompression; + const std::optional& GetExternalSerializer() const { + return ExternalSerializer; } - TSaverContext& SetExternalCompression(const std::optional& value) { - ExternalCompression = value; + TSaverContext& SetExternalSerializer(const std::optional& value) { + AFL_VERIFY(!!value); + ExternalSerializer = value; return *this; } const TString& GetTierName() const { @@ -43,17 +43,17 @@ class TSaverContext { class TColumnSaver { private: NArrow::NTransformation::ITransformer::TPtr Transformer; - NArrow::NSerialization::ISerializer::TPtr Serializer; + NArrow::NSerialization::TSerializerContainer Serializer; public: TColumnSaver() = default; - TColumnSaver(NArrow::NTransformation::ITransformer::TPtr transformer, NArrow::NSerialization::ISerializer::TPtr serializer) + TColumnSaver(NArrow::NTransformation::ITransformer::TPtr transformer, const NArrow::NSerialization::TSerializerContainer serializer) : Transformer(transformer) , Serializer(serializer) { Y_ABORT_UNLESS(Serializer); } bool IsHardPacker() const { - return Serializer && Serializer->IsHardPacker(); + return Serializer->IsHardPacker(); } TString Apply(std::shared_ptr data, std::shared_ptr field) const { @@ -65,9 +65,9 @@ class TColumnSaver { TString Apply(const std::shared_ptr& data) const { Y_ABORT_UNLESS(Serializer); if (Transformer) { - return Serializer->Serialize(Transformer->Transform(data)); + return Serializer->SerializeFull(Transformer->Transform(data)); } else { - return Serializer->Serialize(data); + return Serializer->SerializePayload(data); } } }; @@ -75,22 +75,22 @@ class TColumnSaver { class TColumnLoader { private: NArrow::NTransformation::ITransformer::TPtr Transformer; - NArrow::NSerialization::IDeserializer::TPtr Deserializer; + NArrow::NSerialization::TSerializerContainer Serializer; std::shared_ptr ExpectedSchema; const ui32 ColumnId; public: TString DebugString() const; - TColumnLoader(NArrow::NTransformation::ITransformer::TPtr transformer, NArrow::NSerialization::IDeserializer::TPtr deserializer, + TColumnLoader(NArrow::NTransformation::ITransformer::TPtr transformer, const NArrow::NSerialization::TSerializerContainer& serializer, const std::shared_ptr& expectedSchema, const ui32 columnId) : Transformer(transformer) - , Deserializer(deserializer) + , Serializer(serializer) , ExpectedSchema(expectedSchema) , ColumnId(columnId) { Y_ABORT_UNLESS(ExpectedSchema); auto fieldsCountStr = ::ToString(ExpectedSchema->num_fields()); Y_ABORT_UNLESS(ExpectedSchema->num_fields() == 1, "%s", fieldsCountStr.data()); - Y_ABORT_UNLESS(Deserializer); + Y_ABORT_UNLESS(Serializer); } ui32 GetColumnId() const { @@ -106,8 +106,9 @@ class TColumnLoader { } arrow::Result> Apply(const TString& data) const { - Y_ABORT_UNLESS(Deserializer); - arrow::Result> columnArray = Deserializer->Deserialize(data); + Y_ABORT_UNLESS(Serializer); + arrow::Result> columnArray = + Transformer ? Serializer->Deserialize(data) : Serializer->Deserialize(data, ExpectedSchema); if (!columnArray.ok()) { return columnArray; } @@ -134,21 +135,19 @@ struct TIndexInfo; class TColumnFeatures { private: ui32 ColumnId; - std::optional Compression; + YDB_READONLY_DEF(NArrow::NSerialization::TSerializerContainer, Serializer); std::optional DictionaryEncoding; std::shared_ptr Loader; NArrow::NTransformation::ITransformer::TPtr GetLoadTransformer() const; void InitLoader(const TIndexInfo& info); - TColumnFeatures(const ui32 columnId) - : ColumnId(columnId) { - } + TColumnFeatures(const ui32 columnId); public: TString DebugString() const { TStringBuilder sb; - sb << "compression=" << (Compression ? Compression->DebugString() : "NO") << ";"; + sb << "serializer=" << (Serializer ? Serializer->DebugString() : "NO") << ";"; sb << "encoding=" << (DictionaryEncoding ? DictionaryEncoding->DebugString() : "NO") << ";"; sb << "loader=" << (Loader ? Loader->DebugString() : "NO") << ";"; return sb; @@ -158,8 +157,6 @@ class TColumnFeatures { static std::optional BuildFromProto(const NKikimrSchemeOp::TOlapColumnDescription& columnInfo, const TIndexInfo& indexInfo); static TColumnFeatures BuildFromIndexInfo(const ui32 columnId, const TIndexInfo& indexInfo); - std::unique_ptr GetCompressionCodec() const; - const std::shared_ptr& GetLoader() const { AFL_VERIFY(Loader); return Loader; diff --git a/ydb/core/tx/columnshard/engines/scheme/index_info.cpp b/ydb/core/tx/columnshard/engines/scheme/index_info.cpp index 6bac1a0af456..e60785485be2 100644 --- a/ydb/core/tx/columnshard/engines/scheme/index_info.cpp +++ b/ydb/core/tx/columnshard/engines/scheme/index_info.cpp @@ -3,9 +3,8 @@ #include #include #include -#include +#include #include -#include #include namespace NKikimr::NOlap { @@ -296,32 +295,23 @@ bool TIndexInfo::AllowTtlOverColumn(const TString& name) const { } TColumnSaver TIndexInfo::GetColumnSaver(const ui32 columnId, const TSaverContext& context) const { - arrow::ipc::IpcWriteOptions options; - options.use_threads = false; - NArrow::NTransformation::ITransformer::TPtr transformer; - std::unique_ptr columnCodec; + NArrow::NSerialization::TSerializerContainer serializer; { auto it = ColumnFeatures.find(columnId); AFL_VERIFY(it != ColumnFeatures.end()); transformer = it->second.GetSaveTransformer(); - columnCodec = it->second.GetCompressionCodec(); - } - - if (context.GetExternalCompression()) { - options.codec = context.GetExternalCompression()->BuildArrowCodec(); - } else if (columnCodec) { - options.codec = std::move(columnCodec); - } else if (DefaultCompression) { - options.codec = DefaultCompression->BuildArrowCodec(); - } else { - options.codec = NArrow::TCompression::BuildDefaultCodec(); + serializer = it->second.GetSerializer(); } - if (!transformer) { - return TColumnSaver(transformer, std::make_shared(options)); + if (!!context.GetExternalSerializer()) { + return TColumnSaver(transformer, *context.GetExternalSerializer()); + } else if (!!serializer) { + return TColumnSaver(transformer, serializer); + } else if (DefaultSerializer) { + return TColumnSaver(transformer, DefaultSerializer); } else { - return TColumnSaver(transformer, std::make_shared(options)); + return TColumnSaver(transformer, NArrow::NSerialization::TSerializerContainer::GetDefaultSerializer()); } } @@ -390,8 +380,7 @@ bool TIndexInfo::DeserializeFromProto(const NKikimrSchemeOp::TColumnTableSchema& const ui32 id = col.GetId(); const TString& name = col.GetName(); const bool notNull = col.HasNotNull() ? col.GetNotNull() : false; - auto typeInfoMod = NScheme::TypeInfoModFromProtoColumnType(col.GetTypeId(), - col.HasTypeInfo() ? &col.GetTypeInfo() : nullptr); + auto typeInfoMod = NScheme::TypeInfoModFromProtoColumnType(col.GetTypeId(), col.HasTypeInfo() ? &col.GetTypeInfo() : nullptr); Columns[id] = NTable::TColumn(name, id, typeInfoMod.TypeInfo, typeInfoMod.TypeMod, notNull); ColumnNames[name] = id; } @@ -413,12 +402,12 @@ bool TIndexInfo::DeserializeFromProto(const NKikimrSchemeOp::TColumnTableSchema& } if (schema.HasDefaultCompression()) { - auto result = NArrow::TCompression::BuildFromProto(schema.GetDefaultCompression()); - if (!result) { - AFL_ERROR(NKikimrServices::TX_COLUMNSHARD)("event", "cannot_parse_index_info")("reason", result.GetErrorMessage()); + NArrow::NSerialization::TSerializerContainer container; + if (!container.DeserializeFromProto(schema.GetDefaultCompression())) { + AFL_ERROR(NKikimrServices::TX_COLUMNSHARD)("event", "cannot_parse_index_info")("reason", "cannot_parse_default_serializer"); return false; } - DefaultCompression = *result; + DefaultSerializer = container; } Version = schema.GetVersion(); return true; diff --git a/ydb/core/tx/columnshard/engines/scheme/index_info.h b/ydb/core/tx/columnshard/engines/scheme/index_info.h index 44d15cc375d9..7409e33bd910 100644 --- a/ydb/core/tx/columnshard/engines/scheme/index_info.h +++ b/ydb/core/tx/columnshard/engines/scheme/index_info.h @@ -246,7 +246,7 @@ struct TIndexInfo : public NTable::TScheme::TTableSchema { std::shared_ptr ExtendedKey; // Extend PK with snapshot columns to allow old shapshot reads THashSet RequiredColumns; THashSet MinMaxIdxColumnsIds; - std::optional DefaultCompression; + NArrow::NSerialization::TSerializerContainer DefaultSerializer; }; std::shared_ptr MakeArrowSchema(const NTable::TScheme::TTableSchema::TColumns& columns, const std::vector& ids, bool withSpecials = false); diff --git a/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/meta.cpp b/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/meta.cpp index 77e9430ed953..cf87cf941d8f 100644 --- a/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/meta.cpp +++ b/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/meta.cpp @@ -4,7 +4,7 @@ #include #include #include -#include +#include #include namespace NKikimr::NOlap::NIndexes { @@ -14,6 +14,7 @@ void TPortionIndexChunk::DoAddIntoPortion(const TBlobRange& bRange, TPortionInfo } std::shared_ptr TIndexByColumns::DoBuildIndex(const ui32 indexId, std::map>>& data, const TIndexInfo& indexInfo) const { + AFL_VERIFY(Serializer); AFL_VERIFY(data.size()); std::vector columnReaders; for (auto&& i : ColumnIds) { @@ -27,12 +28,12 @@ std::shared_ptr TIndexByColumns::DoBuildIndex } TChunkedBatchReader reader(std::move(columnReaders)); std::shared_ptr indexBatch = DoBuildIndexImpl(reader); - const TString indexData = TColumnSaver(nullptr, Serializer).Apply(indexBatch); + const TString indexData = Serializer->SerializeFull(indexBatch); return std::make_shared(indexId, recordsCount, NArrow::GetBatchDataSize(indexBatch), indexData); } bool TIndexByColumns::DoDeserializeFromProto(const NKikimrSchemeOp::TOlapIndexDescription& /*proto*/) { - Serializer = std::make_shared(arrow::ipc::IpcWriteOptions::Defaults()); + Serializer = NArrow::NSerialization::TSerializerContainer::GetDefaultSerializer(); return true; } @@ -40,7 +41,7 @@ TIndexByColumns::TIndexByColumns(const ui32 indexId, const TString& indexName, c : TBase(indexId, indexName) , ColumnIds(columnIds) { - Serializer = std::make_shared(arrow::ipc::IpcWriteOptions::Defaults()); + Serializer = NArrow::NSerialization::TSerializerContainer::GetDefaultSerializer(); } NKikimr::TConclusionStatus TIndexByColumns::CheckSameColumnsForModification(const IIndexMeta& newMeta) const { diff --git a/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/checker.cpp b/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/checker.cpp index 368589b11c31..1ec8aede916d 100644 --- a/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/checker.cpp +++ b/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/checker.cpp @@ -1,5 +1,5 @@ #include "checker.h" -#include +#include #include #include #include @@ -14,7 +14,7 @@ void TBloomFilterChecker::DoSerializeToProtoImpl(NKikimrSSA::TProgram::TOlapInde bool TBloomFilterChecker::DoCheckImpl(const std::vector& blobs) const { for (auto&& blob : blobs) { - auto rb = NArrow::TStatusValidator::GetValid(NArrow::NSerialization::TFullDataDeserializer().Deserialize(blob)); + auto rb = NArrow::TStatusValidator::GetValid(NArrow::NSerialization::TSerializerContainer::GetDefaultSerializer()->Deserialize(blob)); AFL_VERIFY(rb); AFL_VERIFY(rb->schema()->num_fields() == 1); AFL_VERIFY(rb->schema()->field(0)->type()->id() == arrow::Type::BOOL); diff --git a/ydb/core/tx/columnshard/engines/scheme/tier_info.h b/ydb/core/tx/columnshard/engines/scheme/tier_info.h index d9808ca9b919..395752201f8d 100644 --- a/ydb/core/tx/columnshard/engines/scheme/tier_info.h +++ b/ydb/core/tx/columnshard/engines/scheme/tier_info.h @@ -3,7 +3,6 @@ #include #include #include -#include #include #include #include @@ -18,7 +17,7 @@ class TTierInfo { YDB_READONLY_DEF(TDuration, EvictDuration); ui32 TtlUnitsInSecond; - YDB_READONLY_DEF(std::optional, Compression); + YDB_READONLY_DEF(std::optional, Serializer); public: TTierInfo(const TString& tierName, TDuration evictDuration, const TString& column, ui32 unitsInSecond = 0) : Name(tierName) @@ -34,8 +33,8 @@ class TTierInfo { return now - EvictDuration; } - TTierInfo& SetCompression(const NArrow::TCompression& value) { - Compression = value; + TTierInfo& SetSerializer(const NArrow::NSerialization::TSerializerContainer& value) { + Serializer = value; return *this; } @@ -51,9 +50,9 @@ class TTierInfo { TString GetDebugString() const { TStringBuilder sb; - sb << "name=" << Name << ";duration=" << EvictDuration << ";column=" << EvictColumnName << ";compression="; - if (Compression) { - sb << Compression->DebugString(); + sb << "name=" << Name << ";duration=" << EvictDuration << ";column=" << EvictColumnName << ";serializer="; + if (Serializer) { + sb << Serializer->DebugString(); } else { sb << "NOT_SPECIFIED(Default)"; } @@ -133,11 +132,11 @@ class TTiering { return {}; } - std::optional GetCompression(const TString& name) const { + std::optional GetSerializer(const TString& name) const { auto it = TierByName.find(name); if (it != TierByName.end()) { Y_ABORT_UNLESS(!name.empty()); - return it->second->GetCompression(); + return it->second->GetSerializer(); } return {}; } diff --git a/ydb/core/tx/columnshard/engines/storage/optimizer/lbuckets/optimizer.h b/ydb/core/tx/columnshard/engines/storage/optimizer/lbuckets/optimizer.h index 531279ccd244..9ce196f5a792 100644 --- a/ydb/core/tx/columnshard/engines/storage/optimizer/lbuckets/optimizer.h +++ b/ydb/core/tx/columnshard/engines/storage/optimizer/lbuckets/optimizer.h @@ -1,11 +1,12 @@ #pragma once #include "counters.h" -#include -#include -#include #include +#include #include +#include +#include +#include #include #include @@ -361,8 +362,12 @@ class TPortionsPool { std::vector> result; std::shared_ptr predictor = NCompaction::TGeneralCompactColumnEngineChanges::BuildMemoryPredictor(); + ui64 txSizeLimit = 0; for (auto&& i : sorted) { result.emplace_back(i); + if (txSizeLimit + i->GetTxVolume() > TGlobalLimits::TxWriteLimitBytes / 2) { + break; + } if (predictor->AddPortion(*i) > sizeLimit && result.size() > 1) { break; } @@ -744,7 +749,7 @@ class TPortionsBucket: public TMoveOnly { return nullptr; } } - AFL_DEBUG(NKikimrServices::TX_COLUMNSHARD)("stop_instant", stopInstant.value_or(TInstant::Zero()))("size", size)("next", NextBorder ? NextBorder->DebugString() : "") + AFL_DEBUG(NKikimrServices::TX_COLUMNSHARD)("stop_instant", stopInstant)("size", size)("next", NextBorder ? NextBorder->DebugString() : "") ("count", portions.size())("info", Others.DebugString())("event", "start_optimization")("stop_point", stopPoint ? stopPoint->DebugString() : ""); TSaverContext saverContext(storagesManager->GetOperator(IStoragesManager::DefaultStorageId), storagesManager); auto result = std::make_shared(limits.GetSplitSettings(), granule, portions, saverContext); diff --git a/ydb/core/tx/columnshard/engines/storage/storage.cpp b/ydb/core/tx/columnshard/engines/storage/storage.cpp index 7e6f7e81b53e..c51c2bd6e166 100644 --- a/ydb/core/tx/columnshard/engines/storage/storage.cpp +++ b/ydb/core/tx/columnshard/engines/storage/storage.cpp @@ -9,12 +9,15 @@ void TGranulesStorage::UpdateGranuleInfo(const TGranuleMeta& granule) { } } -std::shared_ptr TGranulesStorage::GetGranuleForCompaction(const THashMap>& granules) const { +std::shared_ptr TGranulesStorage::GetGranuleForCompaction(const THashMap>& granules, const THashSet& busyGranuleIds) const { const TInstant now = TInstant::Now(); std::optional priority; std::shared_ptr granule; for (auto&& i : granules) { i.second->ActualizeOptimizer(now); + if (busyGranuleIds.contains(i.first)) { + continue; + } if (!priority || *priority < i.second->GetCompactionPriority()) { priority = i.second->GetCompactionPriority(); granule = i.second; diff --git a/ydb/core/tx/columnshard/engines/storage/storage.h b/ydb/core/tx/columnshard/engines/storage/storage.h index 1fa7b524c882..7ddba8009f6f 100644 --- a/ydb/core/tx/columnshard/engines/storage/storage.h +++ b/ydb/core/tx/columnshard/engines/storage/storage.h @@ -62,7 +62,7 @@ class TGranulesStorage { return TModificationGuard(*this); } - std::shared_ptr GetGranuleForCompaction(const THashMap>& granules) const; + std::shared_ptr GetGranuleForCompaction(const THashMap>& granules, const THashSet& busyGranuleIds) const; void UpdateGranuleInfo(const TGranuleMeta& granule); diff --git a/ydb/core/tx/columnshard/engines/ut/helper.cpp b/ydb/core/tx/columnshard/engines/ut/helper.cpp new file mode 100644 index 000000000000..eee9159edea7 --- /dev/null +++ b/ydb/core/tx/columnshard/engines/ut/helper.cpp @@ -0,0 +1,11 @@ +#include "helper.h" + +namespace NKikimr::NOlap::NEngines::NTest { + +NKikimrTxColumnShard::TLogicalMetadata TLocalHelper::GetMetaProto() { + NKikimrTxColumnShard::TLogicalMetadata result; + result.SetDirtyWriteTimeSeconds(TInstant::Now().Seconds()); + return result; +} + +} \ No newline at end of file diff --git a/ydb/core/tx/columnshard/engines/ut/helper.h b/ydb/core/tx/columnshard/engines/ut/helper.h new file mode 100644 index 000000000000..8e17730a21c6 --- /dev/null +++ b/ydb/core/tx/columnshard/engines/ut/helper.h @@ -0,0 +1,11 @@ +#pragma once +#include + +namespace NKikimr::NOlap::NEngines::NTest { + +class TLocalHelper { +public: + static NKikimrTxColumnShard::TLogicalMetadata GetMetaProto(); +}; + +}; \ No newline at end of file diff --git a/ydb/core/tx/columnshard/engines/ut_insert_table.cpp b/ydb/core/tx/columnshard/engines/ut/ut_insert_table.cpp similarity index 89% rename from ydb/core/tx/columnshard/engines/ut_insert_table.cpp rename to ydb/core/tx/columnshard/engines/ut/ut_insert_table.cpp index e54f8248f3d6..9e2dad244ac6 100644 --- a/ydb/core/tx/columnshard/engines/ut_insert_table.cpp +++ b/ydb/core/tx/columnshard/engines/ut/ut_insert_table.cpp @@ -1,5 +1,6 @@ -#include "db_wrapper.h" -#include "insert_table/insert_table.h" +#include "helper.h" +#include +#include #include @@ -9,6 +10,7 @@ namespace NKikimr { using namespace NOlap; +using namespace NKikimr::NOlap::NEngines::NTest; namespace { @@ -40,7 +42,6 @@ class TTestInsertTableDB: public IDbWrapper { } - Y_UNIT_TEST_SUITE(TColumnEngineTestInsertTable) { Y_UNIT_TEST(TestInsertCommit) { ui64 writeId = 0; @@ -53,16 +54,16 @@ Y_UNIT_TEST_SUITE(TColumnEngineTestInsertTable) { ui64 indexSnapshot = 0; // insert, not commited - bool ok = insertTable.Insert(dbTable, TInsertedData(writeId, tableId, dedupId, blobId1, {}, indexSnapshot, {})); + bool ok = insertTable.Insert(dbTable, TInsertedData(writeId, tableId, dedupId, blobId1, TLocalHelper::GetMetaProto(), indexSnapshot, {})); UNIT_ASSERT(ok); // insert the same blobId1 again - ok = insertTable.Insert(dbTable, TInsertedData(writeId, tableId, dedupId, blobId1, {}, indexSnapshot, {})); + ok = insertTable.Insert(dbTable, TInsertedData(writeId, tableId, dedupId, blobId1, TLocalHelper::GetMetaProto(), indexSnapshot, {})); UNIT_ASSERT(!ok); // insert different blodId with the same writeId and dedupId TUnifiedBlobId blobId2(2222, 1, 2, 100, 1); - ok = insertTable.Insert(dbTable, TInsertedData(writeId, tableId, dedupId, blobId2, {}, indexSnapshot, {})); + ok = insertTable.Insert(dbTable, TInsertedData(writeId, tableId, dedupId, blobId2, TLocalHelper::GetMetaProto(), indexSnapshot, {})); UNIT_ASSERT(!ok); // read nothing diff --git a/ydb/core/tx/columnshard/engines/ut_logs_engine.cpp b/ydb/core/tx/columnshard/engines/ut/ut_logs_engine.cpp similarity index 98% rename from ydb/core/tx/columnshard/engines/ut_logs_engine.cpp rename to ydb/core/tx/columnshard/engines/ut/ut_logs_engine.cpp index 8f1bdf36fc4e..a5c07fcc014c 100644 --- a/ydb/core/tx/columnshard/engines/ut_logs_engine.cpp +++ b/ydb/core/tx/columnshard/engines/ut/ut_logs_engine.cpp @@ -1,7 +1,8 @@ +#include "helper.h" #include -#include "column_engine_logs.h" -#include "predicate/predicate.h" -#include "changes/cleanup.h" +#include +#include +#include #include #include @@ -16,6 +17,7 @@ namespace NTypeIds = NScheme::NTypeIds; using TTypeId = NScheme::TTypeId; using TTypeInfo = NScheme::TTypeInfo; using TDefaultTestsController = NKikimr::NYDBTest::NColumnShard::TController; +using namespace NKikimr::NOlap::NEngines::NTest; namespace { @@ -342,7 +344,7 @@ bool Cleanup(TColumnEngineForLogs& engine, TTestDbWrapper& db, TSnapshot snap, u bool Ttl(TColumnEngineForLogs& engine, TTestDbWrapper& db, const THashMap& pathEviction, ui32 expectedToDrop) { - std::shared_ptr changes = engine.StartTtl(pathEviction, {}); + std::shared_ptr changes = engine.StartTtl(pathEviction, {}, 512 * 1024 * 1024); UNIT_ASSERT(changes); UNIT_ASSERT_VALUES_EQUAL(changes->PortionsToRemove.size(), expectedToDrop); @@ -411,8 +413,8 @@ Y_UNIT_TEST_SUITE(TColumnEngineTestLogs) { engine.Load(db); std::vector dataToIndex = { - TInsertedData(2, paths[0], "", blobRanges[0].BlobId, {}, 0, {}), - TInsertedData(1, paths[0], "", blobRanges[1].BlobId, {}, 0, {}) + TInsertedData(2, paths[0], "", blobRanges[0].BlobId, TLocalHelper::GetMetaProto(), 0, {}), + TInsertedData(1, paths[0], "", blobRanges[1].BlobId, TLocalHelper::GetMetaProto(), 0, {}) }; // write @@ -507,7 +509,7 @@ Y_UNIT_TEST_SUITE(TColumnEngineTestLogs) { // PlanStep, TxId, PathId, DedupId, BlobId, Data, [Metadata] std::vector dataToIndex; dataToIndex.push_back( - TInsertedData(txId, pathId, "", blobRange.BlobId, {}, 0, {})); + TInsertedData(txId, pathId, "", blobRange.BlobId, TLocalHelper::GetMetaProto(), 0, {})); bool ok = Insert(engine, db, TSnapshot(planStep, txId), std::move(dataToIndex), blobs, step); UNIT_ASSERT(ok); @@ -605,7 +607,7 @@ Y_UNIT_TEST_SUITE(TColumnEngineTestLogs) { // PlanStep, TxId, PathId, DedupId, BlobId, Data, [Metadata] std::vector dataToIndex; dataToIndex.push_back( - TInsertedData(txId, pathId, "", blobRange.BlobId, {}, 0, {})); + TInsertedData(txId, pathId, "", blobRange.BlobId, TLocalHelper::GetMetaProto(), 0, {})); bool ok = Insert(engine, db, TSnapshot(planStep, txId), std::move(dataToIndex), blobs, step); for (auto&& i : blobs) { @@ -639,7 +641,7 @@ Y_UNIT_TEST_SUITE(TColumnEngineTestLogs) { // PlanStep, TxId, PathId, DedupId, BlobId, Data, [Metadata] std::vector dataToIndex; dataToIndex.push_back( - TInsertedData(txId, pathId, "", blobRange.BlobId, {}, 0, {})); + TInsertedData(txId, pathId, "", blobRange.BlobId, TLocalHelper::GetMetaProto(), 0, {})); bool ok = Insert(engine, db, TSnapshot(planStep, txId), std::move(dataToIndex), blobs, step); UNIT_ASSERT(ok); @@ -680,7 +682,7 @@ Y_UNIT_TEST_SUITE(TColumnEngineTestLogs) { // PlanStep, TxId, PathId, DedupId, BlobId, Data, [Metadata] std::vector dataToIndex; dataToIndex.push_back( - TInsertedData(txId, pathId, "", blobRange.BlobId, {}, 0, {})); + TInsertedData(txId, pathId, "", blobRange.BlobId, TLocalHelper::GetMetaProto(), 0, {})); bool ok = Insert(engine, db, TSnapshot(planStep, txId), std::move(dataToIndex), blobs, step); UNIT_ASSERT(ok); diff --git a/ydb/core/tx/columnshard/engines/ut_program.cpp b/ydb/core/tx/columnshard/engines/ut/ut_program.cpp similarity index 99% rename from ydb/core/tx/columnshard/engines/ut_program.cpp rename to ydb/core/tx/columnshard/engines/ut/ut_program.cpp index 884c5739b5c1..4cfe3282267a 100644 --- a/ydb/core/tx/columnshard/engines/ut_program.cpp +++ b/ydb/core/tx/columnshard/engines/ut/ut_program.cpp @@ -1,4 +1,4 @@ -#include "index_info.h" +#include #include #include diff --git a/ydb/core/tx/columnshard/engines/ut/ya.make b/ydb/core/tx/columnshard/engines/ut/ya.make index 13fc351c5a56..fc8159e31764 100644 --- a/ydb/core/tx/columnshard/engines/ut/ya.make +++ b/ydb/core/tx/columnshard/engines/ut/ya.make @@ -35,6 +35,7 @@ SRCS( ut_insert_table.cpp ut_logs_engine.cpp ut_program.cpp + helper.cpp ydb/core/tx/columnshard/columnshard_ut_common.cpp ) diff --git a/ydb/core/tx/columnshard/engines/writer/indexed_blob_constructor.cpp b/ydb/core/tx/columnshard/engines/writer/indexed_blob_constructor.cpp index 318e4889fe07..7b858a3e6984 100644 --- a/ydb/core/tx/columnshard/engines/writer/indexed_blob_constructor.cpp +++ b/ydb/core/tx/columnshard/engines/writer/indexed_blob_constructor.cpp @@ -35,14 +35,45 @@ void TWideSerializedBatch::InitBlobId(const TUnifiedBlobId& id) { void TWritingBuffer::InitReadyInstant(const TMonotonic instant) { for (auto&& aggr : Aggregations) { - aggr->GetWriteData()->MutableWriteMeta().SetWriteMiddle4StartInstant(instant); + aggr->GetWriteData()->MutableWriteMeta().SetWriteMiddle5StartInstant(instant); } } void TWritingBuffer::InitStartSending(const TMonotonic instant) { for (auto&& aggr : Aggregations) { - aggr->GetWriteData()->MutableWriteMeta().SetWriteMiddle5StartInstant(instant); + aggr->GetWriteData()->MutableWriteMeta().SetWriteMiddle4StartInstant(instant); + } +} + +void TWritingBuffer::InitReplyReceived(const TMonotonic instant) { + for (auto&& aggr : Aggregations) { + aggr->GetWriteData()->MutableWriteMeta().SetWriteMiddle6StartInstant(instant); + } +} + +std::vector TWritingBuffer::GroupIntoBlobs() { + std::vector result; + TWritingBlob currentBlob; + ui64 sumSize = 0; + for (auto&& aggr : Aggregations) { + for (auto&& bInfo : aggr->MutableSplittedBlobs()) { + if (!currentBlob.AddData(bInfo)) { + result.emplace_back(std::move(currentBlob)); + currentBlob = TWritingBlob(); + AFL_VERIFY(currentBlob.AddData(bInfo)); + } + sumSize += bInfo.GetSplittedBlobs().GetSize(); + } + } + if (currentBlob.GetSize()) { + result.emplace_back(std::move(currentBlob)); + } + if (result.size()) { + if (sumSize / result.size() < 4 * 1024 * 1024 && result.size() != 1) { + AFL_ERROR(NKikimrServices::TX_COLUMNSHARD)("event", "error_splitting")("size", sumSize)("count", result.size()); + } } + return result; } } diff --git a/ydb/core/tx/columnshard/engines/writer/indexed_blob_constructor.h b/ydb/core/tx/columnshard/engines/writer/indexed_blob_constructor.h index 7f977a171597..392d76fd10c6 100644 --- a/ydb/core/tx/columnshard/engines/writer/indexed_blob_constructor.h +++ b/ydb/core/tx/columnshard/engines/writer/indexed_blob_constructor.h @@ -160,24 +160,9 @@ class TWritingBuffer: public TMoveOnly { void InitReadyInstant(const TMonotonic instant); void InitStartSending(const TMonotonic instant); + void InitReplyReceived(const TMonotonic instant); - std::vector GroupIntoBlobs() { - std::vector result; - TWritingBlob currentBlob; - for (auto&& aggr : Aggregations) { - for (auto&& bInfo : aggr->MutableSplittedBlobs()) { - if (!currentBlob.AddData(bInfo)) { - result.emplace_back(std::move(currentBlob)); - currentBlob = TWritingBlob(); - AFL_VERIFY(currentBlob.AddData(bInfo)); - } - } - } - if (currentBlob.GetSize()) { - result.emplace_back(std::move(currentBlob)); - } - return result; - } + std::vector GroupIntoBlobs(); }; class TIndexedWriteController : public NColumnShard::IWriteController, public NColumnShard::TMonitoringObjectsCounter { diff --git a/ydb/core/tx/columnshard/engines/writer/write_controller.h b/ydb/core/tx/columnshard/engines/writer/write_controller.h index 554423c88863..f6d030528b27 100644 --- a/ydb/core/tx/columnshard/engines/writer/write_controller.h +++ b/ydb/core/tx/columnshard/engines/writer/write_controller.h @@ -47,6 +47,19 @@ class IWriteController { return WriteTasks.back(); } public: + TString DebugString() const { + TStringBuilder sb; + for (auto&& i : WritingActions) { + sb << i.second->GetStorageId() << ","; + } + ui64 size = 0; + for (auto&& i : WriteTasks) { + size += i.GetBlobId().BlobSize(); + } + + return TStringBuilder() << "size=" << size << ";count=" << WriteTasks.size() << ";actions=" << sb << ";"; + } + void Abort() { for (auto&& i : WritingActions) { i.second->Abort(); diff --git a/ydb/core/tx/columnshard/engines/ya.make b/ydb/core/tx/columnshard/engines/ya.make index 4b058ca9bbca..8e80cb730b69 100644 --- a/ydb/core/tx/columnshard/engines/ya.make +++ b/ydb/core/tx/columnshard/engines/ya.make @@ -29,7 +29,6 @@ PEERDIR( ydb/core/tx/columnshard/engines/insert_table ydb/core/tx/columnshard/engines/changes ydb/core/tx/columnshard/engines/portions - ydb/core/formats/arrow/compression ydb/core/tx/program # for NYql::NUdf alloc stuff used in binary_json diff --git a/ydb/core/tx/columnshard/splitter/ut/ut_splitter.cpp b/ydb/core/tx/columnshard/splitter/ut/ut_splitter.cpp index 3c5b881b4bb7..72aa5539f6b2 100644 --- a/ydb/core/tx/columnshard/splitter/ut/ut_splitter.cpp +++ b/ydb/core/tx/columnshard/splitter/ut/ut_splitter.cpp @@ -1,10 +1,9 @@ #include #include #include -#include #include #include -#include +#include #include Y_UNIT_TEST_SUITE(Splitter) { @@ -23,7 +22,7 @@ Y_UNIT_TEST_SUITE(Splitter) { } virtual NKikimr::NOlap::TColumnSaver GetColumnSaver(const ui32 columnId) const override { - return NKikimr::NOlap::TColumnSaver(nullptr, std::make_shared(arrow::ipc::IpcWriteOptions::Defaults())); + return NKikimr::NOlap::TColumnSaver(nullptr, std::make_shared(arrow::ipc::IpcOptions::Defaults())); } virtual std::optional GetColumnSerializationStats(const ui32 /*columnId*/) const override { @@ -36,7 +35,7 @@ Y_UNIT_TEST_SUITE(Splitter) { NKikimr::NOlap::TColumnLoader GetColumnLoader(const ui32 columnId) const { arrow::FieldVector v = {std::make_shared(GetColumnName(columnId), std::make_shared())}; auto schema = std::make_shared(v); - return NKikimr::NOlap::TColumnLoader(nullptr, std::make_shared(), schema, columnId); + return NKikimr::NOlap::TColumnLoader(nullptr, NSerialization::TSerializerContainer::GetDefaultSerializer(), schema, columnId); } virtual std::shared_ptr GetField(const ui32 columnId) const override { diff --git a/ydb/core/tx/columnshard/splitter/ut/ya.make b/ydb/core/tx/columnshard/splitter/ut/ya.make index e242c0b6b57b..4d9e9af04665 100644 --- a/ydb/core/tx/columnshard/splitter/ut/ya.make +++ b/ydb/core/tx/columnshard/splitter/ut/ya.make @@ -7,7 +7,6 @@ PEERDIR( ydb/library/arrow_kernels ydb/core/tx/columnshard/counters - ydb/core/formats/arrow/compression ydb/core/tx/columnshard/engines/portions ydb/core/kqp/common ydb/library/yql/parser/pg_wrapper diff --git a/ydb/core/tx/columnshard/tables_manager.cpp b/ydb/core/tx/columnshard/tables_manager.cpp index c100b8d3481f..4f628419226f 100644 --- a/ydb/core/tx/columnshard/tables_manager.cpp +++ b/ydb/core/tx/columnshard/tables_manager.cpp @@ -270,7 +270,9 @@ void TTablesManager::AddSchemaVersion(const ui32 presetId, const NOlap::TSnapsho } void TTablesManager::AddTableVersion(const ui64 pathId, const NOlap::TSnapshot& version, const TTableInfo::TTableVersionInfo& versionInfo, NIceDb::TNiceDb& db) { - auto& table = Tables.at(pathId); + auto it = Tables.find(pathId); + AFL_VERIFY(it != Tables.end()); + auto& table = it->second; if (versionInfo.HasSchemaPresetId()) { Y_ABORT_UNLESS(SchemaPresets.contains(versionInfo.GetSchemaPresetId())); diff --git a/ydb/core/tx/data_events/write_data.h b/ydb/core/tx/data_events/write_data.h index 739d9b3e89c5..d25c65e65c1d 100644 --- a/ydb/core/tx/data_events/write_data.h +++ b/ydb/core/tx/data_events/write_data.h @@ -5,6 +5,7 @@ #include #include +#include namespace NKikimr::NOlap { class IBlobsWritingAction; @@ -31,12 +32,14 @@ class TWriteMeta { YDB_ACCESSOR(ui64, WritePartId, 0); YDB_ACCESSOR_DEF(TString, DedupId); + YDB_READONLY(TString, Id, TGUID::CreateTimebased().AsUuidString()); YDB_READONLY(TMonotonic, WriteStartInstant, TMonotonic::Now()); YDB_ACCESSOR(TMonotonic, WriteMiddle1StartInstant, TMonotonic::Now()); YDB_ACCESSOR(TMonotonic, WriteMiddle2StartInstant, TMonotonic::Now()); YDB_ACCESSOR(TMonotonic, WriteMiddle3StartInstant, TMonotonic::Now()); YDB_ACCESSOR(TMonotonic, WriteMiddle4StartInstant, TMonotonic::Now()); YDB_ACCESSOR(TMonotonic, WriteMiddle5StartInstant, TMonotonic::Now()); + YDB_ACCESSOR(TMonotonic, WriteMiddle6StartInstant, TMonotonic::Now()); public: TWriteMeta(const ui64 writeId, const ui64 tableId, const NActors::TActorId& source) : WriteId(writeId) diff --git a/ydb/core/tx/schemeshard/olap/columns/update.cpp b/ydb/core/tx/schemeshard/olap/columns/update.cpp index a6d602b5fa4b..a0427414ca75 100644 --- a/ydb/core/tx/schemeshard/olap/columns/update.cpp +++ b/ydb/core/tx/schemeshard/olap/columns/update.cpp @@ -2,6 +2,7 @@ #include #include #include +#include namespace NKikimr::NSchemeShard { @@ -13,13 +14,13 @@ namespace NKikimr::NSchemeShard { Name = columnSchema.GetName(); NotNullFlag = columnSchema.GetNotNull(); TypeName = columnSchema.GetType(); - if (columnSchema.HasCompression()) { - auto compression = NArrow::TCompression::BuildFromProto(columnSchema.GetCompression()); - if (!compression) { - errors.AddError("Cannot parse compression info: " + compression.GetErrorMessage()); + if (columnSchema.HasSerializer()) { + NArrow::NSerialization::TSerializerContainer serializer; + if (!serializer.DeserializeFromProto(columnSchema.GetSerializer())) { + errors.AddError("Cannot parse serializer info"); return false; } - Compression = *compression; + Serializer = serializer; } if (columnSchema.HasDictionaryEncoding()) { auto settings = NArrow::NDictionary::TEncodingSettings::BuildFromProto(columnSchema.GetDictionaryEncoding()); @@ -72,10 +73,14 @@ namespace NKikimr::NSchemeShard { columnSchema.GetTypeId(), nullptr) .TypeInfo; } - if (columnSchema.HasCompression()) { - auto compression = NArrow::TCompression::BuildFromProto(columnSchema.GetCompression()); - Y_ABORT_UNLESS(compression.IsSuccess(), "%s", compression.GetErrorMessage().data()); - Compression = *compression; + if (columnSchema.HasSerializer()) { + NArrow::NSerialization::TSerializerContainer serializer; + AFL_VERIFY(serializer.DeserializeFromProto(columnSchema.GetSerializer())); + Serializer = serializer; + } else if (columnSchema.HasCompression()) { + NArrow::NSerialization::TSerializerContainer serializer; + AFL_VERIFY(serializer.DeserializeFromProto(columnSchema.GetCompression())); + Serializer = serializer; } if (columnSchema.HasDictionaryEncoding()) { auto settings = NArrow::NDictionary::TEncodingSettings::BuildFromProto(columnSchema.GetDictionaryEncoding()); @@ -89,8 +94,8 @@ namespace NKikimr::NSchemeShard { columnSchema.SetName(Name); columnSchema.SetType(TypeName); columnSchema.SetNotNull(NotNullFlag); - if (Compression) { - *columnSchema.MutableCompression() = Compression->SerializeToProto(); + if (Serializer) { + Serializer->SerializeToProto(*columnSchema.MutableSerializer()); } if (DictionaryEncoding) { *columnSchema.MutableDictionaryEncoding() = DictionaryEncoding->SerializeToProto(); @@ -105,12 +110,8 @@ namespace NKikimr::NSchemeShard { bool TOlapColumnAdd::ApplyDiff(const TOlapColumnDiff& diffColumn, IErrorCollector& errors) { Y_ABORT_UNLESS(GetName() == diffColumn.GetName()); - { - auto result = diffColumn.GetCompression().Apply(Compression); - if (!result) { - errors.AddError("Cannot merge compression info: " + result.GetErrorMessage()); - return false; - } + if (diffColumn.GetSerializer()) { + Serializer = diffColumn.GetSerializer(); } { auto result = diffColumn.GetDictionaryEncoding().Apply(DictionaryEncoding); diff --git a/ydb/core/tx/schemeshard/olap/columns/update.h b/ydb/core/tx/schemeshard/olap/columns/update.h index 45fce0c99094..26eb18a971af 100644 --- a/ydb/core/tx/schemeshard/olap/columns/update.h +++ b/ydb/core/tx/schemeshard/olap/columns/update.h @@ -1,19 +1,18 @@ #pragma once -#include #include #include #include #include #include -#include #include +#include namespace NKikimr::NSchemeShard { class TOlapColumnDiff { private: YDB_READONLY_DEF(TString, Name); - YDB_READONLY_DEF(NArrow::TCompressionDiff, Compression); + YDB_READONLY_DEF(NArrow::NSerialization::TSerializerContainer, Serializer); YDB_READONLY_DEF(NArrow::NDictionary::TEncodingDiff, DictionaryEncoding); public: bool ParseFromRequest(const NKikimrSchemeOp::TOlapColumnDiff& columnSchema, IErrorCollector& errors) { @@ -22,9 +21,11 @@ class TOlapColumnDiff { errors.AddError("empty field name"); return false; } - if (!Compression.DeserializeFromProto(columnSchema.GetCompression())) { - errors.AddError("cannot parse compression diff from proto"); - return false; + if (columnSchema.HasSerializer()) { + if (!Serializer.DeserializeFromProto(columnSchema.GetSerializer())) { + errors.AddError("cannot parse serializer diff from proto"); + return false; + } } if (!DictionaryEncoding.DeserializeFromProto(columnSchema.GetDictionaryEncoding())) { errors.AddError("cannot parse dictionary encoding diff from proto"); @@ -41,7 +42,7 @@ class TOlapColumnAdd { YDB_READONLY_DEF(TString, TypeName); YDB_READONLY_DEF(NScheme::TTypeInfo, Type); YDB_FLAG_ACCESSOR(NotNull, false); - YDB_READONLY_DEF(std::optional, Compression); + YDB_READONLY_DEF(std::optional, Serializer); YDB_READONLY_DEF(std::optional, DictionaryEncoding); public: TOlapColumnAdd(const std::optional& keyOrder) diff --git a/ydb/core/tx/schemeshard/olap/columns/ya.make b/ydb/core/tx/schemeshard/olap/columns/ya.make index 44971d7eeb22..94c1c4c0febe 100644 --- a/ydb/core/tx/schemeshard/olap/columns/ya.make +++ b/ydb/core/tx/schemeshard/olap/columns/ya.make @@ -8,7 +8,8 @@ SRCS( PEERDIR( ydb/core/protos ydb/core/formats/arrow/dictionary - ydb/core/formats/arrow/compression + ydb/core/formats/arrow/serializer + ydb/core/tx/schemeshard/olap/common ) YQL_LAST_ABI_VERSION() diff --git a/ydb/core/tx/schemeshard/olap/common/ya.make b/ydb/core/tx/schemeshard/olap/common/ya.make index 58bbf1cb442a..aea04768253b 100644 --- a/ydb/core/tx/schemeshard/olap/common/ya.make +++ b/ydb/core/tx/schemeshard/olap/common/ya.make @@ -7,6 +7,7 @@ SRCS( PEERDIR( ydb/library/ydb_issue ydb/core/base + ydb/library/aclib ) END() diff --git a/ydb/core/tx/schemeshard/ya.make b/ydb/core/tx/schemeshard/ya.make index f049575c2c9c..8cbf4b637d3c 100644 --- a/ydb/core/tx/schemeshard/ya.make +++ b/ydb/core/tx/schemeshard/ya.make @@ -244,7 +244,6 @@ PEERDIR( ydb/core/engine/minikql ydb/core/external_sources ydb/core/filestore/core - ydb/core/formats/arrow/compression ydb/core/kesus/tablet ydb/core/metering ydb/core/persqueue diff --git a/ydb/core/tx/tiering/manager.cpp b/ydb/core/tx/tiering/manager.cpp index 583d06149fa9..4af8bfcf4704 100644 --- a/ydb/core/tx/tiering/manager.cpp +++ b/ydb/core/tx/tiering/manager.cpp @@ -24,7 +24,7 @@ class TTiersManager::TActor: public TActorBootstrapped { } ~TActor() { - Owner->Stop(); + Owner->Stop(false); } STATEFN(StateMain) { @@ -106,10 +106,16 @@ TManager::TManager(const ui64 tabletId, const NActors::TActorId& tabletActorId, { } -NArrow::TCompression ConvertCompression(const NKikimrSchemeOp::TCompressionOptions& compression) { - auto out = NArrow::TCompression::BuildFromProto(compression); - Y_ABORT_UNLESS(out, "%s", out.GetErrorMessage().data()); - return *out; +NArrow::NSerialization::TSerializerContainer ConvertCompression(const NKikimrSchemeOp::TCompressionOptions& compressionProto) { + NArrow::NSerialization::TSerializerContainer container; + AFL_VERIFY(container.DeserializeFromProto(compressionProto)); + return container; +} + +NArrow::NSerialization::TSerializerContainer ConvertCompression(const NKikimrSchemeOp::TOlapColumn::TSerializer& serializerProto) { + NArrow::NSerialization::TSerializerContainer container; + AFL_VERIFY(container.DeserializeFromProto(serializerProto)); + return container; } } @@ -156,11 +162,11 @@ TTiersManager& TTiersManager::Start(std::shared_ptr ownerPtr) { return *this; } -TTiersManager& TTiersManager::Stop() { +TTiersManager& TTiersManager::Stop(const bool needStopActor) { if (!Actor) { return *this; } - if (TlsActivationContext) { + if (TlsActivationContext && needStopActor) { TActivationContext::AsActorContext().Send(Actor->SelfId(), new NActors::TEvents::TEvPoison); } Actor = nullptr; @@ -208,7 +214,7 @@ THashMap TTiersManager::GetTiering() const { for (auto& [name, tier] : pathTiering.GetTierByName()) { auto it = tierConfigs.find(name); if (it != tierConfigs.end()) { - tier->SetCompression(NTiers::ConvertCompression(it->second.GetCompression())); + tier->SetSerializer(NTiers::ConvertCompression(it->second.GetCompression())); } } } diff --git a/ydb/core/tx/tiering/manager.h b/ydb/core/tx/tiering/manager.h index 6bb6c6194391..dd2c6767c87f 100644 --- a/ydb/core/tx/tiering/manager.h +++ b/ydb/core/tx/tiering/manager.h @@ -15,7 +15,8 @@ namespace NKikimr::NColumnShard { namespace NTiers { -NArrow::TCompression ConvertCompression(const NKikimrSchemeOp::TCompressionOptions& compression); +NArrow::NSerialization::TSerializerContainer ConvertCompression(const NKikimrSchemeOp::TOlapColumn::TSerializer& serializerProto); +NArrow::NSerialization::TSerializerContainer ConvertCompression(const NKikimrSchemeOp::TCompressionOptions& compressionProto); class TManager { private: @@ -80,7 +81,7 @@ class TTiersManager { } TTiersManager& Start(std::shared_ptr ownerPtr); - TTiersManager& Stop(); + TTiersManager& Stop(const bool needStopActor); const NTiers::TManager& GetManagerVerified(const TString& tierId) const; const NTiers::TManager* GetManagerOptional(const TString& tierId) const; NMetadata::NFetcher::ISnapshotsFetcher::TPtr GetExternalDataManipulation() const; diff --git a/ydb/core/tx/tiering/rule/object.h b/ydb/core/tx/tiering/rule/object.h index a597d6204cea..566f10e5efc8 100644 --- a/ydb/core/tx/tiering/rule/object.h +++ b/ydb/core/tx/tiering/rule/object.h @@ -1,6 +1,7 @@ #pragma once #include -#include +#include + #include #include #include diff --git a/ydb/core/tx/tiering/rule/ya.make b/ydb/core/tx/tiering/rule/ya.make index 70f2715e6409..80b625857c1f 100644 --- a/ydb/core/tx/tiering/rule/ya.make +++ b/ydb/core/tx/tiering/rule/ya.make @@ -14,6 +14,7 @@ PEERDIR( ydb/services/metadata/abstract ydb/services/metadata/common ydb/services/metadata/initializer + ydb/services/metadata/manager ydb/services/bg_tasks/abstract ydb/core/tx/schemeshard ) diff --git a/ydb/core/wrappers/s3_storage_config.cpp b/ydb/core/wrappers/s3_storage_config.cpp index 079cd7fb4585..b3a04794feda 100644 --- a/ydb/core/wrappers/s3_storage_config.cpp +++ b/ydb/core/wrappers/s3_storage_config.cpp @@ -5,6 +5,8 @@ #include #include #include +#include + #include #include #include @@ -105,6 +107,7 @@ Aws::Client::ClientConfiguration TS3ExternalStorageConfig::ConfigFromSettings(co if (settings.HasHttpRequestTimeoutMs()) { config.httpRequestTimeoutMs = settings.GetHttpRequestTimeoutMs(); } + config.executor = std::make_shared(1); config.enableTcpKeepAlive = true; // config.lowSpeedLimit = 0; config.maxConnections = 5; @@ -152,6 +155,7 @@ Aws::Client::ClientConfiguration TS3ExternalStorageConfig::ConfigFromSettings(co Aws::Client::ClientConfiguration config; config.endpointOverride = settings.endpoint(); + config.executor = std::make_shared(1); config.verifySSL = false; config.connectTimeoutMs = 10000; config.maxConnections = 5; diff --git a/ydb/library/conclusion/result.h b/ydb/library/conclusion/result.h index 17d72180b3b5..0d9af2fbdcde 100644 --- a/ydb/library/conclusion/result.h +++ b/ydb/library/conclusion/result.h @@ -50,12 +50,26 @@ class TConclusion { return *result; } + TResult& MutableResult() { + auto result = std::get_if(&Result); + Y_ABORT_UNLESS(result, "incorrect object for result request"); + return *result; + } + TResult&& DetachResult() { auto result = std::get_if(&Result); Y_ABORT_UNLESS(result, "incorrect object for result request"); return std::move(*result); } + const TResult* operator->() const { + return &GetResult(); + } + + TResult* operator->() { + return &MutableResult(); + } + const TResult& operator*() const { return GetResult(); } diff --git a/ydb/library/yql/providers/generic/connector/libcpp/ut_helpers/connector_client_mock.h b/ydb/library/yql/providers/generic/connector/libcpp/ut_helpers/connector_client_mock.h index 6f09b9e5ffab..c5b4d78e2be4 100644 --- a/ydb/library/yql/providers/generic/connector/libcpp/ut_helpers/connector_client_mock.h +++ b/ydb/library/yql/providers/generic/connector/libcpp/ut_helpers/connector_client_mock.h @@ -1,7 +1,7 @@ #pragma once #include -#include +#include #include #include #include @@ -677,10 +677,10 @@ namespace NYql::NConnector::NTest { TBuilder& AddResponse( const std::shared_ptr& recordBatch, const NApi::TError& error) { - NKikimr::NArrow::NSerialization::TFullDataSerializer ser(arrow::ipc::IpcWriteOptions::Defaults()); + NKikimr::NArrow::NSerialization::TSerializerContainer ser = NKikimr::NArrow::NSerialization::TSerializerContainer::GetDefaultSerializer(); auto& response = this->Result_->Responses().emplace_back(); response.mutable_error()->CopyFrom(error); - response.set_arrow_ipc_streaming(ser.Serialize(recordBatch)); + response.set_arrow_ipc_streaming(ser->SerializeFull(recordBatch)); return static_cast(*this); } diff --git a/ydb/library/yql/providers/generic/connector/libcpp/utils.cpp b/ydb/library/yql/providers/generic/connector/libcpp/utils.cpp index 2f8b0a1c9c1a..cde710e529e7 100644 --- a/ydb/library/yql/providers/generic/connector/libcpp/utils.cpp +++ b/ydb/library/yql/providers/generic/connector/libcpp/utils.cpp @@ -4,8 +4,7 @@ #include #include #include -#include -#include +#include #include #include @@ -76,8 +75,8 @@ namespace NYql::NConnector { } std::shared_ptr ArrowIPCStreamingToArrowRecordBatch(const TProtoStringType dump) { - NKikimr::NArrow::NSerialization::TFullDataDeserializer deser; - auto result = deser.Deserialize(dump); + NKikimr::NArrow::NSerialization::TSerializerContainer deser = NKikimr::NArrow::NSerialization::TSerializerContainer::GetDefaultSerializer(); + auto result = deser->Deserialize(dump); if (!result.ok()) { ythrow yexception() << result.status().ToString(); } diff --git a/ydb/services/bg_tasks/abstract/interface.h b/ydb/services/bg_tasks/abstract/interface.h index f6cd594e49ff..ff8565a353fa 100644 --- a/ydb/services/bg_tasks/abstract/interface.h +++ b/ydb/services/bg_tasks/abstract/interface.h @@ -111,8 +111,14 @@ class TCommonInterfaceContainer { : Object(object) { } - bool Initialize(const TString& className) { - AFL_VERIFY(!Object)("problem", "initialize for not-empty-object"); + template + TCommonInterfaceContainer(std::shared_ptr object) + : Object(object) { + static_assert(std::is_base_of::value); + } + + bool Initialize(const TString& className, const bool maybeExists = false) { + AFL_VERIFY(maybeExists || !Object)("problem", "initialize for not-empty-object"); Object.reset(TFactory::Construct(className)); if (!Object) { ALS_ERROR(NKikimrServices::BG_TASKS) << "incorrect class name: " << className << " for " << typeid(IInterface).name(); @@ -158,10 +164,12 @@ class TCommonInterfaceContainer { } const IInterface* operator->() const { + AFL_VERIFY(Object); return Object.get(); } IInterface* operator->() { + AFL_VERIFY(Object); return Object.get(); } @@ -169,6 +177,10 @@ class TCommonInterfaceContainer { return !Object; } + operator bool() const { + return !!Object; + } + }; class TStringContainerProcessor { diff --git a/ydb/services/metadata/abstract/request_features.h b/ydb/services/metadata/abstract/request_features.h index c985276ceb72..01d525aded8b 100644 --- a/ydb/services/metadata/abstract/request_features.h +++ b/ydb/services/metadata/abstract/request_features.h @@ -40,5 +40,6 @@ class TFeaturesExtractor: TNonCopyable { } std::optional Extract(const TString& paramName); + }; } diff --git a/ydb/services/metadata/abstract/ya.make b/ydb/services/metadata/abstract/ya.make index 1058cebaa794..7ba40379add6 100644 --- a/ydb/services/metadata/abstract/ya.make +++ b/ydb/services/metadata/abstract/ya.make @@ -19,7 +19,6 @@ PEERDIR( ydb/library/actors/core ydb/library/yql/core/expr_nodes ydb/public/api/protos - ydb/services/metadata/request ) END() From fd0b1ac7c0c968f4507fa74050a9bfc6d7cac2ec Mon Sep 17 00:00:00 2001 From: Maxim Gorbunov Date: Thu, 22 Feb 2024 16:24:30 +0100 Subject: [PATCH 037/117] Generate CMakeLists (#2184) --- CMakeLists.darwin-arm64.txt | 4 +- CMakeLists.darwin-x86_64.txt | 4 +- CMakeLists.linux-aarch64.txt | 4 +- CMakeLists.linux-x86_64.txt | 4 +- CMakeLists.txt | 5 +- CMakeLists.windows-x86_64.txt | 4 +- cmake/global_vars.cmake | 41 + contrib/libs/CMakeLists.darwin-arm64.txt | 1 + contrib/libs/CMakeLists.darwin-x86_64.txt | 1 + contrib/libs/CMakeLists.linux-aarch64.txt | 1 + contrib/libs/CMakeLists.linux-x86_64.txt | 1 + contrib/libs/CMakeLists.windows-x86_64.txt | 4 +- .../apache/arrow/CMakeLists.darwin-arm64.txt | 18 + .../apache/arrow/CMakeLists.darwin-x86_64.txt | 18 + .../apache/arrow/CMakeLists.linux-aarch64.txt | 18 + .../apache/arrow/CMakeLists.linux-x86_64.txt | 18 + .../arrow/CMakeLists.windows-x86_64.txt | 18 + .../apache/orc/CMakeLists.darwin-arm64.txt | 1 + .../apache/orc/CMakeLists.darwin-x86_64.txt | 1 + .../apache/orc/CMakeLists.linux-aarch64.txt | 1 + .../apache/orc/CMakeLists.linux-x86_64.txt | 1 + .../apache/orc/CMakeLists.windows-x86_64.txt | 1 + .../base64/avx2/CMakeLists.windows-x86_64.txt | 4 +- .../ssse3/CMakeLists.windows-x86_64.txt | 4 +- contrib/libs/curl/CMakeLists.darwin-arm64.txt | 2 +- .../libs/curl/CMakeLists.darwin-x86_64.txt | 2 +- .../libs/curl/CMakeLists.linux-aarch64.txt | 2 +- contrib/libs/curl/CMakeLists.linux-x86_64.txt | 2 +- .../libs/curl/CMakeLists.windows-x86_64.txt | 2 +- .../cxxsupp/CMakeLists.windows-x86_64.txt | 5 +- contrib/libs/cxxsupp/builtins/CMakeLists.txt | 2 - .../libcxx/CMakeLists.darwin-arm64.txt | 3 +- .../libcxx/CMakeLists.darwin-x86_64.txt | 3 +- .../libcxx/CMakeLists.linux-aarch64.txt | 3 +- .../libcxx/CMakeLists.linux-x86_64.txt | 3 +- contrib/libs/cxxsupp/libcxx/CMakeLists.txt | 2 - .../libs/cxxsupp/libcxxmsvc/CMakeLists.txt | 11 + .../libcxxmsvc/CMakeLists.windows-x86_64.txt | 75 + .../arch/sse41/CMakeLists.windows-x86_64.txt | 1 - .../arch/sse42/CMakeLists.windows-x86_64.txt | 1 - .../sse42_aesni/CMakeLists.windows-x86_64.txt | 2 - .../libs/fastlz/CMakeLists.darwin-arm64.txt | 1 + .../libs/fastlz/CMakeLists.darwin-x86_64.txt | 1 + .../libs/fastlz/CMakeLists.linux-aarch64.txt | 1 + .../libs/fastlz/CMakeLists.linux-x86_64.txt | 1 + .../libs/fastlz/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 126 + .../CMakeLists.darwin-x86_64.txt | 126 + .../CMakeLists.linux-aarch64.txt | 126 + .../CMakeLists.linux-x86_64.txt | 126 + .../CMakeLists.windows-x86_64.txt | 126 + .../CMakeLists.windows-x86_64.txt | 15 +- .../CMakeLists.windows-x86_64.txt | 22 +- .../CMakeLists.windows-x86_64.txt | 6 +- contrib/libs/libpq/CMakeLists.txt | 2 + .../libs/libpq/CMakeLists.windows-x86_64.txt | 128 + contrib/libs/libpqxx/CMakeLists.txt | 2 + .../libpqxx/CMakeLists.windows-x86_64.txt | 59 + contrib/libs/libunwind/CMakeLists.txt | 2 - .../include/CMakeLists.darwin-arm64.txt | 218 + .../include/CMakeLists.darwin-x86_64.txt | 218 + .../include/CMakeLists.linux-aarch64.txt | 218 + .../include/CMakeLists.linux-x86_64.txt | 218 + .../include/CMakeLists.windows-x86_64.txt | 218 + .../libs/llvm12/lib/DebugInfo/CMakeLists.txt | 2 - .../TableGen/CMakeLists.linux-aarch64.txt | 3 - .../TableGen/CMakeLists.linux-x86_64.txt | 3 - .../libs/llvm14/CMakeLists.darwin-arm64.txt | 21 + .../libs/llvm14/CMakeLists.darwin-x86_64.txt | 21 + .../libs/llvm14/CMakeLists.linux-aarch64.txt | 22 + .../libs/llvm14/CMakeLists.linux-x86_64.txt | 22 + contrib/libs/llvm14/CMakeLists.txt | 19 + .../libs/llvm14/CMakeLists.windows-x86_64.txt | 21 + .../include/CMakeLists.darwin-arm64.txt | 8721 ++++++++++++++++ .../include/CMakeLists.darwin-x86_64.txt | 8721 ++++++++++++++++ .../include/CMakeLists.linux-aarch64.txt | 8722 +++++++++++++++++ .../include/CMakeLists.linux-x86_64.txt | 8722 +++++++++++++++++ contrib/libs/llvm14/include/CMakeLists.txt | 19 + .../include/CMakeLists.windows-x86_64.txt | 8721 ++++++++++++++++ .../lib/Analysis/CMakeLists.darwin-arm64.txt | 144 + .../lib/Analysis/CMakeLists.darwin-x86_64.txt | 144 + .../lib/Analysis/CMakeLists.linux-aarch64.txt | 145 + .../lib/Analysis/CMakeLists.linux-x86_64.txt | 145 + .../libs/llvm14/lib/Analysis/CMakeLists.txt | 19 + .../Analysis/CMakeLists.windows-x86_64.txt | 144 + .../lib/AsmParser/CMakeLists.darwin-arm64.txt | 29 + .../AsmParser/CMakeLists.darwin-x86_64.txt | 29 + .../AsmParser/CMakeLists.linux-aarch64.txt | 30 + .../lib/AsmParser/CMakeLists.linux-x86_64.txt | 30 + .../libs/llvm14/lib/AsmParser/CMakeLists.txt | 19 + .../AsmParser/CMakeLists.windows-x86_64.txt | 29 + .../BinaryFormat/CMakeLists.darwin-arm64.txt | 36 + .../BinaryFormat/CMakeLists.darwin-x86_64.txt | 36 + .../BinaryFormat/CMakeLists.linux-aarch64.txt | 37 + .../BinaryFormat/CMakeLists.linux-x86_64.txt | 37 + .../llvm14/lib/BinaryFormat/CMakeLists.txt | 19 + .../CMakeLists.windows-x86_64.txt | 36 + .../libs/llvm14/lib/Bitcode/CMakeLists.txt | 10 + .../Reader/CMakeLists.darwin-arm64.txt | 31 + .../Reader/CMakeLists.darwin-x86_64.txt | 31 + .../Reader/CMakeLists.linux-aarch64.txt | 32 + .../Reader/CMakeLists.linux-x86_64.txt | 32 + .../llvm14/lib/Bitcode/Reader/CMakeLists.txt | 19 + .../Reader/CMakeLists.windows-x86_64.txt | 31 + .../Writer/CMakeLists.darwin-arm64.txt | 32 + .../Writer/CMakeLists.darwin-x86_64.txt | 32 + .../Writer/CMakeLists.linux-aarch64.txt | 33 + .../Writer/CMakeLists.linux-x86_64.txt | 33 + .../llvm14/lib/Bitcode/Writer/CMakeLists.txt | 19 + .../Writer/CMakeLists.windows-x86_64.txt | 32 + .../libs/llvm14/lib/Bitstream/CMakeLists.txt | 2 +- .../Reader/CMakeLists.darwin-arm64.txt | 24 + .../Reader/CMakeLists.darwin-x86_64.txt | 24 + .../Reader/CMakeLists.linux-aarch64.txt | 25 + .../Reader/CMakeLists.linux-x86_64.txt | 25 + .../lib/Bitstream/Reader/CMakeLists.txt | 19 + .../Reader/CMakeLists.windows-x86_64.txt | 24 + contrib/libs/llvm14/lib/CMakeLists.txt | 30 + .../AsmPrinter/CMakeLists.darwin-arm64.txt | 62 + .../AsmPrinter/CMakeLists.darwin-x86_64.txt | 62 + .../AsmPrinter/CMakeLists.linux-aarch64.txt | 63 + .../AsmPrinter/CMakeLists.linux-x86_64.txt | 63 + .../lib/CodeGen/AsmPrinter/CMakeLists.txt | 19 + .../AsmPrinter/CMakeLists.windows-x86_64.txt | 62 + .../lib/CodeGen/CMakeLists.darwin-arm64.txt | 239 + .../lib/CodeGen/CMakeLists.darwin-x86_64.txt | 239 + .../lib/CodeGen/CMakeLists.linux-aarch64.txt | 240 + .../lib/CodeGen/CMakeLists.linux-x86_64.txt | 240 + .../libs/llvm14/lib/CodeGen/CMakeLists.txt | 19 + .../lib/CodeGen/CMakeLists.windows-x86_64.txt | 239 + .../GlobalISel/CMakeLists.darwin-arm64.txt | 57 + .../GlobalISel/CMakeLists.darwin-x86_64.txt | 57 + .../GlobalISel/CMakeLists.linux-aarch64.txt | 58 + .../GlobalISel/CMakeLists.linux-x86_64.txt | 58 + .../lib/CodeGen/GlobalISel/CMakeLists.txt | 19 + .../GlobalISel/CMakeLists.windows-x86_64.txt | 57 + .../SelectionDAG/CMakeLists.darwin-arm64.txt | 55 + .../SelectionDAG/CMakeLists.darwin-x86_64.txt | 55 + .../SelectionDAG/CMakeLists.linux-aarch64.txt | 56 + .../SelectionDAG/CMakeLists.linux-x86_64.txt | 56 + .../lib/CodeGen/SelectionDAG/CMakeLists.txt | 19 + .../CMakeLists.windows-x86_64.txt | 55 + .../libs/llvm14/lib/DebugInfo/CMakeLists.txt | 11 + .../CodeView/CMakeLists.darwin-arm64.txt | 63 + .../CodeView/CMakeLists.darwin-x86_64.txt | 63 + .../CodeView/CMakeLists.linux-aarch64.txt | 64 + .../CodeView/CMakeLists.linux-x86_64.txt | 64 + .../lib/DebugInfo/CodeView/CMakeLists.txt | 19 + .../CodeView/CMakeLists.windows-x86_64.txt | 63 + .../DWARF/CMakeLists.darwin-arm64.txt | 54 + .../DWARF/CMakeLists.darwin-x86_64.txt | 54 + .../DWARF/CMakeLists.linux-aarch64.txt | 55 + .../DWARF/CMakeLists.linux-x86_64.txt | 55 + .../llvm14/lib/DebugInfo/DWARF/CMakeLists.txt | 19 + .../DWARF/CMakeLists.windows-x86_64.txt | 54 + .../DebugInfo/MSF/CMakeLists.darwin-arm64.txt | 27 + .../MSF/CMakeLists.darwin-x86_64.txt | 27 + .../MSF/CMakeLists.linux-aarch64.txt | 28 + .../DebugInfo/MSF/CMakeLists.linux-x86_64.txt | 28 + .../llvm14/lib/DebugInfo/MSF/CMakeLists.txt | 19 + .../MSF/CMakeLists.windows-x86_64.txt | 27 + .../lib/Demangle/CMakeLists.darwin-arm64.txt | 28 + .../lib/Demangle/CMakeLists.darwin-x86_64.txt | 28 + .../lib/Demangle/CMakeLists.linux-aarch64.txt | 29 + .../lib/Demangle/CMakeLists.linux-x86_64.txt | 29 + .../libs/llvm14/lib/Demangle/CMakeLists.txt | 19 + .../Demangle/CMakeLists.windows-x86_64.txt | 28 + .../CMakeLists.darwin-arm64.txt | 38 + .../CMakeLists.darwin-x86_64.txt | 38 + .../CMakeLists.linux-aarch64.txt | 40 + .../CMakeLists.linux-x86_64.txt | 40 + .../llvm14/lib/ExecutionEngine/CMakeLists.txt | 19 + .../CMakeLists.windows-x86_64.txt | 38 + .../MCJIT/CMakeLists.darwin-arm64.txt | 30 + .../MCJIT/CMakeLists.darwin-x86_64.txt | 30 + .../MCJIT/CMakeLists.linux-aarch64.txt | 31 + .../MCJIT/CMakeLists.linux-x86_64.txt | 31 + .../lib/ExecutionEngine/MCJIT/CMakeLists.txt | 19 + .../MCJIT/CMakeLists.windows-x86_64.txt | 30 + .../lib/ExecutionEngine/Orc/CMakeLists.txt | 10 + .../Orc/Shared/CMakeLists.darwin-arm64.txt | 27 + .../Orc/Shared/CMakeLists.darwin-x86_64.txt | 27 + .../Orc/Shared/CMakeLists.linux-aarch64.txt | 28 + .../Orc/Shared/CMakeLists.linux-x86_64.txt | 28 + .../ExecutionEngine/Orc/Shared/CMakeLists.txt | 19 + .../Orc/Shared/CMakeLists.windows-x86_64.txt | 27 + .../TargetProcess/CMakeLists.darwin-arm64.txt | 31 + .../CMakeLists.darwin-x86_64.txt | 31 + .../CMakeLists.linux-aarch64.txt | 32 + .../TargetProcess/CMakeLists.linux-x86_64.txt | 32 + .../Orc/TargetProcess/CMakeLists.txt | 19 + .../CMakeLists.windows-x86_64.txt | 31 + .../CMakeLists.linux-aarch64.txt | 31 + .../PerfJITEvents/CMakeLists.linux-x86_64.txt | 31 + .../PerfJITEvents/CMakeLists.txt | 13 + .../RuntimeDyld/CMakeLists.darwin-arm64.txt | 35 + .../RuntimeDyld/CMakeLists.darwin-x86_64.txt | 35 + .../RuntimeDyld/CMakeLists.linux-aarch64.txt | 36 + .../RuntimeDyld/CMakeLists.linux-x86_64.txt | 36 + .../RuntimeDyld/CMakeLists.txt | 19 + .../RuntimeDyld/CMakeLists.windows-x86_64.txt | 35 + .../libs/llvm14/lib/Frontend/CMakeLists.txt | 2 +- .../OpenMP/CMakeLists.darwin-arm64.txt | 32 + .../OpenMP/CMakeLists.darwin-x86_64.txt | 32 + .../OpenMP/CMakeLists.linux-aarch64.txt | 33 + .../OpenMP/CMakeLists.linux-x86_64.txt | 33 + .../llvm14/lib/Frontend/OpenMP/CMakeLists.txt | 19 + .../OpenMP/CMakeLists.windows-x86_64.txt | 32 + .../llvm14/lib/IR/CMakeLists.darwin-arm64.txt | 89 + .../lib/IR/CMakeLists.darwin-x86_64.txt | 89 + .../lib/IR/CMakeLists.linux-aarch64.txt | 90 + .../llvm14/lib/IR/CMakeLists.linux-x86_64.txt | 90 + contrib/libs/llvm14/lib/IR/CMakeLists.txt | 19 + .../lib/IR/CMakeLists.windows-x86_64.txt | 89 + .../lib/IRReader/CMakeLists.darwin-arm64.txt | 28 + .../lib/IRReader/CMakeLists.darwin-x86_64.txt | 28 + .../lib/IRReader/CMakeLists.linux-aarch64.txt | 29 + .../lib/IRReader/CMakeLists.linux-x86_64.txt | 29 + .../libs/llvm14/lib/IRReader/CMakeLists.txt | 19 + .../IRReader/CMakeLists.windows-x86_64.txt | 28 + .../lib/Linker/CMakeLists.darwin-arm64.txt | 29 + .../lib/Linker/CMakeLists.darwin-x86_64.txt | 29 + .../lib/Linker/CMakeLists.linux-aarch64.txt | 30 + .../lib/Linker/CMakeLists.linux-x86_64.txt | 30 + contrib/libs/llvm14/lib/Linker/CMakeLists.txt | 19 + .../lib/Linker/CMakeLists.windows-x86_64.txt | 29 + .../llvm14/lib/MC/CMakeLists.darwin-arm64.txt | 92 + .../lib/MC/CMakeLists.darwin-x86_64.txt | 92 + .../lib/MC/CMakeLists.linux-aarch64.txt | 93 + .../llvm14/lib/MC/CMakeLists.linux-x86_64.txt | 93 + contrib/libs/llvm14/lib/MC/CMakeLists.txt | 19 + .../lib/MC/CMakeLists.windows-x86_64.txt | 92 + .../CMakeLists.darwin-arm64.txt | 29 + .../CMakeLists.darwin-x86_64.txt | 29 + .../CMakeLists.linux-aarch64.txt | 30 + .../CMakeLists.linux-x86_64.txt | 30 + .../lib/MC/MCDisassembler/CMakeLists.txt | 19 + .../CMakeLists.windows-x86_64.txt | 29 + .../MC/MCParser/CMakeLists.darwin-arm64.txt | 38 + .../MC/MCParser/CMakeLists.darwin-x86_64.txt | 38 + .../MC/MCParser/CMakeLists.linux-aarch64.txt | 39 + .../MC/MCParser/CMakeLists.linux-x86_64.txt | 39 + .../llvm14/lib/MC/MCParser/CMakeLists.txt | 19 + .../MC/MCParser/CMakeLists.windows-x86_64.txt | 38 + .../lib/Object/CMakeLists.darwin-arm64.txt | 60 + .../lib/Object/CMakeLists.darwin-x86_64.txt | 60 + .../lib/Object/CMakeLists.linux-aarch64.txt | 61 + .../lib/Object/CMakeLists.linux-x86_64.txt | 61 + contrib/libs/llvm14/lib/Object/CMakeLists.txt | 19 + .../lib/Object/CMakeLists.windows-x86_64.txt | 60 + .../ProfileData/CMakeLists.darwin-arm64.txt | 38 + .../ProfileData/CMakeLists.darwin-x86_64.txt | 38 + .../ProfileData/CMakeLists.linux-aarch64.txt | 39 + .../ProfileData/CMakeLists.linux-x86_64.txt | 39 + .../llvm14/lib/ProfileData/CMakeLists.txt | 19 + .../ProfileData/CMakeLists.windows-x86_64.txt | 38 + .../lib/Remarks/CMakeLists.darwin-arm64.txt | 35 + .../lib/Remarks/CMakeLists.darwin-x86_64.txt | 35 + .../lib/Remarks/CMakeLists.linux-aarch64.txt | 36 + .../lib/Remarks/CMakeLists.linux-x86_64.txt | 36 + .../libs/llvm14/lib/Remarks/CMakeLists.txt | 19 + .../lib/Remarks/CMakeLists.windows-x86_64.txt | 35 + .../lib/Support/CMakeLists.darwin-arm64.txt | 167 + .../lib/Support/CMakeLists.darwin-x86_64.txt | 167 + .../lib/Support/CMakeLists.linux-aarch64.txt | 168 + .../lib/Support/CMakeLists.linux-x86_64.txt | 168 + .../libs/llvm14/lib/Support/CMakeLists.txt | 19 + .../lib/Support/CMakeLists.windows-x86_64.txt | 167 + .../lib/TableGen/CMakeLists.darwin-arm64.txt | 34 + .../lib/TableGen/CMakeLists.darwin-x86_64.txt | 34 + .../lib/TableGen/CMakeLists.linux-aarch64.txt | 35 + .../lib/TableGen/CMakeLists.linux-x86_64.txt | 35 + .../libs/llvm14/lib/TableGen/CMakeLists.txt | 19 + .../TableGen/CMakeLists.windows-x86_64.txt | 34 + .../lib/Target/CMakeLists.darwin-arm64.txt | 33 + .../lib/Target/CMakeLists.darwin-x86_64.txt | 33 + .../lib/Target/CMakeLists.linux-aarch64.txt | 34 + .../lib/Target/CMakeLists.linux-x86_64.txt | 34 + contrib/libs/llvm14/lib/Target/CMakeLists.txt | 19 + .../lib/Target/CMakeLists.windows-x86_64.txt | 33 + .../X86/AsmParser/CMakeLists.darwin-arm64.txt | 31 + .../AsmParser/CMakeLists.darwin-x86_64.txt | 31 + .../AsmParser/CMakeLists.linux-aarch64.txt | 32 + .../X86/AsmParser/CMakeLists.linux-x86_64.txt | 32 + .../lib/Target/X86/AsmParser/CMakeLists.txt | 19 + .../AsmParser/CMakeLists.windows-x86_64.txt | 31 + .../Target/X86/CMakeLists.darwin-arm64.txt | 102 + .../Target/X86/CMakeLists.darwin-x86_64.txt | 102 + .../Target/X86/CMakeLists.linux-aarch64.txt | 103 + .../Target/X86/CMakeLists.linux-x86_64.txt | 103 + .../libs/llvm14/lib/Target/X86/CMakeLists.txt | 19 + .../Target/X86/CMakeLists.windows-x86_64.txt | 102 + .../Disassembler/CMakeLists.darwin-arm64.txt | 29 + .../Disassembler/CMakeLists.darwin-x86_64.txt | 29 + .../Disassembler/CMakeLists.linux-aarch64.txt | 30 + .../Disassembler/CMakeLists.linux-x86_64.txt | 30 + .../Target/X86/Disassembler/CMakeLists.txt | 19 + .../CMakeLists.windows-x86_64.txt | 29 + .../MCTargetDesc/CMakeLists.darwin-arm64.txt | 44 + .../MCTargetDesc/CMakeLists.darwin-x86_64.txt | 44 + .../MCTargetDesc/CMakeLists.linux-aarch64.txt | 45 + .../MCTargetDesc/CMakeLists.linux-x86_64.txt | 45 + .../Target/X86/MCTargetDesc/CMakeLists.txt | 19 + .../CMakeLists.windows-x86_64.txt | 44 + .../TargetInfo/CMakeLists.darwin-arm64.txt | 26 + .../TargetInfo/CMakeLists.darwin-x86_64.txt | 26 + .../TargetInfo/CMakeLists.linux-aarch64.txt | 27 + .../TargetInfo/CMakeLists.linux-x86_64.txt | 27 + .../lib/Target/X86/TargetInfo/CMakeLists.txt | 19 + .../TargetInfo/CMakeLists.windows-x86_64.txt | 26 + .../lib/TextAPI/CMakeLists.darwin-arm64.txt | 33 + .../lib/TextAPI/CMakeLists.darwin-x86_64.txt | 33 + .../lib/TextAPI/CMakeLists.linux-aarch64.txt | 34 + .../lib/TextAPI/CMakeLists.linux-x86_64.txt | 34 + .../libs/llvm14/lib/TextAPI/CMakeLists.txt | 19 + .../lib/TextAPI/CMakeLists.windows-x86_64.txt | 33 + .../CMakeLists.darwin-arm64.txt | 29 + .../CMakeLists.darwin-x86_64.txt | 29 + .../CMakeLists.linux-aarch64.txt | 30 + .../CMakeLists.linux-x86_64.txt | 30 + .../AggressiveInstCombine/CMakeLists.txt | 19 + .../CMakeLists.windows-x86_64.txt | 29 + .../CFGuard/CMakeLists.darwin-arm64.txt | 26 + .../CFGuard/CMakeLists.darwin-x86_64.txt | 26 + .../CFGuard/CMakeLists.linux-aarch64.txt | 27 + .../CFGuard/CMakeLists.linux-x86_64.txt | 27 + .../lib/Transforms/CFGuard/CMakeLists.txt | 19 + .../CFGuard/CMakeLists.windows-x86_64.txt | 26 + .../libs/llvm14/lib/Transforms/CMakeLists.txt | 17 + .../IPO/CMakeLists.darwin-arm64.txt | 83 + .../IPO/CMakeLists.darwin-x86_64.txt | 83 + .../IPO/CMakeLists.linux-aarch64.txt | 84 + .../IPO/CMakeLists.linux-x86_64.txt | 84 + .../llvm14/lib/Transforms/IPO/CMakeLists.txt | 19 + .../IPO/CMakeLists.windows-x86_64.txt | 83 + .../InstCombine/CMakeLists.darwin-arm64.txt | 42 + .../InstCombine/CMakeLists.darwin-x86_64.txt | 42 + .../InstCombine/CMakeLists.linux-aarch64.txt | 43 + .../InstCombine/CMakeLists.linux-x86_64.txt | 43 + .../lib/Transforms/InstCombine/CMakeLists.txt | 19 + .../InstCombine/CMakeLists.windows-x86_64.txt | 42 + .../CMakeLists.darwin-arm64.txt | 48 + .../CMakeLists.darwin-x86_64.txt | 48 + .../CMakeLists.linux-aarch64.txt | 49 + .../CMakeLists.linux-x86_64.txt | 49 + .../Transforms/Instrumentation/CMakeLists.txt | 19 + .../CMakeLists.windows-x86_64.txt | 48 + .../ObjCARC/CMakeLists.darwin-arm64.txt | 36 + .../ObjCARC/CMakeLists.darwin-x86_64.txt | 36 + .../ObjCARC/CMakeLists.linux-aarch64.txt | 37 + .../ObjCARC/CMakeLists.linux-x86_64.txt | 37 + .../lib/Transforms/ObjCARC/CMakeLists.txt | 19 + .../ObjCARC/CMakeLists.windows-x86_64.txt | 36 + .../Scalar/CMakeLists.darwin-arm64.txt | 108 + .../Scalar/CMakeLists.darwin-x86_64.txt | 108 + .../Scalar/CMakeLists.linux-aarch64.txt | 109 + .../Scalar/CMakeLists.linux-x86_64.txt | 109 + .../lib/Transforms/Scalar/CMakeLists.txt | 19 + .../Scalar/CMakeLists.windows-x86_64.txt | 108 + .../Utils/CMakeLists.darwin-arm64.txt | 103 + .../Utils/CMakeLists.darwin-x86_64.txt | 103 + .../Utils/CMakeLists.linux-aarch64.txt | 104 + .../Utils/CMakeLists.linux-x86_64.txt | 104 + .../lib/Transforms/Utils/CMakeLists.txt | 19 + .../Utils/CMakeLists.windows-x86_64.txt | 103 + .../Vectorize/CMakeLists.darwin-arm64.txt | 39 + .../Vectorize/CMakeLists.darwin-x86_64.txt | 39 + .../Vectorize/CMakeLists.linux-aarch64.txt | 40 + .../Vectorize/CMakeLists.linux-x86_64.txt | 40 + .../lib/Transforms/Vectorize/CMakeLists.txt | 19 + .../Vectorize/CMakeLists.windows-x86_64.txt | 39 + contrib/libs/llvm14/utils/CMakeLists.txt | 9 + .../TableGen/CMakeLists.darwin-arm64.txt | 90 + .../TableGen/CMakeLists.darwin-x86_64.txt | 90 + .../TableGen/CMakeLists.linux-aarch64.txt | 93 + .../TableGen/CMakeLists.linux-x86_64.txt | 94 + .../libs/llvm14/utils/TableGen/CMakeLists.txt | 19 + .../TableGen/CMakeLists.windows-x86_64.txt | 85 + .../GlobalISel/CMakeLists.darwin-arm64.txt | 32 + .../GlobalISel/CMakeLists.darwin-x86_64.txt | 32 + .../GlobalISel/CMakeLists.linux-aarch64.txt | 33 + .../GlobalISel/CMakeLists.linux-x86_64.txt | 33 + .../utils/TableGen/GlobalISel/CMakeLists.txt | 19 + .../GlobalISel/CMakeLists.windows-x86_64.txt | 32 + contrib/libs/lua/CMakeLists.darwin-arm64.txt | 1 + contrib/libs/lua/CMakeLists.darwin-x86_64.txt | 1 + contrib/libs/lua/CMakeLists.linux-aarch64.txt | 1 + contrib/libs/lua/CMakeLists.linux-x86_64.txt | 1 + .../libs/lua/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 18 + .../CMakeLists.darwin-x86_64.txt | 18 + .../CMakeLists.linux-aarch64.txt | 18 + .../CMakeLists.linux-x86_64.txt | 18 + .../CMakeLists.windows-x86_64.txt | 18 + .../libs/protobuf/CMakeLists.darwin-arm64.txt | 44 - .../protobuf/CMakeLists.darwin-x86_64.txt | 44 - .../protobuf/CMakeLists.linux-aarch64.txt | 44 - .../libs/protobuf/CMakeLists.linux-x86_64.txt | 44 - .../protobuf/CMakeLists.windows-x86_64.txt | 44 - .../libs/tbb/CMakeLists.windows-x86_64.txt | 2 - .../absl/flags/CMakeLists.darwin-arm64.txt | 1 - .../absl/flags/CMakeLists.darwin-x86_64.txt | 1 - .../absl/flags/CMakeLists.linux-aarch64.txt | 1 - .../absl/flags/CMakeLists.linux-x86_64.txt | 1 - .../absl/flags/CMakeLists.windows-x86_64.txt | 1 - .../absl/log/CMakeLists.darwin-arm64.txt | 2 + .../absl/log/CMakeLists.darwin-x86_64.txt | 2 + .../absl/log/CMakeLists.linux-aarch64.txt | 2 + .../absl/log/CMakeLists.linux-x86_64.txt | 2 + .../absl/log/CMakeLists.windows-x86_64.txt | 2 + .../absl/status/CMakeLists.darwin-arm64.txt | 1 + .../absl/status/CMakeLists.darwin-x86_64.txt | 1 + .../absl/status/CMakeLists.linux-aarch64.txt | 1 + .../absl/status/CMakeLists.linux-x86_64.txt | 1 + .../absl/status/CMakeLists.windows-x86_64.txt | 1 + .../absl/strings/CMakeLists.darwin-arm64.txt | 3 +- .../absl/strings/CMakeLists.darwin-x86_64.txt | 3 +- .../absl/strings/CMakeLists.linux-aarch64.txt | 3 +- .../absl/strings/CMakeLists.linux-x86_64.txt | 3 +- .../strings/CMakeLists.windows-x86_64.txt | 3 +- .../aws/aws-c-cal/CMakeLists.darwin-arm64.txt | 1 + .../aws-c-cal/CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 6 +- .../aws-c-http/CMakeLists.windows-x86_64.txt | 1 - .../aws-c-io/CMakeLists.windows-x86_64.txt | 1 - .../boost/CMakeLists.windows-x86_64.txt | 1 - .../CMakeLists.darwin-arm64.txt | 1 - .../CMakeLists.darwin-x86_64.txt | 1 - .../CMakeLists.linux-aarch64.txt | 1 - .../CMakeLists.linux-x86_64.txt | 1 - .../CMakeLists.windows-x86_64.txt | 1 - .../restricted/boost/format/CMakeLists.txt | 2 - .../iterator/CMakeLists.darwin-arm64.txt | 1 - .../iterator/CMakeLists.darwin-x86_64.txt | 1 - .../iterator/CMakeLists.linux-aarch64.txt | 1 - .../iterator/CMakeLists.linux-x86_64.txt | 1 - .../iterator/CMakeLists.windows-x86_64.txt | 1 - .../lexical_cast/CMakeLists.darwin-arm64.txt | 4 - .../lexical_cast/CMakeLists.darwin-x86_64.txt | 4 - .../lexical_cast/CMakeLists.linux-aarch64.txt | 4 - .../lexical_cast/CMakeLists.linux-x86_64.txt | 4 - .../CMakeLists.windows-x86_64.txt | 4 - .../CMakeLists.darwin-x86_64.txt | 1 - .../property_tree/CMakeLists.linux-x86_64.txt | 1 - .../CMakeLists.windows-x86_64.txt | 1 - .../rational/CMakeLists.darwin-x86_64.txt | 3 - .../rational/CMakeLists.linux-x86_64.txt | 3 - .../rational/CMakeLists.windows-x86_64.txt | 3 - .../type_index/CMakeLists.darwin-arm64.txt | 3 - .../type_index/CMakeLists.darwin-x86_64.txt | 3 - .../type_index/CMakeLists.linux-aarch64.txt | 3 - .../type_index/CMakeLists.linux-x86_64.txt | 3 - .../type_index/CMakeLists.windows-x86_64.txt | 3 - .../boost/typeof/CMakeLists.darwin-arm64.txt | 2 - .../boost/typeof/CMakeLists.darwin-x86_64.txt | 2 - .../boost/typeof/CMakeLists.linux-aarch64.txt | 2 - .../boost/typeof/CMakeLists.linux-x86_64.txt | 2 - .../typeof/CMakeLists.windows-x86_64.txt | 2 - .../flatc/bin/CMakeLists.linux-aarch64.txt | 1 - .../flatc/bin/CMakeLists.linux-x86_64.txt | 1 - .../protoc/bin/CMakeLists.linux-aarch64.txt | 3 - .../protoc/bin/CMakeLists.linux-x86_64.txt | 3 - .../CMakeLists.linux-aarch64.txt | 3 - .../CMakeLists.linux-x86_64.txt | 3 - .../grpc_cpp/CMakeLists.linux-aarch64.txt | 3 - .../grpc_cpp/CMakeLists.linux-x86_64.txt | 3 - library/cpp/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 1 + .../CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.linux-aarch64.txt | 1 + .../CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../cpp/archive/CMakeLists.darwin-arm64.txt | 2 + .../cpp/archive/CMakeLists.darwin-x86_64.txt | 2 + .../cpp/archive/CMakeLists.linux-aarch64.txt | 2 + .../cpp/archive/CMakeLists.linux-x86_64.txt | 2 + .../cpp/archive/CMakeLists.windows-x86_64.txt | 2 + .../balloc/lib/CMakeLists.darwin-arm64.txt | 1 + .../balloc/lib/CMakeLists.darwin-x86_64.txt | 1 + .../balloc/lib/CMakeLists.linux-aarch64.txt | 1 + .../balloc/lib/CMakeLists.linux-x86_64.txt | 1 + .../cpp/binsaver/CMakeLists.darwin-arm64.txt | 1 + .../cpp/binsaver/CMakeLists.darwin-x86_64.txt | 1 + .../cpp/binsaver/CMakeLists.linux-aarch64.txt | 1 + .../cpp/binsaver/CMakeLists.linux-x86_64.txt | 1 + .../binsaver/CMakeLists.windows-x86_64.txt | 1 + .../build_info/CMakeLists.darwin-arm64.txt | 1 + .../build_info/CMakeLists.darwin-x86_64.txt | 1 + .../build_info/CMakeLists.linux-aarch64.txt | 1 + .../build_info/CMakeLists.linux-x86_64.txt | 1 + .../build_info/CMakeLists.windows-x86_64.txt | 1 + .../cpp/cgiparam/CMakeLists.darwin-arm64.txt | 1 + .../cpp/cgiparam/CMakeLists.darwin-x86_64.txt | 1 + .../cpp/cgiparam/CMakeLists.linux-aarch64.txt | 1 + .../cpp/cgiparam/CMakeLists.linux-x86_64.txt | 1 + .../cgiparam/CMakeLists.windows-x86_64.txt | 1 + .../cpp/charset/CMakeLists.darwin-arm64.txt | 2 + .../cpp/charset/CMakeLists.darwin-x86_64.txt | 2 + .../cpp/charset/CMakeLists.linux-aarch64.txt | 2 + .../cpp/charset/CMakeLists.linux-x86_64.txt | 2 + .../cpp/charset/CMakeLists.windows-x86_64.txt | 2 + library/cpp/clickhouse/CMakeLists.txt | 10 +- library/cpp/clickhouse/client/CMakeLists.txt | 2 + .../client/CMakeLists.windows-x86_64.txt | 28 + .../client/base/CMakeLists.darwin-arm64.txt | 1 + .../client/base/CMakeLists.darwin-x86_64.txt | 1 + .../client/base/CMakeLists.linux-aarch64.txt | 1 + .../client/base/CMakeLists.linux-x86_64.txt | 1 + .../cpp/clickhouse/client/base/CMakeLists.txt | 2 + .../client/base/CMakeLists.windows-x86_64.txt | 19 + .../clickhouse/client/columns/CMakeLists.txt | 2 + .../columns/CMakeLists.windows-x86_64.txt | 26 + .../clickhouse/client/types/CMakeLists.txt | 2 + .../types/CMakeLists.windows-x86_64.txt | 18 + .../cpp/compproto/CMakeLists.darwin-arm64.txt | 4 + .../compproto/CMakeLists.darwin-x86_64.txt | 4 + .../compproto/CMakeLists.linux-aarch64.txt | 4 + .../cpp/compproto/CMakeLists.linux-x86_64.txt | 4 + .../compproto/CMakeLists.windows-x86_64.txt | 4 + .../cpp/config/CMakeLists.darwin-arm64.txt | 1 + .../cpp/config/CMakeLists.darwin-x86_64.txt | 1 + .../cpp/config/CMakeLists.linux-aarch64.txt | 1 + .../cpp/config/CMakeLists.linux-x86_64.txt | 1 + .../cpp/config/CMakeLists.windows-x86_64.txt | 1 + .../comptrie/CMakeLists.darwin-arm64.txt | 9 + .../comptrie/CMakeLists.darwin-x86_64.txt | 9 + .../comptrie/CMakeLists.linux-aarch64.txt | 9 + .../comptrie/CMakeLists.linux-x86_64.txt | 9 + .../comptrie/CMakeLists.windows-x86_64.txt | 9 + .../kmp/CMakeLists.darwin-arm64.txt | 1 + .../kmp/CMakeLists.darwin-x86_64.txt | 1 + .../kmp/CMakeLists.linux-aarch64.txt | 1 + .../kmp/CMakeLists.linux-x86_64.txt | 1 + .../kmp/CMakeLists.windows-x86_64.txt | 1 + .../avx2/CMakeLists.windows-x86_64.txt | 6 +- .../sse2/CMakeLists.windows-x86_64.txt | 2 +- .../sse41/CMakeLists.windows-x86_64.txt | 2 +- .../ssse3/CMakeLists.windows-x86_64.txt | 2 +- .../old_crc/CMakeLists.darwin-arm64.txt | 1 + .../old_crc/CMakeLists.darwin-x86_64.txt | 1 + .../old_crc/CMakeLists.linux-aarch64.txt | 1 + .../old_crc/CMakeLists.linux-x86_64.txt | 1 + .../old_crc/CMakeLists.windows-x86_64.txt | 1 + .../gencrc/CMakeLists.linux-aarch64.txt | 3 - .../gencrc/CMakeLists.linux-x86_64.txt | 3 - .../protos/CMakeLists.darwin-arm64.txt | 3 + .../protos/CMakeLists.darwin-x86_64.txt | 3 + .../protos/CMakeLists.linux-aarch64.txt | 3 + .../protos/CMakeLists.linux-x86_64.txt | 3 + .../protos/CMakeLists.windows-x86_64.txt | 3 + .../html/pcdata/CMakeLists.darwin-arm64.txt | 1 + .../html/pcdata/CMakeLists.darwin-x86_64.txt | 1 + .../html/pcdata/CMakeLists.linux-aarch64.txt | 1 + .../html/pcdata/CMakeLists.linux-x86_64.txt | 1 + .../html/pcdata/CMakeLists.windows-x86_64.txt | 1 + .../http/fetch/CMakeLists.darwin-arm64.txt | 6 + .../http/fetch/CMakeLists.darwin-x86_64.txt | 6 + .../http/fetch/CMakeLists.linux-aarch64.txt | 6 + .../http/fetch/CMakeLists.linux-x86_64.txt | 6 + .../http/fetch/CMakeLists.windows-x86_64.txt | 6 + .../hyperloglog/CMakeLists.darwin-arm64.txt | 1 + .../hyperloglog/CMakeLists.darwin-x86_64.txt | 1 + .../hyperloglog/CMakeLists.linux-aarch64.txt | 1 + .../hyperloglog/CMakeLists.linux-x86_64.txt | 1 + .../hyperloglog/CMakeLists.windows-x86_64.txt | 1 + .../cpp/int128/CMakeLists.darwin-arm64.txt | 1 + .../cpp/int128/CMakeLists.darwin-x86_64.txt | 1 + .../cpp/int128/CMakeLists.linux-aarch64.txt | 1 + .../cpp/int128/CMakeLists.linux-x86_64.txt | 1 + .../cpp/int128/CMakeLists.windows-x86_64.txt | 1 + .../ipv6_address/CMakeLists.darwin-arm64.txt | 2 + .../ipv6_address/CMakeLists.darwin-x86_64.txt | 2 + .../ipv6_address/CMakeLists.linux-aarch64.txt | 2 + .../ipv6_address/CMakeLists.linux-x86_64.txt | 2 + .../CMakeLists.windows-x86_64.txt | 2 + .../cpp/logger/CMakeLists.darwin-arm64.txt | 4 + .../cpp/logger/CMakeLists.darwin-x86_64.txt | 4 + .../cpp/logger/CMakeLists.linux-aarch64.txt | 4 + .../cpp/logger/CMakeLists.linux-x86_64.txt | 4 + .../cpp/logger/CMakeLists.windows-x86_64.txt | 4 + .../protos/CMakeLists.darwin-arm64.txt | 3 + .../protos/CMakeLists.darwin-x86_64.txt | 3 + .../protos/CMakeLists.linux-aarch64.txt | 3 + .../protos/CMakeLists.linux-x86_64.txt | 3 + .../protos/CMakeLists.windows-x86_64.txt | 3 + .../messagebus/CMakeLists.darwin-arm64.txt | 6 + .../messagebus/CMakeLists.darwin-x86_64.txt | 6 + .../messagebus/CMakeLists.linux-aarch64.txt | 6 + .../messagebus/CMakeLists.linux-x86_64.txt | 6 + .../messagebus/CMakeLists.windows-x86_64.txt | 6 + .../monitoring/CMakeLists.darwin-arm64.txt | 3 + .../monitoring/CMakeLists.darwin-x86_64.txt | 3 + .../monitoring/CMakeLists.linux-aarch64.txt | 3 + .../monitoring/CMakeLists.linux-x86_64.txt | 3 + .../monitoring/CMakeLists.windows-x86_64.txt | 3 + .../json/CMakeLists.darwin-arm64.txt | 1 + .../json/CMakeLists.darwin-x86_64.txt | 1 + .../json/CMakeLists.linux-aarch64.txt | 1 + .../json/CMakeLists.linux-x86_64.txt | 1 + .../json/CMakeLists.windows-x86_64.txt | 1 + .../percentile/CMakeLists.darwin-arm64.txt | 4 + .../percentile/CMakeLists.darwin-x86_64.txt | 4 + .../percentile/CMakeLists.linux-aarch64.txt | 4 + .../percentile/CMakeLists.linux-x86_64.txt | 4 + .../percentile/CMakeLists.windows-x86_64.txt | 4 + .../monlib/encode/CMakeLists.darwin-arm64.txt | 1 + .../encode/CMakeLists.darwin-x86_64.txt | 1 + .../encode/CMakeLists.linux-aarch64.txt | 1 + .../monlib/encode/CMakeLists.linux-x86_64.txt | 1 + .../encode/CMakeLists.windows-x86_64.txt | 1 + .../protos/CMakeLists.darwin-arm64.txt | 3 + .../protos/CMakeLists.darwin-x86_64.txt | 3 + .../protos/CMakeLists.linux-aarch64.txt | 3 + .../protos/CMakeLists.linux-x86_64.txt | 3 + .../protos/CMakeLists.windows-x86_64.txt | 3 + .../metrics/CMakeLists.darwin-arm64.txt | 1 + .../metrics/CMakeLists.darwin-x86_64.txt | 1 + .../metrics/CMakeLists.linux-aarch64.txt | 1 + .../metrics/CMakeLists.linux-x86_64.txt | 1 + .../metrics/CMakeLists.windows-x86_64.txt | 1 + .../resources/CMakeLists.darwin-arm64.txt | 5 + .../resources/CMakeLists.darwin-x86_64.txt | 5 + .../resources/CMakeLists.linux-aarch64.txt | 5 + .../resources/CMakeLists.linux-x86_64.txt | 5 + .../resources/CMakeLists.windows-x86_64.txt | 5 + .../packedtypes/CMakeLists.darwin-arm64.txt | 4 + .../packedtypes/CMakeLists.darwin-x86_64.txt | 4 + .../packedtypes/CMakeLists.linux-aarch64.txt | 4 + .../packedtypes/CMakeLists.linux-x86_64.txt | 4 + .../packedtypes/CMakeLists.windows-x86_64.txt | 4 + .../protobuf/json/CMakeLists.darwin-arm64.txt | 1 + .../json/CMakeLists.darwin-x86_64.txt | 1 + .../json/CMakeLists.linux-aarch64.txt | 1 + .../protobuf/json/CMakeLists.linux-x86_64.txt | 1 + .../json/CMakeLists.windows-x86_64.txt | 1 + .../json/proto/CMakeLists.darwin-arm64.txt | 3 + .../json/proto/CMakeLists.darwin-x86_64.txt | 3 + .../json/proto/CMakeLists.linux-aarch64.txt | 3 + .../json/proto/CMakeLists.linux-x86_64.txt | 3 + .../json/proto/CMakeLists.windows-x86_64.txt | 3 + .../protobuf/util/CMakeLists.darwin-arm64.txt | 3 + .../util/CMakeLists.darwin-x86_64.txt | 3 + .../util/CMakeLists.linux-aarch64.txt | 3 + .../protobuf/util/CMakeLists.linux-x86_64.txt | 3 + .../util/CMakeLists.windows-x86_64.txt | 3 + .../util/proto/CMakeLists.darwin-arm64.txt | 3 + .../util/proto/CMakeLists.darwin-x86_64.txt | 3 + .../util/proto/CMakeLists.linux-aarch64.txt | 3 + .../util/proto/CMakeLists.linux-x86_64.txt | 3 + .../util/proto/CMakeLists.windows-x86_64.txt | 3 + .../CMakeLists.darwin-arm64.txt | 1 + .../CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.linux-aarch64.txt | 1 + .../CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../regex/pire/CMakeLists.darwin-arm64.txt | 2 + .../regex/pire/CMakeLists.darwin-x86_64.txt | 2 + .../regex/pire/CMakeLists.linux-aarch64.txt | 2 + .../regex/pire/CMakeLists.linux-x86_64.txt | 2 + .../regex/pire/CMakeLists.windows-x86_64.txt | 2 + .../retry/protos/CMakeLists.darwin-arm64.txt | 3 + .../retry/protos/CMakeLists.darwin-x86_64.txt | 3 + .../retry/protos/CMakeLists.linux-aarch64.txt | 3 + .../retry/protos/CMakeLists.linux-x86_64.txt | 3 + .../protos/CMakeLists.windows-x86_64.txt | 3 + .../include/CMakeLists.darwin-arm64.txt | 2 +- .../include/CMakeLists.darwin-x86_64.txt | 2 +- .../include/CMakeLists.linux-aarch64.txt | 2 +- .../include/CMakeLists.linux-x86_64.txt | 2 +- .../cpp/scheme/CMakeLists.darwin-arm64.txt | 3 + .../cpp/scheme/CMakeLists.darwin-x86_64.txt | 3 + .../cpp/scheme/CMakeLists.linux-aarch64.txt | 3 + .../cpp/scheme/CMakeLists.linux-x86_64.txt | 3 + .../cpp/scheme/CMakeLists.windows-x86_64.txt | 3 + .../sighandler/CMakeLists.darwin-arm64.txt | 1 + .../sighandler/CMakeLists.darwin-x86_64.txt | 1 + .../sighandler/CMakeLists.linux-aarch64.txt | 1 + .../sighandler/CMakeLists.linux-x86_64.txt | 1 + .../sighandler/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 1 + .../CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.linux-aarch64.txt | 1 + .../CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../parse_size/CMakeLists.darwin-arm64.txt | 1 + .../parse_size/CMakeLists.darwin-x86_64.txt | 1 + .../parse_size/CMakeLists.linux-aarch64.txt | 1 + .../parse_size/CMakeLists.linux-x86_64.txt | 1 + .../parse_size/CMakeLists.windows-x86_64.txt | 1 + .../quote/CMakeLists.darwin-arm64.txt | 1 + .../quote/CMakeLists.darwin-x86_64.txt | 1 + .../quote/CMakeLists.linux-aarch64.txt | 1 + .../quote/CMakeLists.linux-x86_64.txt | 1 + .../quote/CMakeLists.windows-x86_64.txt | 1 + .../url/CMakeLists.darwin-arm64.txt | 1 + .../url/CMakeLists.darwin-x86_64.txt | 1 + .../url/CMakeLists.linux-aarch64.txt | 1 + .../url/CMakeLists.linux-x86_64.txt | 1 + .../url/CMakeLists.windows-x86_64.txt | 1 + .../cpp/tdigest/CMakeLists.darwin-arm64.txt | 1 + .../cpp/tdigest/CMakeLists.darwin-x86_64.txt | 1 + .../cpp/tdigest/CMakeLists.linux-aarch64.txt | 1 + .../cpp/tdigest/CMakeLists.linux-x86_64.txt | 1 + .../cpp/tdigest/CMakeLists.windows-x86_64.txt | 1 + .../equeue/CMakeLists.darwin-arm64.txt | 1 + .../equeue/CMakeLists.darwin-x86_64.txt | 1 + .../equeue/CMakeLists.linux-aarch64.txt | 1 + .../equeue/CMakeLists.linux-x86_64.txt | 1 + .../equeue/CMakeLists.windows-x86_64.txt | 1 + .../light_rw_lock/CMakeLists.darwin-arm64.txt | 1 + .../CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.linux-aarch64.txt | 1 + .../light_rw_lock/CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../queue/CMakeLists.darwin-arm64.txt | 5 + .../queue/CMakeLists.darwin-x86_64.txt | 5 + .../queue/CMakeLists.linux-aarch64.txt | 5 + .../queue/CMakeLists.linux-x86_64.txt | 5 + .../queue/CMakeLists.windows-x86_64.txt | 5 + library/cpp/tld/CMakeLists.darwin-arm64.txt | 1 + library/cpp/tld/CMakeLists.darwin-x86_64.txt | 1 + library/cpp/tld/CMakeLists.linux-aarch64.txt | 1 + library/cpp/tld/CMakeLists.linux-x86_64.txt | 1 + library/cpp/tld/CMakeLists.windows-x86_64.txt | 1 + .../normalization/CMakeLists.darwin-arm64.txt | 1 + .../CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.linux-aarch64.txt | 1 + .../normalization/CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../proto/CMakeLists.darwin-arm64.txt | 4 + .../proto/CMakeLists.darwin-x86_64.txt | 4 + .../proto/CMakeLists.linux-aarch64.txt | 4 + .../proto/CMakeLists.linux-x86_64.txt | 4 + .../proto/CMakeLists.windows-x86_64.txt | 4 + library/cpp/uri/CMakeLists.darwin-arm64.txt | 1 + library/cpp/uri/CMakeLists.darwin-x86_64.txt | 1 + library/cpp/uri/CMakeLists.linux-aarch64.txt | 1 + library/cpp/uri/CMakeLists.linux-x86_64.txt | 1 + library/cpp/uri/CMakeLists.windows-x86_64.txt | 1 + library/cpp/yt/CMakeLists.darwin-arm64.txt | 24 + library/cpp/yt/CMakeLists.darwin-x86_64.txt | 24 + library/cpp/yt/CMakeLists.linux-aarch64.txt | 26 + library/cpp/yt/CMakeLists.linux-x86_64.txt | 26 + library/cpp/yt/CMakeLists.txt | 29 +- library/cpp/yt/CMakeLists.windows-x86_64.txt | 24 + .../cursors/CMakeLists.darwin-arm64.txt | 2 - .../cursors/CMakeLists.darwin-x86_64.txt | 2 - .../cursors/CMakeLists.windows-x86_64.txt | 3 - .../cursors/frame_pointer/CMakeLists.txt | 6 - .../backtrace/cursors/interop/CMakeLists.txt | 6 - .../cursors/libunwind/CMakeLists.txt | 2 - .../cpp/yt/misc/CMakeLists.darwin-arm64.txt | 1 + .../cpp/yt/misc/CMakeLists.darwin-x86_64.txt | 1 + .../cpp/yt/misc/CMakeLists.linux-aarch64.txt | 1 + .../cpp/yt/misc/CMakeLists.linux-x86_64.txt | 1 + .../cpp/yt/misc/CMakeLists.windows-x86_64.txt | 1 + library/cpp/yt/mlock/CMakeLists.txt | 6 - library/cpp/yt/stockpile/CMakeLists.txt | 6 - .../ytalloc/api/CMakeLists.darwin-arm64.txt | 1 + .../ytalloc/api/CMakeLists.darwin-x86_64.txt | 1 + .../ytalloc/api/CMakeLists.linux-aarch64.txt | 1 + .../ytalloc/api/CMakeLists.linux-x86_64.txt | 1 + .../ytalloc/api/CMakeLists.windows-x86_64.txt | 1 + tools/archiver/CMakeLists.linux-aarch64.txt | 3 - tools/archiver/CMakeLists.linux-x86_64.txt | 3 - .../enum_parser/CMakeLists.linux-aarch64.txt | 3 - .../enum_parser/CMakeLists.linux-x86_64.txt | 3 - .../bin/CMakeLists.linux-aarch64.txt | 3 - .../bin/CMakeLists.linux-x86_64.txt | 3 - util/CMakeLists.windows-x86_64.txt | 3 - util/charset/CMakeLists.windows-x86_64.txt | 2 +- ydb/CMakeLists.txt | 1 + ydb/apps/pgwire/CMakeLists.darwin-arm64.txt | 8 +- ydb/apps/pgwire/CMakeLists.darwin-x86_64.txt | 8 +- ydb/apps/pgwire/CMakeLists.linux-aarch64.txt | 9 +- ydb/apps/pgwire/CMakeLists.linux-x86_64.txt | 9 +- ydb/apps/pgwire/CMakeLists.windows-x86_64.txt | 6 + ydb/apps/ydb/CMakeLists.darwin-arm64.txt | 2 - ydb/apps/ydb/CMakeLists.darwin-x86_64.txt | 2 - ydb/apps/ydb/CMakeLists.linux-aarch64.txt | 3 - ydb/apps/ydb/CMakeLists.linux-x86_64.txt | 3 - ydb/apps/ydb/ut/CMakeLists.linux-aarch64.txt | 4 +- ydb/apps/ydb/ut/CMakeLists.linux-x86_64.txt | 4 +- ydb/apps/ydbd/CMakeLists.darwin-arm64.txt | 3 +- ydb/apps/ydbd/CMakeLists.darwin-x86_64.txt | 3 +- ydb/apps/ydbd/CMakeLists.linux-aarch64.txt | 4 +- ydb/apps/ydbd/CMakeLists.linux-x86_64.txt | 4 +- ydb/apps/ydbd/CMakeLists.windows-x86_64.txt | 1 + ydb/core/CMakeLists.txt | 2 + .../actorlib_impl/CMakeLists.darwin-arm64.txt | 15 + .../CMakeLists.darwin-x86_64.txt | 15 + .../CMakeLists.linux-aarch64.txt | 15 + .../actorlib_impl/CMakeLists.linux-x86_64.txt | 15 + .../CMakeLists.windows-x86_64.txt | 15 + .../ut/CMakeLists.darwin-arm64.txt | 4 +- .../ut/CMakeLists.darwin-x86_64.txt | 4 +- .../ut/CMakeLists.linux-aarch64.txt | 5 +- .../ut/CMakeLists.linux-x86_64.txt | 5 +- .../ut/CMakeLists.windows-x86_64.txt | 2 + ydb/core/audit/CMakeLists.darwin-arm64.txt | 2 + ydb/core/audit/CMakeLists.darwin-x86_64.txt | 2 + ydb/core/audit/CMakeLists.linux-aarch64.txt | 2 + ydb/core/audit/CMakeLists.linux-x86_64.txt | 2 + ydb/core/audit/CMakeLists.windows-x86_64.txt | 2 + ydb/core/base/CMakeLists.darwin-arm64.txt | 38 +- ydb/core/base/CMakeLists.darwin-x86_64.txt | 38 +- ydb/core/base/CMakeLists.linux-aarch64.txt | 38 +- ydb/core/base/CMakeLists.linux-x86_64.txt | 38 +- ydb/core/base/CMakeLists.windows-x86_64.txt | 38 +- .../base/services/CMakeLists.darwin-arm64.txt | 3 + .../services/CMakeLists.darwin-x86_64.txt | 3 + .../services/CMakeLists.linux-aarch64.txt | 3 + .../base/services/CMakeLists.linux-x86_64.txt | 3 + .../services/CMakeLists.windows-x86_64.txt | 3 + ydb/core/base/ut/CMakeLists.darwin-arm64.txt | 3 +- ydb/core/base/ut/CMakeLists.darwin-x86_64.txt | 3 +- ydb/core/base/ut/CMakeLists.linux-aarch64.txt | 4 +- ydb/core/base/ut/CMakeLists.linux-x86_64.txt | 4 +- .../base/ut/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 4 +- .../CMakeLists.darwin-x86_64.txt | 4 +- .../CMakeLists.linux-aarch64.txt | 5 +- .../CMakeLists.linux-x86_64.txt | 5 +- .../CMakeLists.windows-x86_64.txt | 2 + .../blob_depot/CMakeLists.darwin-arm64.txt | 16 + .../blob_depot/CMakeLists.darwin-x86_64.txt | 16 + .../blob_depot/CMakeLists.linux-aarch64.txt | 16 + .../blob_depot/CMakeLists.linux-x86_64.txt | 16 + .../blob_depot/CMakeLists.windows-x86_64.txt | 16 + .../agent/CMakeLists.darwin-arm64.txt | 6 + .../agent/CMakeLists.darwin-x86_64.txt | 6 + .../agent/CMakeLists.linux-aarch64.txt | 6 + .../agent/CMakeLists.linux-x86_64.txt | 6 + .../agent/CMakeLists.windows-x86_64.txt | 6 + .../blob_depot/ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../blob_depot/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../blobstorage/CMakeLists.darwin-arm64.txt | 3 + .../blobstorage/CMakeLists.darwin-x86_64.txt | 3 + .../blobstorage/CMakeLists.linux-aarch64.txt | 3 + .../blobstorage/CMakeLists.linux-x86_64.txt | 3 + .../blobstorage/CMakeLists.windows-x86_64.txt | 3 + .../backpressure/CMakeLists.darwin-arm64.txt | 8 + .../backpressure/CMakeLists.darwin-x86_64.txt | 8 + .../backpressure/CMakeLists.linux-aarch64.txt | 8 + .../backpressure/CMakeLists.linux-x86_64.txt | 8 + .../CMakeLists.windows-x86_64.txt | 8 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../ut_client/CMakeLists.darwin-arm64.txt | 6 +- .../ut_client/CMakeLists.darwin-x86_64.txt | 6 +- .../ut_client/CMakeLists.linux-aarch64.txt | 7 +- .../ut_client/CMakeLists.linux-x86_64.txt | 7 +- .../ut_client/CMakeLists.windows-x86_64.txt | 4 + .../base/CMakeLists.darwin-arm64.txt | 12 + .../base/CMakeLists.darwin-x86_64.txt | 12 + .../base/CMakeLists.linux-aarch64.txt | 12 + .../base/CMakeLists.linux-x86_64.txt | 12 + .../base/CMakeLists.windows-x86_64.txt | 12 + .../base/ut/CMakeLists.darwin-arm64.txt | 3 +- .../base/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../base/ut/CMakeLists.linux-aarch64.txt | 4 +- .../base/ut/CMakeLists.linux-x86_64.txt | 4 +- .../base/ut/CMakeLists.windows-x86_64.txt | 1 + .../crypto/CMakeLists.darwin-arm64.txt | 1 + .../crypto/CMakeLists.darwin-x86_64.txt | 1 + .../crypto/CMakeLists.linux-aarch64.txt | 1 + .../crypto/CMakeLists.linux-x86_64.txt | 1 + .../crypto/CMakeLists.windows-x86_64.txt | 1 + .../crypto/ut/CMakeLists.darwin-arm64.txt | 3 +- .../crypto/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../crypto/ut/CMakeLists.linux-aarch64.txt | 4 +- .../crypto/ut/CMakeLists.linux-x86_64.txt | 4 +- .../crypto/ut/CMakeLists.windows-x86_64.txt | 1 + .../dsproxy/CMakeLists.darwin-arm64.txt | 27 + .../dsproxy/CMakeLists.darwin-x86_64.txt | 27 + .../dsproxy/CMakeLists.linux-aarch64.txt | 27 + .../dsproxy/CMakeLists.linux-x86_64.txt | 27 + .../dsproxy/CMakeLists.windows-x86_64.txt | 27 + .../dsproxy/mock/CMakeLists.darwin-arm64.txt | 2 + .../dsproxy/mock/CMakeLists.darwin-x86_64.txt | 2 + .../dsproxy/mock/CMakeLists.linux-aarch64.txt | 2 + .../dsproxy/mock/CMakeLists.linux-x86_64.txt | 2 + .../mock/CMakeLists.windows-x86_64.txt | 2 + .../dsproxy/ut/CMakeLists.darwin-arm64.txt | 3 +- .../dsproxy/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../dsproxy/ut/CMakeLists.linux-aarch64.txt | 4 +- .../dsproxy/ut/CMakeLists.linux-x86_64.txt | 4 +- .../dsproxy/ut/CMakeLists.windows-x86_64.txt | 1 + .../ut_fat/CMakeLists.darwin-arm64.txt | 3 +- .../ut_fat/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_fat/CMakeLists.linux-aarch64.txt | 4 +- .../ut_fat/CMakeLists.linux-x86_64.txt | 4 +- .../ut_fat/CMakeLists.windows-x86_64.txt | 1 + .../ut_ftol/CMakeLists.darwin-arm64.txt | 3 +- .../ut_ftol/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_ftol/CMakeLists.linux-aarch64.txt | 4 +- .../ut_ftol/CMakeLists.linux-x86_64.txt | 4 +- .../ut_ftol/CMakeLists.windows-x86_64.txt | 1 + .../ut_strategy/CMakeLists.darwin-arm64.txt | 72 + .../ut_strategy/CMakeLists.darwin-x86_64.txt | 73 + .../ut_strategy/CMakeLists.linux-aarch64.txt | 75 + .../ut_strategy/CMakeLists.linux-x86_64.txt | 77 + .../dsproxy/ut_strategy/CMakeLists.txt | 19 + .../ut_strategy/CMakeLists.windows-x86_64.txt | 68 + .../groupinfo/CMakeLists.darwin-arm64.txt | 6 + .../groupinfo/CMakeLists.darwin-x86_64.txt | 6 + .../groupinfo/CMakeLists.linux-aarch64.txt | 6 + .../groupinfo/CMakeLists.linux-x86_64.txt | 6 + .../groupinfo/CMakeLists.windows-x86_64.txt | 6 + .../groupinfo/ut/CMakeLists.darwin-arm64.txt | 3 +- .../groupinfo/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../groupinfo/ut/CMakeLists.linux-aarch64.txt | 4 +- .../groupinfo/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../incrhuge/CMakeLists.darwin-arm64.txt | 15 + .../incrhuge/CMakeLists.darwin-x86_64.txt | 15 + .../incrhuge/CMakeLists.linux-aarch64.txt | 15 + .../incrhuge/CMakeLists.linux-x86_64.txt | 15 + .../incrhuge/CMakeLists.windows-x86_64.txt | 15 + .../incrhuge/ut/CMakeLists.darwin-arm64.txt | 3 +- .../incrhuge/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../incrhuge/ut/CMakeLists.linux-aarch64.txt | 4 +- .../incrhuge/ut/CMakeLists.linux-x86_64.txt | 4 +- .../incrhuge/ut/CMakeLists.windows-x86_64.txt | 1 + .../nodewarden/CMakeLists.darwin-arm64.txt | 6 + .../nodewarden/CMakeLists.darwin-x86_64.txt | 6 + .../nodewarden/CMakeLists.linux-aarch64.txt | 6 + .../nodewarden/CMakeLists.linux-x86_64.txt | 6 + .../nodewarden/CMakeLists.windows-x86_64.txt | 6 + .../nodewarden/ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../nodewarden/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../ut_sequence/CMakeLists.darwin-arm64.txt | 3 +- .../ut_sequence/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_sequence/CMakeLists.linux-aarch64.txt | 4 +- .../ut_sequence/CMakeLists.linux-x86_64.txt | 4 +- .../ut_sequence/CMakeLists.windows-x86_64.txt | 1 + .../other/CMakeLists.darwin-arm64.txt | 4 + .../other/CMakeLists.darwin-x86_64.txt | 4 + .../other/CMakeLists.linux-aarch64.txt | 4 + .../other/CMakeLists.linux-x86_64.txt | 4 + .../other/CMakeLists.windows-x86_64.txt | 4 + .../pdisk/mock/CMakeLists.darwin-arm64.txt | 1 + .../pdisk/mock/CMakeLists.darwin-x86_64.txt | 1 + .../pdisk/mock/CMakeLists.linux-aarch64.txt | 1 + .../pdisk/mock/CMakeLists.linux-x86_64.txt | 1 + .../pdisk/mock/CMakeLists.windows-x86_64.txt | 1 + .../pdisk/ut/CMakeLists.darwin-arm64.txt | 3 +- .../pdisk/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../pdisk/ut/CMakeLists.linux-aarch64.txt | 4 +- .../pdisk/ut/CMakeLists.linux-x86_64.txt | 4 +- .../pdisk/ut/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 + .../CMakeLists.darwin-x86_64.txt | 3 + .../CMakeLists.linux-aarch64.txt | 3 + .../CMakeLists.linux-x86_64.txt | 3 + .../CMakeLists.windows-x86_64.txt | 3 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 + .../CMakeLists.darwin-x86_64.txt | 3 + .../CMakeLists.linux-aarch64.txt | 3 + .../CMakeLists.linux-x86_64.txt | 3 + .../CMakeLists.windows-x86_64.txt | 3 + .../CMakeLists.darwin-arm64.txt | 5 +- .../CMakeLists.darwin-x86_64.txt | 5 +- .../CMakeLists.linux-aarch64.txt | 6 +- .../CMakeLists.linux-x86_64.txt | 6 +- .../CMakeLists.windows-x86_64.txt | 3 + .../lib/CMakeLists.darwin-arm64.txt | 8 + .../lib/CMakeLists.darwin-x86_64.txt | 8 + .../lib/CMakeLists.linux-aarch64.txt | 8 + .../lib/CMakeLists.linux-x86_64.txt | 8 + .../lib/CMakeLists.windows-x86_64.txt | 8 + .../ut_balancing/CMakeLists.darwin-arm64.txt | 72 + .../ut_balancing/CMakeLists.darwin-x86_64.txt | 73 + .../ut_balancing/CMakeLists.linux-aarch64.txt | 75 + .../ut_balancing/CMakeLists.linux-x86_64.txt | 77 + .../ut_balancing/CMakeLists.txt | 19 + .../CMakeLists.windows-x86_64.txt | 68 + .../ut_blob_depot/CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../ut_blob_depot/CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_donor/CMakeLists.darwin-arm64.txt | 3 +- .../ut_donor/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_donor/CMakeLists.linux-aarch64.txt | 4 +- .../ut_donor/CMakeLists.linux-x86_64.txt | 4 +- .../ut_donor/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_osiris/CMakeLists.darwin-arm64.txt | 3 +- .../ut_osiris/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_osiris/CMakeLists.linux-aarch64.txt | 4 +- .../ut_osiris/CMakeLists.linux-x86_64.txt | 4 +- .../ut_osiris/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_scrub/CMakeLists.darwin-arm64.txt | 3 +- .../ut_scrub/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_scrub/CMakeLists.linux-aarch64.txt | 4 +- .../ut_scrub/CMakeLists.linux-x86_64.txt | 4 +- .../ut_scrub/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_group/CMakeLists.darwin-arm64.txt | 3 +- .../ut_group/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_group/CMakeLists.linux-aarch64.txt | 4 +- .../ut_group/CMakeLists.linux-x86_64.txt | 4 +- .../ut_group/CMakeLists.windows-x86_64.txt | 1 + .../ut_mirror3of4/CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../ut_mirror3of4/CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../pdiskfit/CMakeLists.linux-aarch64.txt | 3 - .../pdiskfit/CMakeLists.linux-x86_64.txt | 3 - .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut_testshard/CMakeLists.darwin-arm64.txt | 3 +- .../ut_testshard/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_testshard/CMakeLists.linux-aarch64.txt | 4 +- .../ut_testshard/CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_vdisk/CMakeLists.darwin-arm64.txt | 5 +- .../ut_vdisk/CMakeLists.darwin-x86_64.txt | 5 +- .../ut_vdisk/CMakeLists.linux-aarch64.txt | 6 +- .../ut_vdisk/CMakeLists.linux-x86_64.txt | 6 +- .../ut_vdisk/CMakeLists.windows-x86_64.txt | 3 + .../ut_vdisk/lib/CMakeLists.darwin-arm64.txt | 22 + .../ut_vdisk/lib/CMakeLists.darwin-x86_64.txt | 22 + .../ut_vdisk/lib/CMakeLists.linux-aarch64.txt | 22 + .../ut_vdisk/lib/CMakeLists.linux-x86_64.txt | 22 + .../lib/CMakeLists.windows-x86_64.txt | 22 + .../ut_vdisk2/CMakeLists.darwin-arm64.txt | 5 +- .../ut_vdisk2/CMakeLists.darwin-x86_64.txt | 5 +- .../ut_vdisk2/CMakeLists.linux-aarch64.txt | 6 +- .../ut_vdisk2/CMakeLists.linux-x86_64.txt | 6 +- .../ut_vdisk2/CMakeLists.windows-x86_64.txt | 3 + .../vdisk/CMakeLists.darwin-arm64.txt | 4 + .../vdisk/CMakeLists.darwin-x86_64.txt | 4 + .../vdisk/CMakeLists.linux-aarch64.txt | 4 + .../vdisk/CMakeLists.linux-x86_64.txt | 4 + .../vdisk/CMakeLists.windows-x86_64.txt | 4 + .../anubis_osiris/CMakeLists.darwin-arm64.txt | 1 + .../CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.linux-aarch64.txt | 1 + .../anubis_osiris/CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../vdisk/balance/CMakeLists.darwin-arm64.txt | 23 + .../balance/CMakeLists.darwin-x86_64.txt | 23 + .../balance/CMakeLists.linux-aarch64.txt | 24 + .../vdisk/balance/CMakeLists.linux-x86_64.txt | 24 + .../blobstorage/vdisk/balance/CMakeLists.txt | 19 + .../balance/CMakeLists.windows-x86_64.txt | 23 + .../vdisk/common/CMakeLists.darwin-arm64.txt | 32 + .../vdisk/common/CMakeLists.darwin-x86_64.txt | 32 + .../vdisk/common/CMakeLists.linux-aarch64.txt | 32 + .../vdisk/common/CMakeLists.linux-x86_64.txt | 32 + .../common/CMakeLists.windows-x86_64.txt | 32 + .../common/ut/CMakeLists.darwin-arm64.txt | 3 +- .../common/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../common/ut/CMakeLists.linux-aarch64.txt | 4 +- .../common/ut/CMakeLists.linux-x86_64.txt | 4 +- .../common/ut/CMakeLists.windows-x86_64.txt | 1 + .../vdisk/defrag/CMakeLists.darwin-arm64.txt | 5 + .../vdisk/defrag/CMakeLists.darwin-x86_64.txt | 5 + .../vdisk/defrag/CMakeLists.linux-aarch64.txt | 5 + .../vdisk/defrag/CMakeLists.linux-x86_64.txt | 5 + .../defrag/CMakeLists.windows-x86_64.txt | 5 + .../defrag/ut/CMakeLists.darwin-arm64.txt | 3 +- .../defrag/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../defrag/ut/CMakeLists.linux-aarch64.txt | 4 +- .../defrag/ut/CMakeLists.linux-x86_64.txt | 4 +- .../defrag/ut/CMakeLists.windows-x86_64.txt | 1 + .../vdisk/handoff/CMakeLists.darwin-arm64.txt | 7 + .../handoff/CMakeLists.darwin-x86_64.txt | 7 + .../handoff/CMakeLists.linux-aarch64.txt | 7 + .../vdisk/handoff/CMakeLists.linux-x86_64.txt | 7 + .../handoff/CMakeLists.windows-x86_64.txt | 7 + .../vdisk/huge/CMakeLists.darwin-arm64.txt | 6 + .../vdisk/huge/CMakeLists.darwin-x86_64.txt | 6 + .../vdisk/huge/CMakeLists.linux-aarch64.txt | 6 + .../vdisk/huge/CMakeLists.linux-x86_64.txt | 6 + .../vdisk/huge/CMakeLists.windows-x86_64.txt | 6 + .../vdisk/huge/ut/CMakeLists.darwin-arm64.txt | 3 +- .../huge/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../huge/ut/CMakeLists.linux-aarch64.txt | 4 +- .../vdisk/huge/ut/CMakeLists.linux-x86_64.txt | 4 +- .../huge/ut/CMakeLists.windows-x86_64.txt | 1 + .../vdisk/hulldb/CMakeLists.darwin-arm64.txt | 5 + .../vdisk/hulldb/CMakeLists.darwin-x86_64.txt | 5 + .../vdisk/hulldb/CMakeLists.linux-aarch64.txt | 5 + .../vdisk/hulldb/CMakeLists.linux-x86_64.txt | 5 + .../hulldb/CMakeLists.windows-x86_64.txt | 5 + .../barriers/CMakeLists.darwin-arm64.txt | 7 + .../barriers/CMakeLists.darwin-x86_64.txt | 7 + .../barriers/CMakeLists.linux-aarch64.txt | 7 + .../barriers/CMakeLists.linux-x86_64.txt | 7 + .../barriers/CMakeLists.windows-x86_64.txt | 7 + .../barriers/ut/CMakeLists.darwin-arm64.txt | 3 +- .../barriers/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../barriers/ut/CMakeLists.linux-aarch64.txt | 4 +- .../barriers/ut/CMakeLists.linux-x86_64.txt | 4 +- .../barriers/ut/CMakeLists.windows-x86_64.txt | 1 + .../hulldb/base/CMakeLists.darwin-arm64.txt | 12 + .../hulldb/base/CMakeLists.darwin-x86_64.txt | 12 + .../hulldb/base/CMakeLists.linux-aarch64.txt | 12 + .../hulldb/base/CMakeLists.linux-x86_64.txt | 12 + .../hulldb/base/CMakeLists.windows-x86_64.txt | 12 + .../base/ut/CMakeLists.darwin-arm64.txt | 3 +- .../base/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../base/ut/CMakeLists.linux-aarch64.txt | 4 +- .../base/ut/CMakeLists.linux-x86_64.txt | 4 +- .../base/ut/CMakeLists.windows-x86_64.txt | 1 + .../bulksst_add/CMakeLists.darwin-arm64.txt | 1 + .../bulksst_add/CMakeLists.darwin-x86_64.txt | 1 + .../bulksst_add/CMakeLists.linux-aarch64.txt | 1 + .../bulksst_add/CMakeLists.linux-x86_64.txt | 1 + .../bulksst_add/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../compstrat/CMakeLists.darwin-arm64.txt | 11 + .../compstrat/CMakeLists.darwin-x86_64.txt | 11 + .../compstrat/CMakeLists.linux-aarch64.txt | 11 + .../compstrat/CMakeLists.linux-x86_64.txt | 11 + .../compstrat/CMakeLists.windows-x86_64.txt | 11 + .../compstrat/ut/CMakeLists.darwin-arm64.txt | 3 +- .../compstrat/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../compstrat/ut/CMakeLists.linux-aarch64.txt | 4 +- .../compstrat/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../hulldb/fresh/CMakeLists.darwin-arm64.txt | 7 + .../hulldb/fresh/CMakeLists.darwin-x86_64.txt | 7 + .../hulldb/fresh/CMakeLists.linux-aarch64.txt | 7 + .../hulldb/fresh/CMakeLists.linux-x86_64.txt | 7 + .../fresh/CMakeLists.windows-x86_64.txt | 7 + .../fresh/ut/CMakeLists.darwin-arm64.txt | 3 +- .../fresh/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../fresh/ut/CMakeLists.linux-aarch64.txt | 4 +- .../fresh/ut/CMakeLists.linux-x86_64.txt | 4 +- .../fresh/ut/CMakeLists.windows-x86_64.txt | 1 + .../generic/CMakeLists.darwin-arm64.txt | 18 + .../generic/CMakeLists.darwin-x86_64.txt | 18 + .../generic/CMakeLists.linux-aarch64.txt | 18 + .../generic/CMakeLists.linux-x86_64.txt | 18 + .../generic/CMakeLists.windows-x86_64.txt | 18 + .../generic/ut/CMakeLists.darwin-arm64.txt | 3 +- .../generic/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../generic/ut/CMakeLists.linux-aarch64.txt | 4 +- .../generic/ut/CMakeLists.linux-x86_64.txt | 4 +- .../generic/ut/CMakeLists.windows-x86_64.txt | 1 + .../recovery/CMakeLists.darwin-arm64.txt | 1 + .../recovery/CMakeLists.darwin-x86_64.txt | 1 + .../recovery/CMakeLists.linux-aarch64.txt | 1 + .../recovery/CMakeLists.linux-x86_64.txt | 1 + .../recovery/CMakeLists.windows-x86_64.txt | 1 + .../hulldb/test/CMakeLists.darwin-arm64.txt | 2 + .../hulldb/test/CMakeLists.darwin-x86_64.txt | 2 + .../hulldb/test/CMakeLists.linux-aarch64.txt | 2 + .../hulldb/test/CMakeLists.linux-x86_64.txt | 2 + .../hulldb/test/CMakeLists.windows-x86_64.txt | 2 + .../vdisk/hullop/CMakeLists.darwin-arm64.txt | 15 + .../vdisk/hullop/CMakeLists.darwin-x86_64.txt | 15 + .../vdisk/hullop/CMakeLists.linux-aarch64.txt | 15 + .../vdisk/hullop/CMakeLists.linux-x86_64.txt | 15 + .../hullop/CMakeLists.windows-x86_64.txt | 15 + .../CMakeLists.darwin-arm64.txt | 1 + .../CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.linux-aarch64.txt | 1 + .../CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../hullop/ut/CMakeLists.darwin-arm64.txt | 3 +- .../hullop/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../hullop/ut/CMakeLists.linux-aarch64.txt | 4 +- .../hullop/ut/CMakeLists.linux-x86_64.txt | 4 +- .../hullop/ut/CMakeLists.windows-x86_64.txt | 1 + .../vdisk/ingress/CMakeLists.darwin-arm64.txt | 3 + .../ingress/CMakeLists.darwin-x86_64.txt | 3 + .../ingress/CMakeLists.linux-aarch64.txt | 3 + .../vdisk/ingress/CMakeLists.linux-x86_64.txt | 3 + .../ingress/CMakeLists.windows-x86_64.txt | 3 + .../ingress/ut/CMakeLists.darwin-arm64.txt | 3 +- .../ingress/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ingress/ut/CMakeLists.linux-aarch64.txt | 4 +- .../ingress/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ingress/ut/CMakeLists.windows-x86_64.txt | 1 + .../localrecovery/CMakeLists.darwin-arm64.txt | 5 + .../CMakeLists.darwin-x86_64.txt | 5 + .../CMakeLists.linux-aarch64.txt | 5 + .../localrecovery/CMakeLists.linux-x86_64.txt | 5 + .../CMakeLists.windows-x86_64.txt | 5 + .../vdisk/protos/CMakeLists.darwin-arm64.txt | 3 + .../vdisk/protos/CMakeLists.darwin-x86_64.txt | 3 + .../vdisk/protos/CMakeLists.linux-aarch64.txt | 3 + .../vdisk/protos/CMakeLists.linux-x86_64.txt | 3 + .../protos/CMakeLists.windows-x86_64.txt | 3 + .../vdisk/query/CMakeLists.darwin-arm64.txt | 13 + .../vdisk/query/CMakeLists.darwin-x86_64.txt | 13 + .../vdisk/query/CMakeLists.linux-aarch64.txt | 13 + .../vdisk/query/CMakeLists.linux-x86_64.txt | 13 + .../vdisk/query/CMakeLists.windows-x86_64.txt | 13 + .../query/ut/CMakeLists.darwin-arm64.txt | 3 +- .../query/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../query/ut/CMakeLists.linux-aarch64.txt | 4 +- .../query/ut/CMakeLists.linux-x86_64.txt | 4 +- .../query/ut/CMakeLists.windows-x86_64.txt | 1 + .../vdisk/repl/CMakeLists.darwin-arm64.txt | 10 + .../vdisk/repl/CMakeLists.darwin-x86_64.txt | 10 + .../vdisk/repl/CMakeLists.linux-aarch64.txt | 10 + .../vdisk/repl/CMakeLists.linux-x86_64.txt | 10 + .../vdisk/repl/CMakeLists.windows-x86_64.txt | 10 + .../vdisk/repl/ut/CMakeLists.darwin-arm64.txt | 3 +- .../repl/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../repl/ut/CMakeLists.linux-aarch64.txt | 4 +- .../vdisk/repl/ut/CMakeLists.linux-x86_64.txt | 4 +- .../repl/ut/CMakeLists.windows-x86_64.txt | 1 + .../vdisk/scrub/CMakeLists.darwin-arm64.txt | 7 + .../vdisk/scrub/CMakeLists.darwin-x86_64.txt | 7 + .../vdisk/scrub/CMakeLists.linux-aarch64.txt | 7 + .../vdisk/scrub/CMakeLists.linux-x86_64.txt | 7 + .../vdisk/scrub/CMakeLists.windows-x86_64.txt | 7 + .../skeleton/CMakeLists.darwin-arm64.txt | 23 + .../skeleton/CMakeLists.darwin-x86_64.txt | 23 + .../skeleton/CMakeLists.linux-aarch64.txt | 23 + .../skeleton/CMakeLists.linux-x86_64.txt | 23 + .../skeleton/CMakeLists.windows-x86_64.txt | 23 + .../skeleton/ut/CMakeLists.darwin-arm64.txt | 3 +- .../skeleton/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../skeleton/ut/CMakeLists.linux-aarch64.txt | 4 +- .../skeleton/ut/CMakeLists.linux-x86_64.txt | 4 +- .../skeleton/ut/CMakeLists.windows-x86_64.txt | 1 + .../vdisk/syncer/CMakeLists.darwin-arm64.txt | 19 + .../vdisk/syncer/CMakeLists.darwin-x86_64.txt | 19 + .../vdisk/syncer/CMakeLists.linux-aarch64.txt | 19 + .../vdisk/syncer/CMakeLists.linux-x86_64.txt | 19 + .../syncer/CMakeLists.windows-x86_64.txt | 19 + .../syncer/ut/CMakeLists.darwin-arm64.txt | 3 +- .../syncer/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../syncer/ut/CMakeLists.linux-aarch64.txt | 4 +- .../syncer/ut/CMakeLists.linux-x86_64.txt | 4 +- .../syncer/ut/CMakeLists.windows-x86_64.txt | 1 + .../vdisk/synclog/CMakeLists.darwin-arm64.txt | 20 + .../synclog/CMakeLists.darwin-x86_64.txt | 20 + .../synclog/CMakeLists.linux-aarch64.txt | 20 + .../vdisk/synclog/CMakeLists.linux-x86_64.txt | 20 + .../synclog/CMakeLists.windows-x86_64.txt | 20 + .../synclog/ut/CMakeLists.darwin-arm64.txt | 3 +- .../synclog/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../synclog/ut/CMakeLists.linux-aarch64.txt | 4 +- .../synclog/ut/CMakeLists.linux-x86_64.txt | 4 +- .../synclog/ut/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 40 + .../CMakeLists.darwin-x86_64.txt | 40 + .../CMakeLists.linux-aarch64.txt | 41 + .../CMakeLists.linux-x86_64.txt | 41 + ydb/core/change_exchange/CMakeLists.txt | 19 + .../CMakeLists.windows-x86_64.txt | 40 + .../metadata/CMakeLists.darwin-arm64.txt | 2 +- .../metadata/CMakeLists.darwin-x86_64.txt | 2 +- .../metadata/CMakeLists.linux-aarch64.txt | 2 +- .../metadata/CMakeLists.linux-x86_64.txt | 2 +- .../metadata/CMakeLists.windows-x86_64.txt | 2 +- .../metadata/ut/CMakeLists.darwin-arm64.txt | 4 +- .../metadata/ut/CMakeLists.darwin-x86_64.txt | 4 +- .../metadata/ut/CMakeLists.linux-aarch64.txt | 5 +- .../metadata/ut/CMakeLists.linux-x86_64.txt | 5 +- .../metadata/ut/CMakeLists.windows-x86_64.txt | 2 + .../CMakeLists.darwin-arm64.txt | 4 + .../CMakeLists.darwin-x86_64.txt | 4 + .../CMakeLists.linux-aarch64.txt | 4 + .../CMakeLists.linux-x86_64.txt | 4 + .../CMakeLists.windows-x86_64.txt | 4 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 2 + .../CMakeLists.darwin-x86_64.txt | 2 + .../CMakeLists.linux-aarch64.txt | 2 + .../CMakeLists.linux-x86_64.txt | 2 + .../CMakeLists.windows-x86_64.txt | 2 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 1 + .../CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.linux-aarch64.txt | 1 + .../CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../client/server/CMakeLists.darwin-arm64.txt | 13 + .../server/CMakeLists.darwin-x86_64.txt | 13 + .../server/CMakeLists.linux-aarch64.txt | 13 + .../client/server/CMakeLists.linux-x86_64.txt | 13 + .../server/CMakeLists.windows-x86_64.txt | 13 + .../server/ut/CMakeLists.darwin-arm64.txt | 3 +- .../server/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../server/ut/CMakeLists.linux-aarch64.txt | 4 +- .../server/ut/CMakeLists.linux-x86_64.txt | 4 +- .../server/ut/CMakeLists.windows-x86_64.txt | 1 + .../client/ut/CMakeLists.darwin-arm64.txt | 3 +- .../client/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../client/ut/CMakeLists.linux-aarch64.txt | 4 +- .../client/ut/CMakeLists.linux-x86_64.txt | 4 +- .../client/ut/CMakeLists.windows-x86_64.txt | 1 + ydb/core/cms/CMakeLists.darwin-arm64.txt | 26 + ydb/core/cms/CMakeLists.darwin-x86_64.txt | 26 + ydb/core/cms/CMakeLists.linux-aarch64.txt | 26 + ydb/core/cms/CMakeLists.linux-x86_64.txt | 26 + ydb/core/cms/CMakeLists.windows-x86_64.txt | 26 + .../cms/console/CMakeLists.darwin-arm64.txt | 20 + .../cms/console/CMakeLists.darwin-x86_64.txt | 20 + .../cms/console/CMakeLists.linux-aarch64.txt | 20 + .../cms/console/CMakeLists.linux-x86_64.txt | 20 + .../cms/console/CMakeLists.windows-x86_64.txt | 20 + .../console/ut/CMakeLists.darwin-arm64.txt | 3 +- .../console/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../console/ut/CMakeLists.linux-aarch64.txt | 4 +- .../console/ut/CMakeLists.linux-x86_64.txt | 4 +- .../console/ut/CMakeLists.windows-x86_64.txt | 1 + .../console/util/CMakeLists.darwin-arm64.txt | 2 + .../console/util/CMakeLists.darwin-x86_64.txt | 2 + .../console/util/CMakeLists.linux-aarch64.txt | 2 + .../console/util/CMakeLists.linux-x86_64.txt | 2 + .../util/CMakeLists.windows-x86_64.txt | 2 + .../validators/CMakeLists.darwin-arm64.txt | 5 + .../validators/CMakeLists.darwin-x86_64.txt | 5 + .../validators/CMakeLists.linux-aarch64.txt | 5 + .../validators/CMakeLists.linux-x86_64.txt | 5 + .../validators/CMakeLists.windows-x86_64.txt | 5 + .../validators/ut/CMakeLists.darwin-arm64.txt | 4 +- .../ut/CMakeLists.darwin-x86_64.txt | 4 +- .../ut/CMakeLists.linux-aarch64.txt | 5 +- .../validators/ut/CMakeLists.linux-x86_64.txt | 5 +- .../ut/CMakeLists.windows-x86_64.txt | 2 + ydb/core/cms/ut/CMakeLists.darwin-arm64.txt | 4 +- ydb/core/cms/ut/CMakeLists.darwin-x86_64.txt | 4 +- ydb/core/cms/ut/CMakeLists.linux-aarch64.txt | 5 +- ydb/core/cms/ut/CMakeLists.linux-x86_64.txt | 5 +- ydb/core/cms/ut/CMakeLists.windows-x86_64.txt | 2 + .../ut_sentinel/CMakeLists.darwin-arm64.txt | 4 +- .../ut_sentinel/CMakeLists.darwin-x86_64.txt | 4 +- .../ut_sentinel/CMakeLists.linux-aarch64.txt | 5 +- .../ut_sentinel/CMakeLists.linux-x86_64.txt | 5 +- .../ut_sentinel/CMakeLists.windows-x86_64.txt | 2 + ydb/core/control/CMakeLists.darwin-arm64.txt | 8 + ydb/core/control/CMakeLists.darwin-x86_64.txt | 8 + ydb/core/control/CMakeLists.linux-aarch64.txt | 8 + ydb/core/control/CMakeLists.linux-x86_64.txt | 8 + .../control/CMakeLists.windows-x86_64.txt | 8 + .../CMakeLists.darwin-arm64.txt | 20 + .../CMakeLists.darwin-x86_64.txt | 20 + .../CMakeLists.linux-aarch64.txt | 21 + .../CMakeLists.linux-x86_64.txt | 21 + .../control/common_controls/CMakeLists.txt | 19 + .../CMakeLists.windows-x86_64.txt | 20 + .../control/ut/CMakeLists.darwin-arm64.txt | 5 +- .../control/ut/CMakeLists.darwin-x86_64.txt | 5 +- .../control/ut/CMakeLists.linux-aarch64.txt | 6 +- .../control/ut/CMakeLists.linux-x86_64.txt | 6 +- .../control/ut/CMakeLists.windows-x86_64.txt | 3 + ydb/core/debug/CMakeLists.darwin-arm64.txt | 1 + ydb/core/debug/CMakeLists.darwin-x86_64.txt | 1 + ydb/core/debug/CMakeLists.linux-aarch64.txt | 1 + ydb/core/debug/CMakeLists.linux-x86_64.txt | 1 + ydb/core/debug/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 1 + .../ut/CMakeLists.darwin-x86_64.txt | 1 + .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../base_utils/CMakeLists.darwin-arm64.txt | 4 + .../base_utils/CMakeLists.darwin-x86_64.txt | 4 + .../base_utils/CMakeLists.linux-aarch64.txt | 4 + .../base_utils/CMakeLists.linux-x86_64.txt | 4 + .../base_utils/CMakeLists.windows-x86_64.txt | 4 + .../CMakeLists.darwin-arm64.txt | 1 + .../CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.linux-aarch64.txt | 1 + .../CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../cli_utils/CMakeLists.darwin-arm64.txt | 3 + .../cli_utils/CMakeLists.darwin-x86_64.txt | 3 + .../cli_utils/CMakeLists.linux-aarch64.txt | 3 + .../cli_utils/CMakeLists.linux-x86_64.txt | 3 + .../cli_utils/CMakeLists.windows-x86_64.txt | 3 + .../run/CMakeLists.darwin-arm64.txt | 14 +- .../run/CMakeLists.darwin-x86_64.txt | 14 +- .../run/CMakeLists.linux-aarch64.txt | 14 +- .../run/CMakeLists.linux-x86_64.txt | 14 +- .../run/CMakeLists.windows-x86_64.txt | 14 +- .../run/ut/CMakeLists.darwin-arm64.txt | 3 +- .../run/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../run/ut/CMakeLists.linux-aarch64.txt | 4 +- .../run/ut/CMakeLists.linux-x86_64.txt | 4 +- .../run/ut/CMakeLists.windows-x86_64.txt | 1 + .../version/CMakeLists.darwin-arm64.txt | 1 + .../version/CMakeLists.darwin-x86_64.txt | 1 + .../version/CMakeLists.linux-aarch64.txt | 1 + .../version/CMakeLists.linux-x86_64.txt | 1 + .../version/CMakeLists.windows-x86_64.txt | 1 + .../version/ut/CMakeLists.darwin-arm64.txt | 3 +- .../version/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../version/ut/CMakeLists.linux-aarch64.txt | 4 +- .../version/ut/CMakeLists.linux-x86_64.txt | 4 +- .../version/ut/CMakeLists.windows-x86_64.txt | 1 + ydb/core/engine/CMakeLists.darwin-arm64.txt | 3 +- ydb/core/engine/CMakeLists.darwin-x86_64.txt | 3 +- ydb/core/engine/CMakeLists.linux-aarch64.txt | 3 +- ydb/core/engine/CMakeLists.linux-x86_64.txt | 3 +- ydb/core/engine/CMakeLists.windows-x86_64.txt | 3 +- .../minikql/CMakeLists.darwin-arm64.txt | 2 + .../minikql/CMakeLists.darwin-x86_64.txt | 2 + .../minikql/CMakeLists.linux-aarch64.txt | 2 + .../minikql/CMakeLists.linux-x86_64.txt | 2 + .../minikql/CMakeLists.windows-x86_64.txt | 2 + .../engine/ut/CMakeLists.darwin-arm64.txt | 3 +- .../engine/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../engine/ut/CMakeLists.linux-aarch64.txt | 4 +- .../engine/ut/CMakeLists.linux-x86_64.txt | 4 +- .../engine/ut/CMakeLists.windows-x86_64.txt | 1 + ydb/core/erasure/CMakeLists.darwin-arm64.txt | 2 + ydb/core/erasure/CMakeLists.darwin-x86_64.txt | 2 + ydb/core/erasure/CMakeLists.linux-aarch64.txt | 2 + ydb/core/erasure/CMakeLists.linux-x86_64.txt | 2 + .../erasure/CMakeLists.windows-x86_64.txt | 2 + .../erasure/ut/CMakeLists.darwin-arm64.txt | 3 +- .../erasure/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../erasure/ut/CMakeLists.linux-aarch64.txt | 4 +- .../erasure/ut/CMakeLists.linux-x86_64.txt | 4 +- .../erasure/ut/CMakeLists.windows-x86_64.txt | 1 + .../ut_perf/CMakeLists.darwin-arm64.txt | 3 +- .../ut_perf/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_perf/CMakeLists.linux-aarch64.txt | 4 +- .../ut_perf/CMakeLists.linux-x86_64.txt | 4 +- .../ut_perf/CMakeLists.windows-x86_64.txt | 1 + .../ut_rope/CMakeLists.darwin-arm64.txt | 3 +- .../ut_rope/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_rope/CMakeLists.linux-aarch64.txt | 4 +- .../ut_rope/CMakeLists.linux-x86_64.txt | 4 +- .../ut_rope/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + ydb/core/formats/CMakeLists.darwin-arm64.txt | 2 + ydb/core/formats/CMakeLists.darwin-x86_64.txt | 2 + ydb/core/formats/CMakeLists.linux-aarch64.txt | 2 + ydb/core/formats/CMakeLists.linux-x86_64.txt | 2 + .../formats/CMakeLists.windows-x86_64.txt | 2 + .../formats/arrow/CMakeLists.darwin-arm64.txt | 6 + .../arrow/CMakeLists.darwin-x86_64.txt | 6 + .../arrow/CMakeLists.linux-aarch64.txt | 6 + .../formats/arrow/CMakeLists.linux-x86_64.txt | 6 + .../arrow/CMakeLists.windows-x86_64.txt | 6 + .../arrow/ut/CMakeLists.darwin-arm64.txt | 4 +- .../arrow/ut/CMakeLists.darwin-x86_64.txt | 4 +- .../arrow/ut/CMakeLists.linux-aarch64.txt | 5 +- .../arrow/ut/CMakeLists.linux-x86_64.txt | 5 +- .../arrow/ut/CMakeLists.windows-x86_64.txt | 2 + .../libs/actors/CMakeLists.darwin-arm64.txt | 2 +- .../libs/actors/CMakeLists.darwin-x86_64.txt | 2 +- .../libs/actors/CMakeLists.linux-aarch64.txt | 2 +- .../libs/actors/CMakeLists.linux-x86_64.txt | 2 +- .../libs/actors/CMakeLists.windows-x86_64.txt | 2 +- .../logging/CMakeLists.darwin-arm64.txt | 3 + .../logging/CMakeLists.darwin-x86_64.txt | 3 + .../logging/CMakeLists.linux-aarch64.txt | 3 + .../logging/CMakeLists.linux-x86_64.txt | 3 + .../logging/CMakeLists.windows-x86_64.txt | 3 + .../actors/ut/CMakeLists.darwin-arm64.txt | 3 +- .../actors/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../actors/ut/CMakeLists.linux-aarch64.txt | 4 +- .../actors/ut/CMakeLists.linux-x86_64.txt | 4 +- .../actors/ut/CMakeLists.windows-x86_64.txt | 1 + .../proto/CMakeLists.darwin-arm64.txt | 3 + .../proto/CMakeLists.darwin-x86_64.txt | 3 + .../proto/CMakeLists.linux-aarch64.txt | 3 + .../proto/CMakeLists.linux-x86_64.txt | 3 + .../proto/CMakeLists.windows-x86_64.txt | 3 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../checkpointing/CMakeLists.darwin-arm64.txt | 4 + .../CMakeLists.darwin-x86_64.txt | 4 + .../CMakeLists.linux-aarch64.txt | 4 + .../checkpointing/CMakeLists.linux-x86_64.txt | 4 + .../CMakeLists.windows-x86_64.txt | 4 + .../ut/CMakeLists.darwin-arm64.txt | 4 +- .../ut/CMakeLists.darwin-x86_64.txt | 4 +- .../ut/CMakeLists.linux-aarch64.txt | 5 +- .../ut/CMakeLists.linux-x86_64.txt | 5 +- .../ut/CMakeLists.windows-x86_64.txt | 2 + .../libs/common/CMakeLists.darwin-arm64.txt | 4 + .../libs/common/CMakeLists.darwin-x86_64.txt | 4 + .../libs/common/CMakeLists.linux-aarch64.txt | 4 + .../libs/common/CMakeLists.linux-x86_64.txt | 4 + .../libs/common/CMakeLists.windows-x86_64.txt | 4 + .../common/ut/CMakeLists.darwin-arm64.txt | 3 +- .../common/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../common/ut/CMakeLists.linux-aarch64.txt | 4 +- .../common/ut/CMakeLists.linux-x86_64.txt | 4 +- .../common/ut/CMakeLists.windows-x86_64.txt | 1 + .../common/ut/CMakeLists.darwin-arm64.txt | 3 +- .../common/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../common/ut/CMakeLists.linux-aarch64.txt | 4 +- .../common/ut/CMakeLists.linux-x86_64.txt | 4 +- .../common/ut/CMakeLists.windows-x86_64.txt | 1 + .../control_plane/CMakeLists.darwin-arm64.txt | 2 + .../CMakeLists.darwin-x86_64.txt | 2 + .../CMakeLists.linux-aarch64.txt | 2 + .../control_plane/CMakeLists.linux-x86_64.txt | 2 + .../CMakeLists.windows-x86_64.txt | 2 + .../config/protos/CMakeLists.darwin-arm64.txt | 26 + .../protos/CMakeLists.darwin-x86_64.txt | 26 + .../protos/CMakeLists.linux-aarch64.txt | 26 + .../config/protos/CMakeLists.linux-x86_64.txt | 26 + .../protos/CMakeLists.windows-x86_64.txt | 26 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../internal/CMakeLists.darwin-arm64.txt | 2 + .../internal/CMakeLists.darwin-x86_64.txt | 2 + .../internal/CMakeLists.linux-aarch64.txt | 2 + .../internal/CMakeLists.linux-x86_64.txt | 2 + .../internal/CMakeLists.windows-x86_64.txt | 2 + .../internal/ut/CMakeLists.darwin-arm64.txt | 96 + .../internal/ut/CMakeLists.darwin-x86_64.txt | 97 + .../internal/ut/CMakeLists.linux-aarch64.txt | 99 + .../internal/ut/CMakeLists.linux-x86_64.txt | 101 + .../internal/ut/CMakeLists.txt | 19 + .../internal/ut/CMakeLists.windows-x86_64.txt | 92 + .../proto/CMakeLists.darwin-arm64.txt | 3 + .../proto/CMakeLists.darwin-x86_64.txt | 3 + .../proto/CMakeLists.linux-aarch64.txt | 3 + .../proto/CMakeLists.linux-x86_64.txt | 3 + .../proto/CMakeLists.windows-x86_64.txt | 3 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../proto/CMakeLists.darwin-arm64.txt | 3 + .../proto/CMakeLists.darwin-x86_64.txt | 3 + .../proto/CMakeLists.linux-aarch64.txt | 3 + .../proto/CMakeLists.linux-x86_64.txt | 3 + .../proto/CMakeLists.windows-x86_64.txt | 3 + .../fq/libs/grpc/CMakeLists.darwin-arm64.txt | 4 + .../fq/libs/grpc/CMakeLists.darwin-x86_64.txt | 4 + .../fq/libs/grpc/CMakeLists.linux-aarch64.txt | 4 + .../fq/libs/grpc/CMakeLists.linux-x86_64.txt | 4 + .../libs/grpc/CMakeLists.windows-x86_64.txt | 4 + .../libs/hmac/ut/CMakeLists.darwin-arm64.txt | 1 + .../libs/hmac/ut/CMakeLists.darwin-x86_64.txt | 1 + .../libs/hmac/ut/CMakeLists.linux-aarch64.txt | 4 +- .../libs/hmac/ut/CMakeLists.linux-x86_64.txt | 4 +- .../hmac/ut/CMakeLists.windows-x86_64.txt | 1 + .../fq/libs/init/CMakeLists.darwin-arm64.txt | 2 +- .../fq/libs/init/CMakeLists.darwin-x86_64.txt | 2 +- .../fq/libs/init/CMakeLists.linux-aarch64.txt | 2 +- .../fq/libs/init/CMakeLists.linux-x86_64.txt | 2 +- .../libs/init/CMakeLists.windows-x86_64.txt | 2 +- .../fq/libs/mock/CMakeLists.darwin-arm64.txt | 2 +- .../fq/libs/mock/CMakeLists.darwin-x86_64.txt | 2 +- .../fq/libs/mock/CMakeLists.linux-aarch64.txt | 2 +- .../fq/libs/mock/CMakeLists.linux-x86_64.txt | 2 +- .../libs/mock/CMakeLists.windows-x86_64.txt | 2 +- .../libs/protos/CMakeLists.darwin-arm64.txt | 4 + .../libs/protos/CMakeLists.darwin-x86_64.txt | 4 + .../libs/protos/CMakeLists.linux-aarch64.txt | 4 + .../libs/protos/CMakeLists.linux-x86_64.txt | 4 + .../libs/protos/CMakeLists.windows-x86_64.txt | 4 + .../proto/CMakeLists.darwin-arm64.txt | 3 + .../proto/CMakeLists.darwin-x86_64.txt | 3 + .../proto/CMakeLists.linux-aarch64.txt | 3 + .../proto/CMakeLists.linux-x86_64.txt | 3 + .../proto/CMakeLists.windows-x86_64.txt | 3 + .../CMakeLists.darwin-arm64.txt | 2 +- .../CMakeLists.darwin-x86_64.txt | 2 +- .../CMakeLists.linux-aarch64.txt | 2 +- .../CMakeLists.linux-x86_64.txt | 2 +- .../CMakeLists.windows-x86_64.txt | 2 +- .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 1 + .../CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.linux-aarch64.txt | 1 + .../CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../signer/ut/CMakeLists.darwin-arm64.txt | 1 + .../signer/ut/CMakeLists.darwin-x86_64.txt | 1 + .../signer/ut/CMakeLists.linux-aarch64.txt | 4 +- .../signer/ut/CMakeLists.linux-x86_64.txt | 4 +- .../signer/ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + ydb/core/graph/CMakeLists.txt | 13 + .../graph/api/CMakeLists.darwin-arm64.txt | 20 + .../graph/api/CMakeLists.darwin-x86_64.txt | 20 + .../graph/api/CMakeLists.linux-aarch64.txt | 21 + .../graph/api/CMakeLists.linux-x86_64.txt | 21 + ydb/core/graph/api/CMakeLists.txt | 19 + .../graph/api/CMakeLists.windows-x86_64.txt | 20 + .../graph/protos/CMakeLists.darwin-arm64.txt | 46 + .../graph/protos/CMakeLists.darwin-x86_64.txt | 46 + .../graph/protos/CMakeLists.linux-aarch64.txt | 47 + .../graph/protos/CMakeLists.linux-x86_64.txt | 47 + ydb/core/graph/protos/CMakeLists.txt | 19 + .../protos/CMakeLists.windows-x86_64.txt | 46 + .../graph/service/CMakeLists.darwin-arm64.txt | 20 + .../service/CMakeLists.darwin-x86_64.txt | 20 + .../service/CMakeLists.linux-aarch64.txt | 21 + .../graph/service/CMakeLists.linux-x86_64.txt | 21 + ydb/core/graph/service/CMakeLists.txt | 19 + .../service/CMakeLists.windows-x86_64.txt | 20 + .../graph/shard/CMakeLists.darwin-arm64.txt | 37 + .../graph/shard/CMakeLists.darwin-x86_64.txt | 37 + .../graph/shard/CMakeLists.linux-aarch64.txt | 38 + .../graph/shard/CMakeLists.linux-x86_64.txt | 38 + ydb/core/graph/shard/CMakeLists.txt | 19 + .../graph/shard/CMakeLists.windows-x86_64.txt | 37 + .../shard/protos/CMakeLists.darwin-arm64.txt | 47 + .../shard/protos/CMakeLists.darwin-x86_64.txt | 47 + .../shard/protos/CMakeLists.linux-aarch64.txt | 48 + .../shard/protos/CMakeLists.linux-x86_64.txt | 48 + ydb/core/graph/shard/protos/CMakeLists.txt | 19 + .../protos/CMakeLists.windows-x86_64.txt | 47 + .../shard/ut/CMakeLists.darwin-arm64.txt | 71 + .../shard/ut/CMakeLists.darwin-x86_64.txt | 72 + .../shard/ut/CMakeLists.linux-aarch64.txt | 74 + .../shard/ut/CMakeLists.linux-x86_64.txt | 76 + ydb/core/graph/shard/ut/CMakeLists.txt | 19 + .../shard/ut/CMakeLists.windows-x86_64.txt | 67 + ydb/core/graph/ut/CMakeLists.darwin-arm64.txt | 72 + .../graph/ut/CMakeLists.darwin-x86_64.txt | 73 + .../graph/ut/CMakeLists.linux-aarch64.txt | 75 + ydb/core/graph/ut/CMakeLists.linux-x86_64.txt | 77 + ydb/core/graph/ut/CMakeLists.txt | 19 + .../graph/ut/CMakeLists.windows-x86_64.txt | 68 + .../grpc_services/CMakeLists.darwin-arm64.txt | 4 +- .../CMakeLists.darwin-x86_64.txt | 4 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../grpc_services/CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 4 +- .../base/CMakeLists.darwin-arm64.txt | 4 + .../base/CMakeLists.darwin-x86_64.txt | 4 + .../base/CMakeLists.linux-aarch64.txt | 4 + .../base/CMakeLists.linux-x86_64.txt | 4 + .../base/CMakeLists.windows-x86_64.txt | 4 + .../protos/CMakeLists.darwin-arm64.txt | 3 + .../protos/CMakeLists.darwin-x86_64.txt | 3 + .../protos/CMakeLists.linux-aarch64.txt | 3 + .../protos/CMakeLists.linux-x86_64.txt | 3 + .../protos/CMakeLists.windows-x86_64.txt | 3 + .../counters/CMakeLists.darwin-arm64.txt | 2 + .../counters/CMakeLists.darwin-x86_64.txt | 2 + .../counters/CMakeLists.linux-aarch64.txt | 2 + .../counters/CMakeLists.linux-x86_64.txt | 2 + .../counters/CMakeLists.windows-x86_64.txt | 2 + .../local_rpc/CMakeLists.darwin-arm64.txt | 3 + .../local_rpc/CMakeLists.darwin-x86_64.txt | 3 + .../local_rpc/CMakeLists.linux-aarch64.txt | 3 + .../local_rpc/CMakeLists.linux-x86_64.txt | 3 + .../local_rpc/CMakeLists.windows-x86_64.txt | 3 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/grpc/CMakeLists.darwin-arm64.txt | 4 + .../ut/grpc/CMakeLists.darwin-x86_64.txt | 4 + .../ut/grpc/CMakeLists.linux-aarch64.txt | 4 + .../ut/grpc/CMakeLists.linux-x86_64.txt | 4 + .../ut/grpc/CMakeLists.windows-x86_64.txt | 4 + .../health_check/CMakeLists.darwin-arm64.txt | 1 + .../health_check/CMakeLists.darwin-x86_64.txt | 1 + .../health_check/CMakeLists.linux-aarch64.txt | 1 + .../health_check/CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../http_proxy/CMakeLists.darwin-arm64.txt | 10 + .../http_proxy/CMakeLists.darwin-x86_64.txt | 10 + .../http_proxy/CMakeLists.linux-aarch64.txt | 10 + .../http_proxy/CMakeLists.linux-x86_64.txt | 10 + .../http_proxy/CMakeLists.windows-x86_64.txt | 10 + .../http_proxy/ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../http_proxy/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + ydb/core/io_formats/CMakeLists.txt | 14 +- .../arrow/CMakeLists.darwin-arm64.txt | 24 + .../arrow/CMakeLists.darwin-x86_64.txt | 24 + .../arrow/CMakeLists.linux-aarch64.txt | 25 + .../arrow/CMakeLists.linux-x86_64.txt | 25 + ydb/core/io_formats/arrow/CMakeLists.txt | 19 + .../arrow/CMakeLists.windows-x86_64.txt | 24 + .../arrow/ut/CMakeLists.darwin-arm64.txt | 70 + .../arrow/ut/CMakeLists.darwin-x86_64.txt | 71 + .../arrow/ut/CMakeLists.linux-aarch64.txt | 73 + .../arrow/ut/CMakeLists.linux-x86_64.txt | 75 + ydb/core/io_formats/arrow/ut/CMakeLists.txt | 19 + .../arrow/ut/CMakeLists.windows-x86_64.txt | 66 + .../CMakeLists.darwin-arm64.txt | 23 +- .../CMakeLists.darwin-x86_64.txt | 23 +- .../CMakeLists.linux-aarch64.txt | 23 +- .../CMakeLists.linux-x86_64.txt | 23 +- ydb/core/io_formats/cell_maker/CMakeLists.txt | 19 + .../CMakeLists.windows-x86_64.txt | 23 +- .../ydb_dump/CMakeLists.darwin-arm64.txt | 23 + .../ydb_dump/CMakeLists.darwin-x86_64.txt | 23 + .../ydb_dump/CMakeLists.linux-aarch64.txt | 24 + .../ydb_dump/CMakeLists.linux-x86_64.txt | 24 + ydb/core/io_formats/ydb_dump/CMakeLists.txt | 19 + .../ydb_dump/CMakeLists.windows-x86_64.txt | 23 + .../kafka_proxy/CMakeLists.darwin-arm64.txt | 11 + .../kafka_proxy/CMakeLists.darwin-x86_64.txt | 11 + .../kafka_proxy/CMakeLists.linux-aarch64.txt | 11 + .../kafka_proxy/CMakeLists.linux-x86_64.txt | 11 + .../kafka_proxy/CMakeLists.windows-x86_64.txt | 11 + .../ut/CMakeLists.darwin-arm64.txt | 5 +- .../ut/CMakeLists.darwin-x86_64.txt | 5 +- .../ut/CMakeLists.linux-aarch64.txt | 6 +- .../ut/CMakeLists.linux-x86_64.txt | 6 +- .../ut/CMakeLists.windows-x86_64.txt | 3 +- .../proxy/ut/CMakeLists.darwin-arm64.txt | 3 +- .../proxy/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../proxy/ut/CMakeLists.linux-aarch64.txt | 4 +- .../proxy/ut/CMakeLists.linux-x86_64.txt | 4 +- .../proxy/ut/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 2 - .../CMakeLists.darwin-x86_64.txt | 2 - .../CMakeLists.linux-aarch64.txt | 3 - .../CMakeLists.linux-x86_64.txt | 3 - .../tablet/ut/CMakeLists.darwin-arm64.txt | 3 +- .../tablet/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../tablet/ut/CMakeLists.linux-aarch64.txt | 4 +- .../tablet/ut/CMakeLists.linux-x86_64.txt | 4 +- .../tablet/ut/CMakeLists.windows-x86_64.txt | 1 + ydb/core/keyvalue/CMakeLists.darwin-arm64.txt | 26 + .../keyvalue/CMakeLists.darwin-x86_64.txt | 26 + .../keyvalue/CMakeLists.linux-aarch64.txt | 26 + ydb/core/keyvalue/CMakeLists.linux-x86_64.txt | 26 + .../keyvalue/CMakeLists.windows-x86_64.txt | 26 + .../protos/CMakeLists.darwin-arm64.txt | 3 + .../protos/CMakeLists.darwin-x86_64.txt | 3 + .../protos/CMakeLists.linux-aarch64.txt | 3 + .../protos/CMakeLists.linux-x86_64.txt | 3 + .../protos/CMakeLists.windows-x86_64.txt | 3 + .../keyvalue/ut/CMakeLists.darwin-arm64.txt | 3 +- .../keyvalue/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../keyvalue/ut/CMakeLists.linux-aarch64.txt | 4 +- .../keyvalue/ut/CMakeLists.linux-x86_64.txt | 4 +- .../keyvalue/ut/CMakeLists.windows-x86_64.txt | 1 + .../ut_trace/CMakeLists.darwin-arm64.txt | 73 + .../ut_trace/CMakeLists.darwin-x86_64.txt | 74 + .../ut_trace/CMakeLists.linux-aarch64.txt | 76 + .../ut_trace/CMakeLists.linux-x86_64.txt | 78 + ydb/core/keyvalue/ut_trace/CMakeLists.txt | 19 + .../ut_trace/CMakeLists.windows-x86_64.txt | 69 + .../kqp/common/CMakeLists.darwin-arm64.txt | 8 + .../kqp/common/CMakeLists.darwin-x86_64.txt | 8 + .../kqp/common/CMakeLists.linux-aarch64.txt | 8 + .../kqp/common/CMakeLists.linux-x86_64.txt | 8 + .../kqp/common/CMakeLists.windows-x86_64.txt | 8 + .../kqp/counters/CMakeLists.darwin-arm64.txt | 2 + .../kqp/counters/CMakeLists.darwin-x86_64.txt | 2 + .../kqp/counters/CMakeLists.linux-aarch64.txt | 2 + .../kqp/counters/CMakeLists.linux-x86_64.txt | 2 + .../counters/CMakeLists.windows-x86_64.txt | 2 + .../CMakeLists.darwin-arm64.txt | 1 + .../CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.linux-aarch64.txt | 1 + .../CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../expr_nodes/CMakeLists.darwin-arm64.txt | 4 + .../expr_nodes/CMakeLists.darwin-x86_64.txt | 4 + .../expr_nodes/CMakeLists.linux-aarch64.txt | 4 + .../expr_nodes/CMakeLists.linux-x86_64.txt | 4 + .../expr_nodes/CMakeLists.windows-x86_64.txt | 4 + .../kqp/gateway/CMakeLists.darwin-arm64.txt | 3 + .../kqp/gateway/CMakeLists.darwin-x86_64.txt | 3 + .../kqp/gateway/CMakeLists.linux-aarch64.txt | 3 + .../kqp/gateway/CMakeLists.linux-x86_64.txt | 3 + .../kqp/gateway/CMakeLists.windows-x86_64.txt | 3 + ydb/core/kqp/gateway/behaviour/CMakeLists.txt | 1 + .../CMakeLists.darwin-arm64.txt | 2 + .../CMakeLists.darwin-x86_64.txt | 2 + .../CMakeLists.linux-aarch64.txt | 2 + .../CMakeLists.linux-x86_64.txt | 2 + .../CMakeLists.windows-x86_64.txt | 2 + .../operations/CMakeLists.darwin-arm64.txt | 4 + .../operations/CMakeLists.darwin-x86_64.txt | 4 + .../operations/CMakeLists.linux-aarch64.txt | 4 + .../operations/CMakeLists.linux-x86_64.txt | 4 + .../operations/CMakeLists.windows-x86_64.txt | 4 + .../view/CMakeLists.darwin-arm64.txt | 42 + .../view/CMakeLists.darwin-x86_64.txt | 42 + .../view/CMakeLists.linux-aarch64.txt | 44 + .../view/CMakeLists.linux-x86_64.txt | 44 + .../kqp/gateway/behaviour/view/CMakeLists.txt | 19 + .../view/CMakeLists.windows-x86_64.txt | 42 + .../gateway/utils/CMakeLists.darwin-arm64.txt | 23 + .../utils/CMakeLists.darwin-x86_64.txt | 23 + .../utils/CMakeLists.linux-aarch64.txt | 24 + .../gateway/utils/CMakeLists.linux-x86_64.txt | 24 + ydb/core/kqp/gateway/utils/CMakeLists.txt | 19 + .../utils/CMakeLists.windows-x86_64.txt | 23 + ydb/core/kqp/host/CMakeLists.darwin-arm64.txt | 3 +- .../kqp/host/CMakeLists.darwin-x86_64.txt | 3 +- .../kqp/host/CMakeLists.linux-aarch64.txt | 3 +- ydb/core/kqp/host/CMakeLists.linux-x86_64.txt | 3 +- .../kqp/host/CMakeLists.windows-x86_64.txt | 3 +- .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../opt/logical/CMakeLists.darwin-arm64.txt | 1 + .../opt/logical/CMakeLists.darwin-x86_64.txt | 1 + .../opt/logical/CMakeLists.linux-aarch64.txt | 1 + .../opt/logical/CMakeLists.linux-x86_64.txt | 1 + .../opt/logical/CMakeLists.windows-x86_64.txt | 1 + .../effects/CMakeLists.darwin-arm64.txt | 2 + .../effects/CMakeLists.darwin-x86_64.txt | 2 + .../effects/CMakeLists.linux-aarch64.txt | 2 + .../effects/CMakeLists.linux-x86_64.txt | 2 + .../effects/CMakeLists.windows-x86_64.txt | 2 + .../kqp/provider/CMakeLists.darwin-arm64.txt | 14 +- .../kqp/provider/CMakeLists.darwin-x86_64.txt | 14 +- .../kqp/provider/CMakeLists.linux-aarch64.txt | 14 +- .../kqp/provider/CMakeLists.linux-x86_64.txt | 14 +- .../provider/CMakeLists.windows-x86_64.txt | 14 +- .../provider/ut/CMakeLists.darwin-arm64.txt | 3 +- .../provider/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../provider/ut/CMakeLists.linux-aarch64.txt | 4 +- .../provider/ut/CMakeLists.linux-x86_64.txt | 4 +- .../provider/ut/CMakeLists.windows-x86_64.txt | 1 + .../proto/CMakeLists.darwin-arm64.txt | 3 + .../proto/CMakeLists.darwin-x86_64.txt | 3 + .../proto/CMakeLists.linux-aarch64.txt | 3 + .../proto/CMakeLists.linux-x86_64.txt | 3 + .../proto/CMakeLists.windows-x86_64.txt | 3 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../rm_service/ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../rm_service/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../kqp/runtime/CMakeLists.darwin-arm64.txt | 8 +- .../kqp/runtime/CMakeLists.darwin-x86_64.txt | 8 +- .../kqp/runtime/CMakeLists.linux-aarch64.txt | 8 +- .../kqp/runtime/CMakeLists.linux-x86_64.txt | 8 +- .../kqp/runtime/CMakeLists.windows-x86_64.txt | 8 +- .../runtime/ut/CMakeLists.darwin-arm64.txt | 4 +- .../runtime/ut/CMakeLists.darwin-x86_64.txt | 4 +- .../runtime/ut/CMakeLists.linux-aarch64.txt | 5 +- .../runtime/ut/CMakeLists.linux-x86_64.txt | 5 +- .../runtime/ut/CMakeLists.windows-x86_64.txt | 2 + .../session_actor/CMakeLists.darwin-arm64.txt | 2 + .../CMakeLists.darwin-x86_64.txt | 2 + .../CMakeLists.linux-aarch64.txt | 2 + .../session_actor/CMakeLists.linux-x86_64.txt | 2 + .../CMakeLists.windows-x86_64.txt | 2 + .../kqp/topics/CMakeLists.darwin-arm64.txt | 1 + .../kqp/topics/CMakeLists.darwin-x86_64.txt | 1 + .../kqp/topics/CMakeLists.linux-aarch64.txt | 1 + .../kqp/topics/CMakeLists.linux-x86_64.txt | 1 + .../kqp/topics/CMakeLists.windows-x86_64.txt | 1 + ydb/core/kqp/ut/CMakeLists.txt | 1 + .../kqp/ut/arrow/CMakeLists.darwin-arm64.txt | 3 +- .../kqp/ut/arrow/CMakeLists.darwin-x86_64.txt | 3 +- .../kqp/ut/arrow/CMakeLists.linux-aarch64.txt | 4 +- .../kqp/ut/arrow/CMakeLists.linux-x86_64.txt | 4 +- .../ut/arrow/CMakeLists.windows-x86_64.txt | 1 + .../kqp/ut/common/CMakeLists.darwin-arm64.txt | 2 + .../ut/common/CMakeLists.darwin-x86_64.txt | 2 + .../ut/common/CMakeLists.linux-aarch64.txt | 2 + .../kqp/ut/common/CMakeLists.linux-x86_64.txt | 2 + .../ut/common/CMakeLists.windows-x86_64.txt | 2 + .../kqp/ut/cost/CMakeLists.darwin-arm64.txt | 3 +- .../kqp/ut/cost/CMakeLists.darwin-x86_64.txt | 3 +- .../kqp/ut/cost/CMakeLists.linux-aarch64.txt | 4 +- .../kqp/ut/cost/CMakeLists.linux-x86_64.txt | 4 +- .../kqp/ut/cost/CMakeLists.windows-x86_64.txt | 1 + .../kqp/ut/data/CMakeLists.darwin-arm64.txt | 3 +- .../kqp/ut/data/CMakeLists.darwin-x86_64.txt | 3 +- .../kqp/ut/data/CMakeLists.linux-aarch64.txt | 4 +- .../kqp/ut/data/CMakeLists.linux-x86_64.txt | 4 +- .../kqp/ut/data/CMakeLists.windows-x86_64.txt | 1 + .../ut/effects/CMakeLists.darwin-arm64.txt | 3 +- .../ut/effects/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/effects/CMakeLists.linux-aarch64.txt | 4 +- .../ut/effects/CMakeLists.linux-x86_64.txt | 4 +- .../ut/effects/CMakeLists.windows-x86_64.txt | 1 + .../kqp/ut/federated_query/CMakeLists.txt | 15 +- .../generic/CMakeLists.darwin-arm64.txt | 7 +- .../generic/CMakeLists.darwin-x86_64.txt | 7 +- .../generic/CMakeLists.linux-aarch64.txt | 8 +- .../generic/CMakeLists.linux-x86_64.txt | 8 +- .../ut/federated_query/generic/CMakeLists.txt | 2 + .../generic/CMakeLists.windows-x86_64.txt | 75 + .../generic_ut/CMakeLists.darwin-arm64.txt | 3 +- .../generic_ut/CMakeLists.darwin-x86_64.txt | 3 +- .../generic_ut/CMakeLists.linux-aarch64.txt | 4 +- .../generic_ut/CMakeLists.linux-x86_64.txt | 4 +- .../generic_ut/CMakeLists.windows-x86_64.txt | 1 + .../s3/CMakeLists.darwin-arm64.txt | 4 +- .../s3/CMakeLists.darwin-x86_64.txt | 4 +- .../s3/CMakeLists.linux-aarch64.txt | 5 +- .../s3/CMakeLists.linux-x86_64.txt | 5 +- .../s3/CMakeLists.windows-x86_64.txt | 2 + .../ut/idx_test/CMakeLists.darwin-arm64.txt | 3 +- .../ut/idx_test/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/idx_test/CMakeLists.linux-aarch64.txt | 4 +- .../ut/idx_test/CMakeLists.linux-x86_64.txt | 4 +- .../ut/idx_test/CMakeLists.windows-x86_64.txt | 1 + .../ut/indexes/CMakeLists.darwin-arm64.txt | 3 +- .../ut/indexes/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/indexes/CMakeLists.linux-aarch64.txt | 4 +- .../ut/indexes/CMakeLists.linux-x86_64.txt | 4 +- .../ut/indexes/CMakeLists.windows-x86_64.txt | 1 + .../kqp/ut/join/CMakeLists.darwin-arm64.txt | 3 +- .../kqp/ut/join/CMakeLists.darwin-x86_64.txt | 3 +- .../kqp/ut/join/CMakeLists.linux-aarch64.txt | 4 +- .../kqp/ut/join/CMakeLists.linux-x86_64.txt | 4 +- .../kqp/ut/join/CMakeLists.windows-x86_64.txt | 1 + .../kqp/ut/olap/CMakeLists.darwin-arm64.txt | 4 +- .../kqp/ut/olap/CMakeLists.darwin-x86_64.txt | 4 +- .../kqp/ut/olap/CMakeLists.linux-aarch64.txt | 5 +- .../kqp/ut/olap/CMakeLists.linux-x86_64.txt | 5 +- .../kqp/ut/olap/CMakeLists.windows-x86_64.txt | 2 + .../kqp/ut/opt/CMakeLists.darwin-arm64.txt | 3 +- .../kqp/ut/opt/CMakeLists.darwin-x86_64.txt | 3 +- .../kqp/ut/opt/CMakeLists.linux-aarch64.txt | 4 +- .../kqp/ut/opt/CMakeLists.linux-x86_64.txt | 4 +- .../kqp/ut/opt/CMakeLists.windows-x86_64.txt | 1 + .../kqp/ut/perf/CMakeLists.darwin-arm64.txt | 3 +- .../kqp/ut/perf/CMakeLists.darwin-x86_64.txt | 3 +- .../kqp/ut/perf/CMakeLists.linux-aarch64.txt | 4 +- .../kqp/ut/perf/CMakeLists.linux-x86_64.txt | 4 +- .../kqp/ut/perf/CMakeLists.windows-x86_64.txt | 1 + .../kqp/ut/pg/CMakeLists.darwin-arm64.txt | 3 +- .../kqp/ut/pg/CMakeLists.darwin-x86_64.txt | 3 +- .../kqp/ut/pg/CMakeLists.linux-aarch64.txt | 4 +- .../kqp/ut/pg/CMakeLists.linux-x86_64.txt | 4 +- .../kqp/ut/pg/CMakeLists.windows-x86_64.txt | 1 + .../kqp/ut/query/CMakeLists.darwin-arm64.txt | 3 +- .../kqp/ut/query/CMakeLists.darwin-x86_64.txt | 3 +- .../kqp/ut/query/CMakeLists.linux-aarch64.txt | 4 +- .../kqp/ut/query/CMakeLists.linux-x86_64.txt | 4 +- .../ut/query/CMakeLists.windows-x86_64.txt | 1 + .../kqp/ut/scan/CMakeLists.darwin-arm64.txt | 3 +- .../kqp/ut/scan/CMakeLists.darwin-x86_64.txt | 3 +- .../kqp/ut/scan/CMakeLists.linux-aarch64.txt | 4 +- .../kqp/ut/scan/CMakeLists.linux-x86_64.txt | 4 +- .../kqp/ut/scan/CMakeLists.windows-x86_64.txt | 1 + .../kqp/ut/scheme/CMakeLists.darwin-arm64.txt | 3 +- .../ut/scheme/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/scheme/CMakeLists.linux-aarch64.txt | 4 +- .../kqp/ut/scheme/CMakeLists.linux-x86_64.txt | 4 +- .../ut/scheme/CMakeLists.windows-x86_64.txt | 1 + .../ut/service/CMakeLists.darwin-arm64.txt | 4 +- .../ut/service/CMakeLists.darwin-x86_64.txt | 4 +- .../ut/service/CMakeLists.linux-aarch64.txt | 5 +- .../ut/service/CMakeLists.linux-x86_64.txt | 5 +- .../ut/service/CMakeLists.windows-x86_64.txt | 2 + .../ut/spilling/CMakeLists.darwin-arm64.txt | 3 +- .../ut/spilling/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/spilling/CMakeLists.linux-aarch64.txt | 4 +- .../ut/spilling/CMakeLists.linux-x86_64.txt | 4 +- .../ut/spilling/CMakeLists.windows-x86_64.txt | 1 + .../ut/sysview/CMakeLists.darwin-arm64.txt | 3 +- .../ut/sysview/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/sysview/CMakeLists.linux-aarch64.txt | 4 +- .../ut/sysview/CMakeLists.linux-x86_64.txt | 4 +- .../ut/sysview/CMakeLists.windows-x86_64.txt | 1 + .../kqp/ut/tx/CMakeLists.darwin-arm64.txt | 3 +- .../kqp/ut/tx/CMakeLists.darwin-x86_64.txt | 3 +- .../kqp/ut/tx/CMakeLists.linux-aarch64.txt | 4 +- .../kqp/ut/tx/CMakeLists.linux-x86_64.txt | 4 +- .../kqp/ut/tx/CMakeLists.windows-x86_64.txt | 1 + .../kqp/ut/view/CMakeLists.darwin-arm64.txt | 72 + .../kqp/ut/view/CMakeLists.darwin-x86_64.txt | 73 + .../kqp/ut/view/CMakeLists.linux-aarch64.txt | 75 + .../kqp/ut/view/CMakeLists.linux-x86_64.txt | 77 + ydb/core/kqp/ut/view/CMakeLists.txt | 19 + .../kqp/ut/view/CMakeLists.windows-x86_64.txt | 68 + .../kqp/ut/yql/CMakeLists.darwin-arm64.txt | 3 +- .../kqp/ut/yql/CMakeLists.darwin-x86_64.txt | 3 +- .../kqp/ut/yql/CMakeLists.linux-aarch64.txt | 4 +- .../kqp/ut/yql/CMakeLists.linux-x86_64.txt | 4 +- .../kqp/ut/yql/CMakeLists.windows-x86_64.txt | 1 + .../load_test/CMakeLists.darwin-arm64.txt | 5 + .../load_test/CMakeLists.darwin-x86_64.txt | 5 + .../load_test/CMakeLists.linux-aarch64.txt | 5 + .../load_test/CMakeLists.linux-x86_64.txt | 5 + .../load_test/CMakeLists.windows-x86_64.txt | 5 + .../ut_ycsb/CMakeLists.darwin-arm64.txt | 3 +- .../ut_ycsb/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_ycsb/CMakeLists.linux-aarch64.txt | 4 +- .../ut_ycsb/CMakeLists.linux-x86_64.txt | 4 +- .../ut_ycsb/CMakeLists.windows-x86_64.txt | 1 + .../local_pgwire/CMakeLists.darwin-arm64.txt | 4 + .../local_pgwire/CMakeLists.darwin-x86_64.txt | 4 + .../local_pgwire/CMakeLists.linux-aarch64.txt | 4 + .../local_pgwire/CMakeLists.linux-x86_64.txt | 4 + .../CMakeLists.windows-x86_64.txt | 4 + .../log_backend/CMakeLists.darwin-arm64.txt | 2 + .../log_backend/CMakeLists.darwin-x86_64.txt | 2 + .../log_backend/CMakeLists.linux-aarch64.txt | 2 + .../log_backend/CMakeLists.linux-x86_64.txt | 2 + .../log_backend/CMakeLists.windows-x86_64.txt | 2 + ydb/core/metering/CMakeLists.darwin-arm64.txt | 3 + .../metering/CMakeLists.darwin-x86_64.txt | 3 + .../metering/CMakeLists.linux-aarch64.txt | 3 + ydb/core/metering/CMakeLists.linux-x86_64.txt | 3 + .../metering/CMakeLists.windows-x86_64.txt | 3 + .../metering/ut/CMakeLists.darwin-arm64.txt | 3 +- .../metering/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../metering/ut/CMakeLists.linux-aarch64.txt | 4 +- .../metering/ut/CMakeLists.linux-x86_64.txt | 4 +- .../metering/ut/CMakeLists.windows-x86_64.txt | 1 + ydb/core/mind/CMakeLists.darwin-arm64.txt | 16 + ydb/core/mind/CMakeLists.darwin-x86_64.txt | 16 + ydb/core/mind/CMakeLists.linux-aarch64.txt | 16 + ydb/core/mind/CMakeLists.linux-x86_64.txt | 16 + ydb/core/mind/CMakeLists.windows-x86_64.txt | 16 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../bscontroller/CMakeLists.darwin-arm64.txt | 23 + .../bscontroller/CMakeLists.darwin-x86_64.txt | 23 + .../bscontroller/CMakeLists.linux-aarch64.txt | 23 + .../bscontroller/CMakeLists.linux-x86_64.txt | 23 + .../CMakeLists.windows-x86_64.txt | 23 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_selfheal/CMakeLists.darwin-arm64.txt | 10 +- .../ut_selfheal/CMakeLists.darwin-x86_64.txt | 10 +- .../ut_selfheal/CMakeLists.linux-aarch64.txt | 11 +- .../ut_selfheal/CMakeLists.linux-x86_64.txt | 11 +- .../ut_selfheal/CMakeLists.windows-x86_64.txt | 8 + .../mind/hive/CMakeLists.darwin-arm64.txt | 22 + .../mind/hive/CMakeLists.darwin-x86_64.txt | 22 + .../mind/hive/CMakeLists.linux-aarch64.txt | 22 + .../mind/hive/CMakeLists.linux-x86_64.txt | 22 + .../mind/hive/CMakeLists.windows-x86_64.txt | 22 + .../mind/hive/ut/CMakeLists.darwin-arm64.txt | 3 +- .../mind/hive/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../mind/hive/ut/CMakeLists.linux-aarch64.txt | 4 +- .../mind/hive/ut/CMakeLists.linux-x86_64.txt | 4 +- .../hive/ut/CMakeLists.windows-x86_64.txt | 1 + ydb/core/mind/ut/CMakeLists.darwin-arm64.txt | 3 +- ydb/core/mind/ut/CMakeLists.darwin-x86_64.txt | 3 +- ydb/core/mind/ut/CMakeLists.linux-aarch64.txt | 4 +- ydb/core/mind/ut/CMakeLists.linux-x86_64.txt | 4 +- .../mind/ut/CMakeLists.windows-x86_64.txt | 1 + .../mind/ut_fat/CMakeLists.darwin-arm64.txt | 3 +- .../mind/ut_fat/CMakeLists.darwin-x86_64.txt | 3 +- .../mind/ut_fat/CMakeLists.linux-aarch64.txt | 4 +- .../mind/ut_fat/CMakeLists.linux-x86_64.txt | 4 +- .../mind/ut_fat/CMakeLists.windows-x86_64.txt | 1 + ydb/core/mon/CMakeLists.darwin-arm64.txt | 4 + ydb/core/mon/CMakeLists.darwin-x86_64.txt | 4 + ydb/core/mon/CMakeLists.linux-aarch64.txt | 4 + ydb/core/mon/CMakeLists.linux-x86_64.txt | 4 + ydb/core/mon/CMakeLists.windows-x86_64.txt | 4 + .../mon_alloc/CMakeLists.darwin-arm64.txt | 2 - .../mon_alloc/CMakeLists.darwin-x86_64.txt | 2 - .../mon_alloc/CMakeLists.linux-aarch64.txt | 2 - .../mon_alloc/CMakeLists.linux-x86_64.txt | 2 - .../mon_alloc/CMakeLists.windows-x86_64.txt | 2 - .../CMakeLists.darwin-arm64.txt | 3 + .../CMakeLists.darwin-x86_64.txt | 3 + .../CMakeLists.linux-aarch64.txt | 3 + .../CMakeLists.linux-x86_64.txt | 3 + .../CMakeLists.windows-x86_64.txt | 3 + .../persqueue/CMakeLists.darwin-arm64.txt | 2 + .../persqueue/CMakeLists.darwin-x86_64.txt | 2 + .../persqueue/CMakeLists.linux-aarch64.txt | 2 + .../persqueue/CMakeLists.linux-x86_64.txt | 2 + .../persqueue/CMakeLists.windows-x86_64.txt | 2 + .../config/CMakeLists.darwin-arm64.txt | 1 + .../config/CMakeLists.darwin-x86_64.txt | 1 + .../config/CMakeLists.linux-aarch64.txt | 1 + .../config/CMakeLists.linux-x86_64.txt | 1 + .../config/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../persqueue/ut/CMakeLists.darwin-arm64.txt | 3 +- .../persqueue/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../persqueue/ut/CMakeLists.linux-aarch64.txt | 4 +- .../persqueue/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/common/CMakeLists.darwin-arm64.txt | 1 + .../ut/common/CMakeLists.darwin-x86_64.txt | 1 + .../ut/common/CMakeLists.linux-aarch64.txt | 1 + .../ut/common/CMakeLists.linux-x86_64.txt | 1 + .../ut/common/CMakeLists.windows-x86_64.txt | 1 + .../ut/slow/CMakeLists.darwin-arm64.txt | 3 +- .../ut/slow/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/slow/CMakeLists.linux-aarch64.txt | 4 +- .../ut/slow/CMakeLists.linux-x86_64.txt | 4 +- .../ut/slow/CMakeLists.windows-x86_64.txt | 1 + ydb/core/pgproxy/CMakeLists.darwin-arm64.txt | 8 + ydb/core/pgproxy/CMakeLists.darwin-x86_64.txt | 8 + ydb/core/pgproxy/CMakeLists.linux-aarch64.txt | 8 + ydb/core/pgproxy/CMakeLists.linux-x86_64.txt | 8 + .../pgproxy/CMakeLists.windows-x86_64.txt | 8 + .../protos/CMakeLists.darwin-arm64.txt | 3 + .../protos/CMakeLists.darwin-x86_64.txt | 3 + .../protos/CMakeLists.linux-aarch64.txt | 3 + .../protos/CMakeLists.linux-x86_64.txt | 3 + .../protos/CMakeLists.windows-x86_64.txt | 3 + .../pgproxy/ut/CMakeLists.darwin-arm64.txt | 3 +- .../pgproxy/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../pgproxy/ut/CMakeLists.linux-aarch64.txt | 4 +- .../pgproxy/ut/CMakeLists.linux-x86_64.txt | 4 +- .../pgproxy/ut/CMakeLists.windows-x86_64.txt | 1 + ydb/core/protos/CMakeLists.darwin-arm64.txt | 264 + ydb/core/protos/CMakeLists.darwin-x86_64.txt | 264 + ydb/core/protos/CMakeLists.linux-aarch64.txt | 264 + ydb/core/protos/CMakeLists.linux-x86_64.txt | 264 + ydb/core/protos/CMakeLists.windows-x86_64.txt | 264 + .../public_http/CMakeLists.darwin-arm64.txt | 4 + .../public_http/CMakeLists.darwin-x86_64.txt | 4 + .../public_http/CMakeLists.linux-aarch64.txt | 4 + .../public_http/CMakeLists.linux-x86_64.txt | 4 + .../public_http/CMakeLists.windows-x86_64.txt | 4 + .../protos/CMakeLists.darwin-arm64.txt | 3 + .../protos/CMakeLists.darwin-x86_64.txt | 3 + .../protos/CMakeLists.linux-aarch64.txt | 3 + .../protos/CMakeLists.linux-x86_64.txt | 3 + .../protos/CMakeLists.windows-x86_64.txt | 3 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + ydb/core/quoter/CMakeLists.darwin-arm64.txt | 3 + ydb/core/quoter/CMakeLists.darwin-x86_64.txt | 3 + ydb/core/quoter/CMakeLists.linux-aarch64.txt | 3 + ydb/core/quoter/CMakeLists.linux-x86_64.txt | 3 + ydb/core/quoter/CMakeLists.windows-x86_64.txt | 3 + .../quoter/public/CMakeLists.darwin-arm64.txt | 1 + .../public/CMakeLists.darwin-x86_64.txt | 1 + .../public/CMakeLists.linux-aarch64.txt | 1 + .../quoter/public/CMakeLists.linux-x86_64.txt | 1 + .../public/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 2 - .../CMakeLists.darwin-x86_64.txt | 2 - .../CMakeLists.linux-aarch64.txt | 3 - .../CMakeLists.linux-x86_64.txt | 3 - .../quoter/ut/CMakeLists.darwin-arm64.txt | 3 +- .../quoter/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../quoter/ut/CMakeLists.linux-aarch64.txt | 4 +- .../quoter/ut/CMakeLists.linux-x86_64.txt | 4 +- .../raw_socket/CMakeLists.darwin-arm64.txt | 5 + .../raw_socket/CMakeLists.darwin-x86_64.txt | 5 + .../raw_socket/CMakeLists.linux-aarch64.txt | 5 + .../raw_socket/CMakeLists.linux-x86_64.txt | 5 + .../raw_socket/CMakeLists.windows-x86_64.txt | 5 + .../scheme/protos/CMakeLists.darwin-arm64.txt | 8 + .../protos/CMakeLists.darwin-x86_64.txt | 8 + .../protos/CMakeLists.linux-aarch64.txt | 8 + .../scheme/protos/CMakeLists.linux-x86_64.txt | 8 + .../protos/CMakeLists.windows-x86_64.txt | 8 + .../scheme/ut/CMakeLists.darwin-arm64.txt | 3 +- .../scheme/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../scheme/ut/CMakeLists.linux-aarch64.txt | 4 +- .../scheme/ut/CMakeLists.linux-x86_64.txt | 4 +- .../scheme/ut/CMakeLists.windows-x86_64.txt | 1 + ydb/core/security/CMakeLists.darwin-arm64.txt | 4 + .../security/CMakeLists.darwin-x86_64.txt | 4 + .../security/CMakeLists.linux-aarch64.txt | 4 + ydb/core/security/CMakeLists.linux-x86_64.txt | 4 + .../security/CMakeLists.windows-x86_64.txt | 4 + .../security/ut/CMakeLists.darwin-arm64.txt | 3 +- .../security/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../security/ut/CMakeLists.linux-aarch64.txt | 4 +- .../security/ut/CMakeLists.linux-x86_64.txt | 4 +- .../security/ut/CMakeLists.windows-x86_64.txt | 1 + .../statistics/CMakeLists.darwin-arm64.txt | 2 + .../statistics/CMakeLists.darwin-x86_64.txt | 2 + .../statistics/CMakeLists.linux-aarch64.txt | 2 + .../statistics/CMakeLists.linux-x86_64.txt | 2 + .../statistics/CMakeLists.windows-x86_64.txt | 2 + .../aggregator/CMakeLists.darwin-arm64.txt | 4 + .../aggregator/CMakeLists.darwin-x86_64.txt | 4 + .../aggregator/CMakeLists.linux-aarch64.txt | 4 + .../aggregator/CMakeLists.linux-x86_64.txt | 4 + .../aggregator/CMakeLists.windows-x86_64.txt | 4 + .../statistics/ut/CMakeLists.darwin-arm64.txt | 4 +- .../ut/CMakeLists.darwin-x86_64.txt | 4 +- .../ut/CMakeLists.linux-aarch64.txt | 5 +- .../statistics/ut/CMakeLists.linux-x86_64.txt | 5 +- .../ut/CMakeLists.windows-x86_64.txt | 2 + ydb/core/sys_view/CMakeLists.darwin-arm64.txt | 1 + .../sys_view/CMakeLists.darwin-x86_64.txt | 1 + .../sys_view/CMakeLists.linux-aarch64.txt | 1 + ydb/core/sys_view/CMakeLists.linux-x86_64.txt | 1 + .../sys_view/CMakeLists.windows-x86_64.txt | 1 + .../common/CMakeLists.darwin-arm64.txt | 8 + .../common/CMakeLists.darwin-x86_64.txt | 8 + .../common/CMakeLists.linux-aarch64.txt | 8 + .../common/CMakeLists.linux-x86_64.txt | 8 + .../common/CMakeLists.windows-x86_64.txt | 8 + .../nodes/CMakeLists.darwin-arm64.txt | 1 + .../nodes/CMakeLists.darwin-x86_64.txt | 1 + .../nodes/CMakeLists.linux-aarch64.txt | 1 + .../nodes/CMakeLists.linux-x86_64.txt | 1 + .../nodes/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 2 + .../CMakeLists.darwin-x86_64.txt | 2 + .../CMakeLists.linux-aarch64.txt | 2 + .../CMakeLists.linux-x86_64.txt | 2 + .../CMakeLists.windows-x86_64.txt | 2 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../processor/CMakeLists.darwin-arm64.txt | 3 + .../processor/CMakeLists.darwin-x86_64.txt | 3 + .../processor/CMakeLists.linux-aarch64.txt | 3 + .../processor/CMakeLists.linux-x86_64.txt | 3 + .../processor/CMakeLists.windows-x86_64.txt | 3 + .../query_stats/CMakeLists.darwin-arm64.txt | 2 + .../query_stats/CMakeLists.darwin-x86_64.txt | 2 + .../query_stats/CMakeLists.linux-aarch64.txt | 2 + .../query_stats/CMakeLists.linux-x86_64.txt | 2 + .../query_stats/CMakeLists.windows-x86_64.txt | 2 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../service/CMakeLists.darwin-arm64.txt | 7 + .../service/CMakeLists.darwin-x86_64.txt | 7 + .../service/CMakeLists.linux-aarch64.txt | 7 + .../service/CMakeLists.linux-x86_64.txt | 7 + .../service/CMakeLists.windows-x86_64.txt | 7 + .../service/ut/CMakeLists.darwin-arm64.txt | 3 +- .../service/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../service/ut/CMakeLists.linux-aarch64.txt | 4 +- .../service/ut/CMakeLists.linux-x86_64.txt | 4 +- .../service/ut/CMakeLists.windows-x86_64.txt | 1 + .../storage/CMakeLists.darwin-arm64.txt | 5 + .../storage/CMakeLists.darwin-x86_64.txt | 5 + .../storage/CMakeLists.linux-aarch64.txt | 5 + .../storage/CMakeLists.linux-x86_64.txt | 5 + .../storage/CMakeLists.windows-x86_64.txt | 5 + .../tablets/CMakeLists.darwin-arm64.txt | 1 + .../tablets/CMakeLists.darwin-x86_64.txt | 1 + .../tablets/CMakeLists.linux-aarch64.txt | 1 + .../tablets/CMakeLists.linux-x86_64.txt | 1 + .../tablets/CMakeLists.windows-x86_64.txt | 1 + .../ut_kqp/CMakeLists.darwin-arm64.txt | 3 +- .../ut_kqp/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_kqp/CMakeLists.linux-aarch64.txt | 4 +- .../ut_kqp/CMakeLists.linux-x86_64.txt | 4 +- .../ut_kqp/CMakeLists.windows-x86_64.txt | 1 + ydb/core/tablet/CMakeLists.darwin-arm64.txt | 24 + ydb/core/tablet/CMakeLists.darwin-x86_64.txt | 24 + ydb/core/tablet/CMakeLists.linux-aarch64.txt | 24 + ydb/core/tablet/CMakeLists.linux-x86_64.txt | 24 + ydb/core/tablet/CMakeLists.windows-x86_64.txt | 24 + .../tablet/ut/CMakeLists.darwin-arm64.txt | 3 +- .../tablet/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../tablet/ut/CMakeLists.linux-aarch64.txt | 4 +- .../tablet/ut/CMakeLists.linux-x86_64.txt | 4 +- .../tablet/ut/CMakeLists.windows-x86_64.txt | 1 + .../tablet_flat/CMakeLists.darwin-arm64.txt | 24 + .../tablet_flat/CMakeLists.darwin-x86_64.txt | 24 + .../tablet_flat/CMakeLists.linux-aarch64.txt | 24 + .../tablet_flat/CMakeLists.linux-x86_64.txt | 24 + .../tablet_flat/CMakeLists.windows-x86_64.txt | 24 + .../benchmark/CMakeLists.darwin-arm64.txt | 4 +- .../benchmark/CMakeLists.darwin-x86_64.txt | 4 +- .../benchmark/CMakeLists.linux-aarch64.txt | 5 +- .../benchmark/CMakeLists.linux-x86_64.txt | 5 +- .../benchmark/CMakeLists.windows-x86_64.txt | 2 + .../protos/CMakeLists.darwin-arm64.txt | 4 + .../protos/CMakeLists.darwin-x86_64.txt | 4 + .../protos/CMakeLists.linux-aarch64.txt | 4 + .../protos/CMakeLists.linux-x86_64.txt | 4 + .../protos/CMakeLists.windows-x86_64.txt | 4 + .../tool/perf/CMakeLists.darwin-arm64.txt | 2 - .../tool/perf/CMakeLists.darwin-x86_64.txt | 2 - .../tool/perf/CMakeLists.linux-aarch64.txt | 3 - .../tool/perf/CMakeLists.linux-x86_64.txt | 3 - .../tool/surg/CMakeLists.darwin-arm64.txt | 2 - .../tool/surg/CMakeLists.darwin-x86_64.txt | 2 - .../tool/surg/CMakeLists.linux-aarch64.txt | 3 - .../tool/surg/CMakeLists.linux-x86_64.txt | 3 - .../ut/CMakeLists.darwin-arm64.txt | 8 +- .../ut/CMakeLists.darwin-x86_64.txt | 8 +- .../ut/CMakeLists.linux-aarch64.txt | 9 +- .../ut/CMakeLists.linux-x86_64.txt | 9 +- .../ut/CMakeLists.windows-x86_64.txt | 6 +- .../ut_large/CMakeLists.darwin-arm64.txt | 3 +- .../ut_large/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_large/CMakeLists.linux-aarch64.txt | 4 +- .../ut_large/CMakeLists.linux-x86_64.txt | 4 +- .../ut_large/CMakeLists.windows-x86_64.txt | 1 + .../ut_pg/CMakeLists.darwin-arm64.txt | 3 +- .../ut_pg/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_pg/CMakeLists.linux-aarch64.txt | 4 +- .../ut_pg/CMakeLists.linux-x86_64.txt | 4 +- .../ut_pg/CMakeLists.windows-x86_64.txt | 1 + .../ut_util/CMakeLists.darwin-arm64.txt | 3 +- .../ut_util/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_util/CMakeLists.linux-aarch64.txt | 4 +- .../ut_util/CMakeLists.linux-x86_64.txt | 4 +- .../ut_util/CMakeLists.windows-x86_64.txt | 1 + .../test_tablet/CMakeLists.darwin-arm64.txt | 9 + .../test_tablet/CMakeLists.darwin-x86_64.txt | 9 + .../test_tablet/CMakeLists.linux-aarch64.txt | 9 + .../test_tablet/CMakeLists.linux-x86_64.txt | 9 + .../test_tablet/CMakeLists.windows-x86_64.txt | 9 + ydb/core/testlib/CMakeLists.darwin-arm64.txt | 12 +- ydb/core/testlib/CMakeLists.darwin-x86_64.txt | 12 +- ydb/core/testlib/CMakeLists.linux-aarch64.txt | 12 +- ydb/core/testlib/CMakeLists.linux-x86_64.txt | 12 +- .../testlib/CMakeLists.windows-x86_64.txt | 12 +- .../actors/ut/CMakeLists.darwin-arm64.txt | 3 +- .../actors/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../actors/ut/CMakeLists.linux-aarch64.txt | 4 +- .../actors/ut/CMakeLists.linux-x86_64.txt | 4 +- .../actors/ut/CMakeLists.windows-x86_64.txt | 1 + .../basics/CMakeLists.darwin-arm64.txt | 5 +- .../basics/CMakeLists.darwin-x86_64.txt | 5 +- .../basics/CMakeLists.linux-aarch64.txt | 5 +- .../basics/CMakeLists.linux-x86_64.txt | 5 +- .../basics/CMakeLists.windows-x86_64.txt | 5 +- ydb/core/tx/CMakeLists.darwin-arm64.txt | 4 + ydb/core/tx/CMakeLists.darwin-x86_64.txt | 4 + ydb/core/tx/CMakeLists.linux-aarch64.txt | 4 + ydb/core/tx/CMakeLists.linux-x86_64.txt | 4 + ydb/core/tx/CMakeLists.windows-x86_64.txt | 4 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../columnshard/CMakeLists.darwin-arm64.txt | 7 +- .../columnshard/CMakeLists.darwin-x86_64.txt | 7 +- .../columnshard/CMakeLists.linux-aarch64.txt | 7 +- .../columnshard/CMakeLists.linux-x86_64.txt | 7 +- .../columnshard/CMakeLists.windows-x86_64.txt | 7 +- .../predicate/CMakeLists.darwin-arm64.txt | 3 + .../predicate/CMakeLists.darwin-x86_64.txt | 3 + .../predicate/CMakeLists.linux-aarch64.txt | 3 + .../predicate/CMakeLists.linux-x86_64.txt | 3 + .../predicate/CMakeLists.windows-x86_64.txt | 3 + .../plain_reader/CMakeLists.darwin-arm64.txt | 6 +- .../plain_reader/CMakeLists.darwin-x86_64.txt | 6 +- .../plain_reader/CMakeLists.linux-aarch64.txt | 6 +- .../plain_reader/CMakeLists.linux-x86_64.txt | 6 +- .../CMakeLists.windows-x86_64.txt | 6 +- .../scheme/CMakeLists.darwin-arm64.txt | 2 + .../scheme/CMakeLists.darwin-x86_64.txt | 2 + .../scheme/CMakeLists.linux-aarch64.txt | 2 + .../scheme/CMakeLists.linux-x86_64.txt | 2 + .../scheme/CMakeLists.windows-x86_64.txt | 2 + .../indexes/CMakeLists.darwin-arm64.txt | 18 + .../indexes/CMakeLists.darwin-x86_64.txt | 18 + .../indexes/CMakeLists.linux-aarch64.txt | 19 + .../indexes/CMakeLists.linux-x86_64.txt | 19 + .../engines/scheme/indexes/CMakeLists.txt | 19 + .../indexes/CMakeLists.windows-x86_64.txt | 18 + .../abstract/CMakeLists.darwin-arm64.txt | 40 + .../abstract/CMakeLists.darwin-x86_64.txt | 40 + .../abstract/CMakeLists.linux-aarch64.txt | 42 + .../abstract/CMakeLists.linux-x86_64.txt | 42 + .../scheme/indexes/abstract/CMakeLists.txt | 19 + .../abstract/CMakeLists.windows-x86_64.txt | 40 + .../indexes/bloom/CMakeLists.darwin-arm64.txt | 29 + .../bloom/CMakeLists.darwin-x86_64.txt | 29 + .../bloom/CMakeLists.linux-aarch64.txt | 31 + .../indexes/bloom/CMakeLists.linux-x86_64.txt | 31 + .../scheme/indexes/bloom/CMakeLists.txt | 19 + .../bloom/CMakeLists.windows-x86_64.txt | 29 + .../engines/ut/CMakeLists.darwin-arm64.txt | 3 +- .../engines/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../engines/ut/CMakeLists.linux-aarch64.txt | 4 +- .../engines/ut/CMakeLists.linux-x86_64.txt | 4 +- .../engines/ut/CMakeLists.windows-x86_64.txt | 1 + .../writer/CMakeLists.darwin-arm64.txt | 2 + .../writer/CMakeLists.darwin-x86_64.txt | 2 + .../writer/CMakeLists.linux-aarch64.txt | 2 + .../writer/CMakeLists.linux-x86_64.txt | 2 + .../writer/CMakeLists.windows-x86_64.txt | 2 + .../writer/buffer/CMakeLists.darwin-arm64.txt | 23 + .../buffer/CMakeLists.darwin-x86_64.txt | 23 + .../buffer/CMakeLists.linux-aarch64.txt | 24 + .../writer/buffer/CMakeLists.linux-x86_64.txt | 24 + .../engines/writer/buffer/CMakeLists.txt | 19 + .../buffer/CMakeLists.windows-x86_64.txt | 23 + .../splitter/ut/CMakeLists.darwin-arm64.txt | 8 +- .../splitter/ut/CMakeLists.darwin-x86_64.txt | 8 +- .../splitter/ut/CMakeLists.linux-aarch64.txt | 9 +- .../splitter/ut/CMakeLists.linux-x86_64.txt | 9 +- .../splitter/ut/CMakeLists.windows-x86_64.txt | 6 + .../transactions/CMakeLists.darwin-arm64.txt | 23 + .../transactions/CMakeLists.darwin-x86_64.txt | 23 + .../transactions/CMakeLists.linux-aarch64.txt | 24 + .../transactions/CMakeLists.linux-x86_64.txt | 24 + .../columnshard/transactions/CMakeLists.txt | 19 + .../CMakeLists.windows-x86_64.txt | 24 + .../operators/CMakeLists.darwin-arm64.txt | 27 + .../operators/CMakeLists.darwin-x86_64.txt | 27 + .../operators/CMakeLists.linux-aarch64.txt | 29 + .../operators/CMakeLists.linux-x86_64.txt | 29 + .../transactions/operators/CMakeLists.txt | 19 + .../operators/CMakeLists.windows-x86_64.txt | 27 + .../ut_rw/CMakeLists.darwin-arm64.txt | 3 +- .../ut_rw/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_rw/CMakeLists.linux-aarch64.txt | 4 +- .../ut_rw/CMakeLists.linux-x86_64.txt | 4 +- .../ut_rw/CMakeLists.windows-x86_64.txt | 1 + .../ut_schema/CMakeLists.darwin-arm64.txt | 3 +- .../ut_schema/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_schema/CMakeLists.linux-aarch64.txt | 4 +- .../ut_schema/CMakeLists.linux-x86_64.txt | 4 +- .../ut_schema/CMakeLists.windows-x86_64.txt | 1 + .../coordinator/CMakeLists.darwin-arm64.txt | 1 + .../coordinator/CMakeLists.darwin-x86_64.txt | 1 + .../coordinator/CMakeLists.linux-aarch64.txt | 1 + .../coordinator/CMakeLists.linux-x86_64.txt | 1 + .../coordinator/CMakeLists.windows-x86_64.txt | 1 + .../protos/CMakeLists.darwin-arm64.txt | 3 + .../protos/CMakeLists.darwin-x86_64.txt | 3 + .../protos/CMakeLists.linux-aarch64.txt | 3 + .../protos/CMakeLists.linux-x86_64.txt | 3 + .../protos/CMakeLists.windows-x86_64.txt | 3 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../tx/datashard/CMakeLists.darwin-arm64.txt | 51 +- .../tx/datashard/CMakeLists.darwin-x86_64.txt | 51 +- .../tx/datashard/CMakeLists.linux-aarch64.txt | 51 +- .../tx/datashard/CMakeLists.linux-x86_64.txt | 51 +- .../datashard/CMakeLists.windows-x86_64.txt | 51 +- .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_common/CMakeLists.darwin-arm64.txt | 1 + .../ut_common/CMakeLists.darwin-x86_64.txt | 1 + .../ut_common/CMakeLists.linux-aarch64.txt | 1 + .../ut_common/CMakeLists.linux-x86_64.txt | 1 + .../ut_common/CMakeLists.windows-x86_64.txt | 1 + .../ut_compaction/CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../ut_compaction/CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_erase_rows/CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../ut_erase_rows/CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_followers/CMakeLists.darwin-arm64.txt | 3 +- .../ut_followers/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_followers/CMakeLists.linux-aarch64.txt | 4 +- .../ut_followers/CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_init/CMakeLists.darwin-arm64.txt | 3 +- .../ut_init/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_init/CMakeLists.linux-aarch64.txt | 4 +- .../ut_init/CMakeLists.linux-x86_64.txt | 4 +- .../ut_init/CMakeLists.windows-x86_64.txt | 1 + .../ut_keys/CMakeLists.darwin-arm64.txt | 3 +- .../ut_keys/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_keys/CMakeLists.linux-aarch64.txt | 4 +- .../ut_keys/CMakeLists.linux-x86_64.txt | 4 +- .../ut_keys/CMakeLists.windows-x86_64.txt | 1 + .../ut_kqp/CMakeLists.darwin-arm64.txt | 3 +- .../ut_kqp/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_kqp/CMakeLists.linux-aarch64.txt | 4 +- .../ut_kqp/CMakeLists.linux-x86_64.txt | 4 +- .../ut_kqp/CMakeLists.windows-x86_64.txt | 1 + .../ut_kqp_errors/CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../ut_kqp_errors/CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_kqp_scan/CMakeLists.darwin-arm64.txt | 3 +- .../ut_kqp_scan/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_kqp_scan/CMakeLists.linux-aarch64.txt | 4 +- .../ut_kqp_scan/CMakeLists.linux-x86_64.txt | 4 +- .../ut_kqp_scan/CMakeLists.windows-x86_64.txt | 1 + .../ut_locks/CMakeLists.darwin-arm64.txt | 3 +- .../ut_locks/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_locks/CMakeLists.linux-aarch64.txt | 4 +- .../ut_locks/CMakeLists.linux-x86_64.txt | 4 +- .../ut_locks/CMakeLists.windows-x86_64.txt | 1 + .../ut_minikql/CMakeLists.darwin-arm64.txt | 3 +- .../ut_minikql/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_minikql/CMakeLists.linux-aarch64.txt | 4 +- .../ut_minikql/CMakeLists.linux-x86_64.txt | 4 +- .../ut_minikql/CMakeLists.windows-x86_64.txt | 1 + .../ut_minstep/CMakeLists.darwin-arm64.txt | 3 +- .../ut_minstep/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_minstep/CMakeLists.linux-aarch64.txt | 4 +- .../ut_minstep/CMakeLists.linux-x86_64.txt | 4 +- .../ut_minstep/CMakeLists.windows-x86_64.txt | 1 + .../ut_order/CMakeLists.darwin-arm64.txt | 3 +- .../ut_order/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_order/CMakeLists.linux-aarch64.txt | 4 +- .../ut_order/CMakeLists.linux-x86_64.txt | 4 +- .../ut_order/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_range_ops/CMakeLists.darwin-arm64.txt | 3 +- .../ut_range_ops/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_range_ops/CMakeLists.linux-aarch64.txt | 4 +- .../ut_range_ops/CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_read_table/CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../ut_read_table/CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_reassign/CMakeLists.darwin-arm64.txt | 3 +- .../ut_reassign/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_reassign/CMakeLists.linux-aarch64.txt | 4 +- .../ut_reassign/CMakeLists.linux-x86_64.txt | 4 +- .../ut_reassign/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_rs/CMakeLists.darwin-arm64.txt | 3 +- .../ut_rs/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_rs/CMakeLists.linux-aarch64.txt | 4 +- .../ut_rs/CMakeLists.linux-x86_64.txt | 4 +- .../ut_rs/CMakeLists.windows-x86_64.txt | 1 + .../ut_sequence/CMakeLists.darwin-arm64.txt | 3 +- .../ut_sequence/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_sequence/CMakeLists.linux-aarch64.txt | 4 +- .../ut_sequence/CMakeLists.linux-x86_64.txt | 4 +- .../ut_sequence/CMakeLists.windows-x86_64.txt | 1 + .../ut_snapshot/CMakeLists.darwin-arm64.txt | 3 +- .../ut_snapshot/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_snapshot/CMakeLists.linux-aarch64.txt | 4 +- .../ut_snapshot/CMakeLists.linux-x86_64.txt | 4 +- .../ut_snapshot/CMakeLists.windows-x86_64.txt | 1 + .../ut_stats/CMakeLists.darwin-arm64.txt | 3 +- .../ut_stats/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_stats/CMakeLists.linux-aarch64.txt | 4 +- .../ut_stats/CMakeLists.linux-x86_64.txt | 4 +- .../ut_stats/CMakeLists.windows-x86_64.txt | 1 + .../ut_trace/CMakeLists.darwin-arm64.txt | 85 + .../ut_trace/CMakeLists.darwin-x86_64.txt | 86 + .../ut_trace/CMakeLists.linux-aarch64.txt | 88 + .../ut_trace/CMakeLists.linux-x86_64.txt | 90 + ydb/core/tx/datashard/ut_trace/CMakeLists.txt | 19 + .../ut_trace/CMakeLists.windows-x86_64.txt | 81 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_volatile/CMakeLists.darwin-arm64.txt | 4 +- .../ut_volatile/CMakeLists.darwin-x86_64.txt | 4 +- .../ut_volatile/CMakeLists.linux-aarch64.txt | 5 +- .../ut_volatile/CMakeLists.linux-x86_64.txt | 5 +- .../ut_volatile/CMakeLists.windows-x86_64.txt | 2 + .../ut_write/CMakeLists.darwin-arm64.txt | 3 +- .../ut_write/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_write/CMakeLists.linux-aarch64.txt | 4 +- .../ut_write/CMakeLists.linux-x86_64.txt | 4 +- .../ut_write/CMakeLists.windows-x86_64.txt | 1 + .../public/ut/CMakeLists.darwin-arm64.txt | 3 +- .../public/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../public/ut/CMakeLists.linux-aarch64.txt | 4 +- .../public/ut/CMakeLists.linux-x86_64.txt | 4 +- .../public/ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../tx/program/CMakeLists.darwin-arm64.txt | 2 +- .../tx/program/CMakeLists.darwin-x86_64.txt | 2 +- .../tx/program/CMakeLists.linux-aarch64.txt | 2 +- .../tx/program/CMakeLists.linux-x86_64.txt | 2 +- .../tx/program/CMakeLists.windows-x86_64.txt | 2 +- ydb/core/tx/replication/CMakeLists.txt | 1 + .../service/CMakeLists.darwin-arm64.txt | 15 + .../service/CMakeLists.darwin-x86_64.txt | 15 + .../service/CMakeLists.linux-aarch64.txt | 15 + .../service/CMakeLists.linux-x86_64.txt | 15 + .../service/CMakeLists.windows-x86_64.txt | 15 + .../CMakeLists.darwin-arm64.txt | 79 + .../CMakeLists.darwin-x86_64.txt | 80 + .../CMakeLists.linux-aarch64.txt | 82 + .../CMakeLists.linux-x86_64.txt | 84 + .../service/ut_topic_reader/CMakeLists.txt | 19 + .../CMakeLists.windows-x86_64.txt | 75 + .../ut_helpers/CMakeLists.darwin-arm64.txt | 24 + .../ut_helpers/CMakeLists.darwin-x86_64.txt | 24 + .../ut_helpers/CMakeLists.linux-aarch64.txt | 25 + .../ut_helpers/CMakeLists.linux-x86_64.txt | 25 + .../tx/replication/ut_helpers/CMakeLists.txt | 19 + .../ut_helpers/CMakeLists.windows-x86_64.txt | 24 + .../ydb_proxy/ut/CMakeLists.darwin-arm64.txt | 7 +- .../ydb_proxy/ut/CMakeLists.darwin-x86_64.txt | 7 +- .../ydb_proxy/ut/CMakeLists.linux-aarch64.txt | 8 +- .../ydb_proxy/ut/CMakeLists.linux-x86_64.txt | 8 +- .../ut/CMakeLists.windows-x86_64.txt | 5 +- .../ut_cache/CMakeLists.darwin-arm64.txt | 3 +- .../ut_cache/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_cache/CMakeLists.linux-aarch64.txt | 4 +- .../ut_cache/CMakeLists.linux-x86_64.txt | 4 +- .../ut_cache/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_monitoring/CMakeLists.darwin-arm64.txt | 4 +- .../CMakeLists.darwin-x86_64.txt | 4 +- .../CMakeLists.linux-aarch64.txt | 5 +- .../ut_monitoring/CMakeLists.linux-x86_64.txt | 5 +- .../CMakeLists.windows-x86_64.txt | 2 + .../ut_populator/CMakeLists.darwin-arm64.txt | 3 +- .../ut_populator/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_populator/CMakeLists.linux-aarch64.txt | 4 +- .../ut_populator/CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_replica/CMakeLists.darwin-arm64.txt | 4 +- .../ut_replica/CMakeLists.darwin-x86_64.txt | 4 +- .../ut_replica/CMakeLists.linux-aarch64.txt | 5 +- .../ut_replica/CMakeLists.linux-x86_64.txt | 5 +- .../ut_replica/CMakeLists.windows-x86_64.txt | 2 + .../ut_subscriber/CMakeLists.darwin-arm64.txt | 4 +- .../CMakeLists.darwin-x86_64.txt | 4 +- .../CMakeLists.linux-aarch64.txt | 5 +- .../ut_subscriber/CMakeLists.linux-x86_64.txt | 5 +- .../CMakeLists.windows-x86_64.txt | 2 + .../schemeshard/CMakeLists.darwin-arm64.txt | 34 +- .../schemeshard/CMakeLists.darwin-x86_64.txt | 34 +- .../schemeshard/CMakeLists.linux-aarch64.txt | 34 +- .../schemeshard/CMakeLists.linux-x86_64.txt | 34 +- .../schemeshard/CMakeLists.windows-x86_64.txt | 34 +- .../olap/CMakeLists.darwin-arm64.txt | 24 + .../olap/CMakeLists.darwin-x86_64.txt | 24 + .../olap/CMakeLists.linux-aarch64.txt | 25 + .../olap/CMakeLists.linux-x86_64.txt | 25 + ydb/core/tx/schemeshard/olap/CMakeLists.txt | 19 + .../olap/CMakeLists.windows-x86_64.txt | 24 + .../olap/columns/CMakeLists.darwin-arm64.txt | 24 + .../olap/columns/CMakeLists.darwin-x86_64.txt | 24 + .../olap/columns/CMakeLists.linux-aarch64.txt | 25 + .../olap/columns/CMakeLists.linux-x86_64.txt | 25 + .../schemeshard/olap/columns/CMakeLists.txt | 19 + .../columns/CMakeLists.windows-x86_64.txt | 24 + .../olap/common/CMakeLists.darwin-arm64.txt | 19 + .../olap/common/CMakeLists.darwin-x86_64.txt | 19 + .../olap/common/CMakeLists.linux-aarch64.txt | 20 + .../olap/common/CMakeLists.linux-x86_64.txt | 20 + .../tx/schemeshard/olap/common/CMakeLists.txt | 19 + .../olap/common/CMakeLists.windows-x86_64.txt | 19 + .../olap/indexes/CMakeLists.darwin-arm64.txt | 19 + .../olap/indexes/CMakeLists.darwin-x86_64.txt | 19 + .../olap/indexes/CMakeLists.linux-aarch64.txt | 20 + .../olap/indexes/CMakeLists.linux-x86_64.txt | 20 + .../schemeshard/olap/indexes/CMakeLists.txt | 19 + .../indexes/CMakeLists.windows-x86_64.txt | 19 + .../operations/CMakeLists.darwin-arm64.txt | 27 + .../operations/CMakeLists.darwin-x86_64.txt | 27 + .../operations/CMakeLists.linux-aarch64.txt | 28 + .../operations/CMakeLists.linux-x86_64.txt | 28 + .../olap/operations/CMakeLists.txt | 19 + .../operations/CMakeLists.windows-x86_64.txt | 27 + .../olap/schema/CMakeLists.darwin-arm64.txt | 20 + .../olap/schema/CMakeLists.darwin-x86_64.txt | 20 + .../olap/schema/CMakeLists.linux-aarch64.txt | 21 + .../olap/schema/CMakeLists.linux-x86_64.txt | 21 + .../tx/schemeshard/olap/schema/CMakeLists.txt | 19 + .../olap/schema/CMakeLists.windows-x86_64.txt | 20 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 82 + .../CMakeLists.darwin-x86_64.txt | 83 + .../CMakeLists.linux-aarch64.txt | 85 + .../CMakeLists.linux-x86_64.txt | 87 + .../ut_background_cleaning/CMakeLists.txt | 19 + .../CMakeLists.windows-x86_64.txt | 78 + .../ut_backup/CMakeLists.darwin-arm64.txt | 3 +- .../ut_backup/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_backup/CMakeLists.linux-aarch64.txt | 4 +- .../ut_backup/CMakeLists.linux-x86_64.txt | 4 +- .../ut_backup/CMakeLists.windows-x86_64.txt | 1 + .../ut_base/CMakeLists.darwin-arm64.txt | 3 +- .../ut_base/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_base/CMakeLists.linux-aarch64.txt | 4 +- .../ut_base/CMakeLists.linux-x86_64.txt | 4 +- .../ut_base/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_bsvolume/CMakeLists.darwin-arm64.txt | 3 +- .../ut_bsvolume/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_bsvolume/CMakeLists.linux-aarch64.txt | 4 +- .../ut_bsvolume/CMakeLists.linux-x86_64.txt | 4 +- .../ut_bsvolume/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_cdc_stream/CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../ut_cdc_stream/CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_compaction/CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../ut_compaction/CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_export/CMakeLists.darwin-arm64.txt | 3 +- .../ut_export/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_export/CMakeLists.linux-aarch64.txt | 4 +- .../ut_export/CMakeLists.linux-x86_64.txt | 4 +- .../ut_export/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_helpers/CMakeLists.darwin-arm64.txt | 4 + .../ut_helpers/CMakeLists.darwin-x86_64.txt | 4 + .../ut_helpers/CMakeLists.linux-aarch64.txt | 4 + .../ut_helpers/CMakeLists.linux-x86_64.txt | 4 + .../ut_helpers/CMakeLists.windows-x86_64.txt | 4 + .../ut_index/CMakeLists.darwin-arm64.txt | 3 +- .../ut_index/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_index/CMakeLists.linux-aarch64.txt | 4 +- .../ut_index/CMakeLists.linux-x86_64.txt | 4 +- .../ut_index/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_login/CMakeLists.darwin-arm64.txt | 3 +- .../ut_login/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_login/CMakeLists.linux-aarch64.txt | 4 +- .../ut_login/CMakeLists.linux-x86_64.txt | 4 +- .../ut_login/CMakeLists.windows-x86_64.txt | 1 + .../ut_move/CMakeLists.darwin-arm64.txt | 3 +- .../ut_move/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_move/CMakeLists.linux-aarch64.txt | 4 +- .../ut_move/CMakeLists.linux-x86_64.txt | 4 +- .../ut_move/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_olap/CMakeLists.darwin-arm64.txt | 3 +- .../ut_olap/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_olap/CMakeLists.linux-aarch64.txt | 4 +- .../ut_olap/CMakeLists.linux-x86_64.txt | 4 +- .../ut_olap/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_pq_reboots/CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../ut_pq_reboots/CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_reboots/CMakeLists.darwin-arm64.txt | 3 +- .../ut_reboots/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_reboots/CMakeLists.linux-aarch64.txt | 4 +- .../ut_reboots/CMakeLists.linux-x86_64.txt | 4 +- .../ut_reboots/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_restore/CMakeLists.darwin-arm64.txt | 3 +- .../ut_restore/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_restore/CMakeLists.linux-aarch64.txt | 4 +- .../ut_restore/CMakeLists.linux-x86_64.txt | 4 +- .../ut_restore/CMakeLists.windows-x86_64.txt | 1 + .../ut_rtmr/CMakeLists.darwin-arm64.txt | 3 +- .../ut_rtmr/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_rtmr/CMakeLists.linux-aarch64.txt | 4 +- .../ut_rtmr/CMakeLists.linux-x86_64.txt | 4 +- .../ut_rtmr/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_sequence/CMakeLists.darwin-arm64.txt | 3 +- .../ut_sequence/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_sequence/CMakeLists.linux-aarch64.txt | 4 +- .../ut_sequence/CMakeLists.linux-x86_64.txt | 4 +- .../ut_sequence/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_serverless/CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../ut_serverless/CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_stats/CMakeLists.darwin-arm64.txt | 3 +- .../ut_stats/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_stats/CMakeLists.linux-aarch64.txt | 4 +- .../ut_stats/CMakeLists.linux-x86_64.txt | 4 +- .../ut_stats/CMakeLists.windows-x86_64.txt | 1 + .../ut_subdomain/CMakeLists.darwin-arm64.txt | 3 +- .../ut_subdomain/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_subdomain/CMakeLists.linux-aarch64.txt | 4 +- .../ut_subdomain/CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_ttl/CMakeLists.darwin-arm64.txt | 3 +- .../ut_ttl/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_ttl/CMakeLists.linux-aarch64.txt | 4 +- .../ut_ttl/CMakeLists.linux-x86_64.txt | 4 +- .../ut_ttl/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut_view/CMakeLists.darwin-arm64.txt | 3 +- .../ut_view/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_view/CMakeLists.linux-aarch64.txt | 4 +- .../ut_view/CMakeLists.linux-x86_64.txt | 4 +- .../ut_view/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../public/ut/CMakeLists.darwin-arm64.txt | 3 +- .../public/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../public/ut/CMakeLists.linux-aarch64.txt | 4 +- .../public/ut/CMakeLists.linux-x86_64.txt | 4 +- .../public/ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../sharding/ut/CMakeLists.darwin-arm64.txt | 3 +- .../sharding/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../sharding/ut/CMakeLists.linux-aarch64.txt | 4 +- .../sharding/ut/CMakeLists.linux-x86_64.txt | 4 +- .../sharding/ut/CMakeLists.windows-x86_64.txt | 1 + .../tx/tiering/ut/CMakeLists.darwin-arm64.txt | 3 +- .../tiering/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../tiering/ut/CMakeLists.linux-aarch64.txt | 4 +- .../tx/tiering/ut/CMakeLists.linux-x86_64.txt | 4 +- .../tiering/ut/CMakeLists.windows-x86_64.txt | 1 + .../time_cast/ut/CMakeLists.darwin-arm64.txt | 3 +- .../time_cast/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../time_cast/ut/CMakeLists.linux-aarch64.txt | 4 +- .../time_cast/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../tx/tx_proxy/CMakeLists.darwin-arm64.txt | 2 +- .../tx/tx_proxy/CMakeLists.darwin-x86_64.txt | 2 +- .../tx/tx_proxy/CMakeLists.linux-aarch64.txt | 2 +- .../tx/tx_proxy/CMakeLists.linux-x86_64.txt | 2 +- .../tx/tx_proxy/CMakeLists.windows-x86_64.txt | 2 +- .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 4 +- .../CMakeLists.darwin-x86_64.txt | 4 +- .../CMakeLists.linux-aarch64.txt | 5 +- .../CMakeLists.linux-x86_64.txt | 5 +- .../CMakeLists.windows-x86_64.txt | 2 + .../ut_ext_tenant/CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../ut_ext_tenant/CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 4 +- .../CMakeLists.darwin-x86_64.txt | 4 +- .../CMakeLists.linux-aarch64.txt | 5 +- .../CMakeLists.linux-x86_64.txt | 5 +- .../CMakeLists.windows-x86_64.txt | 2 + ydb/core/util/CMakeLists.darwin-arm64.txt | 38 + ydb/core/util/CMakeLists.darwin-x86_64.txt | 38 + ydb/core/util/CMakeLists.linux-aarch64.txt | 38 + ydb/core/util/CMakeLists.linux-x86_64.txt | 38 + ydb/core/util/CMakeLists.windows-x86_64.txt | 38 + .../CMakeLists.darwin-arm64.txt | 2 - .../CMakeLists.darwin-x86_64.txt | 2 - .../CMakeLists.linux-aarch64.txt | 3 - .../CMakeLists.linux-x86_64.txt | 3 - ydb/core/util/ut/CMakeLists.darwin-arm64.txt | 3 +- ydb/core/util/ut/CMakeLists.darwin-x86_64.txt | 3 +- ydb/core/util/ut/CMakeLists.linux-aarch64.txt | 4 +- ydb/core/util/ut/CMakeLists.linux-x86_64.txt | 4 +- .../util/ut/CMakeLists.windows-x86_64.txt | 1 + ydb/core/viewer/CMakeLists.darwin-arm64.txt | 52 + ydb/core/viewer/CMakeLists.darwin-x86_64.txt | 52 + ydb/core/viewer/CMakeLists.linux-aarch64.txt | 52 + ydb/core/viewer/CMakeLists.linux-x86_64.txt | 52 + ydb/core/viewer/CMakeLists.windows-x86_64.txt | 52 + .../viewer/json/CMakeLists.darwin-arm64.txt | 1 + .../viewer/json/CMakeLists.darwin-x86_64.txt | 1 + .../viewer/json/CMakeLists.linux-aarch64.txt | 1 + .../viewer/json/CMakeLists.linux-x86_64.txt | 1 + .../viewer/json/CMakeLists.windows-x86_64.txt | 1 + .../viewer/protos/CMakeLists.darwin-arm64.txt | 3 + .../protos/CMakeLists.darwin-x86_64.txt | 3 + .../protos/CMakeLists.linux-aarch64.txt | 3 + .../viewer/protos/CMakeLists.linux-x86_64.txt | 3 + .../protos/CMakeLists.windows-x86_64.txt | 3 + .../viewer/ut/CMakeLists.darwin-arm64.txt | 3 +- .../viewer/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../viewer/ut/CMakeLists.linux-aarch64.txt | 4 +- .../viewer/ut/CMakeLists.linux-x86_64.txt | 4 +- .../viewer/ut/CMakeLists.windows-x86_64.txt | 1 + .../wrappers/ut/CMakeLists.darwin-arm64.txt | 4 +- .../wrappers/ut/CMakeLists.darwin-x86_64.txt | 4 +- .../wrappers/ut/CMakeLists.linux-aarch64.txt | 5 +- .../wrappers/ut/CMakeLists.linux-x86_64.txt | 5 +- .../wrappers/ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../ymq/actor/ut/CMakeLists.darwin-arm64.txt | 3 +- .../ymq/actor/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ymq/actor/ut/CMakeLists.linux-aarch64.txt | 4 +- .../ymq/actor/ut/CMakeLists.linux-x86_64.txt | 4 +- .../actor/ut/CMakeLists.windows-x86_64.txt | 1 + .../yc_search_ut/CMakeLists.darwin-arm64.txt | 3 +- .../yc_search_ut/CMakeLists.darwin-x86_64.txt | 3 +- .../yc_search_ut/CMakeLists.linux-aarch64.txt | 4 +- .../yc_search_ut/CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + ydb/core/ymq/base/CMakeLists.darwin-arm64.txt | 1 + .../ymq/base/CMakeLists.darwin-x86_64.txt | 1 + .../ymq/base/CMakeLists.linux-aarch64.txt | 1 + ydb/core/ymq/base/CMakeLists.linux-x86_64.txt | 1 + .../ymq/base/CMakeLists.windows-x86_64.txt | 1 + .../ymq/base/ut/CMakeLists.darwin-arm64.txt | 3 +- .../ymq/base/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ymq/base/ut/CMakeLists.linux-aarch64.txt | 4 +- .../ymq/base/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ymq/base/ut/CMakeLists.windows-x86_64.txt | 1 + .../client/bin/CMakeLists.darwin-arm64.txt | 2 - .../client/bin/CMakeLists.darwin-x86_64.txt | 2 - .../client/bin/CMakeLists.linux-aarch64.txt | 3 - .../client/bin/CMakeLists.linux-x86_64.txt | 3 - .../ymq/http/ut/CMakeLists.darwin-arm64.txt | 3 +- .../ymq/http/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ymq/http/ut/CMakeLists.linux-aarch64.txt | 4 +- .../ymq/http/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ymq/http/ut/CMakeLists.windows-x86_64.txt | 1 + .../ymq/proto/CMakeLists.darwin-arm64.txt | 4 + .../ymq/proto/CMakeLists.darwin-x86_64.txt | 4 + .../ymq/proto/CMakeLists.linux-aarch64.txt | 4 + .../ymq/proto/CMakeLists.linux-x86_64.txt | 4 + .../ymq/proto/CMakeLists.windows-x86_64.txt | 4 + ydb/core/ymq/ut/CMakeLists.darwin-arm64.txt | 3 +- ydb/core/ymq/ut/CMakeLists.darwin-x86_64.txt | 3 +- ydb/core/ymq/ut/CMakeLists.linux-aarch64.txt | 4 +- ydb/core/ymq/ut/CMakeLists.linux-x86_64.txt | 4 +- ydb/core/ymq/ut/CMakeLists.windows-x86_64.txt | 1 + .../yql_testlib/CMakeLists.darwin-arm64.txt | 1 + .../yql_testlib/CMakeLists.darwin-x86_64.txt | 1 + .../yql_testlib/CMakeLists.linux-aarch64.txt | 1 + .../yql_testlib/CMakeLists.linux-x86_64.txt | 1 + .../yql_testlib/CMakeLists.windows-x86_64.txt | 1 + ydb/library/CMakeLists.txt | 1 + .../accessor/CMakeLists.darwin-arm64.txt | 2 + .../accessor/CMakeLists.darwin-x86_64.txt | 2 + .../accessor/CMakeLists.linux-aarch64.txt | 2 + .../accessor/CMakeLists.linux-x86_64.txt | 2 + .../accessor/CMakeLists.windows-x86_64.txt | 2 + ydb/library/aclib/CMakeLists.darwin-arm64.txt | 1 + .../aclib/CMakeLists.darwin-x86_64.txt | 1 + .../aclib/CMakeLists.linux-aarch64.txt | 1 + ydb/library/aclib/CMakeLists.linux-x86_64.txt | 1 + .../aclib/CMakeLists.windows-x86_64.txt | 1 + .../aclib/protos/CMakeLists.darwin-arm64.txt | 3 + .../aclib/protos/CMakeLists.darwin-x86_64.txt | 3 + .../aclib/protos/CMakeLists.linux-aarch64.txt | 3 + .../aclib/protos/CMakeLists.linux-x86_64.txt | 3 + .../protos/CMakeLists.windows-x86_64.txt | 3 + .../aclib/ut/CMakeLists.darwin-arm64.txt | 1 + .../aclib/ut/CMakeLists.darwin-x86_64.txt | 1 + .../aclib/ut/CMakeLists.linux-aarch64.txt | 4 +- .../aclib/ut/CMakeLists.linux-x86_64.txt | 4 +- .../aclib/ut/CMakeLists.windows-x86_64.txt | 1 + .../actors/core/CMakeLists.darwin-arm64.txt | 47 + .../actors/core/CMakeLists.darwin-x86_64.txt | 47 + .../actors/core/CMakeLists.linux-aarch64.txt | 47 + .../actors/core/CMakeLists.linux-x86_64.txt | 47 + .../actors/core/CMakeLists.windows-x86_64.txt | 47 + .../core/ut/CMakeLists.darwin-arm64.txt | 3 +- .../core/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../core/ut/CMakeLists.linux-aarch64.txt | 4 +- .../core/ut/CMakeLists.linux-x86_64.txt | 4 +- .../core/ut/CMakeLists.windows-x86_64.txt | 1 + .../core/ut_fat/CMakeLists.darwin-arm64.txt | 3 +- .../core/ut_fat/CMakeLists.darwin-x86_64.txt | 3 +- .../core/ut_fat/CMakeLists.linux-aarch64.txt | 4 +- .../core/ut_fat/CMakeLists.linux-x86_64.txt | 4 +- .../core/ut_fat/CMakeLists.windows-x86_64.txt | 1 + .../cppcoro/CMakeLists.darwin-arm64.txt | 5 + .../cppcoro/CMakeLists.darwin-x86_64.txt | 5 + .../cppcoro/CMakeLists.linux-aarch64.txt | 5 + .../cppcoro/CMakeLists.linux-x86_64.txt | 5 + .../cppcoro/CMakeLists.windows-x86_64.txt | 5 + .../corobenchmark/CMakeLists.darwin-arm64.txt | 2 - .../CMakeLists.darwin-x86_64.txt | 2 - .../CMakeLists.linux-aarch64.txt | 3 - .../corobenchmark/CMakeLists.linux-x86_64.txt | 3 - .../cppcoro/ut/CMakeLists.darwin-arm64.txt | 3 +- .../cppcoro/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../cppcoro/ut/CMakeLists.linux-aarch64.txt | 4 +- .../cppcoro/ut/CMakeLists.linux-x86_64.txt | 4 +- .../cppcoro/ut/CMakeLists.windows-x86_64.txt | 1 + .../dnscachelib/CMakeLists.darwin-arm64.txt | 3 + .../dnscachelib/CMakeLists.darwin-x86_64.txt | 3 + .../dnscachelib/CMakeLists.linux-aarch64.txt | 3 + .../dnscachelib/CMakeLists.linux-x86_64.txt | 3 + .../dnscachelib/CMakeLists.windows-x86_64.txt | 3 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../01_ping_pong/CMakeLists.darwin-arm64.txt | 2 - .../01_ping_pong/CMakeLists.darwin-x86_64.txt | 2 - .../01_ping_pong/CMakeLists.linux-aarch64.txt | 3 - .../01_ping_pong/CMakeLists.linux-x86_64.txt | 3 - .../02_discovery/CMakeLists.darwin-arm64.txt | 4 +- .../02_discovery/CMakeLists.darwin-x86_64.txt | 4 +- .../02_discovery/CMakeLists.linux-aarch64.txt | 5 +- .../02_discovery/CMakeLists.linux-x86_64.txt | 5 +- .../CMakeLists.windows-x86_64.txt | 2 + .../helpers/CMakeLists.darwin-arm64.txt | 4 + .../helpers/CMakeLists.darwin-x86_64.txt | 4 + .../helpers/CMakeLists.linux-aarch64.txt | 4 + .../helpers/CMakeLists.linux-x86_64.txt | 4 + .../helpers/CMakeLists.windows-x86_64.txt | 4 + .../helpers/ut/CMakeLists.darwin-arm64.txt | 3 +- .../helpers/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../helpers/ut/CMakeLists.linux-aarch64.txt | 4 +- .../helpers/ut/CMakeLists.linux-x86_64.txt | 4 +- .../helpers/ut/CMakeLists.windows-x86_64.txt | 1 + .../actors/http/CMakeLists.darwin-arm64.txt | 8 + .../actors/http/CMakeLists.darwin-x86_64.txt | 8 + .../actors/http/CMakeLists.linux-aarch64.txt | 8 + .../actors/http/CMakeLists.linux-x86_64.txt | 8 + .../actors/http/CMakeLists.windows-x86_64.txt | 8 + .../http/ut/CMakeLists.darwin-arm64.txt | 3 +- .../http/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../http/ut/CMakeLists.linux-aarch64.txt | 4 +- .../http/ut/CMakeLists.linux-x86_64.txt | 4 +- .../http/ut/CMakeLists.windows-x86_64.txt | 1 + .../interconnect/CMakeLists.darwin-arm64.txt | 28 + .../interconnect/CMakeLists.darwin-x86_64.txt | 28 + .../interconnect/CMakeLists.linux-aarch64.txt | 29 + .../interconnect/CMakeLists.linux-x86_64.txt | 29 + .../CMakeLists.windows-x86_64.txt | 28 + .../mock/CMakeLists.darwin-arm64.txt | 1 + .../mock/CMakeLists.darwin-x86_64.txt | 1 + .../mock/CMakeLists.linux-aarch64.txt | 1 + .../mock/CMakeLists.linux-x86_64.txt | 1 + .../mock/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/lib/CMakeLists.darwin-arm64.txt | 6 + .../ut/lib/CMakeLists.darwin-x86_64.txt | 6 + .../ut/lib/CMakeLists.linux-aarch64.txt | 6 + .../ut/lib/CMakeLists.linux-x86_64.txt | 6 + .../ut/lib/CMakeLists.windows-x86_64.txt | 6 + .../ut/protos/CMakeLists.darwin-arm64.txt | 3 + .../ut/protos/CMakeLists.darwin-x86_64.txt | 3 + .../ut/protos/CMakeLists.linux-aarch64.txt | 3 + .../ut/protos/CMakeLists.linux-x86_64.txt | 3 + .../ut/protos/CMakeLists.windows-x86_64.txt | 3 + .../ut_fat/CMakeLists.darwin-arm64.txt | 3 +- .../ut_fat/CMakeLists.darwin-x86_64.txt | 3 +- .../ut_fat/CMakeLists.linux-aarch64.txt | 4 +- .../ut_fat/CMakeLists.linux-x86_64.txt | 4 +- .../ut_fat/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../memory_log/CMakeLists.darwin-arm64.txt | 1 + .../memory_log/CMakeLists.darwin-x86_64.txt | 1 + .../memory_log/CMakeLists.linux-aarch64.txt | 1 + .../memory_log/CMakeLists.linux-x86_64.txt | 1 + .../memory_log/CMakeLists.windows-x86_64.txt | 1 + .../prof/ut/CMakeLists.darwin-arm64.txt | 3 +- .../prof/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../prof/ut/CMakeLists.linux-aarch64.txt | 4 +- .../prof/ut/CMakeLists.linux-x86_64.txt | 4 +- .../prof/ut/CMakeLists.windows-x86_64.txt | 1 + .../actors/protos/CMakeLists.darwin-arm64.txt | 6 + .../protos/CMakeLists.darwin-x86_64.txt | 6 + .../protos/CMakeLists.linux-aarch64.txt | 6 + .../actors/protos/CMakeLists.linux-x86_64.txt | 6 + .../protos/CMakeLists.windows-x86_64.txt | 6 + .../testlib/CMakeLists.darwin-arm64.txt | 2 + .../testlib/CMakeLists.darwin-x86_64.txt | 2 + .../testlib/CMakeLists.linux-aarch64.txt | 2 + .../testlib/CMakeLists.linux-x86_64.txt | 2 + .../testlib/CMakeLists.windows-x86_64.txt | 2 + .../common/CMakeLists.darwin-arm64.txt | 18 + .../common/CMakeLists.darwin-x86_64.txt | 18 + .../common}/CMakeLists.linux-aarch64.txt | 22 +- .../common}/CMakeLists.linux-x86_64.txt | 22 +- .../actors/testlib/common/CMakeLists.txt | 19 + .../common}/CMakeLists.windows-x86_64.txt | 20 +- .../testlib/ut/CMakeLists.darwin-arm64.txt | 3 +- .../testlib/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../testlib/ut/CMakeLists.linux-aarch64.txt | 4 +- .../testlib/ut/CMakeLists.linux-x86_64.txt | 4 +- .../testlib/ut/CMakeLists.windows-x86_64.txt | 1 + .../actors/util/CMakeLists.darwin-arm64.txt | 26 + .../actors/util/CMakeLists.darwin-x86_64.txt | 26 + .../actors/util/CMakeLists.linux-aarch64.txt | 26 + .../actors/util/CMakeLists.linux-x86_64.txt | 26 + .../actors/util/CMakeLists.windows-x86_64.txt | 26 + .../util/ut/CMakeLists.darwin-arm64.txt | 3 +- .../util/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../util/ut/CMakeLists.linux-aarch64.txt | 4 +- .../util/ut/CMakeLists.linux-x86_64.txt | 4 +- .../util/ut/CMakeLists.windows-x86_64.txt | 1 + .../actors/wilson/CMakeLists.darwin-arm64.txt | 3 + .../wilson/CMakeLists.darwin-x86_64.txt | 3 + .../wilson/CMakeLists.linux-aarch64.txt | 3 + .../actors/wilson/CMakeLists.linux-x86_64.txt | 3 + .../wilson/CMakeLists.windows-x86_64.txt | 3 + .../test_util/CMakeLists.darwin-arm64.txt | 17 + .../test_util/CMakeLists.darwin-x86_64.txt | 17 + .../test_util/CMakeLists.linux-aarch64.txt | 18 + .../test_util/CMakeLists.linux-x86_64.txt | 18 + .../actors/wilson/test_util/CMakeLists.txt | 19 + .../test_util/CMakeLists.windows-x86_64.txt | 17 + .../wilson/ut/CMakeLists.darwin-arm64.txt | 65 + .../wilson/ut/CMakeLists.darwin-x86_64.txt | 66 + .../wilson/ut/CMakeLists.linux-aarch64.txt | 68 + .../wilson/ut/CMakeLists.linux-x86_64.txt | 70 + ydb/library/actors/wilson/ut/CMakeLists.txt | 19 + .../wilson/ut/CMakeLists.windows-x86_64.txt | 61 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../arrow_kernels/CMakeLists.darwin-arm64.txt | 12 + .../CMakeLists.darwin-x86_64.txt | 12 + .../CMakeLists.linux-aarch64.txt | 12 + .../arrow_kernels/CMakeLists.linux-x86_64.txt | 12 + .../CMakeLists.windows-x86_64.txt | 12 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 22 +- .../CMakeLists.darwin-x86_64.txt | 22 +- .../CMakeLists.linux-aarch64.txt | 20 + .../arrow_parquet/CMakeLists.linux-x86_64.txt | 20 + ydb/library/arrow_parquet/CMakeLists.txt | 19 + .../CMakeLists.windows-x86_64.txt | 19 + .../backup/ut/CMakeLists.darwin-arm64.txt | 3 +- .../backup/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../backup/ut/CMakeLists.linux-aarch64.txt | 4 +- .../backup/ut/CMakeLists.linux-x86_64.txt | 4 +- .../backup/ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 5 +- .../ut/CMakeLists.darwin-x86_64.txt | 5 +- .../ut/CMakeLists.linux-aarch64.txt | 6 +- .../ut/CMakeLists.linux-x86_64.txt | 6 +- .../ut/CMakeLists.windows-x86_64.txt | 3 +- .../conclusion/CMakeLists.darwin-arm64.txt | 1 + .../conclusion/CMakeLists.darwin-x86_64.txt | 1 + .../conclusion/CMakeLists.linux-aarch64.txt | 1 + .../conclusion/CMakeLists.linux-x86_64.txt | 1 + .../conclusion/CMakeLists.windows-x86_64.txt | 1 + .../protos/CMakeLists.darwin-arm64.txt | 3 + .../protos/CMakeLists.darwin-x86_64.txt | 3 + .../protos/CMakeLists.linux-aarch64.txt | 3 + .../protos/CMakeLists.linux-x86_64.txt | 3 + .../protos/CMakeLists.windows-x86_64.txt | 3 + .../dynumber/CMakeLists.darwin-arm64.txt | 1 + .../dynumber/CMakeLists.darwin-x86_64.txt | 1 + .../dynumber/CMakeLists.linux-aarch64.txt | 1 + .../dynumber/CMakeLists.linux-x86_64.txt | 1 + .../dynumber/CMakeLists.windows-x86_64.txt | 1 + .../dynumber/ut/CMakeLists.darwin-arm64.txt | 1 + .../dynumber/ut/CMakeLists.darwin-x86_64.txt | 1 + .../dynumber/ut/CMakeLists.linux-aarch64.txt | 4 +- .../dynumber/ut/CMakeLists.linux-x86_64.txt | 4 +- .../dynumber/ut/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 2 + .../CMakeLists.darwin-x86_64.txt | 2 + .../CMakeLists.linux-aarch64.txt | 2 + .../CMakeLists.linux-x86_64.txt | 2 + .../CMakeLists.windows-x86_64.txt | 2 + .../proto/CMakeLists.darwin-arm64.txt | 3 + .../proto/CMakeLists.darwin-x86_64.txt | 3 + .../proto/CMakeLists.linux-aarch64.txt | 3 + .../proto/CMakeLists.linux-x86_64.txt | 3 + .../proto/CMakeLists.windows-x86_64.txt | 3 + .../fyamlcpp/CMakeLists.darwin-arm64.txt | 1 + .../fyamlcpp/CMakeLists.darwin-x86_64.txt | 1 + .../fyamlcpp/CMakeLists.linux-aarch64.txt | 1 + .../fyamlcpp/CMakeLists.linux-x86_64.txt | 1 + .../fyamlcpp/CMakeLists.windows-x86_64.txt | 1 + .../client/ut/CMakeLists.darwin-arm64.txt | 3 +- .../client/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../client/ut/CMakeLists.linux-aarch64.txt | 4 +- .../client/ut/CMakeLists.linux-x86_64.txt | 4 +- .../client/ut/CMakeLists.windows-x86_64.txt | 1 + .../grpc/common/CMakeLists.darwin-arm64.txt | 4 + .../grpc/common/CMakeLists.darwin-x86_64.txt | 4 + .../grpc/common/CMakeLists.linux-aarch64.txt | 4 + .../grpc/common/CMakeLists.linux-x86_64.txt | 4 + .../grpc/common/CMakeLists.windows-x86_64.txt | 4 + .../server/ut/CMakeLists.darwin-arm64.txt | 3 +- .../server/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../server/ut/CMakeLists.linux-aarch64.txt | 4 +- .../server/ut/CMakeLists.linux-x86_64.txt | 4 +- .../server/ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 1 + .../ut/CMakeLists.darwin-x86_64.txt | 1 + .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../keys/ut/CMakeLists.darwin-arm64.txt | 1 + .../keys/ut/CMakeLists.darwin-x86_64.txt | 1 + .../keys/ut/CMakeLists.linux-aarch64.txt | 4 +- .../keys/ut/CMakeLists.linux-x86_64.txt | 4 +- .../keys/ut/CMakeLists.windows-x86_64.txt | 1 + ydb/library/login/CMakeLists.darwin-arm64.txt | 1 + .../login/CMakeLists.darwin-x86_64.txt | 1 + .../login/CMakeLists.linux-aarch64.txt | 1 + ydb/library/login/CMakeLists.linux-x86_64.txt | 1 + .../login/CMakeLists.windows-x86_64.txt | 1 + .../login/protos/CMakeLists.darwin-arm64.txt | 3 + .../login/protos/CMakeLists.darwin-x86_64.txt | 3 + .../login/protos/CMakeLists.linux-aarch64.txt | 3 + .../login/protos/CMakeLists.linux-x86_64.txt | 3 + .../protos/CMakeLists.windows-x86_64.txt | 3 + .../login/ut/CMakeLists.darwin-arm64.txt | 1 + .../login/ut/CMakeLists.darwin-x86_64.txt | 1 + .../login/ut/CMakeLists.linux-aarch64.txt | 4 +- .../login/ut/CMakeLists.linux-x86_64.txt | 4 +- .../login/ut/CMakeLists.windows-x86_64.txt | 1 + .../mkql_proto/CMakeLists.darwin-arm64.txt | 2 +- .../mkql_proto/CMakeLists.darwin-x86_64.txt | 2 +- .../mkql_proto/CMakeLists.linux-aarch64.txt | 2 +- .../mkql_proto/CMakeLists.linux-x86_64.txt | 2 +- .../mkql_proto/CMakeLists.windows-x86_64.txt | 2 +- .../protos/CMakeLists.darwin-arm64.txt | 4 + .../protos/CMakeLists.darwin-x86_64.txt | 4 + .../protos/CMakeLists.linux-aarch64.txt | 4 + .../protos/CMakeLists.linux-x86_64.txt | 4 + .../protos/CMakeLists.windows-x86_64.txt | 4 + .../mkql_proto/ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../mkql_proto/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/helpers/CMakeLists.darwin-arm64.txt | 2 +- .../ut/helpers/CMakeLists.darwin-x86_64.txt | 2 +- .../ut/helpers/CMakeLists.linux-aarch64.txt | 2 +- .../ut/helpers/CMakeLists.linux-x86_64.txt | 2 +- .../ut/helpers/CMakeLists.windows-x86_64.txt | 2 +- .../ut/CMakeLists.darwin-arm64.txt | 1 + .../ut/CMakeLists.darwin-x86_64.txt | 1 + .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../pdisk_io/CMakeLists.darwin-arm64.txt | 6 + .../pdisk_io/CMakeLists.darwin-x86_64.txt | 6 + .../pdisk_io/CMakeLists.linux-aarch64.txt | 6 + .../pdisk_io/CMakeLists.linux-x86_64.txt | 6 + .../pdisk_io/CMakeLists.windows-x86_64.txt | 6 + .../protos/CMakeLists.darwin-arm64.txt | 3 + .../protos/CMakeLists.darwin-x86_64.txt | 3 + .../protos/CMakeLists.linux-aarch64.txt | 3 + .../protos/CMakeLists.linux-x86_64.txt | 3 + .../protos/CMakeLists.windows-x86_64.txt | 3 + .../CMakeLists.darwin-arm64.txt | 1 + .../CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.linux-aarch64.txt | 1 + .../CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../obfuscate/CMakeLists.darwin-arm64.txt | 1 + .../obfuscate/CMakeLists.darwin-x86_64.txt | 1 + .../obfuscate/CMakeLists.linux-aarch64.txt | 1 + .../obfuscate/CMakeLists.linux-x86_64.txt | 1 + .../obfuscate/CMakeLists.windows-x86_64.txt | 1 + .../topic_parser/CMakeLists.darwin-arm64.txt | 3 + .../topic_parser/CMakeLists.darwin-x86_64.txt | 3 + .../topic_parser/CMakeLists.linux-aarch64.txt | 3 + .../topic_parser/CMakeLists.linux-x86_64.txt | 3 + .../CMakeLists.windows-x86_64.txt | 3 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 1 + .../CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.linux-aarch64.txt | 1 + .../CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 4 +- .../ut/CMakeLists.darwin-x86_64.txt | 4 +- .../ut/CMakeLists.linux-aarch64.txt | 5 +- .../ut/CMakeLists.linux-x86_64.txt | 5 +- .../ut/CMakeLists.windows-x86_64.txt | 2 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../proto/CMakeLists.darwin-arm64.txt | 3 + .../proto/CMakeLists.darwin-x86_64.txt | 3 + .../proto/CMakeLists.linux-aarch64.txt | 3 + .../proto/CMakeLists.linux-x86_64.txt | 3 + .../proto/CMakeLists.windows-x86_64.txt | 3 + .../schlab/CMakeLists.darwin-arm64.txt | 2 + .../schlab/CMakeLists.darwin-x86_64.txt | 2 + .../schlab/CMakeLists.linux-aarch64.txt | 2 + .../schlab/CMakeLists.linux-x86_64.txt | 2 + .../schlab/CMakeLists.windows-x86_64.txt | 2 + .../mon/test/CMakeLists.linux-aarch64.txt | 3 - .../mon/test/CMakeLists.linux-x86_64.txt | 3 - .../schlab/probes/CMakeLists.darwin-arm64.txt | 1 + .../probes/CMakeLists.darwin-x86_64.txt | 1 + .../probes/CMakeLists.linux-aarch64.txt | 1 + .../schlab/probes/CMakeLists.linux-x86_64.txt | 1 + .../probes/CMakeLists.windows-x86_64.txt | 1 + .../schlab/protos/CMakeLists.darwin-arm64.txt | 3 + .../protos/CMakeLists.darwin-x86_64.txt | 3 + .../protos/CMakeLists.linux-aarch64.txt | 3 + .../schlab/protos/CMakeLists.linux-x86_64.txt | 3 + .../protos/CMakeLists.windows-x86_64.txt | 3 + .../schlab/schemu/CMakeLists.darwin-arm64.txt | 2 + .../schemu/CMakeLists.darwin-x86_64.txt | 2 + .../schemu/CMakeLists.linux-aarch64.txt | 2 + .../schlab/schemu/CMakeLists.linux-x86_64.txt | 2 + .../schemu/CMakeLists.windows-x86_64.txt | 2 + .../schlab/schine/CMakeLists.darwin-arm64.txt | 12 + .../schine/CMakeLists.darwin-x86_64.txt | 12 + .../schine/CMakeLists.linux-aarch64.txt | 12 + .../schlab/schine/CMakeLists.linux-x86_64.txt | 12 + .../schine/CMakeLists.windows-x86_64.txt | 12 + .../schlab/schoot/CMakeLists.darwin-arm64.txt | 3 + .../schoot/CMakeLists.darwin-x86_64.txt | 3 + .../schoot/CMakeLists.linux-aarch64.txt | 3 + .../schlab/schoot/CMakeLists.linux-x86_64.txt | 3 + .../schoot/CMakeLists.windows-x86_64.txt | 3 + .../schlab/ut/CMakeLists.darwin-arm64.txt | 1 + .../schlab/ut/CMakeLists.darwin-x86_64.txt | 1 + .../schlab/ut/CMakeLists.linux-aarch64.txt | 4 +- .../schlab/ut/CMakeLists.linux-x86_64.txt | 4 +- .../schlab/ut/CMakeLists.windows-x86_64.txt | 1 + .../security/ut/CMakeLists.darwin-arm64.txt | 3 +- .../security/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../security/ut/CMakeLists.linux-aarch64.txt | 4 +- .../security/ut/CMakeLists.linux-x86_64.txt | 4 +- .../security/ut/CMakeLists.windows-x86_64.txt | 1 + .../services/CMakeLists.darwin-arm64.txt | 4 + .../services/CMakeLists.darwin-x86_64.txt | 4 + .../services/CMakeLists.linux-aarch64.txt | 4 + .../services/CMakeLists.linux-x86_64.txt | 4 + .../services/CMakeLists.windows-x86_64.txt | 4 + .../table_creator/CMakeLists.darwin-arm64.txt | 1 + .../CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.linux-aarch64.txt | 1 + .../table_creator/CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../service_mocks/CMakeLists.darwin-arm64.txt | 10 + .../CMakeLists.darwin-x86_64.txt | 10 + .../CMakeLists.linux-aarch64.txt | 10 + .../service_mocks/CMakeLists.linux-x86_64.txt | 10 + .../CMakeLists.windows-x86_64.txt | 10 + .../testlib/ut/CMakeLists.darwin-arm64.txt | 3 +- .../testlib/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../testlib/ut/CMakeLists.linux-aarch64.txt | 4 +- .../testlib/ut/CMakeLists.linux-x86_64.txt | 4 +- .../testlib/ut/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 + .../CMakeLists.darwin-x86_64.txt | 3 + .../CMakeLists.linux-aarch64.txt | 3 + .../CMakeLists.linux-x86_64.txt | 3 + .../CMakeLists.windows-x86_64.txt | 3 + .../ut/CMakeLists.darwin-arm64.txt | 1 + .../ut/CMakeLists.darwin-x86_64.txt | 1 + .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../wilson_ids/CMakeLists.darwin-arm64.txt | 3 + .../wilson_ids/CMakeLists.darwin-x86_64.txt | 3 + .../wilson_ids/CMakeLists.linux-aarch64.txt | 3 + .../wilson_ids/CMakeLists.linux-x86_64.txt | 3 + .../wilson_ids/CMakeLists.windows-x86_64.txt | 3 + .../workload/CMakeLists.darwin-arm64.txt | 52 +- .../workload/CMakeLists.darwin-x86_64.txt | 44 +- .../workload/CMakeLists.linux-aarch64.txt | 45 +- .../workload/CMakeLists.linux-x86_64.txt | 45 +- .../workload/CMakeLists.windows-x86_64.txt | 44 +- .../yaml_config/CMakeLists.darwin-arm64.txt | 3 + .../yaml_config/CMakeLists.darwin-x86_64.txt | 3 + .../yaml_config/CMakeLists.linux-aarch64.txt | 3 + .../yaml_config/CMakeLists.linux-x86_64.txt | 3 + .../yaml_config/CMakeLists.windows-x86_64.txt | 3 + .../public/CMakeLists.darwin-arm64.txt | 1 + .../public/CMakeLists.darwin-x86_64.txt | 1 + .../public/CMakeLists.linux-aarch64.txt | 1 + .../public/CMakeLists.linux-x86_64.txt | 1 + .../public/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 1 + .../CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.linux-aarch64.txt | 1 + .../CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 1 + .../ut/CMakeLists.darwin-x86_64.txt | 1 + .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 1 + .../CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../validator/CMakeLists.darwin-arm64.txt | 4 + .../validator/CMakeLists.darwin-x86_64.txt | 4 + .../validator/CMakeLists.linux-aarch64.txt | 4 + .../validator/CMakeLists.linux-x86_64.txt | 4 + .../validator/CMakeLists.windows-x86_64.txt | 4 + .../ut/validator/CMakeLists.darwin-arm64.txt | 1 + .../ut/validator/CMakeLists.darwin-x86_64.txt | 1 + .../ut/validator/CMakeLists.linux-aarch64.txt | 4 +- .../ut/validator/CMakeLists.linux-x86_64.txt | 4 +- .../validator/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 1 + .../CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 1 + .../CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ycloud/api/CMakeLists.darwin-arm64.txt | 8 + .../ycloud/api/CMakeLists.darwin-x86_64.txt | 8 + .../ycloud/api/CMakeLists.linux-aarch64.txt | 8 + .../ycloud/api/CMakeLists.linux-x86_64.txt | 8 + .../ycloud/api/CMakeLists.windows-x86_64.txt | 8 + .../ycloud/impl/CMakeLists.darwin-arm64.txt | 10 + .../ycloud/impl/CMakeLists.darwin-x86_64.txt | 10 + .../ycloud/impl/CMakeLists.linux-aarch64.txt | 10 + .../ycloud/impl/CMakeLists.linux-x86_64.txt | 10 + .../ycloud/impl/CMakeLists.windows-x86_64.txt | 10 + .../impl/ut/CMakeLists.darwin-arm64.txt | 3 +- .../impl/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../impl/ut/CMakeLists.linux-aarch64.txt | 4 +- .../impl/ut/CMakeLists.linux-x86_64.txt | 4 +- .../impl/ut/CMakeLists.windows-x86_64.txt | 1 + .../ydb_issue/CMakeLists.darwin-arm64.txt | 1 + .../ydb_issue/CMakeLists.darwin-x86_64.txt | 1 + .../ydb_issue/CMakeLists.linux-aarch64.txt | 1 + .../ydb_issue/CMakeLists.linux-x86_64.txt | 1 + .../ydb_issue/CMakeLists.windows-x86_64.txt | 1 + .../proto/CMakeLists.darwin-arm64.txt | 4 + .../proto/CMakeLists.darwin-x86_64.txt | 4 + .../proto/CMakeLists.linux-aarch64.txt | 4 + .../proto/CMakeLists.linux-x86_64.txt | 4 + .../proto/CMakeLists.windows-x86_64.txt | 4 + ydb/library/yql/CMakeLists.darwin-arm64.txt | 20 + ydb/library/yql/CMakeLists.darwin-x86_64.txt | 20 + ydb/library/yql/CMakeLists.linux-aarch64.txt | 21 + ydb/library/yql/CMakeLists.linux-x86_64.txt | 21 + ydb/library/yql/CMakeLists.txt | 23 +- ydb/library/yql/CMakeLists.windows-x86_64.txt | 20 + .../yql/ast/CMakeLists.darwin-arm64.txt | 10 + .../yql/ast/CMakeLists.darwin-x86_64.txt | 10 + .../yql/ast/CMakeLists.linux-aarch64.txt | 10 + .../yql/ast/CMakeLists.linux-x86_64.txt | 10 + .../yql/ast/CMakeLists.windows-x86_64.txt | 10 + .../yql/ast/ut/CMakeLists.darwin-arm64.txt | 3 +- .../yql/ast/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../yql/ast/ut/CMakeLists.linux-aarch64.txt | 4 +- .../yql/ast/ut/CMakeLists.linux-x86_64.txt | 4 +- .../yql/ast/ut/CMakeLists.windows-x86_64.txt | 1 + .../yql/core/CMakeLists.darwin-arm64.txt | 28 +- .../yql/core/CMakeLists.darwin-x86_64.txt | 28 +- .../yql/core/CMakeLists.linux-aarch64.txt | 27 + .../yql/core/CMakeLists.linux-x86_64.txt | 27 + .../yql/core/CMakeLists.windows-x86_64.txt | 28 +- .../registry/CMakeLists.darwin-arm64.txt | 2 +- .../registry/CMakeLists.darwin-x86_64.txt | 2 +- .../registry/CMakeLists.linux-aarch64.txt | 2 +- .../registry/CMakeLists.linux-x86_64.txt | 2 +- .../registry/CMakeLists.windows-x86_64.txt | 2 +- .../registry/ut/CMakeLists.darwin-arm64.txt | 5 +- .../registry/ut/CMakeLists.darwin-x86_64.txt | 5 +- .../registry/ut/CMakeLists.linux-aarch64.txt | 6 +- .../registry/ut/CMakeLists.linux-x86_64.txt | 6 +- .../registry/ut/CMakeLists.windows-x86_64.txt | 3 +- .../yql/core/cbo/CMakeLists.darwin-arm64.txt | 1 + .../yql/core/cbo/CMakeLists.darwin-x86_64.txt | 1 + .../yql/core/cbo/CMakeLists.linux-aarch64.txt | 1 + .../yql/core/cbo/CMakeLists.linux-x86_64.txt | 1 + .../core/cbo/CMakeLists.windows-x86_64.txt | 1 + .../core/cbo/ut/CMakeLists.darwin-arm64.txt | 1 + .../core/cbo/ut/CMakeLists.darwin-x86_64.txt | 1 + .../core/cbo/ut/CMakeLists.linux-aarch64.txt | 4 +- .../core/cbo/ut/CMakeLists.linux-x86_64.txt | 4 +- .../core/cbo/ut/CMakeLists.windows-x86_64.txt | 1 + .../common_opt/CMakeLists.darwin-arm64.txt | 3 + .../common_opt/CMakeLists.darwin-x86_64.txt | 3 + .../common_opt/CMakeLists.linux-aarch64.txt | 3 + .../common_opt/CMakeLists.linux-x86_64.txt | 3 + .../common_opt/CMakeLists.windows-x86_64.txt | 3 + .../expr_nodes/CMakeLists.darwin-arm64.txt | 4 + .../expr_nodes/CMakeLists.darwin-x86_64.txt | 4 + .../expr_nodes/CMakeLists.linux-aarch64.txt | 4 + .../expr_nodes/CMakeLists.linux-x86_64.txt | 4 + .../expr_nodes/CMakeLists.windows-x86_64.txt | 4 + .../CMakeLists.darwin-arm64.txt | 1 + .../CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.linux-aarch64.txt | 1 + .../CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 4 + .../CMakeLists.darwin-x86_64.txt | 4 + .../CMakeLists.linux-aarch64.txt | 4 + .../CMakeLists.linux-x86_64.txt | 4 + .../CMakeLists.windows-x86_64.txt | 4 + .../ut/CMakeLists.darwin-arm64.txt | 7 +- .../ut/CMakeLists.darwin-x86_64.txt | 7 +- .../ut/CMakeLists.linux-aarch64.txt | 9 +- .../ut/CMakeLists.linux-x86_64.txt | 9 +- .../ut/CMakeLists.windows-x86_64.txt | 5 + .../file_storage/CMakeLists.darwin-arm64.txt | 4 + .../file_storage/CMakeLists.darwin-x86_64.txt | 4 + .../file_storage/CMakeLists.linux-aarch64.txt | 4 + .../file_storage/CMakeLists.linux-x86_64.txt | 4 + .../CMakeLists.windows-x86_64.txt | 4 + .../proto/CMakeLists.darwin-arm64.txt | 3 + .../proto/CMakeLists.darwin-x86_64.txt | 3 + .../proto/CMakeLists.linux-aarch64.txt | 3 + .../proto/CMakeLists.linux-x86_64.txt | 3 + .../proto/CMakeLists.windows-x86_64.txt | 3 + .../proto/CMakeLists.darwin-arm64.txt | 3 + .../proto/CMakeLists.darwin-x86_64.txt | 3 + .../proto/CMakeLists.linux-aarch64.txt | 3 + .../proto/CMakeLists.linux-x86_64.txt | 3 + .../proto/CMakeLists.windows-x86_64.txt | 3 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../issue/protos/CMakeLists.darwin-arm64.txt | 3 + .../issue/protos/CMakeLists.darwin-x86_64.txt | 3 + .../issue/protos/CMakeLists.linux-aarch64.txt | 3 + .../issue/protos/CMakeLists.linux-x86_64.txt | 3 + .../protos/CMakeLists.windows-x86_64.txt | 3 + .../core/issue/ut/CMakeLists.darwin-arm64.txt | 3 +- .../issue/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../issue/ut/CMakeLists.linux-aarch64.txt | 4 +- .../core/issue/ut/CMakeLists.linux-x86_64.txt | 4 +- .../issue/ut/CMakeLists.windows-x86_64.txt | 1 + .../peephole_opt/CMakeLists.darwin-arm64.txt | 2 + .../peephole_opt/CMakeLists.darwin-x86_64.txt | 2 + .../peephole_opt/CMakeLists.linux-aarch64.txt | 2 + .../peephole_opt/CMakeLists.linux-x86_64.txt | 2 + .../CMakeLists.windows-x86_64.txt | 2 + .../pg_settings/CMakeLists.darwin-arm64.txt | 17 + .../pg_settings/CMakeLists.darwin-x86_64.txt | 17 + .../pg_settings/CMakeLists.linux-aarch64.txt | 18 + .../pg_settings/CMakeLists.linux-x86_64.txt | 18 + .../yql/core/pg_settings/CMakeLists.txt | 19 + .../pg_settings/CMakeLists.windows-x86_64.txt | 17 + .../CMakeLists.linux-aarch64.txt | 1 + .../CMakeLists.linux-x86_64.txt | 1 + .../yql/core/progress_merger/CMakeLists.txt | 6 - .../core/services/CMakeLists.darwin-arm64.txt | 6 + .../services/CMakeLists.darwin-x86_64.txt | 6 + .../services/CMakeLists.linux-aarch64.txt | 6 + .../core/services/CMakeLists.linux-x86_64.txt | 6 + .../services/CMakeLists.windows-x86_64.txt | 6 + .../mounts/CMakeLists.darwin-arm64.txt | 1 + .../mounts/CMakeLists.darwin-x86_64.txt | 1 + .../mounts/CMakeLists.linux-aarch64.txt | 1 + .../mounts/CMakeLists.linux-x86_64.txt | 1 + .../mounts/CMakeLists.windows-x86_64.txt | 1 + .../core/spilling/CMakeLists.darwin-arm64.txt | 12 +- .../spilling/CMakeLists.darwin-x86_64.txt | 12 +- .../spilling/CMakeLists.linux-aarch64.txt | 12 +- .../core/spilling/CMakeLists.linux-x86_64.txt | 12 +- .../spilling/CMakeLists.windows-x86_64.txt | 12 +- .../storage/CMakeLists.darwin-arm64.txt | 8 +- .../storage/CMakeLists.darwin-x86_64.txt | 8 +- .../storage/CMakeLists.linux-aarch64.txt | 8 +- .../storage/CMakeLists.linux-x86_64.txt | 8 +- .../storage/CMakeLists.windows-x86_64.txt | 8 +- .../file_storage/CMakeLists.darwin-arm64.txt | 7 - .../file_storage/CMakeLists.darwin-x86_64.txt | 7 - .../file_storage/CMakeLists.linux-aarch64.txt | 7 - .../file_storage/CMakeLists.linux-x86_64.txt | 7 - .../CMakeLists.windows-x86_64.txt | 7 - .../storage/ut/CMakeLists.darwin-arm64.txt | 3 +- .../storage/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../storage/ut/CMakeLists.linux-aarch64.txt | 4 +- .../storage/ut/CMakeLists.linux-x86_64.txt | 4 +- .../storage/ut/CMakeLists.windows-x86_64.txt | 1 + .../spilling/ut/CMakeLists.darwin-arm64.txt | 4 +- .../spilling/ut/CMakeLists.darwin-x86_64.txt | 4 +- .../spilling/ut/CMakeLists.linux-aarch64.txt | 5 +- .../spilling/ut/CMakeLists.linux-x86_64.txt | 5 +- .../spilling/ut/CMakeLists.windows-x86_64.txt | 2 + .../sql_types/CMakeLists.darwin-arm64.txt | 2 + .../sql_types/CMakeLists.darwin-x86_64.txt | 2 + .../sql_types/CMakeLists.linux-aarch64.txt | 2 + .../sql_types/CMakeLists.linux-x86_64.txt | 2 + .../sql_types/CMakeLists.windows-x86_64.txt | 2 + .../sql_types/ut/CMakeLists.darwin-arm64.txt | 1 + .../sql_types/ut/CMakeLists.darwin-x86_64.txt | 1 + .../sql_types/ut/CMakeLists.linux-aarch64.txt | 4 +- .../sql_types/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../core/type_ann/CMakeLists.darwin-arm64.txt | 9 + .../type_ann/CMakeLists.darwin-x86_64.txt | 9 + .../type_ann/CMakeLists.linux-aarch64.txt | 9 + .../core/type_ann/CMakeLists.linux-x86_64.txt | 9 + .../type_ann/CMakeLists.windows-x86_64.txt | 9 + .../yql/core/ut/CMakeLists.darwin-arm64.txt | 7 +- .../yql/core/ut/CMakeLists.darwin-x86_64.txt | 7 +- .../yql/core/ut/CMakeLists.linux-aarch64.txt | 9 +- .../yql/core/ut/CMakeLists.linux-x86_64.txt | 9 +- .../yql/core/ut/CMakeLists.windows-x86_64.txt | 5 + .../ut_common/CMakeLists.darwin-arm64.txt | 1 + .../ut_common/CMakeLists.darwin-x86_64.txt | 1 + .../ut_common/CMakeLists.linux-aarch64.txt | 1 + .../ut_common/CMakeLists.linux-x86_64.txt | 1 + .../ut_common/CMakeLists.windows-x86_64.txt | 1 + .../compute/CMakeLists.darwin-arm64.txt | 3 +- .../compute/CMakeLists.darwin-x86_64.txt | 3 +- .../compute/CMakeLists.linux-aarch64.txt | 3 +- .../compute/CMakeLists.linux-x86_64.txt | 3 +- .../compute/CMakeLists.windows-x86_64.txt | 3 +- .../compute/ut/CMakeLists.darwin-arm64.txt | 7 +- .../compute/ut/CMakeLists.darwin-x86_64.txt | 7 +- .../compute/ut/CMakeLists.linux-aarch64.txt | 8 +- .../compute/ut/CMakeLists.linux-x86_64.txt | 8 +- .../compute/ut/CMakeLists.windows-x86_64.txt | 5 + .../actors/protos/CMakeLists.darwin-arm64.txt | 5 + .../protos/CMakeLists.darwin-x86_64.txt | 5 + .../protos/CMakeLists.linux-aarch64.txt | 5 + .../actors/protos/CMakeLists.linux-x86_64.txt | 5 + .../protos/CMakeLists.windows-x86_64.txt | 5 + .../spilling/CMakeLists.darwin-arm64.txt | 1 + .../spilling/CMakeLists.darwin-x86_64.txt | 1 + .../spilling/CMakeLists.linux-aarch64.txt | 1 + .../spilling/CMakeLists.linux-x86_64.txt | 1 + .../spilling/CMakeLists.windows-x86_64.txt | 1 + .../spilling/ut/CMakeLists.darwin-arm64.txt | 3 +- .../spilling/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../spilling/ut/CMakeLists.linux-aarch64.txt | 4 +- .../spilling/ut/CMakeLists.linux-x86_64.txt | 4 +- .../spilling/ut/CMakeLists.windows-x86_64.txt | 1 + .../task_runner/CMakeLists.darwin-arm64.txt | 2 +- .../task_runner/CMakeLists.darwin-x86_64.txt | 2 +- .../task_runner/CMakeLists.linux-aarch64.txt | 2 +- .../task_runner/CMakeLists.linux-x86_64.txt | 2 +- .../task_runner/CMakeLists.windows-x86_64.txt | 2 +- .../yql/dq/common/CMakeLists.darwin-arm64.txt | 1 + .../dq/common/CMakeLists.darwin-x86_64.txt | 1 + .../dq/common/CMakeLists.linux-aarch64.txt | 1 + .../yql/dq/common/CMakeLists.linux-x86_64.txt | 1 + .../dq/common/CMakeLists.windows-x86_64.txt | 1 + .../dq/comp_nodes/CMakeLists.darwin-arm64.txt | 2 +- .../comp_nodes/CMakeLists.darwin-x86_64.txt | 2 +- .../comp_nodes/CMakeLists.linux-aarch64.txt | 2 +- .../dq/comp_nodes/CMakeLists.linux-x86_64.txt | 2 +- .../comp_nodes/CMakeLists.windows-x86_64.txt | 2 +- .../dq/expr_nodes/CMakeLists.darwin-arm64.txt | 4 + .../expr_nodes/CMakeLists.darwin-x86_64.txt | 4 + .../expr_nodes/CMakeLists.linux-aarch64.txt | 4 + .../dq/expr_nodes/CMakeLists.linux-x86_64.txt | 4 + .../expr_nodes/CMakeLists.windows-x86_64.txt | 4 + .../yql/dq/opt/ut/CMakeLists.darwin-arm64.txt | 3 +- .../dq/opt/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../dq/opt/ut/CMakeLists.linux-aarch64.txt | 4 +- .../yql/dq/opt/ut/CMakeLists.linux-x86_64.txt | 4 +- .../dq/opt/ut/CMakeLists.windows-x86_64.txt | 1 + .../yql/dq/proto/CMakeLists.darwin-arm64.txt | 6 + .../yql/dq/proto/CMakeLists.darwin-x86_64.txt | 6 + .../yql/dq/proto/CMakeLists.linux-aarch64.txt | 6 + .../yql/dq/proto/CMakeLists.linux-x86_64.txt | 6 + .../dq/proto/CMakeLists.windows-x86_64.txt | 6 + .../dq/runtime/CMakeLists.darwin-arm64.txt | 2 +- .../dq/runtime/CMakeLists.darwin-x86_64.txt | 2 +- .../dq/runtime/CMakeLists.linux-aarch64.txt | 2 +- .../dq/runtime/CMakeLists.linux-x86_64.txt | 2 +- .../dq/runtime/CMakeLists.windows-x86_64.txt | 2 +- .../dq/runtime/ut/CMakeLists.darwin-arm64.txt | 3 +- .../runtime/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../runtime/ut/CMakeLists.linux-aarch64.txt | 4 +- .../dq/runtime/ut/CMakeLists.linux-x86_64.txt | 4 +- .../runtime/ut/CMakeLists.windows-x86_64.txt | 1 + .../dq/state/ut/CMakeLists.darwin-arm64.txt | 3 +- .../dq/state/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../dq/state/ut/CMakeLists.linux-aarch64.txt | 4 +- .../dq/state/ut/CMakeLists.linux-x86_64.txt | 4 +- .../dq/state/ut/CMakeLists.windows-x86_64.txt | 1 + .../dq/transform/CMakeLists.darwin-arm64.txt | 2 +- .../dq/transform/CMakeLists.darwin-x86_64.txt | 2 +- .../dq/transform/CMakeLists.linux-aarch64.txt | 2 +- .../dq/transform/CMakeLists.linux-x86_64.txt | 2 +- .../transform/CMakeLists.windows-x86_64.txt | 2 +- .../yql/minikql/CMakeLists.darwin-arm64.txt | 24 + .../yql/minikql/CMakeLists.darwin-x86_64.txt | 24 + .../yql/minikql/CMakeLists.linux-aarch64.txt | 24 + .../yql/minikql/CMakeLists.linux-x86_64.txt | 24 + .../yql/minikql/CMakeLists.windows-x86_64.txt | 24 + .../arrow/ut/CMakeLists.darwin-arm64.txt | 5 +- .../arrow/ut/CMakeLists.darwin-x86_64.txt | 5 +- .../arrow/ut/CMakeLists.linux-aarch64.txt | 6 +- .../arrow/ut/CMakeLists.linux-x86_64.txt | 6 +- .../arrow/ut/CMakeLists.windows-x86_64.txt | 3 +- .../pack_num/CMakeLists.darwin-arm64.txt | 2 - .../pack_num/CMakeLists.darwin-x86_64.txt | 2 - .../pack_num/CMakeLists.linux-aarch64.txt | 3 - .../pack_num/CMakeLists.linux-x86_64.txt | 3 - .../yql/minikql/codegen/CMakeLists.txt | 14 +- .../{ => llvm}/CMakeLists.darwin-arm64.txt | 24 +- .../{ => llvm}/CMakeLists.darwin-x86_64.txt | 24 +- .../{ => llvm}/CMakeLists.linux-aarch64.txt | 24 +- .../{ => llvm}/CMakeLists.linux-x86_64.txt | 24 +- .../yql/minikql/codegen/llvm/CMakeLists.txt | 19 + .../{ => llvm}/CMakeLists.windows-x86_64.txt | 24 +- .../llvm/ut/CMakeLists.darwin-arm64.txt | 82 + .../llvm/ut/CMakeLists.darwin-x86_64.txt | 83 + .../llvm/ut/CMakeLists.linux-aarch64.txt | 86 + .../llvm/ut/CMakeLists.linux-x86_64.txt | 88 + .../minikql/codegen/llvm/ut/CMakeLists.txt | 19 + .../llvm/ut/CMakeLists.windows-x86_64.txt | 78 + .../llvm14/CMakeLists.darwin-arm64.txt | 41 + .../llvm14/CMakeLists.darwin-x86_64.txt | 41 + .../llvm14/CMakeLists.linux-aarch64.txt | 43 + .../llvm14/CMakeLists.linux-x86_64.txt | 43 + .../yql/minikql/codegen/llvm14/CMakeLists.txt | 19 + .../llvm14/CMakeLists.windows-x86_64.txt | 41 + .../llvm14/ut/CMakeLists.darwin-arm64.txt | 82 + .../llvm14/ut/CMakeLists.darwin-x86_64.txt | 83 + .../llvm14/ut/CMakeLists.linux-aarch64.txt | 86 + .../llvm14/ut/CMakeLists.linux-x86_64.txt | 88 + .../minikql/codegen/llvm14/ut/CMakeLists.txt | 19 + .../llvm14/ut/CMakeLists.windows-x86_64.txt | 78 + .../no_llvm/CMakeLists.darwin-arm64.txt | 20 + .../no_llvm/CMakeLists.darwin-x86_64.txt | 20 + .../no_llvm/CMakeLists.linux-aarch64.txt | 21 + .../no_llvm/CMakeLists.linux-x86_64.txt | 21 + .../minikql/codegen/no_llvm/CMakeLists.txt | 19 + .../no_llvm/CMakeLists.windows-x86_64.txt | 20 + .../comp_nodes}/CMakeLists.darwin-arm64.txt | 13 +- .../comp_nodes}/CMakeLists.darwin-x86_64.txt | 13 +- .../comp_nodes}/CMakeLists.linux-aarch64.txt | 14 +- .../comp_nodes}/CMakeLists.linux-x86_64.txt | 14 +- .../yql/minikql/comp_nodes/CMakeLists.txt | 14 +- .../comp_nodes}/CMakeLists.windows-x86_64.txt | 12 +- .../llvm/CMakeLists.darwin-arm64.txt | 168 +- .../llvm/CMakeLists.darwin-x86_64.txt | 168 +- .../llvm/CMakeLists.linux-aarch64.txt | 168 +- .../llvm/CMakeLists.linux-x86_64.txt | 168 +- .../llvm/CMakeLists.windows-x86_64.txt | 168 +- .../llvm/ut/CMakeLists.darwin-arm64.txt | 114 + .../llvm/ut/CMakeLists.darwin-x86_64.txt | 115 + .../llvm/ut/CMakeLists.linux-aarch64.txt | 117 + .../llvm/ut/CMakeLists.linux-x86_64.txt | 119 + .../minikql/comp_nodes/llvm/ut/CMakeLists.txt | 19 + .../llvm/ut/CMakeLists.windows-x86_64.txt | 110 + .../llvm14/CMakeLists.darwin-arm64.txt | 75 + .../llvm14/CMakeLists.darwin-x86_64.txt | 75 + .../llvm14/CMakeLists.linux-aarch64.txt | 76 + .../llvm14/CMakeLists.linux-x86_64.txt | 76 + .../minikql/comp_nodes/llvm14/CMakeLists.txt | 19 + .../llvm14/CMakeLists.windows-x86_64.txt | 75 + .../llvm14/ut/CMakeLists.darwin-arm64.txt | 114 + .../llvm14/ut/CMakeLists.darwin-x86_64.txt | 115 + .../llvm14/ut/CMakeLists.linux-aarch64.txt | 117 + .../llvm14/ut/CMakeLists.linux-x86_64.txt | 119 + .../comp_nodes/llvm14/ut/CMakeLists.txt | 19 + .../llvm14/ut/CMakeLists.windows-x86_64.txt | 110 + .../no_llvm/CMakeLists.darwin-arm64.txt | 162 +- .../no_llvm/CMakeLists.darwin-x86_64.txt | 162 +- .../no_llvm/CMakeLists.linux-aarch64.txt | 162 +- .../no_llvm/CMakeLists.linux-x86_64.txt | 162 +- .../no_llvm/CMakeLists.windows-x86_64.txt | 162 +- .../computation/CMakeLists.darwin-arm64.txt | 41 + .../computation/CMakeLists.darwin-x86_64.txt | 41 + .../computation/CMakeLists.linux-aarch64.txt | 42 + .../computation/CMakeLists.linux-x86_64.txt | 42 + .../yql/minikql/computation/CMakeLists.txt | 14 +- .../computation/CMakeLists.windows-x86_64.txt | 41 + .../llvm/CMakeLists.darwin-arm64.txt | 40 +- .../llvm/CMakeLists.darwin-x86_64.txt | 40 +- .../llvm/CMakeLists.linux-aarch64.txt | 40 +- .../llvm/CMakeLists.linux-x86_64.txt | 40 +- .../llvm/CMakeLists.windows-x86_64.txt | 40 +- .../llvm/ut/CMakeLists.darwin-arm64.txt | 92 + .../llvm/ut/CMakeLists.darwin-x86_64.txt | 93 + .../llvm/ut/CMakeLists.linux-aarch64.txt | 95 + .../llvm/ut/CMakeLists.linux-x86_64.txt | 97 + .../computation/llvm/ut/CMakeLists.txt | 19 + .../llvm/ut/CMakeLists.windows-x86_64.txt | 88 + .../llvm14/CMakeLists.darwin-arm64.txt | 55 + .../llvm14/CMakeLists.darwin-x86_64.txt | 55 + .../llvm14/CMakeLists.linux-aarch64.txt | 56 + .../llvm14/CMakeLists.linux-x86_64.txt | 56 + .../minikql/computation/llvm14/CMakeLists.txt | 19 + .../llvm14/CMakeLists.windows-x86_64.txt | 55 + .../llvm14/ut/CMakeLists.darwin-arm64.txt | 92 + .../llvm14/ut/CMakeLists.darwin-x86_64.txt | 93 + .../llvm14/ut/CMakeLists.linux-aarch64.txt | 95 + .../llvm14/ut/CMakeLists.linux-x86_64.txt | 97 + .../computation/llvm14/ut/CMakeLists.txt | 19 + .../llvm14/ut/CMakeLists.windows-x86_64.txt | 88 + .../no_llvm/CMakeLists.darwin-arm64.txt | 34 +- .../no_llvm/CMakeLists.darwin-x86_64.txt | 34 +- .../no_llvm/CMakeLists.linux-aarch64.txt | 34 +- .../no_llvm/CMakeLists.linux-x86_64.txt | 34 +- .../no_llvm/CMakeLists.windows-x86_64.txt | 34 +- .../datetime/CMakeLists.darwin-arm64.txt | 2 +- .../datetime/CMakeLists.darwin-x86_64.txt | 2 +- .../datetime/CMakeLists.linux-aarch64.txt | 2 +- .../datetime/CMakeLists.linux-x86_64.txt | 2 +- .../datetime/CMakeLists.windows-x86_64.txt | 2 +- .../dom/ut/CMakeLists.darwin-arm64.txt | 5 +- .../dom/ut/CMakeLists.darwin-x86_64.txt | 5 +- .../dom/ut/CMakeLists.linux-aarch64.txt | 6 +- .../dom/ut/CMakeLists.linux-x86_64.txt | 6 +- .../CMakeLists.darwin-arm64.txt | 17 + .../CMakeLists.darwin-x86_64.txt | 17 + .../CMakeLists.linux-aarch64.txt | 18 + .../CMakeLists.linux-x86_64.txt | 18 + .../minikql/invoke_builtins/CMakeLists.txt | 14 +- .../CMakeLists.windows-x86_64.txt | 17 + .../llvm/CMakeLists.darwin-arm64.txt | 81 +- .../llvm/CMakeLists.darwin-x86_64.txt | 81 +- .../llvm/CMakeLists.linux-aarch64.txt | 81 +- .../llvm/CMakeLists.linux-x86_64.txt | 81 +- .../llvm/CMakeLists.windows-x86_64.txt | 81 +- .../llvm/ut/CMakeLists.darwin-arm64.txt | 83 + .../llvm/ut/CMakeLists.darwin-x86_64.txt | 84 + .../llvm/ut/CMakeLists.linux-aarch64.txt | 86 + .../llvm/ut/CMakeLists.linux-x86_64.txt | 88 + .../invoke_builtins/llvm/ut/CMakeLists.txt | 19 + .../llvm/ut/CMakeLists.windows-x86_64.txt | 79 + .../llvm14/CMakeLists.darwin-arm64.txt | 70 + .../llvm14/CMakeLists.darwin-x86_64.txt | 70 + .../llvm14/CMakeLists.linux-aarch64.txt | 71 + .../llvm14/CMakeLists.linux-x86_64.txt | 71 + .../invoke_builtins/llvm14/CMakeLists.txt | 19 + .../llvm14/CMakeLists.windows-x86_64.txt | 70 + .../llvm14/ut/CMakeLists.darwin-arm64.txt | 83 + .../llvm14/ut/CMakeLists.darwin-x86_64.txt | 84 + .../llvm14/ut/CMakeLists.linux-aarch64.txt | 86 + .../llvm14/ut/CMakeLists.linux-x86_64.txt | 88 + .../invoke_builtins/llvm14/ut/CMakeLists.txt | 19 + .../llvm14/ut/CMakeLists.windows-x86_64.txt | 79 + .../no_llvm/CMakeLists.darwin-arm64.txt | 75 +- .../no_llvm/CMakeLists.darwin-x86_64.txt | 75 +- .../no_llvm/CMakeLists.linux-aarch64.txt | 75 +- .../no_llvm/CMakeLists.linux-x86_64.txt | 75 +- .../no_llvm/CMakeLists.windows-x86_64.txt | 75 +- .../benchmark/CMakeLists.darwin-arm64.txt | 4 +- .../benchmark/CMakeLists.darwin-x86_64.txt | 4 +- .../benchmark/CMakeLists.linux-aarch64.txt | 5 +- .../benchmark/CMakeLists.linux-x86_64.txt | 5 +- .../benchmark/CMakeLists.windows-x86_64.txt | 2 +- .../jsonpath/ut/CMakeLists.darwin-arm64.txt | 7 +- .../jsonpath/ut/CMakeLists.darwin-x86_64.txt | 7 +- .../jsonpath/ut/CMakeLists.linux-aarch64.txt | 8 +- .../jsonpath/ut/CMakeLists.linux-x86_64.txt | 8 +- .../jsonpath/ut/CMakeLists.windows-x86_64.txt | 5 +- .../perf/alloc/CMakeLists.darwin-arm64.txt | 2 - .../perf/alloc/CMakeLists.darwin-x86_64.txt | 2 - .../perf/alloc/CMakeLists.linux-aarch64.txt | 3 - .../perf/alloc/CMakeLists.linux-x86_64.txt | 3 - .../block_groupby/CMakeLists.darwin-arm64.txt | 4 +- .../CMakeLists.darwin-x86_64.txt | 4 +- .../CMakeLists.linux-aarch64.txt | 5 +- .../block_groupby/CMakeLists.linux-x86_64.txt | 5 +- .../CMakeLists.windows-x86_64.txt | 2 +- .../mprefetch/CMakeLists.linux-aarch64.txt | 3 - .../mprefetch/CMakeLists.linux-x86_64.txt | 3 - .../perf/mt_param/CMakeLists.darwin-arm64.txt | 4 +- .../mt_param/CMakeLists.darwin-x86_64.txt | 4 +- .../mt_param/CMakeLists.linux-aarch64.txt | 5 +- .../perf/mt_param/CMakeLists.linux-x86_64.txt | 5 +- .../mt_param/CMakeLists.windows-x86_64.txt | 2 +- .../perf/packer/CMakeLists.darwin-arm64.txt | 4 +- .../perf/packer/CMakeLists.darwin-x86_64.txt | 4 +- .../perf/packer/CMakeLists.linux-aarch64.txt | 5 +- .../perf/packer/CMakeLists.linux-x86_64.txt | 5 +- .../perf/packer/CMakeLists.windows-x86_64.txt | 2 +- .../perf/param/CMakeLists.darwin-arm64.txt | 4 +- .../perf/param/CMakeLists.darwin-x86_64.txt | 4 +- .../perf/param/CMakeLists.linux-aarch64.txt | 5 +- .../perf/param/CMakeLists.linux-x86_64.txt | 5 +- .../perf/param/CMakeLists.windows-x86_64.txt | 2 +- .../perf/presort/CMakeLists.darwin-arm64.txt | 4 +- .../perf/presort/CMakeLists.darwin-x86_64.txt | 4 +- .../perf/presort/CMakeLists.linux-aarch64.txt | 5 +- .../perf/presort/CMakeLists.linux-x86_64.txt | 5 +- .../presort/CMakeLists.windows-x86_64.txt | 2 +- .../ut/CMakeLists.darwin-arm64.txt | 4 +- .../ut/CMakeLists.darwin-x86_64.txt | 4 +- .../ut/CMakeLists.linux-aarch64.txt | 5 +- .../ut/CMakeLists.linux-x86_64.txt | 5 +- .../ut/CMakeLists.windows-x86_64.txt | 2 + .../minikql/ut/CMakeLists.darwin-arm64.txt | 6 +- .../minikql/ut/CMakeLists.darwin-x86_64.txt | 6 +- .../minikql/ut/CMakeLists.linux-aarch64.txt | 7 +- .../minikql/ut/CMakeLists.linux-x86_64.txt | 7 +- .../minikql/ut/CMakeLists.windows-x86_64.txt | 4 +- .../lexer_common/CMakeLists.darwin-arm64.txt | 3 + .../lexer_common/CMakeLists.darwin-x86_64.txt | 3 + .../lexer_common/CMakeLists.linux-aarch64.txt | 3 + .../lexer_common/CMakeLists.linux-x86_64.txt | 3 + .../CMakeLists.windows-x86_64.txt | 3 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../pg_catalog/CMakeLists.darwin-arm64.txt | 14 + .../pg_catalog/CMakeLists.darwin-x86_64.txt | 14 + .../pg_catalog/CMakeLists.linux-aarch64.txt | 14 + .../pg_catalog/CMakeLists.linux-x86_64.txt | 14 + .../pg_catalog/CMakeLists.windows-x86_64.txt | 14 + .../pg_catalog/ut/CMakeLists.darwin-arm64.txt | 5 +- .../ut/CMakeLists.darwin-x86_64.txt | 5 +- .../ut/CMakeLists.linux-aarch64.txt | 6 +- .../pg_catalog/ut/CMakeLists.linux-x86_64.txt | 6 +- .../ut/CMakeLists.windows-x86_64.txt | 3 +- .../pg_wrapper/CMakeLists.darwin-arm64.txt | 32 +- .../pg_wrapper/CMakeLists.darwin-x86_64.txt | 32 +- .../pg_wrapper/CMakeLists.linux-aarch64.txt | 32 +- .../pg_wrapper/CMakeLists.linux-x86_64.txt | 32 +- .../pg_wrapper/CMakeLists.windows-x86_64.txt | 32 +- .../interface/CMakeLists.darwin-arm64.txt | 9 + .../interface/CMakeLists.darwin-x86_64.txt | 9 + .../interface/CMakeLists.linux-aarch64.txt | 9 + .../interface/CMakeLists.linux-x86_64.txt | 9 + .../interface/CMakeLists.windows-x86_64.txt | 9 + .../pg_wrapper/ut/CMakeLists.darwin-arm64.txt | 11 +- .../ut/CMakeLists.darwin-x86_64.txt | 11 +- .../ut/CMakeLists.linux-aarch64.txt | 12 +- .../pg_wrapper/ut/CMakeLists.linux-x86_64.txt | 12 +- .../ut/CMakeLists.windows-x86_64.txt | 9 +- .../CMakeLists.darwin-arm64.txt | 3 + .../CMakeLists.darwin-x86_64.txt | 3 + .../CMakeLists.linux-aarch64.txt | 3 + .../CMakeLists.linux-x86_64.txt | 3 + .../CMakeLists.windows-x86_64.txt | 3 + .../yql/parser/proto_ast/gen/CMakeLists.txt | 3 +- .../gen/jsonpath/CMakeLists.darwin-arm64.txt | 9 + .../gen/jsonpath/CMakeLists.darwin-x86_64.txt | 9 + .../gen/jsonpath/CMakeLists.linux-aarch64.txt | 9 + .../gen/jsonpath/CMakeLists.linux-x86_64.txt | 9 + .../jsonpath/CMakeLists.windows-x86_64.txt | 9 + .../gen/v0/CMakeLists.darwin-arm64.txt | 65 +- .../gen/v0/CMakeLists.darwin-x86_64.txt | 65 +- .../gen/v0/CMakeLists.linux-aarch64.txt | 65 +- .../gen/v0/CMakeLists.linux-x86_64.txt | 65 +- .../gen/v0/CMakeLists.windows-x86_64.txt | 65 +- .../CMakeLists.darwin-arm64.txt | 128 + .../CMakeLists.darwin-x86_64.txt | 128 + .../CMakeLists.linux-aarch64.txt | 129 + .../CMakeLists.linux-x86_64.txt | 129 + .../gen/v0_proto_split/CMakeLists.txt | 19 + .../CMakeLists.windows-x86_64.txt | 128 + .../gen/v1/CMakeLists.darwin-arm64.txt | 11 +- .../gen/v1/CMakeLists.darwin-x86_64.txt | 11 +- .../gen/v1/CMakeLists.linux-aarch64.txt | 11 +- .../gen/v1/CMakeLists.linux-x86_64.txt | 11 +- .../gen/v1/CMakeLists.windows-x86_64.txt | 11 +- .../gen/v1_ansi/CMakeLists.darwin-arm64.txt | 11 +- .../gen/v1_ansi/CMakeLists.darwin-x86_64.txt | 11 +- .../gen/v1_ansi/CMakeLists.linux-aarch64.txt | 11 +- .../gen/v1_ansi/CMakeLists.linux-x86_64.txt | 11 +- .../gen/v1_ansi/CMakeLists.windows-x86_64.txt | 11 +- .../CMakeLists.darwin-arm64.txt | 138 + .../CMakeLists.darwin-x86_64.txt | 138 + .../CMakeLists.linux-aarch64.txt | 139 + .../CMakeLists.linux-x86_64.txt | 139 + .../gen/v1_proto_split/CMakeLists.txt | 19 + .../CMakeLists.windows-x86_64.txt | 138 + .../yql/protos/CMakeLists.darwin-arm64.txt | 5 + .../yql/protos/CMakeLists.darwin-x86_64.txt | 5 + .../yql/protos/CMakeLists.linux-aarch64.txt | 5 + .../yql/protos/CMakeLists.linux-x86_64.txt | 5 + .../yql/protos/CMakeLists.windows-x86_64.txt | 5 + .../actors/CMakeLists.darwin-arm64.txt | 2 +- .../actors/CMakeLists.darwin-x86_64.txt | 2 +- .../actors/CMakeLists.linux-aarch64.txt | 2 +- .../actors/CMakeLists.linux-x86_64.txt | 2 +- .../actors/CMakeLists.windows-x86_64.txt | 2 +- .../expr_nodes/CMakeLists.darwin-arm64.txt | 3 + .../expr_nodes/CMakeLists.darwin-x86_64.txt | 3 + .../expr_nodes/CMakeLists.linux-aarch64.txt | 3 + .../expr_nodes/CMakeLists.linux-x86_64.txt | 3 + .../expr_nodes/CMakeLists.windows-x86_64.txt | 3 + .../proto/CMakeLists.darwin-arm64.txt | 4 + .../proto/CMakeLists.darwin-x86_64.txt | 4 + .../proto/CMakeLists.linux-aarch64.txt | 4 + .../proto/CMakeLists.linux-x86_64.txt | 4 + .../proto/CMakeLists.windows-x86_64.txt | 4 + .../provider/CMakeLists.darwin-arm64.txt | 6 +- .../provider/CMakeLists.darwin-x86_64.txt | 6 +- .../provider/CMakeLists.linux-aarch64.txt | 6 +- .../provider/CMakeLists.linux-x86_64.txt | 6 +- .../provider/CMakeLists.windows-x86_64.txt | 6 +- .../common/codec/CMakeLists.darwin-arm64.txt | 7 +- .../common/codec/CMakeLists.darwin-x86_64.txt | 7 +- .../common/codec/CMakeLists.linux-aarch64.txt | 7 +- .../common/codec/CMakeLists.linux-x86_64.txt | 7 +- .../codec/CMakeLists.windows-x86_64.txt | 7 +- .../codec/ut/CMakeLists.darwin-arm64.txt | 3 +- .../codec/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../codec/ut/CMakeLists.linux-aarch64.txt | 4 +- .../codec/ut/CMakeLists.linux-x86_64.txt | 4 +- .../codec/ut/CMakeLists.windows-x86_64.txt | 1 + .../comp_nodes/CMakeLists.darwin-arm64.txt | 23 +- .../comp_nodes/CMakeLists.darwin-x86_64.txt | 23 +- .../comp_nodes/CMakeLists.linux-aarch64.txt | 23 +- .../comp_nodes/CMakeLists.linux-x86_64.txt | 23 +- .../comp_nodes/CMakeLists.windows-x86_64.txt | 23 +- .../common/config/CMakeLists.darwin-arm64.txt | 1 + .../config/CMakeLists.darwin-x86_64.txt | 1 + .../config/CMakeLists.linux-aarch64.txt | 1 + .../common/config/CMakeLists.linux-x86_64.txt | 1 + .../config/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 4 + .../CMakeLists.darwin-x86_64.txt | 4 + .../CMakeLists.linux-aarch64.txt | 4 + .../CMakeLists.linux-x86_64.txt | 4 + .../CMakeLists.windows-x86_64.txt | 4 + .../gateway/CMakeLists.darwin-arm64.txt | 1 + .../gateway/CMakeLists.darwin-x86_64.txt | 1 + .../gateway/CMakeLists.linux-aarch64.txt | 1 + .../gateway/CMakeLists.linux-x86_64.txt | 1 + .../gateway/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../protos/CMakeLists.darwin-arm64.txt | 3 + .../protos/CMakeLists.darwin-x86_64.txt | 3 + .../protos/CMakeLists.linux-aarch64.txt | 3 + .../protos/CMakeLists.linux-x86_64.txt | 3 + .../protos/CMakeLists.windows-x86_64.txt | 3 + .../common/mkql/CMakeLists.darwin-arm64.txt | 3 + .../common/mkql/CMakeLists.darwin-x86_64.txt | 3 + .../common/mkql/CMakeLists.linux-aarch64.txt | 3 + .../common/mkql/CMakeLists.linux-x86_64.txt | 3 + .../common/mkql/CMakeLists.windows-x86_64.txt | 3 + .../common/proto/CMakeLists.darwin-arm64.txt | 4 + .../common/proto/CMakeLists.darwin-x86_64.txt | 4 + .../common/proto/CMakeLists.linux-aarch64.txt | 4 + .../common/proto/CMakeLists.linux-x86_64.txt | 4 + .../proto/CMakeLists.windows-x86_64.txt | 4 + .../provider/CMakeLists.darwin-arm64.txt | 4 + .../provider/CMakeLists.darwin-x86_64.txt | 4 + .../provider/CMakeLists.linux-aarch64.txt | 4 + .../provider/CMakeLists.linux-x86_64.txt | 4 + .../provider/CMakeLists.windows-x86_64.txt | 4 + .../CMakeLists.darwin-arm64.txt | 2 + .../CMakeLists.darwin-x86_64.txt | 2 + .../CMakeLists.linux-aarch64.txt | 2 + .../CMakeLists.linux-x86_64.txt | 2 + .../CMakeLists.windows-x86_64.txt | 2 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../grpc/CMakeLists.darwin-arm64.txt | 4 + .../grpc/CMakeLists.darwin-x86_64.txt | 4 + .../grpc/CMakeLists.linux-aarch64.txt | 4 + .../grpc/CMakeLists.linux-x86_64.txt | 4 + .../grpc/CMakeLists.windows-x86_64.txt | 4 + .../udf_resolve/CMakeLists.darwin-arm64.txt | 4 + .../udf_resolve/CMakeLists.darwin-x86_64.txt | 4 + .../udf_resolve/CMakeLists.linux-aarch64.txt | 4 + .../udf_resolve/CMakeLists.linux-x86_64.txt | 4 + .../udf_resolve/CMakeLists.windows-x86_64.txt | 4 + .../ut_helpers/CMakeLists.darwin-arm64.txt | 2 +- .../ut_helpers/CMakeLists.darwin-x86_64.txt | 2 +- .../ut_helpers/CMakeLists.linux-aarch64.txt | 2 +- .../ut_helpers/CMakeLists.linux-x86_64.txt | 2 +- .../ut_helpers/CMakeLists.windows-x86_64.txt | 2 +- .../config/CMakeLists.darwin-arm64.txt | 1 + .../config/CMakeLists.darwin-x86_64.txt | 1 + .../config/CMakeLists.linux-aarch64.txt | 1 + .../config/CMakeLists.linux-x86_64.txt | 1 + .../config/CMakeLists.windows-x86_64.txt | 1 + .../providers/dq/CMakeLists.darwin-arm64.txt | 29 - .../providers/dq/CMakeLists.darwin-x86_64.txt | 29 - .../providers/dq/CMakeLists.linux-aarch64.txt | 29 - .../providers/dq/CMakeLists.linux-x86_64.txt | 29 - ydb/library/yql/providers/dq/CMakeLists.txt | 32 +- .../dq/CMakeLists.windows-x86_64.txt | 27 - .../dq/actors/ut/CMakeLists.darwin-arm64.txt | 3 +- .../dq/actors/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../dq/actors/ut/CMakeLists.linux-aarch64.txt | 4 +- .../dq/actors/ut/CMakeLists.linux-x86_64.txt | 4 +- .../actors/ut/CMakeLists.windows-x86_64.txt | 1 + .../dq/actors/yt/CMakeLists.darwin-arm64.txt | 6 + .../dq/actors/yt/CMakeLists.darwin-x86_64.txt | 6 + .../dq/actors/yt/CMakeLists.linux-aarch64.txt | 6 + .../dq/actors/yt/CMakeLists.linux-x86_64.txt | 6 + .../actors/yt/CMakeLists.windows-x86_64.txt | 2 + .../dq/api/grpc/CMakeLists.darwin-arm64.txt | 4 + .../dq/api/grpc/CMakeLists.darwin-x86_64.txt | 4 + .../dq/api/grpc/CMakeLists.linux-aarch64.txt | 4 + .../dq/api/grpc/CMakeLists.linux-x86_64.txt | 4 + .../dq/api/grpc/CMakeLists.windows-x86_64.txt | 4 + .../dq/api/protos/CMakeLists.darwin-arm64.txt | 5 + .../api/protos/CMakeLists.darwin-x86_64.txt | 5 + .../api/protos/CMakeLists.linux-aarch64.txt | 5 + .../dq/api/protos/CMakeLists.linux-x86_64.txt | 5 + .../api/protos/CMakeLists.windows-x86_64.txt | 5 + .../dq/config/CMakeLists.darwin-arm64.txt | 3 + .../dq/config/CMakeLists.darwin-x86_64.txt | 3 + .../dq/config/CMakeLists.linux-aarch64.txt | 3 + .../dq/config/CMakeLists.linux-x86_64.txt | 3 + .../dq/config/CMakeLists.windows-x86_64.txt | 3 + .../dq/expr_nodes/CMakeLists.darwin-arm64.txt | 4 + .../expr_nodes/CMakeLists.darwin-x86_64.txt | 4 + .../expr_nodes/CMakeLists.linux-aarch64.txt | 4 + .../dq/expr_nodes/CMakeLists.linux-x86_64.txt | 4 + .../expr_nodes/CMakeLists.windows-x86_64.txt | 4 + .../ut/CMakeLists.darwin-arm64.txt | 5 +- .../ut/CMakeLists.darwin-x86_64.txt | 5 +- .../ut/CMakeLists.linux-aarch64.txt | 7 +- .../ut/CMakeLists.linux-x86_64.txt | 7 +- .../providers/dq/local_gateway/CMakeLists.txt | 2 + .../CMakeLists.windows-x86_64.txt | 29 + .../dq/opt/CMakeLists.darwin-arm64.txt | 2 +- .../dq/opt/CMakeLists.darwin-x86_64.txt | 2 +- .../dq/opt/CMakeLists.linux-aarch64.txt | 2 +- .../dq/opt/CMakeLists.linux-x86_64.txt | 2 +- .../dq/opt/CMakeLists.windows-x86_64.txt | 2 +- .../dq/planner/CMakeLists.darwin-arm64.txt | 2 +- .../dq/planner/CMakeLists.darwin-x86_64.txt | 2 +- .../dq/planner/CMakeLists.linux-aarch64.txt | 2 +- .../dq/planner/CMakeLists.linux-x86_64.txt | 2 +- .../dq/planner/CMakeLists.windows-x86_64.txt | 2 +- .../dq/provider/CMakeLists.darwin-arm64.txt | 10 + .../dq/provider/CMakeLists.darwin-x86_64.txt | 10 + .../dq/provider/CMakeLists.linux-aarch64.txt | 10 + .../dq/provider/CMakeLists.linux-x86_64.txt | 10 + .../dq/provider/CMakeLists.windows-x86_64.txt | 10 + .../provider/exec/CMakeLists.darwin-arm64.txt | 1 + .../exec/CMakeLists.darwin-x86_64.txt | 1 + .../exec/CMakeLists.linux-aarch64.txt | 1 + .../provider/exec/CMakeLists.linux-x86_64.txt | 1 + .../exec/CMakeLists.windows-x86_64.txt | 1 + .../provider/ut/CMakeLists.darwin-arm64.txt | 3 +- .../provider/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../provider/ut/CMakeLists.linux-aarch64.txt | 4 +- .../provider/ut/CMakeLists.linux-x86_64.txt | 4 +- .../provider/ut/CMakeLists.windows-x86_64.txt | 1 + .../dq/runtime/CMakeLists.darwin-arm64.txt | 2 +- .../dq/runtime/CMakeLists.darwin-x86_64.txt | 2 +- .../dq/runtime/CMakeLists.linux-aarch64.txt | 2 +- .../dq/runtime/CMakeLists.linux-x86_64.txt | 2 +- .../dq/runtime/CMakeLists.windows-x86_64.txt | 2 +- .../scheduler/ut/CMakeLists.darwin-arm64.txt | 3 +- .../scheduler/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../scheduler/ut/CMakeLists.linux-aarch64.txt | 4 +- .../scheduler/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../dq/stats_collector/CMakeLists.txt | 2 + .../CMakeLists.windows-x86_64.txt | 23 + .../task_runner/CMakeLists.darwin-arm64.txt | 2 +- .../task_runner/CMakeLists.darwin-x86_64.txt | 2 +- .../task_runner/CMakeLists.linux-aarch64.txt | 2 +- .../task_runner/CMakeLists.linux-x86_64.txt | 2 +- .../task_runner/CMakeLists.windows-x86_64.txt | 2 +- .../expr_nodes/CMakeLists.darwin-arm64.txt | 3 + .../expr_nodes/CMakeLists.darwin-x86_64.txt | 3 + .../expr_nodes/CMakeLists.linux-aarch64.txt | 3 + .../expr_nodes/CMakeLists.linux-x86_64.txt | 3 + .../expr_nodes/CMakeLists.windows-x86_64.txt | 3 + .../proto/CMakeLists.darwin-arm64.txt | 3 + .../proto/CMakeLists.darwin-x86_64.txt | 3 + .../proto/CMakeLists.linux-aarch64.txt | 3 + .../proto/CMakeLists.linux-x86_64.txt | 3 + .../proto/CMakeLists.windows-x86_64.txt | 3 + .../actors/CMakeLists.darwin-arm64.txt | 2 +- .../actors/CMakeLists.darwin-x86_64.txt | 2 +- .../actors/CMakeLists.linux-aarch64.txt | 2 +- .../actors/CMakeLists.linux-x86_64.txt | 2 +- .../actors/CMakeLists.windows-x86_64.txt | 2 +- .../api/common/CMakeLists.darwin-arm64.txt | 4 + .../api/common/CMakeLists.darwin-x86_64.txt | 4 + .../api/common/CMakeLists.linux-aarch64.txt | 4 + .../api/common/CMakeLists.linux-x86_64.txt | 4 + .../api/common/CMakeLists.windows-x86_64.txt | 4 + .../api/service/CMakeLists.darwin-arm64.txt | 4 + .../api/service/CMakeLists.darwin-x86_64.txt | 4 + .../api/service/CMakeLists.linux-aarch64.txt | 4 + .../api/service/CMakeLists.linux-x86_64.txt | 4 + .../api/service/CMakeLists.windows-x86_64.txt | 4 + .../protos/CMakeLists.darwin-arm64.txt | 3 + .../protos/CMakeLists.darwin-x86_64.txt | 3 + .../protos/CMakeLists.linux-aarch64.txt | 3 + .../protos/CMakeLists.linux-x86_64.txt | 3 + .../protos/CMakeLists.windows-x86_64.txt | 3 + .../expr_nodes/CMakeLists.darwin-arm64.txt | 3 + .../expr_nodes/CMakeLists.darwin-x86_64.txt | 3 + .../expr_nodes/CMakeLists.linux-aarch64.txt | 3 + .../expr_nodes/CMakeLists.linux-x86_64.txt | 3 + .../expr_nodes/CMakeLists.windows-x86_64.txt | 3 + .../generic/proto/CMakeLists.darwin-arm64.txt | 4 + .../proto/CMakeLists.darwin-x86_64.txt | 4 + .../proto/CMakeLists.linux-aarch64.txt | 4 + .../generic/proto/CMakeLists.linux-x86_64.txt | 4 + .../proto/CMakeLists.windows-x86_64.txt | 4 + .../provider/CMakeLists.darwin-arm64.txt | 6 +- .../provider/CMakeLists.darwin-x86_64.txt | 6 +- .../provider/CMakeLists.linux-aarch64.txt | 6 +- .../provider/CMakeLists.linux-x86_64.txt | 6 +- .../provider/CMakeLists.windows-x86_64.txt | 6 +- .../ut/pushdown/CMakeLists.darwin-arm64.txt | 4 +- .../ut/pushdown/CMakeLists.darwin-x86_64.txt | 4 +- .../ut/pushdown/CMakeLists.linux-aarch64.txt | 5 +- .../ut/pushdown/CMakeLists.linux-x86_64.txt | 5 +- .../ut/pushdown/CMakeLists.windows-x86_64.txt | 2 + .../pg/expr_nodes/CMakeLists.darwin-arm64.txt | 3 + .../expr_nodes/CMakeLists.darwin-x86_64.txt | 3 + .../expr_nodes/CMakeLists.linux-aarch64.txt | 3 + .../pg/expr_nodes/CMakeLists.linux-x86_64.txt | 3 + .../expr_nodes/CMakeLists.windows-x86_64.txt | 3 + .../pg/provider/CMakeLists.darwin-arm64.txt | 2 + .../pg/provider/CMakeLists.darwin-x86_64.txt | 2 + .../pg/provider/CMakeLists.linux-aarch64.txt | 2 + .../pg/provider/CMakeLists.linux-x86_64.txt | 2 + .../pg/provider/CMakeLists.windows-x86_64.txt | 2 + .../pq/async_io/CMakeLists.darwin-arm64.txt | 2 +- .../pq/async_io/CMakeLists.darwin-x86_64.txt | 2 +- .../pq/async_io/CMakeLists.linux-aarch64.txt | 2 +- .../pq/async_io/CMakeLists.linux-x86_64.txt | 2 +- .../pq/async_io/CMakeLists.windows-x86_64.txt | 2 +- .../pq/expr_nodes/CMakeLists.darwin-arm64.txt | 3 + .../expr_nodes/CMakeLists.darwin-x86_64.txt | 3 + .../expr_nodes/CMakeLists.linux-aarch64.txt | 3 + .../pq/expr_nodes/CMakeLists.linux-x86_64.txt | 3 + .../expr_nodes/CMakeLists.windows-x86_64.txt | 3 + .../pq/proto/CMakeLists.darwin-arm64.txt | 5 + .../pq/proto/CMakeLists.darwin-x86_64.txt | 5 + .../pq/proto/CMakeLists.linux-aarch64.txt | 5 + .../pq/proto/CMakeLists.linux-x86_64.txt | 5 + .../pq/proto/CMakeLists.windows-x86_64.txt | 5 + .../pq/provider/CMakeLists.darwin-arm64.txt | 2 +- .../pq/provider/CMakeLists.darwin-x86_64.txt | 2 +- .../pq/provider/CMakeLists.linux-aarch64.txt | 2 +- .../pq/provider/CMakeLists.linux-x86_64.txt | 2 +- .../pq/provider/CMakeLists.windows-x86_64.txt | 2 +- .../expr_nodes/CMakeLists.darwin-arm64.txt | 3 + .../expr_nodes/CMakeLists.darwin-x86_64.txt | 3 + .../expr_nodes/CMakeLists.linux-aarch64.txt | 3 + .../expr_nodes/CMakeLists.linux-x86_64.txt | 3 + .../expr_nodes/CMakeLists.windows-x86_64.txt | 3 + .../provider/CMakeLists.darwin-arm64.txt | 1 + .../provider/CMakeLists.darwin-x86_64.txt | 1 + .../provider/CMakeLists.linux-aarch64.txt | 1 + .../provider/CMakeLists.linux-x86_64.txt | 1 + .../provider/CMakeLists.windows-x86_64.txt | 1 + .../s3/actors/CMakeLists.darwin-arm64.txt | 3 +- .../s3/actors/CMakeLists.darwin-x86_64.txt | 3 +- .../s3/actors/CMakeLists.linux-aarch64.txt | 3 +- .../s3/actors/CMakeLists.linux-x86_64.txt | 3 +- .../s3/actors/CMakeLists.windows-x86_64.txt | 2 +- .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../s3/expr_nodes/CMakeLists.darwin-arm64.txt | 3 + .../expr_nodes/CMakeLists.darwin-x86_64.txt | 3 + .../expr_nodes/CMakeLists.linux-aarch64.txt | 3 + .../s3/expr_nodes/CMakeLists.linux-x86_64.txt | 3 + .../expr_nodes/CMakeLists.windows-x86_64.txt | 3 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../s3/proto/CMakeLists.darwin-arm64.txt | 7 + .../s3/proto/CMakeLists.darwin-x86_64.txt | 7 + .../s3/proto/CMakeLists.linux-aarch64.txt | 7 + .../s3/proto/CMakeLists.linux-x86_64.txt | 7 + .../s3/proto/CMakeLists.windows-x86_64.txt | 7 + .../s3/provider/CMakeLists.darwin-arm64.txt | 2 +- .../s3/provider/CMakeLists.darwin-x86_64.txt | 2 +- .../s3/provider/CMakeLists.linux-aarch64.txt | 2 +- .../s3/provider/CMakeLists.linux-x86_64.txt | 2 +- .../s3/provider/CMakeLists.windows-x86_64.txt | 2 +- .../provider/ut/CMakeLists.darwin-arm64.txt | 3 +- .../provider/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../provider/ut/CMakeLists.linux-aarch64.txt | 4 +- .../provider/ut/CMakeLists.linux-x86_64.txt | 4 +- .../provider/ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../async_io/CMakeLists.darwin-arm64.txt | 2 +- .../async_io/CMakeLists.darwin-x86_64.txt | 2 +- .../async_io/CMakeLists.linux-aarch64.txt | 2 +- .../async_io/CMakeLists.linux-x86_64.txt | 2 +- .../async_io/CMakeLists.windows-x86_64.txt | 2 +- .../expr_nodes/CMakeLists.darwin-arm64.txt | 3 + .../expr_nodes/CMakeLists.darwin-x86_64.txt | 3 + .../expr_nodes/CMakeLists.linux-aarch64.txt | 3 + .../expr_nodes/CMakeLists.linux-x86_64.txt | 3 + .../expr_nodes/CMakeLists.windows-x86_64.txt | 3 + .../solomon/proto/CMakeLists.darwin-arm64.txt | 3 + .../proto/CMakeLists.darwin-x86_64.txt | 3 + .../proto/CMakeLists.linux-aarch64.txt | 3 + .../solomon/proto/CMakeLists.linux-x86_64.txt | 3 + .../proto/CMakeLists.windows-x86_64.txt | 3 + .../expr_nodes/CMakeLists.darwin-arm64.txt | 3 + .../expr_nodes/CMakeLists.darwin-x86_64.txt | 3 + .../expr_nodes/CMakeLists.linux-aarch64.txt | 3 + .../expr_nodes/CMakeLists.linux-x86_64.txt | 3 + .../expr_nodes/CMakeLists.windows-x86_64.txt | 3 + .../ydb/actors/CMakeLists.darwin-arm64.txt | 2 +- .../ydb/actors/CMakeLists.darwin-x86_64.txt | 2 +- .../ydb/actors/CMakeLists.linux-aarch64.txt | 2 +- .../ydb/actors/CMakeLists.linux-x86_64.txt | 2 +- .../ydb/actors/CMakeLists.windows-x86_64.txt | 2 +- .../comp_nodes/CMakeLists.darwin-arm64.txt | 2 +- .../comp_nodes/CMakeLists.darwin-x86_64.txt | 2 +- .../comp_nodes/CMakeLists.linux-aarch64.txt | 2 +- .../comp_nodes/CMakeLists.linux-x86_64.txt | 2 +- .../comp_nodes/CMakeLists.windows-x86_64.txt | 2 +- .../expr_nodes/CMakeLists.darwin-arm64.txt | 3 + .../expr_nodes/CMakeLists.darwin-x86_64.txt | 3 + .../expr_nodes/CMakeLists.linux-aarch64.txt | 3 + .../expr_nodes/CMakeLists.linux-x86_64.txt | 3 + .../expr_nodes/CMakeLists.windows-x86_64.txt | 3 + .../ydb/proto/CMakeLists.darwin-arm64.txt | 4 + .../ydb/proto/CMakeLists.darwin-x86_64.txt | 4 + .../ydb/proto/CMakeLists.linux-aarch64.txt | 4 + .../ydb/proto/CMakeLists.linux-x86_64.txt | 4 + .../ydb/proto/CMakeLists.windows-x86_64.txt | 4 + .../ydb/provider/CMakeLists.darwin-arm64.txt | 2 +- .../ydb/provider/CMakeLists.darwin-x86_64.txt | 2 +- .../ydb/provider/CMakeLists.linux-aarch64.txt | 2 +- .../ydb/provider/CMakeLists.linux-x86_64.txt | 2 +- .../provider/CMakeLists.windows-x86_64.txt | 2 +- ydb/library/yql/providers/yt/CMakeLists.txt | 22 +- .../yt/codec/CMakeLists.darwin-arm64.txt | 4 +- .../yt/codec/CMakeLists.darwin-x86_64.txt | 4 +- .../yt/codec/CMakeLists.linux-aarch64.txt | 4 +- .../yt/codec/CMakeLists.linux-x86_64.txt | 4 +- .../yt/codec/CMakeLists.windows-x86_64.txt | 4 +- .../codec/codegen/CMakeLists.darwin-arm64.txt | 82 +- .../codegen/CMakeLists.darwin-x86_64.txt | 82 +- .../codegen/CMakeLists.linux-aarch64.txt | 83 +- .../codec/codegen/CMakeLists.linux-x86_64.txt | 83 +- .../codegen/CMakeLists.windows-x86_64.txt | 82 +- .../no_llvm/CMakeLists.darwin-arm64.txt | 23 + .../no_llvm/CMakeLists.darwin-x86_64.txt | 23 + .../no_llvm/CMakeLists.linux-aarch64.txt | 24 + .../no_llvm/CMakeLists.linux-x86_64.txt | 24 + .../yt/codec/codegen/no_llvm/CMakeLists.txt | 19 + .../no_llvm/CMakeLists.windows-x86_64.txt | 23 + .../codegen/ut/CMakeLists.darwin-arm64.txt | 5 +- .../codegen/ut/CMakeLists.darwin-x86_64.txt | 5 +- .../codegen/ut/CMakeLists.linux-aarch64.txt | 6 +- .../codegen/ut/CMakeLists.linux-x86_64.txt | 6 +- .../codegen/ut/CMakeLists.windows-x86_64.txt | 3 +- .../yt/codec/ut/CMakeLists.darwin-arm64.txt | 7 +- .../yt/codec/ut/CMakeLists.darwin-x86_64.txt | 7 +- .../yt/codec/ut/CMakeLists.linux-aarch64.txt | 8 +- .../yt/codec/ut/CMakeLists.linux-x86_64.txt | 8 +- .../yt/codec/ut/CMakeLists.windows-x86_64.txt | 5 +- .../ut/no_llvm/CMakeLists.darwin-arm64.txt | 78 + .../ut/no_llvm/CMakeLists.darwin-x86_64.txt | 79 + .../ut/no_llvm/CMakeLists.linux-aarch64.txt | 81 + .../ut/no_llvm/CMakeLists.linux-x86_64.txt | 83 + .../yt/codec/ut/no_llvm/CMakeLists.txt | 19 + .../ut/no_llvm/CMakeLists.windows-x86_64.txt | 74 + .../yt/comp_nodes/CMakeLists.darwin-arm64.txt | 29 +- .../comp_nodes/CMakeLists.darwin-x86_64.txt | 29 +- .../comp_nodes/CMakeLists.linux-aarch64.txt | 29 +- .../yt/comp_nodes/CMakeLists.linux-x86_64.txt | 29 +- .../comp_nodes/CMakeLists.windows-x86_64.txt | 29 +- .../comp_nodes/dq/CMakeLists.darwin-arm64.txt | 5 +- .../dq/CMakeLists.darwin-x86_64.txt | 5 +- .../dq/CMakeLists.linux-aarch64.txt | 6 +- .../comp_nodes/dq/CMakeLists.linux-x86_64.txt | 6 +- .../dq/CMakeLists.windows-x86_64.txt | 5 +- .../llvm/CMakeLists.darwin-arm64.txt | 73 + .../llvm/CMakeLists.darwin-x86_64.txt | 73 + .../llvm/CMakeLists.linux-aarch64.txt | 74 + .../llvm/CMakeLists.linux-x86_64.txt | 74 + .../yt/comp_nodes/llvm/CMakeLists.txt | 19 + .../llvm/CMakeLists.windows-x86_64.txt | 73 + .../llvm14/CMakeLists.darwin-arm64.txt | 73 + .../llvm14/CMakeLists.darwin-x86_64.txt | 73 + .../llvm14/CMakeLists.linux-aarch64.txt | 74 + .../llvm14/CMakeLists.linux-x86_64.txt | 74 + .../yt/comp_nodes/llvm14/CMakeLists.txt | 19 + .../llvm14/CMakeLists.windows-x86_64.txt | 73 + .../no_llvm/CMakeLists.darwin-arm64.txt | 67 + .../no_llvm/CMakeLists.darwin-x86_64.txt | 67 + .../no_llvm/CMakeLists.linux-aarch64.txt | 68 + .../no_llvm/CMakeLists.linux-x86_64.txt | 68 + .../yt/comp_nodes/no_llvm/CMakeLists.txt | 19 + .../no_llvm/CMakeLists.windows-x86_64.txt | 67 + .../CMakeLists.darwin-arm64.txt | 2 +- .../CMakeLists.darwin-x86_64.txt | 2 +- .../CMakeLists.linux-aarch64.txt | 2 +- .../CMakeLists.linux-x86_64.txt | 2 +- .../yt/dq_task_preprocessor/CMakeLists.txt | 2 + .../CMakeLists.windows-x86_64.txt | 34 + .../yt/expr_nodes/CMakeLists.darwin-arm64.txt | 3 + .../expr_nodes/CMakeLists.darwin-x86_64.txt | 3 + .../expr_nodes/CMakeLists.linux-aarch64.txt | 3 + .../yt/expr_nodes/CMakeLists.linux-x86_64.txt | 3 + .../expr_nodes/CMakeLists.windows-x86_64.txt | 3 + .../gateway/file/CMakeLists.darwin-arm64.txt | 2 +- .../gateway/file/CMakeLists.darwin-x86_64.txt | 2 +- .../gateway/file/CMakeLists.linux-aarch64.txt | 2 +- .../gateway/file/CMakeLists.linux-x86_64.txt | 2 +- .../file/CMakeLists.windows-x86_64.txt | 2 +- .../gateway/lib/CMakeLists.darwin-arm64.txt | 5 + .../gateway/lib/CMakeLists.darwin-x86_64.txt | 5 + .../gateway/lib/CMakeLists.linux-aarch64.txt | 5 + .../gateway/lib/CMakeLists.linux-x86_64.txt | 5 + .../gateway/lib/CMakeLists.windows-x86_64.txt | 5 + .../native/CMakeLists.darwin-arm64.txt | 2 +- .../native/CMakeLists.darwin-x86_64.txt | 2 +- .../native/CMakeLists.linux-aarch64.txt | 2 +- .../native/CMakeLists.linux-x86_64.txt | 2 +- .../native/CMakeLists.windows-x86_64.txt | 2 +- .../native/ut/CMakeLists.darwin-arm64.txt | 7 +- .../native/ut/CMakeLists.darwin-x86_64.txt | 7 +- .../native/ut/CMakeLists.linux-aarch64.txt | 9 +- .../native/ut/CMakeLists.linux-x86_64.txt | 9 +- .../native/ut/CMakeLists.windows-x86_64.txt | 5 + .../yt/job/CMakeLists.darwin-arm64.txt | 3 +- .../yt/job/CMakeLists.darwin-x86_64.txt | 3 +- .../yt/job/CMakeLists.linux-aarch64.txt | 3 +- .../yt/job/CMakeLists.linux-x86_64.txt | 3 +- .../yt/job/CMakeLists.windows-x86_64.txt | 3 +- .../CMakeLists.darwin-arm64.txt | 1 + .../CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.linux-aarch64.txt | 1 + .../CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../expr_traits/CMakeLists.darwin-arm64.txt | 2 +- .../expr_traits/CMakeLists.darwin-x86_64.txt | 2 +- .../expr_traits/CMakeLists.linux-aarch64.txt | 2 +- .../expr_traits/CMakeLists.linux-x86_64.txt | 2 +- .../expr_traits/CMakeLists.windows-x86_64.txt | 2 +- .../yt/lib/hash/CMakeLists.darwin-arm64.txt | 1 + .../yt/lib/hash/CMakeLists.darwin-x86_64.txt | 1 + .../yt/lib/hash/CMakeLists.linux-aarch64.txt | 1 + .../yt/lib/hash/CMakeLists.linux-x86_64.txt | 1 + .../yt/lib/hash/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 2 +- .../CMakeLists.darwin-x86_64.txt | 2 +- .../CMakeLists.linux-aarch64.txt | 2 +- .../CMakeLists.linux-x86_64.txt | 2 +- .../CMakeLists.windows-x86_64.txt | 2 +- .../yt/lib/log/CMakeLists.darwin-arm64.txt | 1 + .../yt/lib/log/CMakeLists.darwin-x86_64.txt | 1 + .../yt/lib/log/CMakeLists.linux-aarch64.txt | 1 + .../yt/lib/log/CMakeLists.linux-x86_64.txt | 1 + .../yt/lib/log/CMakeLists.windows-x86_64.txt | 1 + .../yt/provider/CMakeLists.darwin-arm64.txt | 2 + .../yt/provider/CMakeLists.darwin-x86_64.txt | 2 + .../yt/provider/CMakeLists.linux-aarch64.txt | 2 + .../yt/provider/CMakeLists.linux-x86_64.txt | 2 + .../yt/provider/CMakeLists.windows-x86_64.txt | 2 + .../provider/ut/CMakeLists.darwin-arm64.txt | 8 +- .../provider/ut/CMakeLists.darwin-x86_64.txt | 8 +- .../provider/ut/CMakeLists.linux-aarch64.txt | 10 +- .../provider/ut/CMakeLists.linux-x86_64.txt | 10 +- .../provider/ut/CMakeLists.windows-x86_64.txt | 6 +- .../decimal/CMakeLists.darwin-arm64.txt | 2 + .../decimal/CMakeLists.darwin-x86_64.txt | 2 + .../decimal/CMakeLists.linux-aarch64.txt | 2 + .../decimal/CMakeLists.linux-x86_64.txt | 2 + .../decimal/CMakeLists.windows-x86_64.txt | 2 + .../decimal/ut/CMakeLists.darwin-arm64.txt | 1 + .../decimal/ut/CMakeLists.darwin-x86_64.txt | 1 + .../decimal/ut/CMakeLists.linux-aarch64.txt | 4 +- .../decimal/ut/CMakeLists.linux-x86_64.txt | 4 +- .../decimal/ut/CMakeLists.windows-x86_64.txt | 1 + .../embedded/CMakeLists.darwin-arm64.txt | 8 + .../embedded/CMakeLists.darwin-x86_64.txt | 8 + .../embedded/CMakeLists.linux-aarch64.txt | 8 + .../embedded/CMakeLists.linux-x86_64.txt | 8 + .../embedded/CMakeLists.windows-x86_64.txt | 8 + .../no_llvm/CMakeLists.darwin-arm64.txt | 59 + .../no_llvm/CMakeLists.darwin-x86_64.txt | 59 + .../no_llvm/CMakeLists.linux-aarch64.txt | 60 + .../no_llvm/CMakeLists.linux-x86_64.txt | 60 + .../public/embedded/no_llvm/CMakeLists.txt | 19 + .../no_llvm/CMakeLists.windows-x86_64.txt | 59 + .../embedded/ut/CMakeLists.darwin-arm64.txt | 74 + .../embedded/ut/CMakeLists.darwin-x86_64.txt | 75 + .../embedded/ut/CMakeLists.linux-aarch64.txt | 77 + .../embedded/ut/CMakeLists.linux-x86_64.txt | 79 + .../yql/public/embedded/ut/CMakeLists.txt | 19 + .../embedded/ut/CMakeLists.windows-x86_64.txt | 70 + .../ut/no_llvm/CMakeLists.darwin-arm64.txt | 73 + .../ut/no_llvm/CMakeLists.darwin-x86_64.txt | 74 + .../ut/no_llvm/CMakeLists.linux-aarch64.txt | 76 + .../ut/no_llvm/CMakeLists.linux-x86_64.txt | 78 + .../public/embedded/ut/no_llvm/CMakeLists.txt | 19 + .../ut/no_llvm/CMakeLists.windows-x86_64.txt | 69 + .../fastcheck/ut/CMakeLists.darwin-arm64.txt | 3 +- .../fastcheck/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../fastcheck/ut/CMakeLists.linux-aarch64.txt | 4 +- .../fastcheck/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../issue/protos/CMakeLists.darwin-arm64.txt | 4 + .../issue/protos/CMakeLists.darwin-x86_64.txt | 4 + .../issue/protos/CMakeLists.linux-aarch64.txt | 4 + .../issue/protos/CMakeLists.linux-x86_64.txt | 4 + .../protos/CMakeLists.windows-x86_64.txt | 4 + .../issue/ut/CMakeLists.darwin-arm64.txt | 3 +- .../issue/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../issue/ut/CMakeLists.linux-aarch64.txt | 4 +- .../issue/ut/CMakeLists.linux-x86_64.txt | 4 +- .../issue/ut/CMakeLists.windows-x86_64.txt | 1 + .../purecalc/CMakeLists.darwin-arm64.txt | 1 + .../purecalc/CMakeLists.darwin-x86_64.txt | 1 + .../purecalc/CMakeLists.linux-aarch64.txt | 1 + .../purecalc/CMakeLists.linux-x86_64.txt | 1 + .../purecalc/CMakeLists.windows-x86_64.txt | 1 + .../common/CMakeLists.darwin-arm64.txt | 9 +- .../common/CMakeLists.darwin-x86_64.txt | 9 +- .../common/CMakeLists.linux-aarch64.txt | 9 +- .../common/CMakeLists.linux-x86_64.txt | 9 +- .../common/CMakeLists.windows-x86_64.txt | 9 +- .../no_llvm/CMakeLists.darwin-arm64.txt | 72 + .../no_llvm/CMakeLists.darwin-x86_64.txt | 72 + .../no_llvm/CMakeLists.linux-aarch64.txt | 73 + .../no_llvm/CMakeLists.linux-x86_64.txt | 73 + .../purecalc/common/no_llvm/CMakeLists.txt | 19 + .../no_llvm/CMakeLists.windows-x86_64.txt | 72 + .../protobuf/CMakeLists.darwin-arm64.txt | 3 +- .../protobuf/CMakeLists.darwin-x86_64.txt | 3 +- .../protobuf/CMakeLists.linux-aarch64.txt | 4 +- .../protobuf/CMakeLists.linux-x86_64.txt | 4 +- .../protobuf/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 2 - .../CMakeLists.darwin-x86_64.txt | 2 - .../CMakeLists.linux-aarch64.txt | 3 - .../CMakeLists.linux-x86_64.txt | 3 - .../io_specs/mkql/CMakeLists.darwin-arm64.txt | 7 +- .../mkql/CMakeLists.darwin-x86_64.txt | 7 +- .../mkql/CMakeLists.linux-aarch64.txt | 7 +- .../io_specs/mkql/CMakeLists.linux-x86_64.txt | 7 +- .../mkql/CMakeLists.windows-x86_64.txt | 7 +- .../mkql/no_llvm/CMakeLists.darwin-arm64.txt | 30 + .../mkql/no_llvm/CMakeLists.darwin-x86_64.txt | 30 + .../mkql/no_llvm/CMakeLists.linux-aarch64.txt | 31 + .../mkql/no_llvm/CMakeLists.linux-x86_64.txt | 31 + .../io_specs/mkql/no_llvm/CMakeLists.txt | 19 + .../no_llvm/CMakeLists.windows-x86_64.txt | 30 + .../mkql/ut/CMakeLists.darwin-arm64.txt | 6 +- .../mkql/ut/CMakeLists.darwin-x86_64.txt | 6 +- .../mkql/ut/CMakeLists.linux-aarch64.txt | 7 +- .../mkql/ut/CMakeLists.linux-x86_64.txt | 7 +- .../mkql/ut/CMakeLists.windows-x86_64.txt | 4 +- .../ut/no_llvm/CMakeLists.darwin-arm64.txt | 75 + .../ut/no_llvm/CMakeLists.darwin-x86_64.txt | 76 + .../ut/no_llvm/CMakeLists.linux-aarch64.txt | 78 + .../ut/no_llvm/CMakeLists.linux-x86_64.txt | 80 + .../io_specs/mkql/ut/no_llvm/CMakeLists.txt | 19 + .../ut/no_llvm/CMakeLists.windows-x86_64.txt | 71 + .../protobuf/ut/CMakeLists.darwin-arm64.txt | 5 +- .../protobuf/ut/CMakeLists.darwin-x86_64.txt | 5 +- .../protobuf/ut/CMakeLists.linux-aarch64.txt | 6 +- .../protobuf/ut/CMakeLists.linux-x86_64.txt | 6 +- .../protobuf/ut/CMakeLists.windows-x86_64.txt | 3 +- .../protobuf_raw/CMakeLists.darwin-arm64.txt | 1 + .../protobuf_raw/CMakeLists.darwin-x86_64.txt | 1 + .../protobuf_raw/CMakeLists.linux-aarch64.txt | 1 + .../protobuf_raw/CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../no_llvm/CMakeLists.darwin-arm64.txt | 30 + .../no_llvm/CMakeLists.darwin-x86_64.txt | 30 + .../no_llvm/CMakeLists.linux-aarch64.txt | 31 + .../no_llvm/CMakeLists.linux-x86_64.txt | 31 + .../public/purecalc/no_llvm/CMakeLists.txt | 19 + .../no_llvm/CMakeLists.windows-x86_64.txt | 30 + .../purecalc/ut/CMakeLists.darwin-arm64.txt | 5 +- .../purecalc/ut/CMakeLists.darwin-x86_64.txt | 5 +- .../purecalc/ut/CMakeLists.linux-aarch64.txt | 6 +- .../purecalc/ut/CMakeLists.linux-x86_64.txt | 6 +- .../purecalc/ut/CMakeLists.windows-x86_64.txt | 3 + .../ut/lib/CMakeLists.darwin-arm64.txt | 1 + .../ut/lib/CMakeLists.darwin-x86_64.txt | 1 + .../ut/lib/CMakeLists.linux-aarch64.txt | 1 + .../ut/lib/CMakeLists.linux-x86_64.txt | 1 + .../ut/lib/CMakeLists.windows-x86_64.txt | 1 + .../ut/protos/CMakeLists.darwin-arm64.txt | 3 + .../ut/protos/CMakeLists.darwin-x86_64.txt | 3 + .../ut/protos/CMakeLists.linux-aarch64.txt | 3 + .../ut/protos/CMakeLists.linux-x86_64.txt | 3 + .../ut/protos/CMakeLists.windows-x86_64.txt | 3 + .../public/types/CMakeLists.darwin-arm64.txt | 3 + .../public/types/CMakeLists.darwin-x86_64.txt | 3 + .../public/types/CMakeLists.linux-aarch64.txt | 3 + .../public/types/CMakeLists.linux-x86_64.txt | 3 + .../types/CMakeLists.windows-x86_64.txt | 3 + .../public/udf/CMakeLists.darwin-arm64.txt | 21 + .../public/udf/CMakeLists.darwin-x86_64.txt | 21 + .../public/udf/CMakeLists.linux-aarch64.txt | 21 + .../public/udf/CMakeLists.linux-x86_64.txt | 21 + .../public/udf/CMakeLists.windows-x86_64.txt | 21 + .../CMakeLists.darwin-arm64.txt | 16 +- .../CMakeLists.darwin-x86_64.txt | 16 +- .../CMakeLists.linux-aarch64.txt | 17 +- .../CMakeLists.linux-x86_64.txt | 17 +- .../CMakeLists.windows-x86_64.txt | 16 +- .../service/stub/CMakeLists.darwin-arm64.txt | 15 +- .../service/stub/CMakeLists.darwin-x86_64.txt | 15 +- .../service/stub/CMakeLists.linux-aarch64.txt | 16 +- .../service/stub/CMakeLists.linux-x86_64.txt | 16 +- .../stub/CMakeLists.windows-x86_64.txt | 15 +- .../CMakeLists.darwin-arm64.txt | 16 +- .../CMakeLists.darwin-x86_64.txt | 16 +- .../CMakeLists.linux-aarch64.txt | 17 +- .../CMakeLists.linux-x86_64.txt | 17 +- .../CMakeLists.windows-x86_64.txt | 16 +- .../public/udf/tz/CMakeLists.darwin-arm64.txt | 1 + .../udf/tz/CMakeLists.darwin-x86_64.txt | 1 + .../udf/tz/CMakeLists.linux-aarch64.txt | 1 + .../public/udf/tz/CMakeLists.linux-x86_64.txt | 1 + .../udf/tz/CMakeLists.windows-x86_64.txt | 1 + .../udf/tz/ut/CMakeLists.darwin-arm64.txt | 1 + .../udf/tz/ut/CMakeLists.darwin-x86_64.txt | 1 + .../udf/tz/ut/CMakeLists.linux-aarch64.txt | 4 +- .../udf/tz/ut/CMakeLists.linux-x86_64.txt | 4 +- .../udf/tz/ut/CMakeLists.windows-x86_64.txt | 1 + .../public/udf/ut/CMakeLists.darwin-arm64.txt | 3 +- .../udf/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../udf/ut/CMakeLists.linux-aarch64.txt | 4 +- .../public/udf/ut/CMakeLists.linux-x86_64.txt | 4 +- .../udf/ut/CMakeLists.windows-x86_64.txt | 1 + .../yql/sql/pg/CMakeLists.darwin-arm64.txt | 1 - .../yql/sql/pg/CMakeLists.darwin-x86_64.txt | 1 - .../yql/sql/pg/CMakeLists.linux-aarch64.txt | 1 - .../yql/sql/pg/CMakeLists.linux-x86_64.txt | 1 - .../yql/sql/pg/CMakeLists.windows-x86_64.txt | 1 - .../yql/sql/pg/ut/CMakeLists.darwin-arm64.txt | 6 +- .../sql/pg/ut/CMakeLists.darwin-x86_64.txt | 6 +- .../sql/pg/ut/CMakeLists.linux-aarch64.txt | 7 +- .../yql/sql/pg/ut/CMakeLists.linux-x86_64.txt | 7 +- .../sql/pg/ut/CMakeLists.windows-x86_64.txt | 4 +- .../sql/settings/CMakeLists.darwin-arm64.txt | 1 + .../sql/settings/CMakeLists.darwin-x86_64.txt | 1 + .../sql/settings/CMakeLists.linux-aarch64.txt | 1 + .../sql/settings/CMakeLists.linux-x86_64.txt | 1 + .../settings/CMakeLists.windows-x86_64.txt | 1 + .../yql/sql/v0/CMakeLists.darwin-arm64.txt | 1 + .../yql/sql/v0/CMakeLists.darwin-x86_64.txt | 1 + .../yql/sql/v0/CMakeLists.linux-aarch64.txt | 1 + .../yql/sql/v0/CMakeLists.linux-x86_64.txt | 1 + .../yql/sql/v0/CMakeLists.windows-x86_64.txt | 1 + .../yql/sql/v0/ut/CMakeLists.darwin-arm64.txt | 3 +- .../sql/v0/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../sql/v0/ut/CMakeLists.linux-aarch64.txt | 4 +- .../yql/sql/v0/ut/CMakeLists.linux-x86_64.txt | 4 +- .../sql/v0/ut/CMakeLists.windows-x86_64.txt | 1 + .../yql/sql/v1/CMakeLists.darwin-arm64.txt | 2 +- .../yql/sql/v1/CMakeLists.darwin-x86_64.txt | 2 +- .../yql/sql/v1/CMakeLists.linux-aarch64.txt | 2 +- .../yql/sql/v1/CMakeLists.linux-x86_64.txt | 2 +- .../yql/sql/v1/CMakeLists.windows-x86_64.txt | 2 +- .../v1/format/ut/CMakeLists.darwin-arm64.txt | 3 +- .../v1/format/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../v1/format/ut/CMakeLists.linux-aarch64.txt | 4 +- .../v1/format/ut/CMakeLists.linux-x86_64.txt | 4 +- .../format/ut/CMakeLists.windows-x86_64.txt | 1 + .../sql/v1/lexer/CMakeLists.darwin-arm64.txt | 2 +- .../sql/v1/lexer/CMakeLists.darwin-x86_64.txt | 2 +- .../sql/v1/lexer/CMakeLists.linux-aarch64.txt | 2 +- .../sql/v1/lexer/CMakeLists.linux-x86_64.txt | 2 +- .../v1/lexer/CMakeLists.windows-x86_64.txt | 2 +- .../sql/v1/perf/CMakeLists.darwin-arm64.txt | 2 - .../sql/v1/perf/CMakeLists.darwin-x86_64.txt | 2 - .../sql/v1/perf/CMakeLists.linux-aarch64.txt | 3 - .../sql/v1/perf/CMakeLists.linux-x86_64.txt | 3 - .../proto_parser/CMakeLists.darwin-arm64.txt | 2 +- .../proto_parser/CMakeLists.darwin-x86_64.txt | 2 +- .../proto_parser/CMakeLists.linux-aarch64.txt | 2 +- .../proto_parser/CMakeLists.linux-x86_64.txt | 2 +- .../CMakeLists.windows-x86_64.txt | 2 +- .../yql/sql/v1/ut/CMakeLists.darwin-arm64.txt | 3 +- .../sql/v1/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../sql/v1/ut/CMakeLists.linux-aarch64.txt | 4 +- .../yql/sql/v1/ut/CMakeLists.linux-x86_64.txt | 4 +- .../sql/v1/ut/CMakeLists.windows-x86_64.txt | 1 + ydb/library/yql/tools/CMakeLists.txt | 1 + .../tools/astdiff/CMakeLists.darwin-arm64.txt | 2 - .../astdiff/CMakeLists.darwin-x86_64.txt | 2 - .../astdiff/CMakeLists.linux-aarch64.txt | 3 - .../tools/astdiff/CMakeLists.linux-x86_64.txt | 3 - .../dq/dq_cli/CMakeLists.darwin-arm64.txt | 2 - .../dq/dq_cli/CMakeLists.darwin-x86_64.txt | 2 - .../dq/dq_cli/CMakeLists.linux-aarch64.txt | 3 - .../dq/dq_cli/CMakeLists.linux-x86_64.txt | 3 - .../service_node/CMakeLists.darwin-arm64.txt | 6 +- .../service_node/CMakeLists.darwin-x86_64.txt | 6 +- .../service_node/CMakeLists.linux-aarch64.txt | 8 +- .../service_node/CMakeLists.linux-x86_64.txt | 8 +- .../worker_node/CMakeLists.darwin-arm64.txt | 6 +- .../worker_node/CMakeLists.darwin-x86_64.txt | 6 +- .../worker_node/CMakeLists.linux-aarch64.txt | 8 +- .../worker_node/CMakeLists.linux-x86_64.txt | 8 +- .../tools/dqrun/CMakeLists.darwin-arm64.txt | 8 +- .../tools/dqrun/CMakeLists.darwin-x86_64.txt | 8 +- .../tools/dqrun/CMakeLists.linux-aarch64.txt | 10 +- .../tools/dqrun/CMakeLists.linux-x86_64.txt | 10 +- .../tools/mrjob/CMakeLists.darwin-arm64.txt | 7 +- .../tools/mrjob/CMakeLists.darwin-x86_64.txt | 7 +- .../tools/mrjob/CMakeLists.linux-aarch64.txt | 9 +- .../tools/mrjob/CMakeLists.linux-x86_64.txt | 9 +- .../tools/mrjob/CMakeLists.windows-x86_64.txt | 5 + .../tools/mrrun/CMakeLists.darwin-arm64.txt | 88 + .../tools/mrrun/CMakeLists.darwin-x86_64.txt | 89 + .../tools/mrrun/CMakeLists.linux-aarch64.txt | 91 + .../tools/mrrun/CMakeLists.linux-x86_64.txt | 92 + ydb/library/yql/tools/mrrun/CMakeLists.txt | 19 + .../tools/mrrun/CMakeLists.windows-x86_64.txt | 83 + .../tools/pgrun/CMakeLists.darwin-arm64.txt | 8 +- .../tools/pgrun/CMakeLists.darwin-x86_64.txt | 8 +- .../tools/pgrun/CMakeLists.linux-aarch64.txt | 10 +- .../tools/pgrun/CMakeLists.linux-x86_64.txt | 10 +- .../tools/pgrun/CMakeLists.windows-x86_64.txt | 6 +- .../tools/sql2yql/CMakeLists.darwin-arm64.txt | 5 - .../sql2yql/CMakeLists.darwin-x86_64.txt | 5 - .../sql2yql/CMakeLists.linux-aarch64.txt | 6 - .../tools/sql2yql/CMakeLists.linux-x86_64.txt | 6 - .../sql2yql/CMakeLists.windows-x86_64.txt | 3 - .../sql_formatter/CMakeLists.darwin-arm64.txt | 2 - .../CMakeLists.darwin-x86_64.txt | 2 - .../CMakeLists.linux-aarch64.txt | 3 - .../sql_formatter/CMakeLists.linux-x86_64.txt | 3 - .../udf_dep_stub/CMakeLists.linux-aarch64.txt | 3 - .../udf_dep_stub/CMakeLists.linux-x86_64.txt | 3 - .../udf_probe/CMakeLists.darwin-arm64.txt | 2 - .../udf_probe/CMakeLists.darwin-x86_64.txt | 2 - .../udf_probe/CMakeLists.linux-aarch64.txt | 3 - .../udf_probe/CMakeLists.linux-x86_64.txt | 3 - .../udf_resolver/CMakeLists.darwin-arm64.txt | 2 - .../udf_resolver/CMakeLists.darwin-x86_64.txt | 2 - .../udf_resolver/CMakeLists.linux-aarch64.txt | 3 - .../udf_resolver/CMakeLists.linux-x86_64.txt | 3 - .../tools/yqlrun/CMakeLists.darwin-arm64.txt | 14 +- .../tools/yqlrun/CMakeLists.darwin-x86_64.txt | 14 +- .../tools/yqlrun/CMakeLists.linux-aarch64.txt | 16 +- .../tools/yqlrun/CMakeLists.linux-x86_64.txt | 16 +- .../yqlrun/CMakeLists.windows-x86_64.txt | 12 +- .../yqlrun/http/CMakeLists.darwin-arm64.txt | 48 - .../yqlrun/http/CMakeLists.darwin-x86_64.txt | 48 - .../yqlrun/http/CMakeLists.linux-aarch64.txt | 48 - .../yqlrun/http/CMakeLists.linux-x86_64.txt | 48 - .../yqlrun/http/CMakeLists.windows-x86_64.txt | 48 - .../client/CMakeLists.darwin-arm64.txt | 2 - .../client/CMakeLists.darwin-x86_64.txt | 2 - .../client/CMakeLists.linux-aarch64.txt | 3 - .../client/CMakeLists.linux-x86_64.txt | 3 - .../CMakeLists.linux-aarch64.txt | 3 - .../compress_base/CMakeLists.linux-x86_64.txt | 3 - .../datetime/CMakeLists.linux-aarch64.txt | 3 - .../datetime/CMakeLists.linux-x86_64.txt | 3 - .../datetime2/CMakeLists.darwin-arm64.txt | 2 - .../datetime2/CMakeLists.darwin-x86_64.txt | 2 - .../datetime2/CMakeLists.linux-aarch64.txt | 3 - .../datetime2/CMakeLists.linux-x86_64.txt | 3 - .../digest/CMakeLists.linux-aarch64.txt | 3 - .../common/digest/CMakeLists.linux-x86_64.txt | 3 - .../common/file/CMakeLists.darwin-arm64.txt | 2 - .../common/file/CMakeLists.darwin-x86_64.txt | 2 - .../common/file/CMakeLists.linux-aarch64.txt | 3 - .../common/file/CMakeLists.linux-x86_64.txt | 3 - .../histogram/CMakeLists.linux-aarch64.txt | 3 - .../histogram/CMakeLists.linux-x86_64.txt | 3 - .../hyperloglog/CMakeLists.linux-aarch64.txt | 3 - .../hyperloglog/CMakeLists.linux-x86_64.txt | 3 - .../hyperscan/CMakeLists.linux-x86_64.txt | 3 - .../ip_base/CMakeLists.linux-aarch64.txt | 3 - .../ip_base/CMakeLists.linux-x86_64.txt | 3 - .../ip_base/lib/CMakeLists.darwin-arm64.txt | 2 + .../ip_base/lib/CMakeLists.darwin-x86_64.txt | 2 + .../ip_base/lib/CMakeLists.linux-aarch64.txt | 2 + .../ip_base/lib/CMakeLists.linux-x86_64.txt | 2 + .../ip_base/lib/CMakeLists.windows-x86_64.txt | 2 + .../common/json/CMakeLists.linux-aarch64.txt | 3 - .../common/json/CMakeLists.linux-x86_64.txt | 3 - .../common/json2/CMakeLists.darwin-arm64.txt | 2 - .../common/json2/CMakeLists.darwin-x86_64.txt | 2 - .../common/json2/CMakeLists.linux-aarch64.txt | 3 - .../common/json2/CMakeLists.linux-x86_64.txt | 3 - .../common/math/CMakeLists.darwin-arm64.txt | 111 - .../common/math/CMakeLists.darwin-x86_64.txt | 111 - .../common/math/CMakeLists.linux-aarch64.txt | 114 - .../common/math/CMakeLists.linux-x86_64.txt | 114 - .../common/math/CMakeLists.windows-x86_64.txt | 111 - .../common/pire/CMakeLists.linux-aarch64.txt | 3 - .../common/pire/CMakeLists.linux-x86_64.txt | 3 - .../protobuf/CMakeLists.linux-aarch64.txt | 3 - .../protobuf/CMakeLists.linux-x86_64.txt | 3 - .../common/re2/CMakeLists.darwin-arm64.txt | 2 - .../common/re2/CMakeLists.darwin-x86_64.txt | 2 - .../common/re2/CMakeLists.linux-aarch64.txt | 3 - .../common/re2/CMakeLists.linux-x86_64.txt | 3 - .../common/set/CMakeLists.linux-aarch64.txt | 3 - .../common/set/CMakeLists.linux-x86_64.txt | 3 - .../common/stat/CMakeLists.linux-aarch64.txt | 3 - .../common/stat/CMakeLists.linux-x86_64.txt | 3 - .../stat/static/CMakeLists.darwin-arm64.txt | 1 + .../stat/static/CMakeLists.darwin-x86_64.txt | 1 + .../stat/static/CMakeLists.linux-aarch64.txt | 1 + .../stat/static/CMakeLists.linux-x86_64.txt | 1 + .../stat/static/CMakeLists.windows-x86_64.txt | 1 + .../stat/ut/CMakeLists.darwin-arm64.txt | 5 +- .../stat/ut/CMakeLists.darwin-x86_64.txt | 5 +- .../stat/ut/CMakeLists.linux-aarch64.txt | 6 +- .../stat/ut/CMakeLists.linux-x86_64.txt | 6 +- .../stat/ut/CMakeLists.windows-x86_64.txt | 3 +- .../streaming/CMakeLists.linux-aarch64.txt | 3 - .../streaming/CMakeLists.linux-x86_64.txt | 3 - .../common/string/CMakeLists.darwin-arm64.txt | 2 - .../string/CMakeLists.darwin-x86_64.txt | 2 - .../string/CMakeLists.linux-aarch64.txt | 3 - .../common/string/CMakeLists.linux-x86_64.txt | 3 - .../common/top/CMakeLists.linux-aarch64.txt | 3 - .../common/top/CMakeLists.linux-x86_64.txt | 3 - .../topfreq/CMakeLists.linux-aarch64.txt | 3 - .../topfreq/CMakeLists.linux-x86_64.txt | 3 - .../topfreq/ut/CMakeLists.darwin-arm64.txt | 5 +- .../topfreq/ut/CMakeLists.darwin-x86_64.txt | 5 +- .../topfreq/ut/CMakeLists.linux-aarch64.txt | 6 +- .../topfreq/ut/CMakeLists.linux-x86_64.txt | 6 +- .../topfreq/ut/CMakeLists.windows-x86_64.txt | 3 +- .../unicode_base/CMakeLists.darwin-arm64.txt | 2 - .../unicode_base/CMakeLists.darwin-x86_64.txt | 2 - .../unicode_base/CMakeLists.linux-aarch64.txt | 3 - .../unicode_base/CMakeLists.linux-x86_64.txt | 3 - .../url_base/CMakeLists.darwin-arm64.txt | 2 - .../url_base/CMakeLists.darwin-x86_64.txt | 2 - .../url_base/CMakeLists.linux-aarch64.txt | 3 - .../url_base/CMakeLists.linux-x86_64.txt | 3 - .../common/yson2/CMakeLists.darwin-arm64.txt | 2 - .../common/yson2/CMakeLists.darwin-x86_64.txt | 2 - .../common/yson2/CMakeLists.linux-aarch64.txt | 3 - .../common/yson2/CMakeLists.linux-x86_64.txt | 3 - .../callables/CMakeLists.linux-aarch64.txt | 3 - .../callables/CMakeLists.linux-x86_64.txt | 3 - .../dicts/CMakeLists.linux-aarch64.txt | 3 - .../dicts/CMakeLists.linux-x86_64.txt | 3 - .../dummylog/CMakeLists.linux-aarch64.txt | 3 - .../dummylog/CMakeLists.linux-x86_64.txt | 3 - .../lists/CMakeLists.linux-aarch64.txt | 3 - .../lists/CMakeLists.linux-x86_64.txt | 3 - .../structs/CMakeLists.linux-aarch64.txt | 3 - .../structs/CMakeLists.linux-x86_64.txt | 3 - .../tagged/CMakeLists.linux-aarch64.txt | 3 - .../tagged/CMakeLists.linux-x86_64.txt | 3 - .../CMakeLists.linux-aarch64.txt | 3 - .../CMakeLists.linux-x86_64.txt | 3 - .../logs/dsv/CMakeLists.linux-aarch64.txt | 3 - .../udfs/logs/dsv/CMakeLists.linux-x86_64.txt | 3 - .../test/simple/CMakeLists.linux-aarch64.txt | 3 - .../test/simple/CMakeLists.linux-x86_64.txt | 3 - .../test_import/CMakeLists.linux-aarch64.txt | 3 - .../test_import/CMakeLists.linux-x86_64.txt | 3 - .../yql/utils/CMakeLists.darwin-arm64.txt | 19 + .../yql/utils/CMakeLists.darwin-x86_64.txt | 19 + .../yql/utils/CMakeLists.linux-aarch64.txt | 19 + .../yql/utils/CMakeLists.linux-x86_64.txt | 19 + .../yql/utils/CMakeLists.windows-x86_64.txt | 19 + .../actor_system/CMakeLists.darwin-arm64.txt | 1 + .../actor_system/CMakeLists.darwin-x86_64.txt | 1 + .../actor_system/CMakeLists.linux-aarch64.txt | 1 + .../actor_system/CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../actors/ut/CMakeLists.darwin-arm64.txt | 4 +- .../actors/ut/CMakeLists.darwin-x86_64.txt | 4 +- .../actors/ut/CMakeLists.linux-aarch64.txt | 5 +- .../actors/ut/CMakeLists.linux-x86_64.txt | 5 +- .../backtrace/CMakeLists.darwin-arm64.txt | 3 - .../backtrace/CMakeLists.darwin-x86_64.txt | 3 - .../backtrace/CMakeLists.linux-aarch64.txt | 3 - .../backtrace/CMakeLists.linux-x86_64.txt | 4 +- .../backtrace/CMakeLists.windows-x86_64.txt | 3 - .../backtrace/ut/CMakeLists.darwin-arm64.txt | 1 + .../backtrace/ut/CMakeLists.darwin-x86_64.txt | 1 + .../backtrace/ut/CMakeLists.linux-aarch64.txt | 4 +- .../backtrace/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../bindings/ut/CMakeLists.darwin-arm64.txt | 3 +- .../bindings/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../bindings/ut/CMakeLists.linux-aarch64.txt | 4 +- .../bindings/ut/CMakeLists.linux-x86_64.txt | 4 +- .../bindings/ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../log/proto/CMakeLists.darwin-arm64.txt | 3 + .../log/proto/CMakeLists.darwin-x86_64.txt | 3 + .../log/proto/CMakeLists.linux-aarch64.txt | 3 + .../log/proto/CMakeLists.linux-x86_64.txt | 3 + .../log/proto/CMakeLists.windows-x86_64.txt | 3 + .../utils/log/ut/CMakeLists.darwin-arm64.txt | 1 + .../utils/log/ut/CMakeLists.darwin-x86_64.txt | 1 + .../utils/log/ut/CMakeLists.linux-aarch64.txt | 4 +- .../utils/log/ut/CMakeLists.linux-x86_64.txt | 4 +- .../log/ut/CMakeLists.windows-x86_64.txt | 1 + .../utils/plan/ut/CMakeLists.darwin-arm64.txt | 3 +- .../plan/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../plan/ut/CMakeLists.linux-aarch64.txt | 4 +- .../utils/plan/ut/CMakeLists.linux-x86_64.txt | 4 +- .../plan/ut/CMakeLists.windows-x86_64.txt | 1 + .../utils/signals/CMakeLists.darwin-arm64.txt | 27 + .../signals/CMakeLists.darwin-x86_64.txt | 27 + .../signals/CMakeLists.linux-aarch64.txt | 28 + .../utils/signals/CMakeLists.linux-x86_64.txt | 28 + ydb/library/yql/utils/signals/CMakeLists.txt | 19 + .../signals/CMakeLists.windows-x86_64.txt | 27 + .../yql/utils/simd/exec/CMakeLists.txt | 1 + .../add_columns/CMakeLists.darwin-arm64.txt | 30 + .../add_columns/CMakeLists.darwin-x86_64.txt | 31 + .../add_columns/CMakeLists.linux-aarch64.txt | 33 + .../add_columns/CMakeLists.linux-x86_64.txt | 35 + .../simd/exec/add_columns/CMakeLists.txt | 19 + .../add_columns/CMakeLists.windows-x86_64.txt | 26 + .../pack_tuple/CMakeLists.linux-aarch64.txt | 3 - .../pack_tuple/CMakeLists.linux-x86_64.txt | 3 - .../stream_store/CMakeLists.linux-aarch64.txt | 3 - .../stream_store/CMakeLists.linux-x86_64.txt | 3 - .../CMakeLists.linux-aarch64.txt | 3 - .../CMakeLists.linux-x86_64.txt | 3 - .../utils/simd/ut/CMakeLists.darwin-arm64.txt | 1 + .../simd/ut/CMakeLists.darwin-x86_64.txt | 1 + .../simd/ut/CMakeLists.linux-aarch64.txt | 4 +- .../utils/simd/ut/CMakeLists.linux-x86_64.txt | 4 +- .../simd/ut/CMakeLists.windows-x86_64.txt | 1 + .../yql/utils/sys/CMakeLists.darwin-arm64.txt | 2 + .../utils/sys/CMakeLists.darwin-x86_64.txt | 2 + .../utils/sys/CMakeLists.linux-aarch64.txt | 2 + .../yql/utils/sys/CMakeLists.linux-x86_64.txt | 2 + .../utils/sys/CMakeLists.windows-x86_64.txt | 2 + .../yql/utils/ut/CMakeLists.darwin-arm64.txt | 3 +- .../yql/utils/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../yql/utils/ut/CMakeLists.linux-aarch64.txt | 4 +- .../yql/utils/ut/CMakeLists.linux-x86_64.txt | 4 +- .../utils/ut/CMakeLists.windows-x86_64.txt | 1 + .../yql/yt/CMakeLists.linux-aarch64.txt | 20 + .../yql/yt/CMakeLists.linux-x86_64.txt | 20 + ydb/library/yql/yt/CMakeLists.txt | 13 + .../yt/dynamic/CMakeLists.linux-aarch64.txt | 10 +- .../yt/dynamic/CMakeLists.linux-x86_64.txt | 10 +- ydb/library/yql/yt/dynamic/CMakeLists.txt | 6 - .../yt/native/CMakeLists.linux-aarch64.txt | 26 +- .../yql/yt/native/CMakeLists.linux-x86_64.txt | 26 +- ydb/library/yql/yt/native/CMakeLists.txt | 6 - .../CMakeLists.darwin-arm64.txt | 3 + .../CMakeLists.darwin-x86_64.txt | 3 + .../CMakeLists.linux-aarch64.txt | 3 + .../CMakeLists.linux-x86_64.txt | 3 + .../CMakeLists.windows-x86_64.txt | 3 + .../api/client/yc_private/CMakeLists.txt | 1 + .../accessservice/CMakeLists.darwin-arm64.txt | 93 + .../CMakeLists.darwin-x86_64.txt | 93 + .../CMakeLists.linux-aarch64.txt | 94 + .../accessservice/CMakeLists.linux-x86_64.txt | 94 + .../yc_private/accessservice/CMakeLists.txt | 19 + .../CMakeLists.windows-x86_64.txt | 93 + .../compute/inner/CMakeLists.darwin-arm64.txt | 4 + .../inner/CMakeLists.darwin-x86_64.txt | 4 + .../inner/CMakeLists.linux-aarch64.txt | 4 + .../compute/inner/CMakeLists.linux-x86_64.txt | 4 + .../inner/CMakeLists.windows-x86_64.txt | 4 + .../iam/CMakeLists.darwin-arm64.txt | 22 + .../iam/CMakeLists.darwin-x86_64.txt | 22 + .../iam/CMakeLists.linux-aarch64.txt | 22 + .../iam/CMakeLists.linux-x86_64.txt | 22 + .../iam/CMakeLists.windows-x86_64.txt | 22 + .../kms/CMakeLists.darwin-arm64.txt | 6 + .../kms/CMakeLists.darwin-x86_64.txt | 6 + .../kms/CMakeLists.linux-aarch64.txt | 6 + .../kms/CMakeLists.linux-x86_64.txt | 6 + .../kms/CMakeLists.windows-x86_64.txt | 6 + .../CMakeLists.darwin-arm64.txt | 4 + .../CMakeLists.darwin-x86_64.txt | 4 + .../CMakeLists.linux-aarch64.txt | 4 + .../CMakeLists.linux-x86_64.txt | 4 + .../CMakeLists.windows-x86_64.txt | 4 + .../CMakeLists.darwin-arm64.txt | 4 + .../CMakeLists.darwin-x86_64.txt | 4 + .../CMakeLists.linux-aarch64.txt | 4 + .../CMakeLists.linux-x86_64.txt | 4 + .../CMakeLists.windows-x86_64.txt | 4 + .../operation/CMakeLists.darwin-arm64.txt | 4 + .../operation/CMakeLists.darwin-x86_64.txt | 4 + .../operation/CMakeLists.linux-aarch64.txt | 4 + .../operation/CMakeLists.linux-x86_64.txt | 4 + .../operation/CMakeLists.windows-x86_64.txt | 4 + .../CMakeLists.darwin-arm64.txt | 8 + .../CMakeLists.darwin-x86_64.txt | 8 + .../CMakeLists.linux-aarch64.txt | 8 + .../CMakeLists.linux-x86_64.txt | 8 + .../CMakeLists.windows-x86_64.txt | 8 + .../CMakeLists.darwin-arm64.txt | 6 + .../CMakeLists.darwin-x86_64.txt | 6 + .../CMakeLists.linux-aarch64.txt | 6 + .../CMakeLists.linux-x86_64.txt | 6 + .../CMakeLists.windows-x86_64.txt | 6 + .../common/CMakeLists.darwin-arm64.txt | 4 + .../common/CMakeLists.darwin-x86_64.txt | 4 + .../common/CMakeLists.linux-aarch64.txt | 4 + .../common/CMakeLists.linux-x86_64.txt | 4 + .../common/CMakeLists.windows-x86_64.txt | 4 + .../events/CMakeLists.darwin-arm64.txt | 8 + .../events/CMakeLists.darwin-x86_64.txt | 8 + .../events/CMakeLists.linux-aarch64.txt | 8 + .../events/CMakeLists.linux-x86_64.txt | 8 + .../events/CMakeLists.windows-x86_64.txt | 8 + .../yc_public/iam/CMakeLists.darwin-arm64.txt | 4 + .../iam/CMakeLists.darwin-x86_64.txt | 4 + .../iam/CMakeLists.linux-aarch64.txt | 4 + .../yc_public/iam/CMakeLists.linux-x86_64.txt | 4 + .../iam/CMakeLists.windows-x86_64.txt | 4 + .../logging/CMakeLists.darwin-arm64.txt | 8 + .../logging/CMakeLists.darwin-x86_64.txt | 8 + .../logging/CMakeLists.linux-aarch64.txt | 8 + .../logging/CMakeLists.linux-x86_64.txt | 8 + .../logging/CMakeLists.windows-x86_64.txt | 8 + .../api/grpc/CMakeLists.darwin-arm64.txt | 34 + .../api/grpc/CMakeLists.darwin-x86_64.txt | 34 + .../api/grpc/CMakeLists.linux-aarch64.txt | 34 + .../api/grpc/CMakeLists.linux-x86_64.txt | 34 + .../api/grpc/CMakeLists.windows-x86_64.txt | 34 + .../grpc/draft/CMakeLists.darwin-arm64.txt | 30 +- .../grpc/draft/CMakeLists.darwin-x86_64.txt | 30 +- .../grpc/draft/CMakeLists.linux-aarch64.txt | 30 +- .../grpc/draft/CMakeLists.linux-x86_64.txt | 30 +- .../grpc/draft/CMakeLists.windows-x86_64.txt | 30 +- .../api/protos/CMakeLists.darwin-arm64.txt | 47 +- .../api/protos/CMakeLists.darwin-x86_64.txt | 47 +- .../api/protos/CMakeLists.linux-aarch64.txt | 47 +- .../api/protos/CMakeLists.linux-x86_64.txt | 47 +- .../api/protos/CMakeLists.windows-x86_64.txt | 47 +- .../annotations/CMakeLists.darwin-arm64.txt | 4 + .../annotations/CMakeLists.darwin-x86_64.txt | 4 + .../annotations/CMakeLists.linux-aarch64.txt | 4 + .../annotations/CMakeLists.linux-x86_64.txt | 4 + .../annotations/CMakeLists.windows-x86_64.txt | 4 + .../lib/base/CMakeLists.darwin-arm64.txt | 3 + .../lib/base/CMakeLists.darwin-x86_64.txt | 3 + .../lib/base/CMakeLists.linux-aarch64.txt | 3 + .../lib/base/CMakeLists.linux-x86_64.txt | 3 + .../lib/base/CMakeLists.windows-x86_64.txt | 3 + .../client/CMakeLists.darwin-arm64.txt | 3 +- .../client/CMakeLists.darwin-x86_64.txt | 3 +- .../client/CMakeLists.linux-aarch64.txt | 3 +- .../client/CMakeLists.linux-x86_64.txt | 3 +- .../client/CMakeLists.windows-x86_64.txt | 3 +- .../kicli/CMakeLists.darwin-arm64.txt | 1 + .../kicli/CMakeLists.darwin-x86_64.txt | 1 + .../kicli/CMakeLists.linux-aarch64.txt | 1 + .../kicli/CMakeLists.linux-x86_64.txt | 1 + .../kicli/CMakeLists.windows-x86_64.txt | 1 + .../kicli/ut/CMakeLists.darwin-arm64.txt | 3 +- .../kicli/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../kicli/ut/CMakeLists.linux-aarch64.txt | 4 +- .../kicli/ut/CMakeLists.linux-x86_64.txt | 4 +- .../kicli/ut/CMakeLists.windows-x86_64.txt | 1 + .../idx_test/ut/CMakeLists.darwin-arm64.txt | 3 +- .../idx_test/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../idx_test/ut/CMakeLists.linux-aarch64.txt | 4 +- .../idx_test/ut/CMakeLists.linux-x86_64.txt | 4 +- .../idx_test/ut/CMakeLists.windows-x86_64.txt | 1 + .../json_value/ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../json_value/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../lib/jwt/CMakeLists.darwin-arm64.txt | 1 + .../lib/jwt/CMakeLists.darwin-x86_64.txt | 1 + .../lib/jwt/CMakeLists.linux-aarch64.txt | 1 + .../lib/jwt/CMakeLists.linux-x86_64.txt | 1 + .../lib/jwt/CMakeLists.windows-x86_64.txt | 1 + .../protos/CMakeLists.darwin-arm64.txt | 3 + .../protos/CMakeLists.darwin-x86_64.txt | 3 + .../protos/CMakeLists.linux-aarch64.txt | 3 + .../protos/CMakeLists.linux-x86_64.txt | 3 + .../protos/CMakeLists.windows-x86_64.txt | 3 + .../ut/CMakeLists.darwin-arm64.txt | 1 + .../ut/CMakeLists.darwin-x86_64.txt | 1 + .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../scheme_types/CMakeLists.darwin-arm64.txt | 1 + .../scheme_types/CMakeLists.darwin-x86_64.txt | 1 + .../scheme_types/CMakeLists.linux-aarch64.txt | 1 + .../scheme_types/CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../validation/CMakeLists.linux-aarch64.txt | 3 - .../validation/CMakeLists.linux-x86_64.txt | 3 - .../validation/ut/CMakeLists.darwin-arm64.txt | 1 + .../ut/CMakeLists.darwin-x86_64.txt | 1 + .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../validation/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/protos/CMakeLists.darwin-arm64.txt | 3 + .../ut/protos/CMakeLists.darwin-x86_64.txt | 3 + .../ut/protos/CMakeLists.linux-aarch64.txt | 3 + .../ut/protos/CMakeLists.linux-x86_64.txt | 3 + .../ut/protos/CMakeLists.windows-x86_64.txt | 3 + .../commands/CMakeLists.darwin-arm64.txt | 15 +- .../commands/CMakeLists.darwin-x86_64.txt | 14 +- .../commands/CMakeLists.linux-aarch64.txt | 14 +- .../commands/CMakeLists.linux-x86_64.txt | 14 +- .../commands/CMakeLists.windows-x86_64.txt | 14 +- .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../common/CMakeLists.darwin-arm64.txt | 2 + .../common/CMakeLists.darwin-x86_64.txt | 2 + .../common/CMakeLists.linux-aarch64.txt | 2 + .../common/CMakeLists.linux-x86_64.txt | 2 + .../common/CMakeLists.windows-x86_64.txt | 2 + .../common/ut/CMakeLists.darwin-arm64.txt | 3 +- .../common/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../common/ut/CMakeLists.linux-aarch64.txt | 4 +- .../common/ut/CMakeLists.linux-x86_64.txt | 4 +- .../common/ut/CMakeLists.windows-x86_64.txt | 1 + .../topic/ut/CMakeLists.darwin-arm64.txt | 4 +- .../topic/ut/CMakeLists.darwin-x86_64.txt | 4 +- .../topic/ut/CMakeLists.linux-aarch64.txt | 5 +- .../topic/ut/CMakeLists.linux-x86_64.txt | 5 +- .../topic/ut/CMakeLists.windows-x86_64.txt | 2 + .../draft/ut/CMakeLists.darwin-arm64.txt | 3 +- .../draft/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../draft/ut/CMakeLists.linux-aarch64.txt | 4 +- .../draft/ut/CMakeLists.linux-x86_64.txt | 4 +- .../draft/ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../iam/impl/CMakeLists.darwin-arm64.txt | 3 + .../iam/impl/CMakeLists.darwin-x86_64.txt | 3 + .../iam/impl/CMakeLists.linux-aarch64.txt | 3 + .../iam/impl/CMakeLists.linux-x86_64.txt | 3 + .../iam/impl/CMakeLists.windows-x86_64.txt | 3 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../ydb_driver/ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ydb_driver/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 + .../CMakeLists.darwin-x86_64.txt | 3 + .../CMakeLists.linux-aarch64.txt | 3 + .../CMakeLists.linux-x86_64.txt | 3 + .../CMakeLists.windows-x86_64.txt | 3 + .../impl/CMakeLists.darwin-arm64.txt | 4 + .../impl/CMakeLists.darwin-x86_64.txt | 4 + .../impl/CMakeLists.linux-aarch64.txt | 4 + .../impl/CMakeLists.linux-x86_64.txt | 4 + .../impl/CMakeLists.windows-x86_64.txt | 4 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../ydb_params/ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ydb_params/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 + .../CMakeLists.darwin-x86_64.txt | 3 + .../CMakeLists.linux-aarch64.txt | 3 + .../CMakeLists.linux-x86_64.txt | 3 + .../CMakeLists.windows-x86_64.txt | 3 + .../impl/CMakeLists.darwin-arm64.txt | 1 + .../impl/CMakeLists.darwin-x86_64.txt | 1 + .../impl/CMakeLists.linux-aarch64.txt | 1 + .../impl/CMakeLists.linux-x86_64.txt | 1 + .../impl/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/ut_utils/CMakeLists.darwin-arm64.txt | 4 + .../ut/ut_utils/CMakeLists.darwin-x86_64.txt | 4 + .../ut/ut_utils/CMakeLists.linux-aarch64.txt | 4 + .../ut/ut_utils/CMakeLists.linux-x86_64.txt | 4 + .../ut/ut_utils/CMakeLists.windows-x86_64.txt | 4 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 + .../CMakeLists.darwin-x86_64.txt | 3 + .../CMakeLists.linux-aarch64.txt | 3 + .../CMakeLists.linux-x86_64.txt | 3 + .../CMakeLists.windows-x86_64.txt | 3 + .../codecs/CMakeLists.darwin-arm64.txt | 1 + .../codecs/CMakeLists.darwin-x86_64.txt | 1 + .../codecs/CMakeLists.linux-aarch64.txt | 1 + .../codecs/CMakeLists.linux-x86_64.txt | 1 + .../codecs/CMakeLists.windows-x86_64.txt | 1 + .../ydb_query/CMakeLists.darwin-arm64.txt | 4 + .../ydb_query/CMakeLists.darwin-x86_64.txt | 4 + .../ydb_query/CMakeLists.linux-aarch64.txt | 4 + .../ydb_query/CMakeLists.linux-x86_64.txt | 4 + .../ydb_query/CMakeLists.windows-x86_64.txt | 4 + .../impl/CMakeLists.darwin-arm64.txt | 1 + .../impl/CMakeLists.darwin-x86_64.txt | 1 + .../impl/CMakeLists.linux-aarch64.txt | 1 + .../impl/CMakeLists.linux-x86_64.txt | 1 + .../impl/CMakeLists.windows-x86_64.txt | 1 + .../ydb_result/ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ydb_result/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../ydb_topic/CMakeLists.darwin-arm64.txt | 1 + .../ydb_topic/CMakeLists.darwin-x86_64.txt | 1 + .../ydb_topic/CMakeLists.linux-aarch64.txt | 1 + .../ydb_topic/CMakeLists.linux-x86_64.txt | 1 + .../ydb_topic/CMakeLists.windows-x86_64.txt | 1 + .../codecs/CMakeLists.darwin-arm64.txt | 1 + .../codecs/CMakeLists.darwin-x86_64.txt | 1 + .../codecs/CMakeLists.linux-aarch64.txt | 1 + .../codecs/CMakeLists.linux-x86_64.txt | 1 + .../codecs/CMakeLists.windows-x86_64.txt | 1 + .../impl/CMakeLists.darwin-arm64.txt | 5 + .../impl/CMakeLists.darwin-x86_64.txt | 5 + .../impl/CMakeLists.linux-aarch64.txt | 5 + .../impl/CMakeLists.linux-x86_64.txt | 5 + .../impl/CMakeLists.windows-x86_64.txt | 5 + .../ydb_topic/ut/CMakeLists.darwin-arm64.txt | 3 +- .../ydb_topic/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ydb_topic/ut/CMakeLists.linux-aarch64.txt | 4 +- .../ydb_topic/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/ut_utils/CMakeLists.darwin-arm64.txt | 2 + .../ut/ut_utils/CMakeLists.darwin-x86_64.txt | 2 + .../ut/ut_utils/CMakeLists.linux-aarch64.txt | 2 + .../ut/ut_utils/CMakeLists.linux-x86_64.txt | 2 + .../ut/ut_utils/CMakeLists.windows-x86_64.txt | 2 + .../ydb_value/ut/CMakeLists.darwin-arm64.txt | 3 +- .../ydb_value/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ydb_value/ut/CMakeLists.linux-aarch64.txt | 4 +- .../ydb_value/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../basic_example/CMakeLists.darwin-arm64.txt | 2 - .../CMakeLists.darwin-x86_64.txt | 2 - .../CMakeLists.linux-aarch64.txt | 3 - .../basic_example/CMakeLists.linux-x86_64.txt | 3 - .../CMakeLists.darwin-arm64.txt | 2 - .../CMakeLists.darwin-x86_64.txt | 2 - .../CMakeLists.linux-aarch64.txt | 3 - .../CMakeLists.linux-x86_64.txt | 3 - .../pagination/CMakeLists.darwin-arm64.txt | 2 - .../pagination/CMakeLists.darwin-x86_64.txt | 2 - .../pagination/CMakeLists.linux-aarch64.txt | 3 - .../pagination/CMakeLists.linux-x86_64.txt | 3 - .../CMakeLists.darwin-arm64.txt | 2 - .../CMakeLists.darwin-x86_64.txt | 2 - .../CMakeLists.linux-aarch64.txt | 3 - .../CMakeLists.linux-x86_64.txt | 3 - .../CMakeLists.darwin-arm64.txt | 2 - .../CMakeLists.darwin-x86_64.txt | 2 - .../CMakeLists.linux-aarch64.txt | 3 - .../CMakeLists.linux-x86_64.txt | 3 - .../eventloop/CMakeLists.darwin-arm64.txt | 2 - .../eventloop/CMakeLists.darwin-x86_64.txt | 2 - .../eventloop/CMakeLists.linux-aarch64.txt | 3 - .../eventloop/CMakeLists.linux-x86_64.txt | 3 - .../simple/CMakeLists.darwin-arm64.txt | 2 - .../simple/CMakeLists.darwin-x86_64.txt | 2 - .../simple/CMakeLists.linux-aarch64.txt | 3 - .../simple/CMakeLists.linux-x86_64.txt | 3 - .../transaction/CMakeLists.darwin-arm64.txt | 2 - .../transaction/CMakeLists.darwin-x86_64.txt | 2 - .../transaction/CMakeLists.linux-aarch64.txt | 3 - .../transaction/CMakeLists.linux-x86_64.txt | 3 - .../examples/ttl/CMakeLists.darwin-arm64.txt | 4 +- .../examples/ttl/CMakeLists.darwin-x86_64.txt | 4 +- .../examples/ttl/CMakeLists.linux-aarch64.txt | 5 +- .../examples/ttl/CMakeLists.linux-x86_64.txt | 5 +- .../ttl/CMakeLists.windows-x86_64.txt | 2 + .../protos/CMakeLists.darwin-arm64.txt | 3 + .../protos/CMakeLists.darwin-x86_64.txt | 3 + .../protos/CMakeLists.linux-aarch64.txt | 3 + .../protos/CMakeLists.linux-x86_64.txt | 3 + .../protos/CMakeLists.windows-x86_64.txt | 3 + .../bg_tasks/ut/CMakeLists.darwin-arm64.txt | 3 +- .../bg_tasks/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../bg_tasks/ut/CMakeLists.linux-aarch64.txt | 4 +- .../bg_tasks/ut/CMakeLists.linux-x86_64.txt | 4 +- .../bg_tasks/ut/CMakeLists.windows-x86_64.txt | 1 + .../cms/ut/CMakeLists.darwin-arm64.txt | 3 +- .../cms/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../cms/ut/CMakeLists.linux-aarch64.txt | 4 +- .../cms/ut/CMakeLists.linux-x86_64.txt | 4 +- .../cms/ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../api/grpc/CMakeLists.darwin-arm64.txt | 4 + .../api/grpc/CMakeLists.darwin-x86_64.txt | 4 + .../api/grpc/CMakeLists.linux-aarch64.txt | 4 + .../api/grpc/CMakeLists.linux-x86_64.txt | 4 + .../api/grpc/CMakeLists.windows-x86_64.txt | 4 + .../api/protos/CMakeLists.darwin-arm64.txt | 3 + .../api/protos/CMakeLists.darwin-x86_64.txt | 3 + .../api/protos/CMakeLists.linux-aarch64.txt | 3 + .../api/protos/CMakeLists.linux-x86_64.txt | 3 + .../api/protos/CMakeLists.windows-x86_64.txt | 3 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../ext_index/ut/CMakeLists.darwin-arm64.txt | 3 +- .../ext_index/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ext_index/ut/CMakeLists.linux-aarch64.txt | 4 +- .../ext_index/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../keyvalue/ut/CMakeLists.darwin-arm64.txt | 3 +- .../keyvalue/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../keyvalue/ut/CMakeLists.linux-aarch64.txt | 4 +- .../keyvalue/ut/CMakeLists.linux-x86_64.txt | 4 +- .../keyvalue/ut/CMakeLists.windows-x86_64.txt | 1 + .../abstract/CMakeLists.darwin-arm64.txt | 6 +- .../abstract/CMakeLists.darwin-x86_64.txt | 6 +- .../abstract/CMakeLists.linux-aarch64.txt | 6 +- .../abstract/CMakeLists.linux-x86_64.txt | 6 +- .../abstract/CMakeLists.windows-x86_64.txt | 6 +- .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../secret/ut/CMakeLists.darwin-arm64.txt | 3 +- .../secret/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../secret/ut/CMakeLists.linux-aarch64.txt | 4 +- .../secret/ut/CMakeLists.linux-x86_64.txt | 4 +- .../secret/ut/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../persqueue_v1/CMakeLists.darwin-arm64.txt | 4 + .../persqueue_v1/CMakeLists.darwin-x86_64.txt | 4 + .../persqueue_v1/CMakeLists.linux-aarch64.txt | 4 + .../persqueue_v1/CMakeLists.linux-x86_64.txt | 4 + .../CMakeLists.windows-x86_64.txt | 4 + .../actors/CMakeLists.darwin-arm64.txt | 15 + .../actors/CMakeLists.darwin-x86_64.txt | 15 + .../actors/CMakeLists.linux-aarch64.txt | 15 + .../actors/CMakeLists.linux-x86_64.txt | 15 + .../actors/CMakeLists.windows-x86_64.txt | 15 + .../ut/CMakeLists.darwin-arm64.txt | 8 +- .../ut/CMakeLists.darwin-x86_64.txt | 8 +- .../ut/CMakeLists.linux-aarch64.txt | 9 +- .../ut/CMakeLists.linux-x86_64.txt | 9 +- .../ut/CMakeLists.windows-x86_64.txt | 6 + .../describes_ut/CMakeLists.darwin-arm64.txt | 3 +- .../describes_ut/CMakeLists.darwin-x86_64.txt | 3 +- .../describes_ut/CMakeLists.linux-aarch64.txt | 4 +- .../describes_ut/CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 7 +- .../CMakeLists.darwin-x86_64.txt | 7 +- .../CMakeLists.linux-aarch64.txt | 8 +- .../CMakeLists.linux-x86_64.txt | 8 +- .../CMakeLists.windows-x86_64.txt | 5 + .../ut/CMakeLists.darwin-arm64.txt | 3 +- .../ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ut/CMakeLists.linux-aarch64.txt | 4 +- .../ut/CMakeLists.linux-x86_64.txt | 4 +- .../ut/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../ydb/ut/CMakeLists.darwin-arm64.txt | 3 +- .../ydb/ut/CMakeLists.darwin-x86_64.txt | 3 +- .../ydb/ut/CMakeLists.linux-aarch64.txt | 4 +- .../ydb/ut/CMakeLists.linux-x86_64.txt | 4 +- .../ydb/ut/CMakeLists.windows-x86_64.txt | 1 + .../kqp_indexes/CMakeLists.darwin-arm64.txt | 3 +- .../kqp_indexes/CMakeLists.darwin-x86_64.txt | 3 +- .../kqp_indexes/CMakeLists.linux-aarch64.txt | 4 +- .../kqp_indexes/CMakeLists.linux-x86_64.txt | 4 +- .../kqp_indexes/CMakeLists.windows-x86_64.txt | 1 + .../CMakeLists.darwin-arm64.txt | 3 +- .../CMakeLists.darwin-x86_64.txt | 3 +- .../CMakeLists.linux-aarch64.txt | 4 +- .../CMakeLists.linux-x86_64.txt | 4 +- .../CMakeLists.windows-x86_64.txt | 1 + .../idx_test/CMakeLists.darwin-arm64.txt | 2 - .../idx_test/CMakeLists.darwin-x86_64.txt | 2 - .../idx_test/CMakeLists.linux-aarch64.txt | 3 - .../idx_test/CMakeLists.linux-x86_64.txt | 3 - .../tools/kqprun/CMakeLists.darwin-arm64.txt | 2 - .../tools/kqprun/CMakeLists.darwin-x86_64.txt | 2 - .../tools/kqprun/CMakeLists.linux-aarch64.txt | 3 - .../tools/kqprun/CMakeLists.linux-x86_64.txt | 3 - .../tools/pq_read/CMakeLists.darwin-arm64.txt | 2 - .../pq_read/CMakeLists.darwin-x86_64.txt | 2 - .../pq_read/CMakeLists.linux-aarch64.txt | 3 - .../tools/pq_read/CMakeLists.linux-x86_64.txt | 3 - ydb/tools/CMakeLists.txt | 10 + ydb/tools/blobsan/CMakeLists.darwin-arm64.txt | 31 + .../blobsan/CMakeLists.darwin-x86_64.txt | 32 + .../blobsan/CMakeLists.linux-aarch64.txt | 34 + ydb/tools/blobsan/CMakeLists.linux-x86_64.txt | 36 + ydb/tools/blobsan/CMakeLists.txt | 19 + .../blobsan/CMakeLists.windows-x86_64.txt | 27 + .../tsserver/CMakeLists.darwin-arm64.txt | 28 + .../tsserver/CMakeLists.darwin-x86_64.txt | 29 + .../tsserver/CMakeLists.linux-aarch64.txt | 31 + .../tsserver/CMakeLists.linux-x86_64.txt | 33 + ydb/tools/tsserver/CMakeLists.txt | 19 + .../tsserver/CMakeLists.windows-x86_64.txt | 24 + yt/CMakeLists.txt | 1 - .../client/CMakeLists.linux-aarch64.txt | 3 +- .../table_schema/CMakeLists.darwin-arm64.txt | 1 + .../table_schema/CMakeLists.darwin-x86_64.txt | 1 + .../table_schema/CMakeLists.linux-aarch64.txt | 1 + .../table_schema/CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + yt/yt/build/CMakeLists.darwin-arm64.txt | 6 +- yt/yt/build/CMakeLists.darwin-x86_64.txt | 6 +- yt/yt/build/CMakeLists.linux-aarch64.txt | 6 +- yt/yt/build/CMakeLists.linux-x86_64.txt | 6 +- yt/yt/build/CMakeLists.windows-x86_64.txt | 6 +- yt/yt/client/CMakeLists.darwin-arm64.txt | 9 +- yt/yt/client/CMakeLists.darwin-x86_64.txt | 9 +- yt/yt/client/CMakeLists.linux-aarch64.txt | 9 +- yt/yt/client/CMakeLists.linux-x86_64.txt | 9 +- .../arrow/fbs/CMakeLists.linux-aarch64.txt | 12 + .../arrow/fbs/CMakeLists.linux-x86_64.txt | 12 + yt/yt/core/CMakeLists.darwin-arm64.txt | 8 +- yt/yt/core/CMakeLists.darwin-x86_64.txt | 8 +- yt/yt/core/CMakeLists.linux-aarch64.txt | 6 +- yt/yt/core/CMakeLists.linux-x86_64.txt | 6 +- yt/yt/core/CMakeLists.windows-x86_64.txt | 8 +- yt/yt/core/http/CMakeLists.darwin-arm64.txt | 5 +- yt/yt/core/http/CMakeLists.darwin-x86_64.txt | 5 +- yt/yt/core/http/CMakeLists.linux-aarch64.txt | 5 +- yt/yt/core/http/CMakeLists.linux-x86_64.txt | 5 +- yt/yt/core/http/CMakeLists.windows-x86_64.txt | 5 +- .../yt/core/rpc}/CMakeLists.linux-aarch64.txt | 2 +- .../yt/core/rpc}/CMakeLists.linux-x86_64.txt | 2 +- yt/yt/core/rpc/CMakeLists.txt | 6 +- .../rpc/grpc/CMakeLists.linux-aarch64.txt | 1 + .../core/rpc/grpc/CMakeLists.linux-x86_64.txt | 1 + yt/yt/core/rpc/grpc/CMakeLists.txt | 6 - .../CMakeLists.linux-aarch64.txt | 9 + .../CMakeLists.linux-x86_64.txt | 9 + yt/yt/core/service_discovery/CMakeLists.txt | 6 +- .../core/service_discovery/yp/CMakeLists.txt | 6 - yt/yt/library/CMakeLists.darwin-arm64.txt | 2 - yt/yt/library/CMakeLists.darwin-x86_64.txt | 2 - yt/yt/library/CMakeLists.windows-x86_64.txt | 2 - yt/yt/library/monitoring/CMakeLists.txt | 6 - .../profiling/CMakeLists.darwin-arm64.txt | 3 - .../profiling/CMakeLists.darwin-x86_64.txt | 3 - .../profiling/CMakeLists.windows-x86_64.txt | 3 - yt/yt/library/profiling/perf/CMakeLists.txt | 6 - .../solomon/CMakeLists.linux-aarch64.txt | 1 + .../solomon/CMakeLists.linux-x86_64.txt | 1 + .../library/profiling/solomon/CMakeLists.txt | 6 - .../library/profiling/tcmalloc/CMakeLists.txt | 6 - .../program/CMakeLists.linux-aarch64.txt | 1 + .../program/CMakeLists.linux-x86_64.txt | 1 + yt/yt/library/program/CMakeLists.txt | 6 - .../CMakeLists.darwin-arm64.txt | 1 + .../CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.linux-aarch64.txt | 1 + .../CMakeLists.linux-x86_64.txt | 1 + .../tracing/CMakeLists.darwin-arm64.txt | 1 - .../tracing/CMakeLists.darwin-x86_64.txt | 1 - .../tracing/CMakeLists.windows-x86_64.txt | 1 - .../jaeger/CMakeLists.linux-aarch64.txt | 1 + .../jaeger/CMakeLists.linux-x86_64.txt | 1 + yt/yt/library/tracing/jaeger/CMakeLists.txt | 6 - yt/yt/library/tvm/CMakeLists.darwin-arm64.txt | 1 - .../library/tvm/CMakeLists.darwin-x86_64.txt | 1 - .../library/tvm/CMakeLists.windows-x86_64.txt | 1 - yt/yt/library/tvm/service/CMakeLists.txt | 6 - .../ytprof/CMakeLists.darwin-arm64.txt | 32 - .../ytprof/CMakeLists.darwin-x86_64.txt | 32 - .../ytprof/CMakeLists.windows-x86_64.txt | 31 - .../ytprof/proto/CMakeLists.linux-aarch64.txt | 3 + .../ytprof/proto/CMakeLists.linux-x86_64.txt | 3 + yt/yt/library/ytprof/proto/CMakeLists.txt | 6 - .../yt/client/CMakeLists.darwin-arm64.txt | 36 + .../yt/client/CMakeLists.darwin-x86_64.txt | 36 + .../yt/client/CMakeLists.linux-aarch64.txt | 36 + .../yt/client/CMakeLists.linux-x86_64.txt | 36 + .../yt/core/CMakeLists.darwin-arm64.txt | 15 + .../yt/core/CMakeLists.darwin-x86_64.txt | 15 + .../yt/core/CMakeLists.linux-aarch64.txt | 15 + .../yt/core/CMakeLists.linux-x86_64.txt | 15 + .../yt/core/CMakeLists.windows-x86_64.txt | 15 + .../yt/formats/CMakeLists.darwin-arm64.txt | 4 + .../yt/formats/CMakeLists.darwin-x86_64.txt | 4 + .../yt/formats/CMakeLists.linux-aarch64.txt | 4 + .../yt/formats/CMakeLists.linux-x86_64.txt | 4 + .../yt/formats/CMakeLists.windows-x86_64.txt | 4 + 5850 files changed, 100873 insertions(+), 10598 deletions(-) create mode 100644 cmake/global_vars.cmake create mode 100644 contrib/libs/cxxsupp/libcxxmsvc/CMakeLists.txt create mode 100644 contrib/libs/cxxsupp/libcxxmsvc/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/libpq/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/libpqxx/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/CMakeLists.txt create mode 100644 contrib/libs/llvm14/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/include/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/include/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/include/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/include/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/include/CMakeLists.txt create mode 100644 contrib/libs/llvm14/include/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Analysis/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Analysis/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Analysis/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Analysis/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Analysis/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Analysis/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/AsmParser/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/AsmParser/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/AsmParser/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/AsmParser/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/AsmParser/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/AsmParser/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Bitcode/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.windows-x86_64.txt rename library/cpp/clickhouse/CMakeLists.darwin-arm64.txt => contrib/libs/llvm14/lib/Bitstream/CMakeLists.txt (94%) create mode 100644 contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/DebugInfo/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Demangle/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Demangle/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Demangle/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Demangle/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Demangle/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Demangle/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/Orc/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/PerfJITEvents/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/PerfJITEvents/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/PerfJITEvents/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.windows-x86_64.txt rename library/cpp/clickhouse/CMakeLists.darwin-x86_64.txt => contrib/libs/llvm14/lib/Frontend/CMakeLists.txt (94%) create mode 100644 contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/IR/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/IR/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/IR/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/IR/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/IR/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/IR/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/IRReader/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/IRReader/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/IRReader/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/IRReader/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/IRReader/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/IRReader/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Linker/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Linker/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Linker/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Linker/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Linker/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Linker/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/MC/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/MC/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/MC/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/MC/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/MC/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/MC/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Object/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Object/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Object/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Object/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Object/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Object/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/ProfileData/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/ProfileData/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/ProfileData/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/ProfileData/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/ProfileData/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/ProfileData/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Remarks/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Remarks/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Remarks/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Remarks/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Remarks/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Remarks/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Support/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Support/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Support/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Support/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Support/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Support/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/TableGen/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/TableGen/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/TableGen/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/TableGen/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/TableGen/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/TableGen/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Target/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Target/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Target/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Target/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Target/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Target/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/TextAPI/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/TextAPI/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/TextAPI/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/TextAPI/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/TextAPI/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/TextAPI/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.txt create mode 100644 contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/utils/CMakeLists.txt create mode 100644 contrib/libs/llvm14/utils/TableGen/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/utils/TableGen/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/utils/TableGen/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/utils/TableGen/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/utils/TableGen/CMakeLists.txt create mode 100644 contrib/libs/llvm14/utils/TableGen/CMakeLists.windows-x86_64.txt create mode 100644 contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.darwin-arm64.txt create mode 100644 contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.darwin-x86_64.txt create mode 100644 contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.linux-aarch64.txt create mode 100644 contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.linux-x86_64.txt create mode 100644 contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.txt create mode 100644 contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.windows-x86_64.txt create mode 100644 library/cpp/clickhouse/client/CMakeLists.windows-x86_64.txt create mode 100644 library/cpp/clickhouse/client/base/CMakeLists.windows-x86_64.txt create mode 100644 library/cpp/clickhouse/client/columns/CMakeLists.windows-x86_64.txt create mode 100644 library/cpp/clickhouse/client/types/CMakeLists.windows-x86_64.txt create mode 100644 library/cpp/yt/CMakeLists.darwin-arm64.txt create mode 100644 library/cpp/yt/CMakeLists.darwin-x86_64.txt create mode 100644 library/cpp/yt/CMakeLists.linux-aarch64.txt create mode 100644 library/cpp/yt/CMakeLists.linux-x86_64.txt create mode 100644 library/cpp/yt/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.txt create mode 100644 ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.txt create mode 100644 ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/blobstorage/vdisk/balance/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/blobstorage/vdisk/balance/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/blobstorage/vdisk/balance/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/blobstorage/vdisk/balance/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/blobstorage/vdisk/balance/CMakeLists.txt create mode 100644 ydb/core/blobstorage/vdisk/balance/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/change_exchange/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/change_exchange/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/change_exchange/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/change_exchange/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/change_exchange/CMakeLists.txt create mode 100644 ydb/core/change_exchange/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/control/common_controls/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/control/common_controls/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/control/common_controls/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/control/common_controls/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/control/common_controls/CMakeLists.txt create mode 100644 ydb/core/control/common_controls/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.txt create mode 100644 ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/graph/CMakeLists.txt create mode 100644 ydb/core/graph/api/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/graph/api/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/graph/api/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/graph/api/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/graph/api/CMakeLists.txt create mode 100644 ydb/core/graph/api/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/graph/protos/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/graph/protos/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/graph/protos/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/graph/protos/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/graph/protos/CMakeLists.txt create mode 100644 ydb/core/graph/protos/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/graph/service/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/graph/service/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/graph/service/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/graph/service/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/graph/service/CMakeLists.txt create mode 100644 ydb/core/graph/service/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/graph/shard/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/graph/shard/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/graph/shard/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/graph/shard/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/graph/shard/CMakeLists.txt create mode 100644 ydb/core/graph/shard/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/graph/shard/protos/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/graph/shard/protos/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/graph/shard/protos/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/graph/shard/protos/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/graph/shard/protos/CMakeLists.txt create mode 100644 ydb/core/graph/shard/protos/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/graph/shard/ut/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/graph/shard/ut/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/graph/shard/ut/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/graph/shard/ut/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/graph/shard/ut/CMakeLists.txt create mode 100644 ydb/core/graph/shard/ut/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/graph/ut/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/graph/ut/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/graph/ut/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/graph/ut/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/graph/ut/CMakeLists.txt create mode 100644 ydb/core/graph/ut/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/io_formats/arrow/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/io_formats/arrow/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/io_formats/arrow/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/io_formats/arrow/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/io_formats/arrow/CMakeLists.txt create mode 100644 ydb/core/io_formats/arrow/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/io_formats/arrow/ut/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/io_formats/arrow/ut/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/io_formats/arrow/ut/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/io_formats/arrow/ut/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/io_formats/arrow/ut/CMakeLists.txt create mode 100644 ydb/core/io_formats/arrow/ut/CMakeLists.windows-x86_64.txt rename ydb/core/io_formats/{ => cell_maker}/CMakeLists.darwin-arm64.txt (63%) rename ydb/core/io_formats/{ => cell_maker}/CMakeLists.darwin-x86_64.txt (63%) rename ydb/core/io_formats/{ => cell_maker}/CMakeLists.linux-aarch64.txt (64%) rename ydb/core/io_formats/{ => cell_maker}/CMakeLists.linux-x86_64.txt (64%) create mode 100644 ydb/core/io_formats/cell_maker/CMakeLists.txt rename ydb/core/io_formats/{ => cell_maker}/CMakeLists.windows-x86_64.txt (63%) create mode 100644 ydb/core/io_formats/ydb_dump/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/io_formats/ydb_dump/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/io_formats/ydb_dump/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/io_formats/ydb_dump/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/io_formats/ydb_dump/CMakeLists.txt create mode 100644 ydb/core/io_formats/ydb_dump/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/keyvalue/ut_trace/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/keyvalue/ut_trace/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/keyvalue/ut_trace/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/keyvalue/ut_trace/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/keyvalue/ut_trace/CMakeLists.txt create mode 100644 ydb/core/keyvalue/ut_trace/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/kqp/gateway/behaviour/view/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/kqp/gateway/behaviour/view/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/kqp/gateway/behaviour/view/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/kqp/gateway/behaviour/view/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/kqp/gateway/behaviour/view/CMakeLists.txt create mode 100644 ydb/core/kqp/gateway/behaviour/view/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/kqp/gateway/utils/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/kqp/gateway/utils/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/kqp/gateway/utils/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/kqp/gateway/utils/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/kqp/gateway/utils/CMakeLists.txt create mode 100644 ydb/core/kqp/gateway/utils/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/kqp/ut/federated_query/generic/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/kqp/ut/view/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/kqp/ut/view/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/kqp/ut/view/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/kqp/ut/view/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/kqp/ut/view/CMakeLists.txt create mode 100644 ydb/core/kqp/ut/view/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.txt create mode 100644 ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.txt create mode 100644 ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.txt create mode 100644 ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.txt create mode 100644 ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/tx/columnshard/transactions/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/tx/columnshard/transactions/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/tx/columnshard/transactions/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/tx/columnshard/transactions/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/tx/columnshard/transactions/CMakeLists.txt create mode 100644 ydb/core/tx/columnshard/transactions/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/tx/columnshard/transactions/operators/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/tx/columnshard/transactions/operators/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/tx/columnshard/transactions/operators/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/tx/columnshard/transactions/operators/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/tx/columnshard/transactions/operators/CMakeLists.txt create mode 100644 ydb/core/tx/columnshard/transactions/operators/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/tx/datashard/ut_trace/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/tx/datashard/ut_trace/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/tx/datashard/ut_trace/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/tx/datashard/ut_trace/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/tx/datashard/ut_trace/CMakeLists.txt create mode 100644 ydb/core/tx/datashard/ut_trace/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.txt create mode 100644 ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/tx/replication/ut_helpers/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/tx/replication/ut_helpers/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/tx/replication/ut_helpers/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/tx/replication/ut_helpers/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/tx/replication/ut_helpers/CMakeLists.txt create mode 100644 ydb/core/tx/replication/ut_helpers/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/tx/schemeshard/olap/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/tx/schemeshard/olap/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/tx/schemeshard/olap/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/tx/schemeshard/olap/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/tx/schemeshard/olap/CMakeLists.txt create mode 100644 ydb/core/tx/schemeshard/olap/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/tx/schemeshard/olap/columns/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/tx/schemeshard/olap/columns/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/tx/schemeshard/olap/columns/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/tx/schemeshard/olap/columns/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/tx/schemeshard/olap/columns/CMakeLists.txt create mode 100644 ydb/core/tx/schemeshard/olap/columns/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/tx/schemeshard/olap/common/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/tx/schemeshard/olap/common/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/tx/schemeshard/olap/common/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/tx/schemeshard/olap/common/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/tx/schemeshard/olap/common/CMakeLists.txt create mode 100644 ydb/core/tx/schemeshard/olap/common/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/tx/schemeshard/olap/indexes/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/tx/schemeshard/olap/indexes/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/tx/schemeshard/olap/indexes/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/tx/schemeshard/olap/indexes/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/tx/schemeshard/olap/indexes/CMakeLists.txt create mode 100644 ydb/core/tx/schemeshard/olap/indexes/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/tx/schemeshard/olap/operations/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/tx/schemeshard/olap/operations/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/tx/schemeshard/olap/operations/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/tx/schemeshard/olap/operations/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/tx/schemeshard/olap/operations/CMakeLists.txt create mode 100644 ydb/core/tx/schemeshard/olap/operations/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/tx/schemeshard/olap/schema/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/tx/schemeshard/olap/schema/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/tx/schemeshard/olap/schema/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/tx/schemeshard/olap/schema/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/tx/schemeshard/olap/schema/CMakeLists.txt create mode 100644 ydb/core/tx/schemeshard/olap/schema/CMakeLists.windows-x86_64.txt create mode 100644 ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.txt create mode 100644 ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/actors/testlib/common/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/actors/testlib/common/CMakeLists.darwin-x86_64.txt rename ydb/library/{yql/providers/yt => actors/testlib/common}/CMakeLists.linux-aarch64.txt (57%) rename ydb/library/{yql/providers/yt => actors/testlib/common}/CMakeLists.linux-x86_64.txt (57%) create mode 100644 ydb/library/actors/testlib/common/CMakeLists.txt rename ydb/library/{yql/providers/yt => actors/testlib/common}/CMakeLists.windows-x86_64.txt (60%) create mode 100644 ydb/library/actors/wilson/test_util/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/actors/wilson/test_util/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/actors/wilson/test_util/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/actors/wilson/test_util/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/actors/wilson/test_util/CMakeLists.txt create mode 100644 ydb/library/actors/wilson/test_util/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/actors/wilson/ut/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/actors/wilson/ut/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/actors/wilson/ut/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/actors/wilson/ut/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/actors/wilson/ut/CMakeLists.txt create mode 100644 ydb/library/actors/wilson/ut/CMakeLists.windows-x86_64.txt rename ydb/library/{yql/providers/yt => arrow_parquet}/CMakeLists.darwin-arm64.txt (57%) rename ydb/library/{yql/providers/yt => arrow_parquet}/CMakeLists.darwin-x86_64.txt (57%) create mode 100644 ydb/library/arrow_parquet/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/arrow_parquet/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/arrow_parquet/CMakeLists.txt create mode 100644 ydb/library/arrow_parquet/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/core/pg_settings/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/core/pg_settings/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/core/pg_settings/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/core/pg_settings/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/core/pg_settings/CMakeLists.txt create mode 100644 ydb/library/yql/core/pg_settings/CMakeLists.windows-x86_64.txt rename ydb/library/yql/minikql/codegen/{ => llvm}/CMakeLists.darwin-arm64.txt (51%) rename ydb/library/yql/minikql/codegen/{ => llvm}/CMakeLists.darwin-x86_64.txt (51%) rename ydb/library/yql/minikql/codegen/{ => llvm}/CMakeLists.linux-aarch64.txt (53%) rename ydb/library/yql/minikql/codegen/{ => llvm}/CMakeLists.linux-x86_64.txt (53%) create mode 100644 ydb/library/yql/minikql/codegen/llvm/CMakeLists.txt rename ydb/library/yql/minikql/codegen/{ => llvm}/CMakeLists.windows-x86_64.txt (51%) create mode 100644 ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.txt create mode 100644 ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/minikql/codegen/llvm14/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/minikql/codegen/llvm14/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/minikql/codegen/llvm14/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/minikql/codegen/llvm14/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/minikql/codegen/llvm14/CMakeLists.txt create mode 100644 ydb/library/yql/minikql/codegen/llvm14/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.txt create mode 100644 ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.txt create mode 100644 ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.windows-x86_64.txt rename ydb/{core/kqp/ut/federated_query => library/yql/minikql/comp_nodes}/CMakeLists.darwin-arm64.txt (66%) rename ydb/{core/kqp/ut/federated_query => library/yql/minikql/comp_nodes}/CMakeLists.darwin-x86_64.txt (66%) rename ydb/{core/kqp/ut/federated_query => library/yql/minikql/comp_nodes}/CMakeLists.linux-aarch64.txt (63%) rename ydb/{core/kqp/ut/federated_query => library/yql/minikql/comp_nodes}/CMakeLists.linux-x86_64.txt (63%) rename ydb/{core/kqp/ut/federated_query => library/yql/minikql/comp_nodes}/CMakeLists.windows-x86_64.txt (66%) create mode 100644 ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.txt create mode 100644 ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.txt create mode 100644 ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.txt create mode 100644 ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/minikql/computation/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/minikql/computation/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/minikql/computation/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/minikql/computation/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/minikql/computation/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.txt create mode 100644 ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/minikql/computation/llvm14/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/minikql/computation/llvm14/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/minikql/computation/llvm14/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/minikql/computation/llvm14/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/minikql/computation/llvm14/CMakeLists.txt create mode 100644 ydb/library/yql/minikql/computation/llvm14/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.txt create mode 100644 ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.txt create mode 100644 ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.txt create mode 100644 ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.txt create mode 100644 ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.windows-x86_64.txt delete mode 100644 ydb/library/yql/providers/dq/CMakeLists.darwin-arm64.txt delete mode 100644 ydb/library/yql/providers/dq/CMakeLists.darwin-x86_64.txt delete mode 100644 ydb/library/yql/providers/dq/CMakeLists.linux-aarch64.txt delete mode 100644 ydb/library/yql/providers/dq/CMakeLists.linux-x86_64.txt delete mode 100644 ydb/library/yql/providers/dq/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/providers/dq/local_gateway/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/providers/dq/stats_collector/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.txt create mode 100644 ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.txt create mode 100644 ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.txt create mode 100644 ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.txt create mode 100644 ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.txt create mode 100644 ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/public/embedded/no_llvm/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/public/embedded/no_llvm/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/public/embedded/no_llvm/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/public/embedded/no_llvm/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/public/embedded/no_llvm/CMakeLists.txt create mode 100644 ydb/library/yql/public/embedded/no_llvm/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/public/embedded/ut/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/public/embedded/ut/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/public/embedded/ut/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/public/embedded/ut/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/public/embedded/ut/CMakeLists.txt create mode 100644 ydb/library/yql/public/embedded/ut/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.txt create mode 100644 ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.txt create mode 100644 ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.txt create mode 100644 ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.txt create mode 100644 ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/public/purecalc/no_llvm/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/public/purecalc/no_llvm/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/public/purecalc/no_llvm/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/public/purecalc/no_llvm/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/public/purecalc/no_llvm/CMakeLists.txt create mode 100644 ydb/library/yql/public/purecalc/no_llvm/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/tools/mrrun/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/tools/mrrun/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/tools/mrrun/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/tools/mrrun/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/tools/mrrun/CMakeLists.txt create mode 100644 ydb/library/yql/tools/mrrun/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/utils/signals/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/utils/signals/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/utils/signals/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/utils/signals/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/utils/signals/CMakeLists.txt create mode 100644 ydb/library/yql/utils/signals/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.darwin-arm64.txt create mode 100644 ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.txt create mode 100644 ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.windows-x86_64.txt create mode 100644 ydb/library/yql/yt/CMakeLists.linux-aarch64.txt create mode 100644 ydb/library/yql/yt/CMakeLists.linux-x86_64.txt create mode 100644 ydb/library/yql/yt/CMakeLists.txt create mode 100644 ydb/public/api/client/yc_private/accessservice/CMakeLists.darwin-arm64.txt create mode 100644 ydb/public/api/client/yc_private/accessservice/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/public/api/client/yc_private/accessservice/CMakeLists.linux-aarch64.txt create mode 100644 ydb/public/api/client/yc_private/accessservice/CMakeLists.linux-x86_64.txt create mode 100644 ydb/public/api/client/yc_private/accessservice/CMakeLists.txt create mode 100644 ydb/public/api/client/yc_private/accessservice/CMakeLists.windows-x86_64.txt create mode 100644 ydb/tools/CMakeLists.txt create mode 100644 ydb/tools/blobsan/CMakeLists.darwin-arm64.txt create mode 100644 ydb/tools/blobsan/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/tools/blobsan/CMakeLists.linux-aarch64.txt create mode 100644 ydb/tools/blobsan/CMakeLists.linux-x86_64.txt create mode 100644 ydb/tools/blobsan/CMakeLists.txt create mode 100644 ydb/tools/blobsan/CMakeLists.windows-x86_64.txt create mode 100644 ydb/tools/tsserver/CMakeLists.darwin-arm64.txt create mode 100644 ydb/tools/tsserver/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/tools/tsserver/CMakeLists.linux-aarch64.txt create mode 100644 ydb/tools/tsserver/CMakeLists.linux-x86_64.txt create mode 100644 ydb/tools/tsserver/CMakeLists.txt create mode 100644 ydb/tools/tsserver/CMakeLists.windows-x86_64.txt rename {library/cpp/clickhouse => yt/yt/core/rpc}/CMakeLists.linux-aarch64.txt (94%) rename {library/cpp/clickhouse => yt/yt/core/rpc}/CMakeLists.linux-x86_64.txt (94%) create mode 100644 yt/yt/core/service_discovery/CMakeLists.linux-aarch64.txt create mode 100644 yt/yt/core/service_discovery/CMakeLists.linux-x86_64.txt diff --git a/CMakeLists.darwin-arm64.txt b/CMakeLists.darwin-arm64.txt index 075d57df5021..8da2d76ec957 100644 --- a/CMakeLists.darwin-arm64.txt +++ b/CMakeLists.darwin-arm64.txt @@ -10,6 +10,6 @@ add_subdirectory(tools) add_subdirectory(contrib) add_subdirectory(library) add_subdirectory(util) -add_subdirectory(yt) -add_subdirectory(certs) add_subdirectory(ydb) +add_subdirectory(certs) +add_subdirectory(yt) diff --git a/CMakeLists.darwin-x86_64.txt b/CMakeLists.darwin-x86_64.txt index 075d57df5021..8da2d76ec957 100644 --- a/CMakeLists.darwin-x86_64.txt +++ b/CMakeLists.darwin-x86_64.txt @@ -10,6 +10,6 @@ add_subdirectory(tools) add_subdirectory(contrib) add_subdirectory(library) add_subdirectory(util) -add_subdirectory(yt) -add_subdirectory(certs) add_subdirectory(ydb) +add_subdirectory(certs) +add_subdirectory(yt) diff --git a/CMakeLists.linux-aarch64.txt b/CMakeLists.linux-aarch64.txt index 075d57df5021..8da2d76ec957 100644 --- a/CMakeLists.linux-aarch64.txt +++ b/CMakeLists.linux-aarch64.txt @@ -10,6 +10,6 @@ add_subdirectory(tools) add_subdirectory(contrib) add_subdirectory(library) add_subdirectory(util) -add_subdirectory(yt) -add_subdirectory(certs) add_subdirectory(ydb) +add_subdirectory(certs) +add_subdirectory(yt) diff --git a/CMakeLists.linux-x86_64.txt b/CMakeLists.linux-x86_64.txt index 075d57df5021..8da2d76ec957 100644 --- a/CMakeLists.linux-x86_64.txt +++ b/CMakeLists.linux-x86_64.txt @@ -10,6 +10,6 @@ add_subdirectory(tools) add_subdirectory(contrib) add_subdirectory(library) add_subdirectory(util) -add_subdirectory(yt) -add_subdirectory(certs) add_subdirectory(ydb) +add_subdirectory(certs) +add_subdirectory(yt) diff --git a/CMakeLists.txt b/CMakeLists.txt index 7ee2ab2b04e7..7f582399aa69 100644 --- a/CMakeLists.txt +++ b/CMakeLists.txt @@ -25,18 +25,17 @@ enable_testing() # Can't set it in cuda.cmake because of CMake policy subdirectory stack rules cmake_policy(SET CMP0104 OLD) +include(cmake/global_flags.cmake) +include(cmake/global_vars.cmake) include(cmake/antlr.cmake) include(cmake/archive.cmake) include(cmake/bison.cmake) include(cmake/common.cmake) include(cmake/conan.cmake) include(cmake/fbs.cmake) -include(cmake/global_flags.cmake) -include(cmake/llvm-tools.cmake) include(cmake/masm.cmake) include(cmake/protobuf.cmake) include(cmake/shared_libs.cmake) -include(cmake/global_vars.cmake) if (CMAKE_CROSSCOMPILING) include(${CMAKE_BINARY_DIR}/conan_paths.cmake) diff --git a/CMakeLists.windows-x86_64.txt b/CMakeLists.windows-x86_64.txt index e8667d4e27c2..02abf1fdaa25 100644 --- a/CMakeLists.windows-x86_64.txt +++ b/CMakeLists.windows-x86_64.txt @@ -10,6 +10,6 @@ add_subdirectory(tools) add_subdirectory(contrib) add_subdirectory(util) add_subdirectory(library) -add_subdirectory(yt) -add_subdirectory(certs) add_subdirectory(ydb) +add_subdirectory(certs) +add_subdirectory(yt) diff --git a/cmake/global_vars.cmake b/cmake/global_vars.cmake new file mode 100644 index 000000000000..ebe4053b03c4 --- /dev/null +++ b/cmake/global_vars.cmake @@ -0,0 +1,41 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if(CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + set(YASM_FLAGS -f elf64 -D UNIX -D _x86_64_ -D_YASM_ -g dwarf2) + set(BISON_FLAGS -v) + set(FBS_CPP_FLAGS --no-warnings --cpp --keep-prefix --gen-mutable --schema -b --yandex-maps-iter --gen-object-api --filename-suffix .fbs) + set(RAGEL_FLAGS -L -I ${CMAKE_SOURCE_DIR}/) +endif() + +if(CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + set(BISON_FLAGS -v) + set(FBS_CPP_FLAGS --no-warnings --cpp --keep-prefix --gen-mutable --schema -b --yandex-maps-iter --gen-object-api --filename-suffix .fbs) + set(RAGEL_FLAGS -L -I ${CMAKE_SOURCE_DIR}/) +endif() + +if(CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + set(YASM_FLAGS -f macho64 -D DARWIN -D UNIX -D _x86_64_ -D_YASM_) + set(BISON_FLAGS -v) + set(FBS_CPP_FLAGS --no-warnings --cpp --keep-prefix --gen-mutable --schema -b --yandex-maps-iter --gen-object-api --filename-suffix .fbs) + set(RAGEL_FLAGS -L -I ${CMAKE_SOURCE_DIR}/) +endif() + +if(CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + set(BISON_FLAGS -v) + set(FBS_CPP_FLAGS --no-warnings --cpp --keep-prefix --gen-mutable --schema -b --yandex-maps-iter --gen-object-api --filename-suffix .fbs) + set(RAGEL_FLAGS -L -I ${CMAKE_SOURCE_DIR}/) +endif() + +if(WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + set(YASM_FLAGS -f win64 -D WIN64 -D _x86_64_ -D_YASM_) + set(BISON_FLAGS -v) + set(FBS_CPP_FLAGS --no-warnings --cpp --keep-prefix --gen-mutable --schema -b --yandex-maps-iter --gen-object-api --filename-suffix .fbs) + set(RAGEL_FLAGS -L -I ${CMAKE_SOURCE_DIR}/) +endif() + diff --git a/contrib/libs/CMakeLists.darwin-arm64.txt b/contrib/libs/CMakeLists.darwin-arm64.txt index 0f0d8f137b69..52a2dfaa4469 100644 --- a/contrib/libs/CMakeLists.darwin-arm64.txt +++ b/contrib/libs/CMakeLists.darwin-arm64.txt @@ -40,6 +40,7 @@ add_subdirectory(libunwind) add_subdirectory(libxml) add_subdirectory(linuxvdso) add_subdirectory(llvm12) +add_subdirectory(llvm14) add_subdirectory(lua) add_subdirectory(lz4) add_subdirectory(lzma) diff --git a/contrib/libs/CMakeLists.darwin-x86_64.txt b/contrib/libs/CMakeLists.darwin-x86_64.txt index f33f1273a2bb..9fb9b3981255 100644 --- a/contrib/libs/CMakeLists.darwin-x86_64.txt +++ b/contrib/libs/CMakeLists.darwin-x86_64.txt @@ -41,6 +41,7 @@ add_subdirectory(libunwind) add_subdirectory(libxml) add_subdirectory(linuxvdso) add_subdirectory(llvm12) +add_subdirectory(llvm14) add_subdirectory(lua) add_subdirectory(lz4) add_subdirectory(lzma) diff --git a/contrib/libs/CMakeLists.linux-aarch64.txt b/contrib/libs/CMakeLists.linux-aarch64.txt index 83f4328c25c3..918ac70643f7 100644 --- a/contrib/libs/CMakeLists.linux-aarch64.txt +++ b/contrib/libs/CMakeLists.linux-aarch64.txt @@ -43,6 +43,7 @@ add_subdirectory(libxml) add_subdirectory(linux-headers) add_subdirectory(linuxvdso) add_subdirectory(llvm12) +add_subdirectory(llvm14) add_subdirectory(lua) add_subdirectory(lz4) add_subdirectory(lzma) diff --git a/contrib/libs/CMakeLists.linux-x86_64.txt b/contrib/libs/CMakeLists.linux-x86_64.txt index ee516bf225dd..a842f7bfed35 100644 --- a/contrib/libs/CMakeLists.linux-x86_64.txt +++ b/contrib/libs/CMakeLists.linux-x86_64.txt @@ -44,6 +44,7 @@ add_subdirectory(libxml) add_subdirectory(linux-headers) add_subdirectory(linuxvdso) add_subdirectory(llvm12) +add_subdirectory(llvm14) add_subdirectory(lua) add_subdirectory(lz4) add_subdirectory(lzma) diff --git a/contrib/libs/CMakeLists.windows-x86_64.txt b/contrib/libs/CMakeLists.windows-x86_64.txt index 7bacb8e92b8f..aa6b9c7f5c4e 100644 --- a/contrib/libs/CMakeLists.windows-x86_64.txt +++ b/contrib/libs/CMakeLists.windows-x86_64.txt @@ -33,10 +33,12 @@ add_subdirectory(libbz2) add_subdirectory(libc_compat) add_subdirectory(libevent) add_subdirectory(libfyaml) -add_subdirectory(libunwind) +add_subdirectory(libpq) +add_subdirectory(libpqxx) add_subdirectory(libxml) add_subdirectory(linuxvdso) add_subdirectory(llvm12) +add_subdirectory(llvm14) add_subdirectory(lua) add_subdirectory(lz4) add_subdirectory(lzma) diff --git a/contrib/libs/apache/arrow/CMakeLists.darwin-arm64.txt b/contrib/libs/apache/arrow/CMakeLists.darwin-arm64.txt index b9e70350e76b..641d42bcb9b0 100644 --- a/contrib/libs/apache/arrow/CMakeLists.darwin-arm64.txt +++ b/contrib/libs/apache/arrow/CMakeLists.darwin-arm64.txt @@ -99,6 +99,24 @@ target_link_libraries(libs-apache-arrow PUBLIC contrib-libs-flatbuffers ) target_sources(libs-apache-arrow PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/File.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/File.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Message.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Message.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Schema.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Schema.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/SparseTensor.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/SparseTensor.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Tensor.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Tensor.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/feather.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/feather.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/File.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Message.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Schema.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/SparseTensor.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Tensor.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/feather.bfbs ${CMAKE_SOURCE_DIR}/contrib/libs/apache/arrow/cpp/src/arrow/adapters/orc/adapter.cc ${CMAKE_SOURCE_DIR}/contrib/libs/apache/arrow/cpp/src/arrow/adapters/orc/adapter_util.cc ${CMAKE_SOURCE_DIR}/contrib/libs/apache/arrow/cpp/src/arrow/array/array_base.cc diff --git a/contrib/libs/apache/arrow/CMakeLists.darwin-x86_64.txt b/contrib/libs/apache/arrow/CMakeLists.darwin-x86_64.txt index b9e70350e76b..641d42bcb9b0 100644 --- a/contrib/libs/apache/arrow/CMakeLists.darwin-x86_64.txt +++ b/contrib/libs/apache/arrow/CMakeLists.darwin-x86_64.txt @@ -99,6 +99,24 @@ target_link_libraries(libs-apache-arrow PUBLIC contrib-libs-flatbuffers ) target_sources(libs-apache-arrow PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/File.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/File.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Message.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Message.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Schema.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Schema.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/SparseTensor.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/SparseTensor.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Tensor.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Tensor.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/feather.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/feather.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/File.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Message.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Schema.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/SparseTensor.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Tensor.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/feather.bfbs ${CMAKE_SOURCE_DIR}/contrib/libs/apache/arrow/cpp/src/arrow/adapters/orc/adapter.cc ${CMAKE_SOURCE_DIR}/contrib/libs/apache/arrow/cpp/src/arrow/adapters/orc/adapter_util.cc ${CMAKE_SOURCE_DIR}/contrib/libs/apache/arrow/cpp/src/arrow/array/array_base.cc diff --git a/contrib/libs/apache/arrow/CMakeLists.linux-aarch64.txt b/contrib/libs/apache/arrow/CMakeLists.linux-aarch64.txt index fb698641cb4c..a571d3c0de1c 100644 --- a/contrib/libs/apache/arrow/CMakeLists.linux-aarch64.txt +++ b/contrib/libs/apache/arrow/CMakeLists.linux-aarch64.txt @@ -100,6 +100,24 @@ target_link_libraries(libs-apache-arrow PUBLIC contrib-libs-flatbuffers ) target_sources(libs-apache-arrow PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/File.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/File.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Message.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Message.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Schema.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Schema.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/SparseTensor.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/SparseTensor.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Tensor.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Tensor.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/feather.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/feather.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/File.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Message.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Schema.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/SparseTensor.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Tensor.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/feather.bfbs ${CMAKE_SOURCE_DIR}/contrib/libs/apache/arrow/cpp/src/arrow/adapters/orc/adapter.cc ${CMAKE_SOURCE_DIR}/contrib/libs/apache/arrow/cpp/src/arrow/adapters/orc/adapter_util.cc ${CMAKE_SOURCE_DIR}/contrib/libs/apache/arrow/cpp/src/arrow/array/array_base.cc diff --git a/contrib/libs/apache/arrow/CMakeLists.linux-x86_64.txt b/contrib/libs/apache/arrow/CMakeLists.linux-x86_64.txt index fb698641cb4c..a571d3c0de1c 100644 --- a/contrib/libs/apache/arrow/CMakeLists.linux-x86_64.txt +++ b/contrib/libs/apache/arrow/CMakeLists.linux-x86_64.txt @@ -100,6 +100,24 @@ target_link_libraries(libs-apache-arrow PUBLIC contrib-libs-flatbuffers ) target_sources(libs-apache-arrow PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/File.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/File.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Message.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Message.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Schema.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Schema.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/SparseTensor.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/SparseTensor.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Tensor.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Tensor.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/feather.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/feather.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/File.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Message.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Schema.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/SparseTensor.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Tensor.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/feather.bfbs ${CMAKE_SOURCE_DIR}/contrib/libs/apache/arrow/cpp/src/arrow/adapters/orc/adapter.cc ${CMAKE_SOURCE_DIR}/contrib/libs/apache/arrow/cpp/src/arrow/adapters/orc/adapter_util.cc ${CMAKE_SOURCE_DIR}/contrib/libs/apache/arrow/cpp/src/arrow/array/array_base.cc diff --git a/contrib/libs/apache/arrow/CMakeLists.windows-x86_64.txt b/contrib/libs/apache/arrow/CMakeLists.windows-x86_64.txt index 5a5a245f2f1b..a8a9998410b4 100644 --- a/contrib/libs/apache/arrow/CMakeLists.windows-x86_64.txt +++ b/contrib/libs/apache/arrow/CMakeLists.windows-x86_64.txt @@ -98,6 +98,24 @@ target_link_libraries(libs-apache-arrow PUBLIC contrib-libs-flatbuffers ) target_sources(libs-apache-arrow PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/File.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/File.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Message.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Message.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Schema.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Schema.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/SparseTensor.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/SparseTensor.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Tensor.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Tensor.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/feather.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/feather.iter.fbs.h + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/File.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Message.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Schema.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/SparseTensor.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/Tensor.bfbs + ${CMAKE_BINARY_DIR}/contrib/libs/apache/arrow/cpp/src/generated/feather.bfbs ${CMAKE_SOURCE_DIR}/contrib/libs/apache/arrow/cpp/src/arrow/adapters/orc/adapter.cc ${CMAKE_SOURCE_DIR}/contrib/libs/apache/arrow/cpp/src/arrow/adapters/orc/adapter_util.cc ${CMAKE_SOURCE_DIR}/contrib/libs/apache/arrow/cpp/src/arrow/array/array_base.cc diff --git a/contrib/libs/apache/orc/CMakeLists.darwin-arm64.txt b/contrib/libs/apache/orc/CMakeLists.darwin-arm64.txt index af2fe0863ce9..1b80303735d5 100644 --- a/contrib/libs/apache/orc/CMakeLists.darwin-arm64.txt +++ b/contrib/libs/apache/orc/CMakeLists.darwin-arm64.txt @@ -44,6 +44,7 @@ target_proto_messages(libs-apache-orc PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/apache/orc/proto/orc_proto.proto ) target_sources(libs-apache-orc PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/apache/orc/proto/orc_proto.pb.h ${CMAKE_SOURCE_DIR}/contrib/libs/apache/orc/c++/src/Adaptor.cc ${CMAKE_SOURCE_DIR}/contrib/libs/apache/orc/c++/src/BloomFilter.cc ${CMAKE_SOURCE_DIR}/contrib/libs/apache/orc/c++/src/ByteRLE.cc diff --git a/contrib/libs/apache/orc/CMakeLists.darwin-x86_64.txt b/contrib/libs/apache/orc/CMakeLists.darwin-x86_64.txt index af2fe0863ce9..1b80303735d5 100644 --- a/contrib/libs/apache/orc/CMakeLists.darwin-x86_64.txt +++ b/contrib/libs/apache/orc/CMakeLists.darwin-x86_64.txt @@ -44,6 +44,7 @@ target_proto_messages(libs-apache-orc PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/apache/orc/proto/orc_proto.proto ) target_sources(libs-apache-orc PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/apache/orc/proto/orc_proto.pb.h ${CMAKE_SOURCE_DIR}/contrib/libs/apache/orc/c++/src/Adaptor.cc ${CMAKE_SOURCE_DIR}/contrib/libs/apache/orc/c++/src/BloomFilter.cc ${CMAKE_SOURCE_DIR}/contrib/libs/apache/orc/c++/src/ByteRLE.cc diff --git a/contrib/libs/apache/orc/CMakeLists.linux-aarch64.txt b/contrib/libs/apache/orc/CMakeLists.linux-aarch64.txt index 0ae0e1d25007..41303e280b59 100644 --- a/contrib/libs/apache/orc/CMakeLists.linux-aarch64.txt +++ b/contrib/libs/apache/orc/CMakeLists.linux-aarch64.txt @@ -45,6 +45,7 @@ target_proto_messages(libs-apache-orc PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/apache/orc/proto/orc_proto.proto ) target_sources(libs-apache-orc PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/apache/orc/proto/orc_proto.pb.h ${CMAKE_SOURCE_DIR}/contrib/libs/apache/orc/c++/src/Adaptor.cc ${CMAKE_SOURCE_DIR}/contrib/libs/apache/orc/c++/src/BloomFilter.cc ${CMAKE_SOURCE_DIR}/contrib/libs/apache/orc/c++/src/ByteRLE.cc diff --git a/contrib/libs/apache/orc/CMakeLists.linux-x86_64.txt b/contrib/libs/apache/orc/CMakeLists.linux-x86_64.txt index 0ae0e1d25007..41303e280b59 100644 --- a/contrib/libs/apache/orc/CMakeLists.linux-x86_64.txt +++ b/contrib/libs/apache/orc/CMakeLists.linux-x86_64.txt @@ -45,6 +45,7 @@ target_proto_messages(libs-apache-orc PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/apache/orc/proto/orc_proto.proto ) target_sources(libs-apache-orc PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/apache/orc/proto/orc_proto.pb.h ${CMAKE_SOURCE_DIR}/contrib/libs/apache/orc/c++/src/Adaptor.cc ${CMAKE_SOURCE_DIR}/contrib/libs/apache/orc/c++/src/BloomFilter.cc ${CMAKE_SOURCE_DIR}/contrib/libs/apache/orc/c++/src/ByteRLE.cc diff --git a/contrib/libs/apache/orc/CMakeLists.windows-x86_64.txt b/contrib/libs/apache/orc/CMakeLists.windows-x86_64.txt index af2fe0863ce9..1b80303735d5 100644 --- a/contrib/libs/apache/orc/CMakeLists.windows-x86_64.txt +++ b/contrib/libs/apache/orc/CMakeLists.windows-x86_64.txt @@ -44,6 +44,7 @@ target_proto_messages(libs-apache-orc PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/apache/orc/proto/orc_proto.proto ) target_sources(libs-apache-orc PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/apache/orc/proto/orc_proto.pb.h ${CMAKE_SOURCE_DIR}/contrib/libs/apache/orc/c++/src/Adaptor.cc ${CMAKE_SOURCE_DIR}/contrib/libs/apache/orc/c++/src/BloomFilter.cc ${CMAKE_SOURCE_DIR}/contrib/libs/apache/orc/c++/src/ByteRLE.cc diff --git a/contrib/libs/base64/avx2/CMakeLists.windows-x86_64.txt b/contrib/libs/base64/avx2/CMakeLists.windows-x86_64.txt index b199f09cda5c..28788912b47e 100644 --- a/contrib/libs/base64/avx2/CMakeLists.windows-x86_64.txt +++ b/contrib/libs/base64/avx2/CMakeLists.windows-x86_64.txt @@ -21,7 +21,7 @@ set_property( APPEND PROPERTY COMPILE_OPTIONS - -mavx2 + /D__AVX2__=1 ) set_property( SOURCE @@ -29,5 +29,5 @@ set_property( APPEND PROPERTY COMPILE_OPTIONS - -mavx2 + /D__AVX2__=1 ) diff --git a/contrib/libs/base64/ssse3/CMakeLists.windows-x86_64.txt b/contrib/libs/base64/ssse3/CMakeLists.windows-x86_64.txt index 5b488a3ae2c7..8080dd9d7313 100644 --- a/contrib/libs/base64/ssse3/CMakeLists.windows-x86_64.txt +++ b/contrib/libs/base64/ssse3/CMakeLists.windows-x86_64.txt @@ -21,7 +21,7 @@ set_property( APPEND PROPERTY COMPILE_OPTIONS - -mssse3 + /D__SSSE3__=1 ) set_property( SOURCE @@ -29,5 +29,5 @@ set_property( APPEND PROPERTY COMPILE_OPTIONS - -mssse3 + /D__SSSE3__=1 ) diff --git a/contrib/libs/curl/CMakeLists.darwin-arm64.txt b/contrib/libs/curl/CMakeLists.darwin-arm64.txt index 6dcd71469bd6..b4c4d8e40ee8 100644 --- a/contrib/libs/curl/CMakeLists.darwin-arm64.txt +++ b/contrib/libs/curl/CMakeLists.darwin-arm64.txt @@ -61,7 +61,6 @@ target_sources(contrib-libs-curl PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_get_line.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_gethostname.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_gssapi.c - ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_log.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_memrchr.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_multibyte.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_ntlm_core.c @@ -72,6 +71,7 @@ target_sources(contrib-libs-curl PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_sasl.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_sspi.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_threads.c + ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_trc.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/dict.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/doh.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/dynbuf.c diff --git a/contrib/libs/curl/CMakeLists.darwin-x86_64.txt b/contrib/libs/curl/CMakeLists.darwin-x86_64.txt index 6dcd71469bd6..b4c4d8e40ee8 100644 --- a/contrib/libs/curl/CMakeLists.darwin-x86_64.txt +++ b/contrib/libs/curl/CMakeLists.darwin-x86_64.txt @@ -61,7 +61,6 @@ target_sources(contrib-libs-curl PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_get_line.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_gethostname.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_gssapi.c - ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_log.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_memrchr.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_multibyte.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_ntlm_core.c @@ -72,6 +71,7 @@ target_sources(contrib-libs-curl PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_sasl.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_sspi.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_threads.c + ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_trc.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/dict.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/doh.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/dynbuf.c diff --git a/contrib/libs/curl/CMakeLists.linux-aarch64.txt b/contrib/libs/curl/CMakeLists.linux-aarch64.txt index 8b2de2eb4176..620feaf01073 100644 --- a/contrib/libs/curl/CMakeLists.linux-aarch64.txt +++ b/contrib/libs/curl/CMakeLists.linux-aarch64.txt @@ -58,7 +58,6 @@ target_sources(contrib-libs-curl PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_get_line.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_gethostname.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_gssapi.c - ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_log.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_memrchr.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_multibyte.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_ntlm_core.c @@ -69,6 +68,7 @@ target_sources(contrib-libs-curl PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_sasl.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_sspi.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_threads.c + ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_trc.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/dict.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/doh.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/dynbuf.c diff --git a/contrib/libs/curl/CMakeLists.linux-x86_64.txt b/contrib/libs/curl/CMakeLists.linux-x86_64.txt index 8b2de2eb4176..620feaf01073 100644 --- a/contrib/libs/curl/CMakeLists.linux-x86_64.txt +++ b/contrib/libs/curl/CMakeLists.linux-x86_64.txt @@ -58,7 +58,6 @@ target_sources(contrib-libs-curl PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_get_line.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_gethostname.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_gssapi.c - ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_log.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_memrchr.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_multibyte.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_ntlm_core.c @@ -69,6 +68,7 @@ target_sources(contrib-libs-curl PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_sasl.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_sspi.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_threads.c + ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_trc.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/dict.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/doh.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/dynbuf.c diff --git a/contrib/libs/curl/CMakeLists.windows-x86_64.txt b/contrib/libs/curl/CMakeLists.windows-x86_64.txt index 4d72bbd0b504..2672052d1a57 100644 --- a/contrib/libs/curl/CMakeLists.windows-x86_64.txt +++ b/contrib/libs/curl/CMakeLists.windows-x86_64.txt @@ -56,7 +56,6 @@ target_sources(contrib-libs-curl PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_get_line.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_gethostname.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_gssapi.c - ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_log.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_memrchr.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_multibyte.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_ntlm_core.c @@ -67,6 +66,7 @@ target_sources(contrib-libs-curl PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_sasl.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_sspi.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_threads.c + ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/curl_trc.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/dict.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/doh.c ${CMAKE_SOURCE_DIR}/contrib/libs/curl/lib/dynbuf.c diff --git a/contrib/libs/cxxsupp/CMakeLists.windows-x86_64.txt b/contrib/libs/cxxsupp/CMakeLists.windows-x86_64.txt index d5862909e416..f1baa27a2abf 100644 --- a/contrib/libs/cxxsupp/CMakeLists.windows-x86_64.txt +++ b/contrib/libs/cxxsupp/CMakeLists.windows-x86_64.txt @@ -6,10 +6,9 @@ # original buildsystem will not be accepted. -add_subdirectory(builtins) -add_subdirectory(libcxx) +add_subdirectory(libcxxmsvc) add_library(contrib-libs-cxxsupp INTERFACE) target_link_libraries(contrib-libs-cxxsupp INTERFACE - libs-cxxsupp-libcxx + libs-cxxsupp-libcxxmsvc ) diff --git a/contrib/libs/cxxsupp/builtins/CMakeLists.txt b/contrib/libs/cxxsupp/builtins/CMakeLists.txt index d863ebd18067..380079ac7b4a 100644 --- a/contrib/libs/cxxsupp/builtins/CMakeLists.txt +++ b/contrib/libs/cxxsupp/builtins/CMakeLists.txt @@ -14,6 +14,4 @@ elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL include(CMakeLists.darwin-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) endif() diff --git a/contrib/libs/cxxsupp/libcxx/CMakeLists.darwin-arm64.txt b/contrib/libs/cxxsupp/libcxx/CMakeLists.darwin-arm64.txt index 109da232d23a..921dddae5a60 100644 --- a/contrib/libs/cxxsupp/libcxx/CMakeLists.darwin-arm64.txt +++ b/contrib/libs/cxxsupp/libcxx/CMakeLists.darwin-arm64.txt @@ -31,7 +31,6 @@ target_link_libraries(libs-cxxsupp-libcxx PUBLIC target_sources(libs-cxxsupp-libcxx PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/algorithm.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/any.cpp - ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/assert.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/atomic.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/barrier.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/bind.cpp @@ -52,6 +51,7 @@ target_sources(libs-cxxsupp-libcxx PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/legacy_pointer_safety.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/locale.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/memory.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/memory_resource.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/mutex.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/mutex_destructor.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/optional.cpp @@ -72,6 +72,7 @@ target_sources(libs-cxxsupp-libcxx PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/valarray.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/variant.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/vector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/verbose_abort.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/format.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/new.cpp ) diff --git a/contrib/libs/cxxsupp/libcxx/CMakeLists.darwin-x86_64.txt b/contrib/libs/cxxsupp/libcxx/CMakeLists.darwin-x86_64.txt index 109da232d23a..921dddae5a60 100644 --- a/contrib/libs/cxxsupp/libcxx/CMakeLists.darwin-x86_64.txt +++ b/contrib/libs/cxxsupp/libcxx/CMakeLists.darwin-x86_64.txt @@ -31,7 +31,6 @@ target_link_libraries(libs-cxxsupp-libcxx PUBLIC target_sources(libs-cxxsupp-libcxx PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/algorithm.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/any.cpp - ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/assert.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/atomic.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/barrier.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/bind.cpp @@ -52,6 +51,7 @@ target_sources(libs-cxxsupp-libcxx PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/legacy_pointer_safety.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/locale.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/memory.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/memory_resource.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/mutex.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/mutex_destructor.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/optional.cpp @@ -72,6 +72,7 @@ target_sources(libs-cxxsupp-libcxx PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/valarray.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/variant.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/vector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/verbose_abort.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/format.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/new.cpp ) diff --git a/contrib/libs/cxxsupp/libcxx/CMakeLists.linux-aarch64.txt b/contrib/libs/cxxsupp/libcxx/CMakeLists.linux-aarch64.txt index 4c91bf7fa8c6..9842df1ef1f4 100644 --- a/contrib/libs/cxxsupp/libcxx/CMakeLists.linux-aarch64.txt +++ b/contrib/libs/cxxsupp/libcxx/CMakeLists.linux-aarch64.txt @@ -32,7 +32,6 @@ target_link_libraries(libs-cxxsupp-libcxx PUBLIC target_sources(libs-cxxsupp-libcxx PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/algorithm.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/any.cpp - ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/assert.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/atomic.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/barrier.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/bind.cpp @@ -53,6 +52,7 @@ target_sources(libs-cxxsupp-libcxx PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/legacy_pointer_safety.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/locale.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/memory.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/memory_resource.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/mutex.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/mutex_destructor.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/optional.cpp @@ -73,6 +73,7 @@ target_sources(libs-cxxsupp-libcxx PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/valarray.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/variant.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/vector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/verbose_abort.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/format.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/new.cpp ) diff --git a/contrib/libs/cxxsupp/libcxx/CMakeLists.linux-x86_64.txt b/contrib/libs/cxxsupp/libcxx/CMakeLists.linux-x86_64.txt index 4c91bf7fa8c6..9842df1ef1f4 100644 --- a/contrib/libs/cxxsupp/libcxx/CMakeLists.linux-x86_64.txt +++ b/contrib/libs/cxxsupp/libcxx/CMakeLists.linux-x86_64.txt @@ -32,7 +32,6 @@ target_link_libraries(libs-cxxsupp-libcxx PUBLIC target_sources(libs-cxxsupp-libcxx PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/algorithm.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/any.cpp - ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/assert.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/atomic.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/barrier.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/bind.cpp @@ -53,6 +52,7 @@ target_sources(libs-cxxsupp-libcxx PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/legacy_pointer_safety.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/locale.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/memory.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/memory_resource.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/mutex.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/mutex_destructor.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/optional.cpp @@ -73,6 +73,7 @@ target_sources(libs-cxxsupp-libcxx PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/valarray.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/variant.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/vector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/verbose_abort.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/format.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxx/src/new.cpp ) diff --git a/contrib/libs/cxxsupp/libcxx/CMakeLists.txt b/contrib/libs/cxxsupp/libcxx/CMakeLists.txt index d863ebd18067..380079ac7b4a 100644 --- a/contrib/libs/cxxsupp/libcxx/CMakeLists.txt +++ b/contrib/libs/cxxsupp/libcxx/CMakeLists.txt @@ -14,6 +14,4 @@ elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL include(CMakeLists.darwin-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) endif() diff --git a/contrib/libs/cxxsupp/libcxxmsvc/CMakeLists.txt b/contrib/libs/cxxsupp/libcxxmsvc/CMakeLists.txt new file mode 100644 index 000000000000..03d4a7153cff --- /dev/null +++ b/contrib/libs/cxxsupp/libcxxmsvc/CMakeLists.txt @@ -0,0 +1,11 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/cxxsupp/libcxxmsvc/CMakeLists.windows-x86_64.txt b/contrib/libs/cxxsupp/libcxxmsvc/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..33422e3d6e9f --- /dev/null +++ b/contrib/libs/cxxsupp/libcxxmsvc/CMakeLists.windows-x86_64.txt @@ -0,0 +1,75 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(libs-cxxsupp-libcxxmsvc) +target_compile_options(libs-cxxsupp-libcxxmsvc PUBLIC + -D_LIBCPP_VASPRINTF_DEFINED + -D_WCHAR_H_CPLUSPLUS_98_CONFORMANCE_ +) +target_compile_options(libs-cxxsupp-libcxxmsvc PRIVATE + -D_LIBCPP_BUILDING_LIBRARY + $,,-Wno-everything> +) +target_include_directories(libs-cxxsupp-libcxxmsvc PUBLIC + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/include +) +target_include_directories(libs-cxxsupp-libcxxmsvc PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src +) +target_sources(libs-cxxsupp-libcxxmsvc PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/support/win32/locale_win32.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/support/win32/support.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/support/win32/atomic_win32.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/support/win32/new_win32.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/support/win32/thread_win32.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/algorithm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/any.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/assert.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/atomic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/barrier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/bind.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/charconv.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/chrono.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/condition_variable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/condition_variable_destructor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/debug.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/exception.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/filesystem/directory_iterator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/filesystem/operations.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/functional.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/future.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/hash.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/ios.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/ios.instantiations.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/iostream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/legacy_pointer_safety.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/locale.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/memory.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/mutex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/mutex_destructor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/optional.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/random.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/random_shuffle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/regex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/ryu/d2fixed.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/ryu/d2s.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/ryu/f2s.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/shared_mutex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/stdexcept.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/string.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/strstream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/system_error.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/thread.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/typeinfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/utility.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/valarray.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/variant.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/vector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/cxxsupp/libcxxmsvc/src/format.cpp +) diff --git a/contrib/libs/farmhash/arch/sse41/CMakeLists.windows-x86_64.txt b/contrib/libs/farmhash/arch/sse41/CMakeLists.windows-x86_64.txt index 921c50874eac..58aa3609ec96 100644 --- a/contrib/libs/farmhash/arch/sse41/CMakeLists.windows-x86_64.txt +++ b/contrib/libs/farmhash/arch/sse41/CMakeLists.windows-x86_64.txt @@ -9,7 +9,6 @@ add_library(farmhash-arch-sse41) target_compile_options(farmhash-arch-sse41 PRIVATE - -msse4.1 $,,-Wno-everything> ) target_link_libraries(farmhash-arch-sse41 PUBLIC diff --git a/contrib/libs/farmhash/arch/sse42/CMakeLists.windows-x86_64.txt b/contrib/libs/farmhash/arch/sse42/CMakeLists.windows-x86_64.txt index 92f77b4d9a6a..83392f428edb 100644 --- a/contrib/libs/farmhash/arch/sse42/CMakeLists.windows-x86_64.txt +++ b/contrib/libs/farmhash/arch/sse42/CMakeLists.windows-x86_64.txt @@ -9,7 +9,6 @@ add_library(farmhash-arch-sse42) target_compile_options(farmhash-arch-sse42 PRIVATE - -msse4.2 $,,-Wno-everything> ) target_link_libraries(farmhash-arch-sse42 PUBLIC diff --git a/contrib/libs/farmhash/arch/sse42_aesni/CMakeLists.windows-x86_64.txt b/contrib/libs/farmhash/arch/sse42_aesni/CMakeLists.windows-x86_64.txt index c73d04f960e9..6bc0649050f7 100644 --- a/contrib/libs/farmhash/arch/sse42_aesni/CMakeLists.windows-x86_64.txt +++ b/contrib/libs/farmhash/arch/sse42_aesni/CMakeLists.windows-x86_64.txt @@ -9,8 +9,6 @@ add_library(farmhash-arch-sse42_aesni) target_compile_options(farmhash-arch-sse42_aesni PRIVATE - -msse4.2 - -maes $,,-Wno-everything> ) target_link_libraries(farmhash-arch-sse42_aesni PUBLIC diff --git a/contrib/libs/fastlz/CMakeLists.darwin-arm64.txt b/contrib/libs/fastlz/CMakeLists.darwin-arm64.txt index eab41c060a76..e4608106057b 100644 --- a/contrib/libs/fastlz/CMakeLists.darwin-arm64.txt +++ b/contrib/libs/fastlz/CMakeLists.darwin-arm64.txt @@ -15,5 +15,6 @@ target_link_libraries(contrib-libs-fastlz PUBLIC contrib-libs-cxxsupp ) target_sources(contrib-libs-fastlz PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/fastlz/rename.h ${CMAKE_SOURCE_DIR}/contrib/libs/fastlz/fastlz.c ) diff --git a/contrib/libs/fastlz/CMakeLists.darwin-x86_64.txt b/contrib/libs/fastlz/CMakeLists.darwin-x86_64.txt index eab41c060a76..e4608106057b 100644 --- a/contrib/libs/fastlz/CMakeLists.darwin-x86_64.txt +++ b/contrib/libs/fastlz/CMakeLists.darwin-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(contrib-libs-fastlz PUBLIC contrib-libs-cxxsupp ) target_sources(contrib-libs-fastlz PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/fastlz/rename.h ${CMAKE_SOURCE_DIR}/contrib/libs/fastlz/fastlz.c ) diff --git a/contrib/libs/fastlz/CMakeLists.linux-aarch64.txt b/contrib/libs/fastlz/CMakeLists.linux-aarch64.txt index e6a67c5372d0..13191c0bfefc 100644 --- a/contrib/libs/fastlz/CMakeLists.linux-aarch64.txt +++ b/contrib/libs/fastlz/CMakeLists.linux-aarch64.txt @@ -16,5 +16,6 @@ target_link_libraries(contrib-libs-fastlz PUBLIC contrib-libs-cxxsupp ) target_sources(contrib-libs-fastlz PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/fastlz/rename.h ${CMAKE_SOURCE_DIR}/contrib/libs/fastlz/fastlz.c ) diff --git a/contrib/libs/fastlz/CMakeLists.linux-x86_64.txt b/contrib/libs/fastlz/CMakeLists.linux-x86_64.txt index e6a67c5372d0..13191c0bfefc 100644 --- a/contrib/libs/fastlz/CMakeLists.linux-x86_64.txt +++ b/contrib/libs/fastlz/CMakeLists.linux-x86_64.txt @@ -16,5 +16,6 @@ target_link_libraries(contrib-libs-fastlz PUBLIC contrib-libs-cxxsupp ) target_sources(contrib-libs-fastlz PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/fastlz/rename.h ${CMAKE_SOURCE_DIR}/contrib/libs/fastlz/fastlz.c ) diff --git a/contrib/libs/fastlz/CMakeLists.windows-x86_64.txt b/contrib/libs/fastlz/CMakeLists.windows-x86_64.txt index eab41c060a76..e4608106057b 100644 --- a/contrib/libs/fastlz/CMakeLists.windows-x86_64.txt +++ b/contrib/libs/fastlz/CMakeLists.windows-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(contrib-libs-fastlz PUBLIC contrib-libs-cxxsupp ) target_sources(contrib-libs-fastlz PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/fastlz/rename.h ${CMAKE_SOURCE_DIR}/contrib/libs/fastlz/fastlz.c ) diff --git a/contrib/libs/googleapis-common-protos/CMakeLists.darwin-arm64.txt b/contrib/libs/googleapis-common-protos/CMakeLists.darwin-arm64.txt index a2b6d3385ff2..7544d08723c1 100644 --- a/contrib/libs/googleapis-common-protos/CMakeLists.darwin-arm64.txt +++ b/contrib/libs/googleapis-common-protos/CMakeLists.darwin-arm64.txt @@ -837,6 +837,132 @@ target_proto_messages(contrib-libs-googleapis-common-protos PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/googleapis-common-protos/google/type/quaternion.proto ${CMAKE_SOURCE_DIR}/contrib/libs/googleapis-common-protos/google/type/timeofday.proto ) +target_sources(contrib-libs-googleapis-common-protos PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/annotations.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/annotations.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/auth.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/auth.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/backend.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/backend.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/billing.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/billing.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/client.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/client.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/config_change.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/config_change.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/consumer.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/consumer.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/context.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/context.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/control.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/control.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/distribution.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/distribution.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/documentation.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/documentation.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/endpoint.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/endpoint.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/error_reason.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/error_reason.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/field_behavior.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/field_behavior.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/field_info.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/field_info.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/http.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/http.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/httpbody.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/httpbody.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/label.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/label.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/launch_stage.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/launch_stage.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/log.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/log.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/logging.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/logging.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/metric.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/metric.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/monitored_resource.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/monitored_resource.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/monitoring.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/monitoring.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/policy.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/policy.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/quota.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/quota.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/resource.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/resource.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/routing.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/routing.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/service.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/service.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/source_info.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/source_info.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/system_parameter.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/system_parameter.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/usage.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/usage.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/visibility.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/visibility.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/cloud/extended_operations.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/cloud/extended_operations.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/cloud/location/locations.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/cloud/location/locations.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/gapic/metadata/gapic_metadata.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/gapic/metadata/gapic_metadata.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/logging/type/http_request.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/logging/type/http_request.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/logging/type/log_severity.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/logging/type/log_severity.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/longrunning/operations.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/longrunning/operations.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/code.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/code.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/context/attribute_context.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/context/attribute_context.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/context/audit_context.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/context/audit_context.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/error_details.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/error_details.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/http.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/http.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/status.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/status.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/calendar_period.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/calendar_period.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/color.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/color.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/date.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/date.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/datetime.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/datetime.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/dayofweek.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/dayofweek.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/decimal.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/decimal.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/expr.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/expr.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/fraction.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/fraction.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/interval.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/interval.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/latlng.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/latlng.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/localized_text.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/localized_text.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/money.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/money.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/month.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/month.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/phone_number.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/phone_number.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/postal_address.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/postal_address.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/quaternion.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/quaternion.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/timeofday.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/timeofday.grpc.pb.h +) target_proto_addincls(contrib-libs-googleapis-common-protos ./contrib/libs/googleapis-common-protos ${CMAKE_SOURCE_DIR}/contrib/libs/googleapis-common-protos diff --git a/contrib/libs/googleapis-common-protos/CMakeLists.darwin-x86_64.txt b/contrib/libs/googleapis-common-protos/CMakeLists.darwin-x86_64.txt index a2b6d3385ff2..7544d08723c1 100644 --- a/contrib/libs/googleapis-common-protos/CMakeLists.darwin-x86_64.txt +++ b/contrib/libs/googleapis-common-protos/CMakeLists.darwin-x86_64.txt @@ -837,6 +837,132 @@ target_proto_messages(contrib-libs-googleapis-common-protos PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/googleapis-common-protos/google/type/quaternion.proto ${CMAKE_SOURCE_DIR}/contrib/libs/googleapis-common-protos/google/type/timeofday.proto ) +target_sources(contrib-libs-googleapis-common-protos PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/annotations.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/annotations.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/auth.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/auth.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/backend.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/backend.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/billing.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/billing.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/client.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/client.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/config_change.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/config_change.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/consumer.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/consumer.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/context.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/context.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/control.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/control.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/distribution.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/distribution.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/documentation.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/documentation.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/endpoint.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/endpoint.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/error_reason.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/error_reason.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/field_behavior.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/field_behavior.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/field_info.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/field_info.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/http.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/http.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/httpbody.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/httpbody.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/label.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/label.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/launch_stage.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/launch_stage.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/log.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/log.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/logging.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/logging.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/metric.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/metric.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/monitored_resource.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/monitored_resource.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/monitoring.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/monitoring.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/policy.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/policy.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/quota.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/quota.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/resource.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/resource.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/routing.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/routing.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/service.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/service.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/source_info.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/source_info.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/system_parameter.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/system_parameter.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/usage.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/usage.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/visibility.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/visibility.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/cloud/extended_operations.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/cloud/extended_operations.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/cloud/location/locations.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/cloud/location/locations.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/gapic/metadata/gapic_metadata.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/gapic/metadata/gapic_metadata.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/logging/type/http_request.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/logging/type/http_request.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/logging/type/log_severity.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/logging/type/log_severity.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/longrunning/operations.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/longrunning/operations.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/code.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/code.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/context/attribute_context.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/context/attribute_context.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/context/audit_context.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/context/audit_context.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/error_details.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/error_details.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/http.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/http.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/status.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/status.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/calendar_period.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/calendar_period.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/color.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/color.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/date.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/date.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/datetime.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/datetime.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/dayofweek.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/dayofweek.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/decimal.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/decimal.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/expr.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/expr.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/fraction.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/fraction.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/interval.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/interval.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/latlng.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/latlng.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/localized_text.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/localized_text.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/money.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/money.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/month.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/month.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/phone_number.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/phone_number.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/postal_address.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/postal_address.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/quaternion.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/quaternion.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/timeofday.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/timeofday.grpc.pb.h +) target_proto_addincls(contrib-libs-googleapis-common-protos ./contrib/libs/googleapis-common-protos ${CMAKE_SOURCE_DIR}/contrib/libs/googleapis-common-protos diff --git a/contrib/libs/googleapis-common-protos/CMakeLists.linux-aarch64.txt b/contrib/libs/googleapis-common-protos/CMakeLists.linux-aarch64.txt index 48c7a1d1cb2e..a7bbbfe6782f 100644 --- a/contrib/libs/googleapis-common-protos/CMakeLists.linux-aarch64.txt +++ b/contrib/libs/googleapis-common-protos/CMakeLists.linux-aarch64.txt @@ -838,6 +838,132 @@ target_proto_messages(contrib-libs-googleapis-common-protos PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/googleapis-common-protos/google/type/quaternion.proto ${CMAKE_SOURCE_DIR}/contrib/libs/googleapis-common-protos/google/type/timeofday.proto ) +target_sources(contrib-libs-googleapis-common-protos PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/annotations.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/annotations.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/auth.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/auth.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/backend.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/backend.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/billing.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/billing.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/client.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/client.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/config_change.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/config_change.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/consumer.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/consumer.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/context.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/context.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/control.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/control.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/distribution.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/distribution.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/documentation.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/documentation.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/endpoint.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/endpoint.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/error_reason.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/error_reason.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/field_behavior.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/field_behavior.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/field_info.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/field_info.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/http.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/http.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/httpbody.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/httpbody.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/label.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/label.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/launch_stage.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/launch_stage.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/log.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/log.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/logging.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/logging.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/metric.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/metric.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/monitored_resource.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/monitored_resource.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/monitoring.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/monitoring.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/policy.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/policy.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/quota.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/quota.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/resource.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/resource.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/routing.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/routing.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/service.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/service.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/source_info.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/source_info.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/system_parameter.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/system_parameter.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/usage.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/usage.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/visibility.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/visibility.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/cloud/extended_operations.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/cloud/extended_operations.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/cloud/location/locations.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/cloud/location/locations.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/gapic/metadata/gapic_metadata.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/gapic/metadata/gapic_metadata.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/logging/type/http_request.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/logging/type/http_request.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/logging/type/log_severity.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/logging/type/log_severity.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/longrunning/operations.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/longrunning/operations.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/code.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/code.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/context/attribute_context.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/context/attribute_context.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/context/audit_context.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/context/audit_context.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/error_details.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/error_details.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/http.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/http.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/status.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/status.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/calendar_period.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/calendar_period.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/color.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/color.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/date.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/date.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/datetime.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/datetime.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/dayofweek.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/dayofweek.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/decimal.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/decimal.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/expr.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/expr.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/fraction.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/fraction.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/interval.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/interval.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/latlng.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/latlng.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/localized_text.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/localized_text.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/money.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/money.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/month.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/month.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/phone_number.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/phone_number.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/postal_address.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/postal_address.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/quaternion.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/quaternion.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/timeofday.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/timeofday.grpc.pb.h +) target_proto_addincls(contrib-libs-googleapis-common-protos ./contrib/libs/googleapis-common-protos ${CMAKE_SOURCE_DIR}/contrib/libs/googleapis-common-protos diff --git a/contrib/libs/googleapis-common-protos/CMakeLists.linux-x86_64.txt b/contrib/libs/googleapis-common-protos/CMakeLists.linux-x86_64.txt index 48c7a1d1cb2e..a7bbbfe6782f 100644 --- a/contrib/libs/googleapis-common-protos/CMakeLists.linux-x86_64.txt +++ b/contrib/libs/googleapis-common-protos/CMakeLists.linux-x86_64.txt @@ -838,6 +838,132 @@ target_proto_messages(contrib-libs-googleapis-common-protos PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/googleapis-common-protos/google/type/quaternion.proto ${CMAKE_SOURCE_DIR}/contrib/libs/googleapis-common-protos/google/type/timeofday.proto ) +target_sources(contrib-libs-googleapis-common-protos PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/annotations.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/annotations.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/auth.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/auth.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/backend.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/backend.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/billing.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/billing.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/client.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/client.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/config_change.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/config_change.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/consumer.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/consumer.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/context.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/context.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/control.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/control.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/distribution.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/distribution.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/documentation.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/documentation.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/endpoint.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/endpoint.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/error_reason.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/error_reason.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/field_behavior.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/field_behavior.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/field_info.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/field_info.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/http.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/http.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/httpbody.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/httpbody.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/label.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/label.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/launch_stage.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/launch_stage.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/log.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/log.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/logging.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/logging.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/metric.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/metric.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/monitored_resource.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/monitored_resource.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/monitoring.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/monitoring.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/policy.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/policy.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/quota.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/quota.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/resource.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/resource.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/routing.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/routing.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/service.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/service.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/source_info.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/source_info.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/system_parameter.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/system_parameter.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/usage.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/usage.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/visibility.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/visibility.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/cloud/extended_operations.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/cloud/extended_operations.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/cloud/location/locations.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/cloud/location/locations.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/gapic/metadata/gapic_metadata.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/gapic/metadata/gapic_metadata.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/logging/type/http_request.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/logging/type/http_request.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/logging/type/log_severity.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/logging/type/log_severity.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/longrunning/operations.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/longrunning/operations.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/code.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/code.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/context/attribute_context.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/context/attribute_context.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/context/audit_context.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/context/audit_context.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/error_details.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/error_details.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/http.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/http.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/status.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/status.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/calendar_period.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/calendar_period.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/color.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/color.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/date.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/date.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/datetime.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/datetime.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/dayofweek.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/dayofweek.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/decimal.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/decimal.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/expr.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/expr.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/fraction.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/fraction.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/interval.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/interval.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/latlng.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/latlng.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/localized_text.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/localized_text.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/money.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/money.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/month.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/month.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/phone_number.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/phone_number.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/postal_address.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/postal_address.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/quaternion.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/quaternion.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/timeofday.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/timeofday.grpc.pb.h +) target_proto_addincls(contrib-libs-googleapis-common-protos ./contrib/libs/googleapis-common-protos ${CMAKE_SOURCE_DIR}/contrib/libs/googleapis-common-protos diff --git a/contrib/libs/googleapis-common-protos/CMakeLists.windows-x86_64.txt b/contrib/libs/googleapis-common-protos/CMakeLists.windows-x86_64.txt index a2b6d3385ff2..7544d08723c1 100644 --- a/contrib/libs/googleapis-common-protos/CMakeLists.windows-x86_64.txt +++ b/contrib/libs/googleapis-common-protos/CMakeLists.windows-x86_64.txt @@ -837,6 +837,132 @@ target_proto_messages(contrib-libs-googleapis-common-protos PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/googleapis-common-protos/google/type/quaternion.proto ${CMAKE_SOURCE_DIR}/contrib/libs/googleapis-common-protos/google/type/timeofday.proto ) +target_sources(contrib-libs-googleapis-common-protos PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/annotations.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/annotations.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/auth.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/auth.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/backend.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/backend.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/billing.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/billing.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/client.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/client.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/config_change.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/config_change.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/consumer.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/consumer.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/context.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/context.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/control.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/control.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/distribution.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/distribution.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/documentation.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/documentation.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/endpoint.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/endpoint.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/error_reason.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/error_reason.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/field_behavior.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/field_behavior.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/field_info.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/field_info.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/http.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/http.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/httpbody.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/httpbody.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/label.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/label.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/launch_stage.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/launch_stage.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/log.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/log.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/logging.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/logging.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/metric.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/metric.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/monitored_resource.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/monitored_resource.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/monitoring.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/monitoring.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/policy.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/policy.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/quota.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/quota.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/resource.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/resource.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/routing.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/routing.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/service.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/service.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/source_info.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/source_info.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/system_parameter.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/system_parameter.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/usage.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/usage.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/visibility.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/api/visibility.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/cloud/extended_operations.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/cloud/extended_operations.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/cloud/location/locations.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/cloud/location/locations.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/gapic/metadata/gapic_metadata.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/gapic/metadata/gapic_metadata.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/logging/type/http_request.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/logging/type/http_request.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/logging/type/log_severity.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/logging/type/log_severity.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/longrunning/operations.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/longrunning/operations.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/code.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/code.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/context/attribute_context.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/context/attribute_context.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/context/audit_context.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/context/audit_context.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/error_details.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/error_details.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/http.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/http.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/status.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/rpc/status.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/calendar_period.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/calendar_period.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/color.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/color.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/date.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/date.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/datetime.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/datetime.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/dayofweek.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/dayofweek.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/decimal.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/decimal.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/expr.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/expr.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/fraction.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/fraction.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/interval.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/interval.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/latlng.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/latlng.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/localized_text.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/localized_text.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/money.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/money.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/month.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/month.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/phone_number.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/phone_number.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/postal_address.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/postal_address.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/quaternion.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/quaternion.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/timeofday.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/googleapis-common-protos/google/type/timeofday.grpc.pb.h +) target_proto_addincls(contrib-libs-googleapis-common-protos ./contrib/libs/googleapis-common-protos ${CMAKE_SOURCE_DIR}/contrib/libs/googleapis-common-protos diff --git a/contrib/libs/hyperscan/runtime_avx2/CMakeLists.windows-x86_64.txt b/contrib/libs/hyperscan/runtime_avx2/CMakeLists.windows-x86_64.txt index 85764417b721..53cc46d2b92d 100644 --- a/contrib/libs/hyperscan/runtime_avx2/CMakeLists.windows-x86_64.txt +++ b/contrib/libs/hyperscan/runtime_avx2/CMakeLists.windows-x86_64.txt @@ -9,18 +9,17 @@ add_library(libs-hyperscan-runtime_avx2) target_compile_options(libs-hyperscan-runtime_avx2 PRIVATE - -msse4.1 + /D__SSE4_1__=1 -DHAVE_SSE41 - -msse4.2 + /D__SSE4_2__=1 -DHAVE_SSE42 - -mpopcnt + /D__POPCNT__=1 -DHAVE_POPCOUNT_INSTR - -mavx + /arch:AVX + /DAVX_ENABLED=1 -DHAVE_AVX - -mavx2 - -mfma - -mbmi - -mbmi2 + /arch:AVX2 + /DAVX2_ENABLED=1 -DHAVE_AVX2 -DCrc32c_ComputeBuf=avx2_Crc32c_ComputeBuf -DblockInitSufPQ=avx2_blockInitSufPQ diff --git a/contrib/libs/hyperscan/runtime_avx512/CMakeLists.windows-x86_64.txt b/contrib/libs/hyperscan/runtime_avx512/CMakeLists.windows-x86_64.txt index e11134a46a83..bf75f07d09b6 100644 --- a/contrib/libs/hyperscan/runtime_avx512/CMakeLists.windows-x86_64.txt +++ b/contrib/libs/hyperscan/runtime_avx512/CMakeLists.windows-x86_64.txt @@ -9,24 +9,20 @@ add_library(libs-hyperscan-runtime_avx512) target_compile_options(libs-hyperscan-runtime_avx512 PRIVATE - -msse4.1 + /D__SSE4_1__=1 -DHAVE_SSE41 - -msse4.2 + /D__SSE4_2__=1 -DHAVE_SSE42 -DHAVE_POPCOUNT_INSTR - -mpopcnt - -mavx + /D__POPCNT__=1 + /arch:AVX + /DAVX_ENABLED=1 -DHAVE_AVX - -mavx2 - -mfma - -mbmi - -mbmi2 + /arch:AVX2 + /DAVX2_ENABLED=1 -DHAVE_AVX2 - -mavx512f - -mavx512cd - -mavx512bw - -mavx512dq - -mavx512vl + /arch:AVX512 + /DAVX512_ENABLED=1 -DHAVE_AVX512 -DCrc32c_ComputeBuf=avx512_Crc32c_ComputeBuf -DblockInitSufPQ=avx512_blockInitSufPQ diff --git a/contrib/libs/hyperscan/runtime_corei7/CMakeLists.windows-x86_64.txt b/contrib/libs/hyperscan/runtime_corei7/CMakeLists.windows-x86_64.txt index c3088fa842c2..c66f3c8131d7 100644 --- a/contrib/libs/hyperscan/runtime_corei7/CMakeLists.windows-x86_64.txt +++ b/contrib/libs/hyperscan/runtime_corei7/CMakeLists.windows-x86_64.txt @@ -9,11 +9,11 @@ add_library(libs-hyperscan-runtime_corei7) target_compile_options(libs-hyperscan-runtime_corei7 PRIVATE - -msse4.1 + /D__SSE4_1__=1 -DHAVE_SSE41 - -msse4.2 + /D__SSE4_2__=1 -DHAVE_SSE42 - -mpopcnt + /D__POPCNT__=1 -DHAVE_POPCOUNT_INSTR -DCrc32c_ComputeBuf=corei7_Crc32c_ComputeBuf -DblockInitSufPQ=corei7_blockInitSufPQ diff --git a/contrib/libs/libpq/CMakeLists.txt b/contrib/libs/libpq/CMakeLists.txt index 380079ac7b4a..d863ebd18067 100644 --- a/contrib/libs/libpq/CMakeLists.txt +++ b/contrib/libs/libpq/CMakeLists.txt @@ -14,4 +14,6 @@ elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL include(CMakeLists.darwin-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) endif() diff --git a/contrib/libs/libpq/CMakeLists.windows-x86_64.txt b/contrib/libs/libpq/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..993d96763bad --- /dev/null +++ b/contrib/libs/libpq/CMakeLists.windows-x86_64.txt @@ -0,0 +1,128 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(contrib-libs-libpq) +target_compile_options(contrib-libs-libpq PRIVATE + -DFRONTEND + -DUNSAFE_STAT_OK + -D_POSIX_PTHREAD_SEMANTICS + -D_REENTRANT + -D_THREAD_SAFE + $,,-Wno-everything> +) +target_include_directories(contrib-libs-libpq PUBLIC + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/include +) +target_include_directories(contrib-libs-libpq PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/backend + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/interfaces/libpq + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/include/port + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/include/port/win32 + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/include/port/win32_msvc +) +target_link_libraries(contrib-libs-libpq PUBLIC + contrib-libs-libc_compat + contrib-libs-openssl + contrib-libs-zlib +) +target_sources(contrib-libs-libpq PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/archive.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/base64.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/checksum_helper.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/compression.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/config_info.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/controldata_utils.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/cryptohash_openssl.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/d2s.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/encnames.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/exec.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/f2s.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/fe_memutils.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/file_perm.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/file_utils.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/hashfn.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/hmac_openssl.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/ip.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/jsonapi.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/keywords.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/kwlookup.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/link-canary.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/logging.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/md5_common.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/percentrepl.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/pg_get_line.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/pg_lzcompress.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/pg_prng.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/pgfnames.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/protocol_openssl.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/psprintf.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/relpath.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/restricted_token.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/rmtree.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/saslprep.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/scram-common.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/sprompt.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/string.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/stringinfo.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/unicode_norm.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/username.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/wait_error.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/common/wchar.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/interfaces/libpq/fe-auth-scram.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/interfaces/libpq/fe-auth.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/interfaces/libpq/fe-connect.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/interfaces/libpq/fe-exec.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/interfaces/libpq/fe-lobj.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/interfaces/libpq/fe-misc.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/interfaces/libpq/fe-print.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/interfaces/libpq/fe-protocol3.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/interfaces/libpq/fe-secure-common.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/interfaces/libpq/fe-secure-openssl.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/interfaces/libpq/fe-secure.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/interfaces/libpq/fe-trace.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/interfaces/libpq/libpq-events.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/interfaces/libpq/pqexpbuffer.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/bsearch_arg.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/chklocale.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/getpeereid.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/inet_net_ntop.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/noblock.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/path.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/pg_bitutils.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/pg_crc32c_sb8.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/pg_strong_random.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/pgcheckdir.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/pgmkdirp.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/pgsleep.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/pgstrcasecmp.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/pgstrsignal.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/pqsignal.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/qsort.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/qsort_arg.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/quotes.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/snprintf.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/strerror.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/tar.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/thread.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/pg_crc32c_sse42.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/pg_crc32c_sse42_choose.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/interfaces/libpq/pthread-win32.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/interfaces/libpq/win32.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/dirmod.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/inet_aton.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/open.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/win32common.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/win32error.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/win32gettimeofday.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/win32ntdll.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/win32setlocale.c + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/port/win32stat.c +) diff --git a/contrib/libs/libpqxx/CMakeLists.txt b/contrib/libs/libpqxx/CMakeLists.txt index 380079ac7b4a..d863ebd18067 100644 --- a/contrib/libs/libpqxx/CMakeLists.txt +++ b/contrib/libs/libpqxx/CMakeLists.txt @@ -14,4 +14,6 @@ elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL include(CMakeLists.darwin-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) endif() diff --git a/contrib/libs/libpqxx/CMakeLists.windows-x86_64.txt b/contrib/libs/libpqxx/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..14c39564eedb --- /dev/null +++ b/contrib/libs/libpqxx/CMakeLists.windows-x86_64.txt @@ -0,0 +1,59 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(contrib-libs-libpqxx) +target_compile_options(contrib-libs-libpqxx PRIVATE + -DHAVE_CONFIG_H + $,,-Wno-everything> +) +target_include_directories(contrib-libs-libpqxx PUBLIC + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/include +) +target_include_directories(contrib-libs-libpqxx PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq + ${CMAKE_SOURCE_DIR}/contrib/libs/libpq/src/interfaces/libpq +) +target_link_libraries(contrib-libs-libpqxx PUBLIC + contrib-libs-cxxsupp + contrib-libs-libpq +) +target_sources(contrib-libs-libpqxx PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/array.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/binarystring.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/connection.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/connection_base.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/cursor.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/dbtransaction.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/encodings.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/errorhandler.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/except.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/field.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/largeobject.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/nontransaction.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/notification.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/pipeline.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/prepared_statement.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/result.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/robusttransaction.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/row.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/sql_cursor.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/statement_parameters.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/strconv.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/stream_base.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/stream_from.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/stream_to.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/subtransaction.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/tablereader.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/tablestream.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/tablewriter.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/transaction.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/transaction_base.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/util.cxx + ${CMAKE_SOURCE_DIR}/contrib/libs/libpqxx/src/version.cxx +) diff --git a/contrib/libs/libunwind/CMakeLists.txt b/contrib/libs/libunwind/CMakeLists.txt index d863ebd18067..380079ac7b4a 100644 --- a/contrib/libs/libunwind/CMakeLists.txt +++ b/contrib/libs/libunwind/CMakeLists.txt @@ -14,6 +14,4 @@ elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL include(CMakeLists.darwin-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) endif() diff --git a/contrib/libs/llvm12/include/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm12/include/CMakeLists.darwin-arm64.txt index 7ea3024199af..0b44da499887 100644 --- a/contrib/libs/llvm12/include/CMakeLists.darwin-arm64.txt +++ b/contrib/libs/llvm12/include/CMakeLists.darwin-arm64.txt @@ -670,6 +670,224 @@ target_link_libraries(libs-llvm12-include PUBLIC contrib-libs-llvm12 ) target_sources(libs-llvm12-include PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenACC/ACC.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenACC/ACC.h.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenMP/OMP.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenMP/OMP.h.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/Attributes.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/Attributes.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicEnums.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicEnums.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicImpl.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicImpl.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsAArch64.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsAArch64.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsAMDGPU.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsAMDGPU.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsARM.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsARM.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsBPF.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsBPF.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsHexagon.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsHexagon.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsMips.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsMips.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsNVPTX.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsNVPTX.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsPowerPC.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsPowerPC.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsR600.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsR600.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsRISCV.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsRISCV.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsS390.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsS390.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsVE.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsVE.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsWebAssembly.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsWebAssembly.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsX86.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsX86.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsXCore.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsXCore.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Frontend/OpenACC/ACC.cpp + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Frontend/OpenACC/ACC.cpp.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Frontend/OpenMP/OMP.cpp + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Frontend/OpenMP/OMP.cpp.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmWriter1.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenSystemOperands.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenSystemOperands.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenMCPseudoLowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenSystemRegister.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenSystemRegister.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmWriter1.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenEVEX2VEXTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenEVEX2VEXTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/ToolDrivers/llvm-dlltool/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/ToolDrivers/llvm-dlltool/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/ToolDrivers/llvm-lib/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/ToolDrivers/llvm-lib/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/dsymutil/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/dsymutil/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-cvtres/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-cvtres/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-lipo/LipoOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-lipo/LipoOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-ml/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-ml/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-mt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-mt/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/BitcodeStripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/BitcodeStripOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/InstallNameToolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/InstallNameToolOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/ObjcopyOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/ObjcopyOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/StripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/StripOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-rc/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-rc/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-symbolizer/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-symbolizer/Opts.inc.d ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenACC/ACC.h.inc ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenMP/OMP.h.inc ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/Attributes.inc diff --git a/contrib/libs/llvm12/include/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm12/include/CMakeLists.darwin-x86_64.txt index 7ea3024199af..0b44da499887 100644 --- a/contrib/libs/llvm12/include/CMakeLists.darwin-x86_64.txt +++ b/contrib/libs/llvm12/include/CMakeLists.darwin-x86_64.txt @@ -670,6 +670,224 @@ target_link_libraries(libs-llvm12-include PUBLIC contrib-libs-llvm12 ) target_sources(libs-llvm12-include PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenACC/ACC.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenACC/ACC.h.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenMP/OMP.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenMP/OMP.h.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/Attributes.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/Attributes.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicEnums.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicEnums.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicImpl.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicImpl.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsAArch64.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsAArch64.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsAMDGPU.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsAMDGPU.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsARM.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsARM.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsBPF.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsBPF.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsHexagon.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsHexagon.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsMips.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsMips.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsNVPTX.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsNVPTX.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsPowerPC.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsPowerPC.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsR600.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsR600.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsRISCV.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsRISCV.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsS390.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsS390.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsVE.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsVE.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsWebAssembly.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsWebAssembly.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsX86.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsX86.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsXCore.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsXCore.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Frontend/OpenACC/ACC.cpp + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Frontend/OpenACC/ACC.cpp.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Frontend/OpenMP/OMP.cpp + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Frontend/OpenMP/OMP.cpp.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmWriter1.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenSystemOperands.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenSystemOperands.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenMCPseudoLowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenSystemRegister.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenSystemRegister.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmWriter1.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenEVEX2VEXTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenEVEX2VEXTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/ToolDrivers/llvm-dlltool/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/ToolDrivers/llvm-dlltool/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/ToolDrivers/llvm-lib/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/ToolDrivers/llvm-lib/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/dsymutil/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/dsymutil/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-cvtres/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-cvtres/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-lipo/LipoOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-lipo/LipoOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-ml/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-ml/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-mt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-mt/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/BitcodeStripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/BitcodeStripOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/InstallNameToolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/InstallNameToolOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/ObjcopyOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/ObjcopyOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/StripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/StripOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-rc/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-rc/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-symbolizer/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-symbolizer/Opts.inc.d ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenACC/ACC.h.inc ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenMP/OMP.h.inc ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/Attributes.inc diff --git a/contrib/libs/llvm12/include/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm12/include/CMakeLists.linux-aarch64.txt index 468c652df5d9..dc8ea924e249 100644 --- a/contrib/libs/llvm12/include/CMakeLists.linux-aarch64.txt +++ b/contrib/libs/llvm12/include/CMakeLists.linux-aarch64.txt @@ -671,6 +671,224 @@ target_link_libraries(libs-llvm12-include PUBLIC contrib-libs-llvm12 ) target_sources(libs-llvm12-include PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenACC/ACC.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenACC/ACC.h.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenMP/OMP.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenMP/OMP.h.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/Attributes.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/Attributes.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicEnums.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicEnums.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicImpl.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicImpl.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsAArch64.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsAArch64.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsAMDGPU.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsAMDGPU.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsARM.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsARM.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsBPF.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsBPF.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsHexagon.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsHexagon.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsMips.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsMips.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsNVPTX.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsNVPTX.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsPowerPC.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsPowerPC.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsR600.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsR600.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsRISCV.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsRISCV.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsS390.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsS390.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsVE.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsVE.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsWebAssembly.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsWebAssembly.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsX86.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsX86.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsXCore.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsXCore.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Frontend/OpenACC/ACC.cpp + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Frontend/OpenACC/ACC.cpp.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Frontend/OpenMP/OMP.cpp + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Frontend/OpenMP/OMP.cpp.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmWriter1.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenSystemOperands.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenSystemOperands.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenMCPseudoLowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenSystemRegister.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenSystemRegister.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmWriter1.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenEVEX2VEXTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenEVEX2VEXTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/ToolDrivers/llvm-dlltool/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/ToolDrivers/llvm-dlltool/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/ToolDrivers/llvm-lib/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/ToolDrivers/llvm-lib/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/dsymutil/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/dsymutil/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-cvtres/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-cvtres/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-lipo/LipoOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-lipo/LipoOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-ml/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-ml/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-mt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-mt/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/BitcodeStripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/BitcodeStripOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/InstallNameToolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/InstallNameToolOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/ObjcopyOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/ObjcopyOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/StripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/StripOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-rc/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-rc/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-symbolizer/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-symbolizer/Opts.inc.d ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenACC/ACC.h.inc ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenMP/OMP.h.inc ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/Attributes.inc diff --git a/contrib/libs/llvm12/include/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm12/include/CMakeLists.linux-x86_64.txt index 468c652df5d9..dc8ea924e249 100644 --- a/contrib/libs/llvm12/include/CMakeLists.linux-x86_64.txt +++ b/contrib/libs/llvm12/include/CMakeLists.linux-x86_64.txt @@ -671,6 +671,224 @@ target_link_libraries(libs-llvm12-include PUBLIC contrib-libs-llvm12 ) target_sources(libs-llvm12-include PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenACC/ACC.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenACC/ACC.h.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenMP/OMP.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenMP/OMP.h.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/Attributes.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/Attributes.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicEnums.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicEnums.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicImpl.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicImpl.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsAArch64.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsAArch64.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsAMDGPU.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsAMDGPU.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsARM.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsARM.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsBPF.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsBPF.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsHexagon.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsHexagon.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsMips.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsMips.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsNVPTX.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsNVPTX.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsPowerPC.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsPowerPC.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsR600.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsR600.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsRISCV.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsRISCV.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsS390.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsS390.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsVE.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsVE.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsWebAssembly.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsWebAssembly.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsX86.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsX86.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsXCore.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsXCore.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Frontend/OpenACC/ACC.cpp + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Frontend/OpenACC/ACC.cpp.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Frontend/OpenMP/OMP.cpp + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Frontend/OpenMP/OMP.cpp.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmWriter1.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenSystemOperands.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenSystemOperands.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenMCPseudoLowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenSystemRegister.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenSystemRegister.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmWriter1.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenEVEX2VEXTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenEVEX2VEXTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/ToolDrivers/llvm-dlltool/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/ToolDrivers/llvm-dlltool/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/ToolDrivers/llvm-lib/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/ToolDrivers/llvm-lib/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/dsymutil/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/dsymutil/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-cvtres/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-cvtres/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-lipo/LipoOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-lipo/LipoOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-ml/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-ml/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-mt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-mt/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/BitcodeStripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/BitcodeStripOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/InstallNameToolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/InstallNameToolOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/ObjcopyOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/ObjcopyOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/StripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/StripOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-rc/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-rc/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-symbolizer/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-symbolizer/Opts.inc.d ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenACC/ACC.h.inc ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenMP/OMP.h.inc ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/Attributes.inc diff --git a/contrib/libs/llvm12/include/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm12/include/CMakeLists.windows-x86_64.txt index 7ea3024199af..0b44da499887 100644 --- a/contrib/libs/llvm12/include/CMakeLists.windows-x86_64.txt +++ b/contrib/libs/llvm12/include/CMakeLists.windows-x86_64.txt @@ -670,6 +670,224 @@ target_link_libraries(libs-llvm12-include PUBLIC contrib-libs-llvm12 ) target_sources(libs-llvm12-include PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenACC/ACC.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenACC/ACC.h.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenMP/OMP.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenMP/OMP.h.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/Attributes.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/Attributes.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicEnums.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicEnums.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicImpl.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicImpl.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsAArch64.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsAArch64.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsAMDGPU.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsAMDGPU.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsARM.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsARM.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsBPF.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsBPF.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsHexagon.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsHexagon.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsMips.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsMips.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsNVPTX.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsNVPTX.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsPowerPC.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsPowerPC.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsR600.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsR600.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsRISCV.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsRISCV.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsS390.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsS390.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsVE.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsVE.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsWebAssembly.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsWebAssembly.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsX86.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsX86.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsXCore.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/IntrinsicsXCore.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Frontend/OpenACC/ACC.cpp + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Frontend/OpenACC/ACC.cpp.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Frontend/OpenMP/OMP.cpp + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Frontend/OpenMP/OMP.cpp.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenAsmWriter1.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenSystemOperands.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/AArch64/AArch64GenSystemOperands.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenMCPseudoLowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenSystemRegister.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/ARM/ARMGenSystemRegister.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/BPF/BPFGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/PowerPC/PPCGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenAsmWriter1.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenEVEX2VEXTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenEVEX2VEXTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/Target/X86/X86GenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/ToolDrivers/llvm-dlltool/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/ToolDrivers/llvm-dlltool/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/ToolDrivers/llvm-lib/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/lib/ToolDrivers/llvm-lib/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/dsymutil/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/dsymutil/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-cvtres/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-cvtres/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-lipo/LipoOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-lipo/LipoOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-ml/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-ml/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-mt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-mt/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/BitcodeStripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/BitcodeStripOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/InstallNameToolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/InstallNameToolOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/ObjcopyOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/ObjcopyOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/StripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-objcopy/StripOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-rc/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-rc/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-symbolizer/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/tools/llvm-symbolizer/Opts.inc.d ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenACC/ACC.h.inc ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/Frontend/OpenMP/OMP.h.inc ${CMAKE_BINARY_DIR}/contrib/libs/llvm12/include/llvm/IR/Attributes.inc diff --git a/contrib/libs/llvm12/lib/DebugInfo/CMakeLists.txt b/contrib/libs/llvm12/lib/DebugInfo/CMakeLists.txt index a1fc05a892e5..705bb739960c 100644 --- a/contrib/libs/llvm12/lib/DebugInfo/CMakeLists.txt +++ b/contrib/libs/llvm12/lib/DebugInfo/CMakeLists.txt @@ -9,5 +9,3 @@ add_subdirectory(CodeView) add_subdirectory(DWARF) add_subdirectory(MSF) -add_subdirectory(PDB) -add_subdirectory(Symbolize) diff --git a/contrib/libs/llvm12/utils/TableGen/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm12/utils/TableGen/CMakeLists.linux-aarch64.txt index 1421a2e7acfc..3460c057128e 100644 --- a/contrib/libs/llvm12/utils/TableGen/CMakeLists.linux-aarch64.txt +++ b/contrib/libs/llvm12/utils/TableGen/CMakeLists.linux-aarch64.txt @@ -31,9 +31,6 @@ target_link_options(llvm-tblgen PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(llvm-tblgen PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/llvm12/utils/TableGen/AsmMatcherEmitter.cpp diff --git a/contrib/libs/llvm12/utils/TableGen/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm12/utils/TableGen/CMakeLists.linux-x86_64.txt index 947f97be9421..63db0f795dcd 100644 --- a/contrib/libs/llvm12/utils/TableGen/CMakeLists.linux-x86_64.txt +++ b/contrib/libs/llvm12/utils/TableGen/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(llvm-tblgen PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(llvm-tblgen PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/llvm12/utils/TableGen/AsmMatcherEmitter.cpp diff --git a/contrib/libs/llvm14/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..71de99706a42 --- /dev/null +++ b/contrib/libs/llvm14/CMakeLists.darwin-arm64.txt @@ -0,0 +1,21 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(include) +add_subdirectory(lib) +add_subdirectory(utils) + +add_library(contrib-libs-llvm14 INTERFACE) +target_include_directories(contrib-libs-llvm14 INTERFACE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include +) +target_link_libraries(contrib-libs-llvm14 INTERFACE + contrib-libs-cxxsupp + yutil +) diff --git a/contrib/libs/llvm14/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..71de99706a42 --- /dev/null +++ b/contrib/libs/llvm14/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,21 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(include) +add_subdirectory(lib) +add_subdirectory(utils) + +add_library(contrib-libs-llvm14 INTERFACE) +target_include_directories(contrib-libs-llvm14 INTERFACE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include +) +target_link_libraries(contrib-libs-llvm14 INTERFACE + contrib-libs-cxxsupp + yutil +) diff --git a/contrib/libs/llvm14/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..408e915e88d3 --- /dev/null +++ b/contrib/libs/llvm14/CMakeLists.linux-aarch64.txt @@ -0,0 +1,22 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(include) +add_subdirectory(lib) +add_subdirectory(utils) + +add_library(contrib-libs-llvm14 INTERFACE) +target_include_directories(contrib-libs-llvm14 INTERFACE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include +) +target_link_libraries(contrib-libs-llvm14 INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil +) diff --git a/contrib/libs/llvm14/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..408e915e88d3 --- /dev/null +++ b/contrib/libs/llvm14/CMakeLists.linux-x86_64.txt @@ -0,0 +1,22 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(include) +add_subdirectory(lib) +add_subdirectory(utils) + +add_library(contrib-libs-llvm14 INTERFACE) +target_include_directories(contrib-libs-llvm14 INTERFACE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include +) +target_link_libraries(contrib-libs-llvm14 INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil +) diff --git a/contrib/libs/llvm14/CMakeLists.txt b/contrib/libs/llvm14/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..71de99706a42 --- /dev/null +++ b/contrib/libs/llvm14/CMakeLists.windows-x86_64.txt @@ -0,0 +1,21 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(include) +add_subdirectory(lib) +add_subdirectory(utils) + +add_library(contrib-libs-llvm14 INTERFACE) +target_include_directories(contrib-libs-llvm14 INTERFACE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include +) +target_link_libraries(contrib-libs-llvm14 INTERFACE + contrib-libs-cxxsupp + yutil +) diff --git a/contrib/libs/llvm14/include/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/include/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..6ae718c49825 --- /dev/null +++ b/contrib/libs/llvm14/include/CMakeLists.darwin-arm64.txt @@ -0,0 +1,8721 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) + +add_library(libs-llvm14-include STATIC) +set_property(TARGET libs-llvm14-include PROPERTY + LINKER_LANGUAGE CXX +) +target_link_libraries(libs-llvm14-include PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 +) +target_sources(libs-llvm14-include PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/Directive/DirectiveBase.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + --gen-directive-decl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/Directive/DirectiveBase.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + --gen-directive-impl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/Directive/DirectiveBase.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + --gen-directive-decl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/Directive/DirectiveBase.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + --gen-directive-impl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/AttributesAMDGPU.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-attrs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-impl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=aarch64 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=amdgcn + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=arm + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=bpf + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=hexagon + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=mips + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=nvvm + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=ppc + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=r600 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=riscv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=s390 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=ve + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=wasm + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=x86 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=xcore + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -asmwriternum=1 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-exegesis + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-fast-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-emitter + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-pseudo-lowering + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel-combiner + -combiners=AArch64O0PreLegalizerCombinerHelper + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel-combiner + -combiners=AArch64PostLegalizerCombinerHelper + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel-combiner + -combiners=AArch64PostLegalizerLoweringHelper + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel-combiner + -combiners=AArch64PreLegalizerCombinerHelper + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-bank + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-searchable-tables + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-fast-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-emitter + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-pseudo-lowering + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-bank + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-searchable-tables + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-emitter + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-exegesis + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-fast-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-emitter + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-bank + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -asmwriternum=1 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-x86-EVEX2VEX-tables + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-exegesis + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-fast-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc.d + --long-string-literals=0 +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-bank + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/dsymutil + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cvtres + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-lipo + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-ml + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-mt + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-nm + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/CommonOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/CommonOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-readobj + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-size + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-strings + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc.d +) +if(NOT CMAKE_CROSSCOMPILING) + add_dependencies(libs-llvm14-include + llvm-tblgen +) +endif() diff --git a/contrib/libs/llvm14/include/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/include/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..6ae718c49825 --- /dev/null +++ b/contrib/libs/llvm14/include/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,8721 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) + +add_library(libs-llvm14-include STATIC) +set_property(TARGET libs-llvm14-include PROPERTY + LINKER_LANGUAGE CXX +) +target_link_libraries(libs-llvm14-include PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 +) +target_sources(libs-llvm14-include PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/Directive/DirectiveBase.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + --gen-directive-decl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/Directive/DirectiveBase.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + --gen-directive-impl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/Directive/DirectiveBase.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + --gen-directive-decl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/Directive/DirectiveBase.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + --gen-directive-impl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/AttributesAMDGPU.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-attrs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-impl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=aarch64 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=amdgcn + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=arm + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=bpf + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=hexagon + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=mips + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=nvvm + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=ppc + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=r600 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=riscv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=s390 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=ve + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=wasm + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=x86 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=xcore + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -asmwriternum=1 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-exegesis + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-fast-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-emitter + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-pseudo-lowering + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel-combiner + -combiners=AArch64O0PreLegalizerCombinerHelper + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel-combiner + -combiners=AArch64PostLegalizerCombinerHelper + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel-combiner + -combiners=AArch64PostLegalizerLoweringHelper + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel-combiner + -combiners=AArch64PreLegalizerCombinerHelper + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-bank + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-searchable-tables + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-fast-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-emitter + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-pseudo-lowering + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-bank + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-searchable-tables + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-emitter + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-exegesis + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-fast-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-emitter + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-bank + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -asmwriternum=1 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-x86-EVEX2VEX-tables + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-exegesis + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-fast-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc.d + --long-string-literals=0 +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-bank + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/dsymutil + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cvtres + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-lipo + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-ml + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-mt + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-nm + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/CommonOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/CommonOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-readobj + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-size + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-strings + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc.d +) +if(NOT CMAKE_CROSSCOMPILING) + add_dependencies(libs-llvm14-include + llvm-tblgen +) +endif() diff --git a/contrib/libs/llvm14/include/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/include/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..51551c8d96c6 --- /dev/null +++ b/contrib/libs/llvm14/include/CMakeLists.linux-aarch64.txt @@ -0,0 +1,8722 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) + +add_library(libs-llvm14-include STATIC) +set_property(TARGET libs-llvm14-include PROPERTY + LINKER_LANGUAGE CXX +) +target_link_libraries(libs-llvm14-include PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 +) +target_sources(libs-llvm14-include PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/Directive/DirectiveBase.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + --gen-directive-decl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/Directive/DirectiveBase.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + --gen-directive-impl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/Directive/DirectiveBase.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + --gen-directive-decl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/Directive/DirectiveBase.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + --gen-directive-impl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/AttributesAMDGPU.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-attrs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-impl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=aarch64 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=amdgcn + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=arm + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=bpf + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=hexagon + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=mips + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=nvvm + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=ppc + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=r600 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=riscv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=s390 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=ve + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=wasm + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=x86 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=xcore + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -asmwriternum=1 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-exegesis + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-fast-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-emitter + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-pseudo-lowering + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel-combiner + -combiners=AArch64O0PreLegalizerCombinerHelper + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel-combiner + -combiners=AArch64PostLegalizerCombinerHelper + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel-combiner + -combiners=AArch64PostLegalizerLoweringHelper + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel-combiner + -combiners=AArch64PreLegalizerCombinerHelper + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-bank + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-searchable-tables + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-fast-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-emitter + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-pseudo-lowering + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-bank + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-searchable-tables + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-emitter + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-exegesis + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-fast-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-emitter + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-bank + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -asmwriternum=1 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-x86-EVEX2VEX-tables + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-exegesis + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-fast-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc.d + --long-string-literals=0 +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-bank + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/dsymutil + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cvtres + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-lipo + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-ml + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-mt + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-nm + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/CommonOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/CommonOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-readobj + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-size + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-strings + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc.d +) +if(NOT CMAKE_CROSSCOMPILING) + add_dependencies(libs-llvm14-include + llvm-tblgen +) +endif() diff --git a/contrib/libs/llvm14/include/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/include/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..51551c8d96c6 --- /dev/null +++ b/contrib/libs/llvm14/include/CMakeLists.linux-x86_64.txt @@ -0,0 +1,8722 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) + +add_library(libs-llvm14-include STATIC) +set_property(TARGET libs-llvm14-include PROPERTY + LINKER_LANGUAGE CXX +) +target_link_libraries(libs-llvm14-include PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 +) +target_sources(libs-llvm14-include PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/Directive/DirectiveBase.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + --gen-directive-decl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/Directive/DirectiveBase.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + --gen-directive-impl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/Directive/DirectiveBase.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + --gen-directive-decl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/Directive/DirectiveBase.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + --gen-directive-impl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/AttributesAMDGPU.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-attrs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-impl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=aarch64 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=amdgcn + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=arm + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=bpf + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=hexagon + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=mips + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=nvvm + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=ppc + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=r600 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=riscv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=s390 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=ve + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=wasm + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=x86 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=xcore + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -asmwriternum=1 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-exegesis + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-fast-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-emitter + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-pseudo-lowering + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel-combiner + -combiners=AArch64O0PreLegalizerCombinerHelper + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel-combiner + -combiners=AArch64PostLegalizerCombinerHelper + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel-combiner + -combiners=AArch64PostLegalizerLoweringHelper + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel-combiner + -combiners=AArch64PreLegalizerCombinerHelper + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-bank + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-searchable-tables + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-fast-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-emitter + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-pseudo-lowering + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-bank + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-searchable-tables + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-emitter + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-exegesis + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-fast-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-emitter + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-bank + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -asmwriternum=1 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-x86-EVEX2VEX-tables + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-exegesis + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-fast-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc.d + --long-string-literals=0 +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-bank + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/dsymutil + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cvtres + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-lipo + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-ml + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-mt + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-nm + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/CommonOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/CommonOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-readobj + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-size + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-strings + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc.d +) +if(NOT CMAKE_CROSSCOMPILING) + add_dependencies(libs-llvm14-include + llvm-tblgen +) +endif() diff --git a/contrib/libs/llvm14/include/CMakeLists.txt b/contrib/libs/llvm14/include/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/include/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/include/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/include/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..6ae718c49825 --- /dev/null +++ b/contrib/libs/llvm14/include/CMakeLists.windows-x86_64.txt @@ -0,0 +1,8721 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) +get_built_tool_path( + TOOL_llvm-tblgen_bin + TOOL_llvm-tblgen_dependency + contrib/libs/llvm14/utils/TableGen + llvm-tblgen +) + +add_library(libs-llvm14-include STATIC) +set_property(TARGET libs-llvm14-include PROPERTY + LINKER_LANGUAGE CXX +) +target_link_libraries(libs-llvm14-include PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 +) +target_sources(libs-llvm14-include PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc.d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/Directive/DirectiveBase.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + --gen-directive-decl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.h.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/Directive/DirectiveBase.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + --gen-directive-impl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenACC/ACC.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/Directive/DirectiveBase.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + --gen-directive-decl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.h.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/Directive/DirectiveBase.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + --gen-directive-impl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/Frontend/OpenMP/OMP.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/AttributesAMDGPU.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-attrs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/Attributes.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicEnums.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-impl + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicImpl.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=aarch64 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=amdgcn + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=arm + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=bpf + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=hexagon + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=mips + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=nvvm + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVPTX.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=ppc + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=r600 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsR600.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=riscv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=s390 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsS390.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=ve + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=wasm + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=x86 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-intrinsic-enums + -intrinsic-prefix=xcore + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.h.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -asmwriternum=1 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenAsmWriter1.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-exegesis + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenExegesis.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-fast-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenFastISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenGlobalISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-emitter + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCCodeEmitter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-pseudo-lowering + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenMCPseudoLowering.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel-combiner + -combiners=AArch64O0PreLegalizerCombinerHelper + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenO0PreLegalizeGICombiner.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel-combiner + -combiners=AArch64PostLegalizerCombinerHelper + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGICombiner.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel-combiner + -combiners=AArch64PostLegalizerLoweringHelper + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPostLegalizeGILowering.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel-combiner + -combiners=AArch64PreLegalizerCombinerHelper + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenPreLegalizeGICombiner.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-bank + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterBank.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64CallingConvention.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrAtomics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrGISel.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SMEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SVEInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA53.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA55.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedA64FX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedAmpere1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedCyclone.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedExynosM5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkor.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedFalkorDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedKryoDetails.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredAmpere.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredExynos.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedTSV110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX2T99.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SchedThunderX3T110.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64SystemOperands.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SMEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/SVEInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Combine.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-searchable-tables + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/AArch64/AArch64GenSystemOperands.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-fast-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenFastISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenGlobalISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-emitter + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCCodeEmitter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-pseudo-lowering + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenMCPseudoLowering.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-bank + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterBank.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrCDE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrMVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrNEON.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrThumb2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMInstrVFP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA57WriteRes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleA9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleM7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleR52.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleSwift.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMScheduleV6.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMSystemRegister.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/TableGen/SearchableTable.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-searchable-tables + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARM.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/ARM/ARMGenSystemRegister.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-emitter + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenMCCodeEmitter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPF.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/BPF/BPFGenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXIntrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTX.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/NVPTX/NVPTXGenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-exegesis + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenExegesis.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-fast-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenFastISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenGlobalISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenInstrInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-emitter + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenMCCodeEmitter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-bank + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterBank.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/GISel/PPCRegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P10InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/P9InstrResources.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstr64Bit.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrAltivec.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrHTM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrPrefix.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrSPE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCInstrVSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCRegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCSchedule440.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleA2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE500mc.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleE5500.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG4Plus.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleG5.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP10.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP7.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP8.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCScheduleP9.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPC.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/PowerPC/PPCGenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-matcher + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmMatcher.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-asm-writer + -asmwriternum=1 + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenAsmWriter1.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-callingconv + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenCallingConv.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-dag-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + -omit-comments + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDAGISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-disassembler + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenDisassemblerTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-x86-EVEX2VEX-tables + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenEVEX2VEXTables.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-exegesis + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenExegesis.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-fast-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenFastISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-global-isel + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenGlobalISel.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-instr-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenInstrInfo.inc.d + --long-string-literals=0 +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-bank + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterBank.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-register-info + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenRegisterInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Instr3DNow.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrAVX512.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrArithmetic.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCMovSetCC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrControl.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrExtension.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFPStack.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFormats.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFragmentsSIMD.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrKL.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrMMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSGX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSNP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSSE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrShiftRotate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrSystem.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTDX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrTSX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVMX.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrVecCompiler.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrXOP.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBanks.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedBroadwell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedHaswell.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedIceLake.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedPredicates.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSandyBridge.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeClient.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SchedSkylakeServer.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Schedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleAtom.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBdVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleBtVer2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleSLM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver1.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver2.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ScheduleZnver3.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/SDNodeProperties.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/CodeGen/ValueTypes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/Intrinsics.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAArch64.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsAMDGPU.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsARM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsBPF.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagon.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsHexagonDep.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsMips.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsNVVM.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsPowerPC.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsRISCV.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsSystemZ.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVE.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsVEVL.gen.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsWebAssembly.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsX86.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/IR/IntrinsicsXCore.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GenericOpcodes.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/RegisterBank.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/SelectionDAGCompat.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/GlobalISel/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/Target.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetCallingConv.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetInstrPredicate.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetItinerary.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetPfmCounters.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSchedule.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Target/TargetSelectionDAG.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-subtarget + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86/X86GenSubtargetInfo.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-dlltool/Options.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/ToolDrivers/llvm-lib/Options.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/dsymutil + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/dsymutil/Options.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cvtres + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cvtres/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-cxxfilt/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-lipo + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-lipo/LipoOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-ml + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-ml/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-mt + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-mt/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-nm + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-nm/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/BitcodeStripOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/InstallNameToolOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/CommonOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/ObjcopyOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/CommonOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objcopy/StripOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/ObjdumpOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-objdump/OtoolOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-rc/WindresOpts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-readobj + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-readobj/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-size + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-size/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-strings + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-strings/Opts.inc.d +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc.d + DEPENDS + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.td + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include/llvm/Option/OptParser.td + ${TOOL_llvm-tblgen_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14 + COMMAND + ${TOOL_llvm-tblgen_bin} + -gen-opt-parser-defs + -I + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer + -Iinclude + -I${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/include + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.td + --write-if-changed + -o + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc + -d + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/tools/llvm-symbolizer/Opts.inc.d +) +if(NOT CMAKE_CROSSCOMPILING) + add_dependencies(libs-llvm14-include + llvm-tblgen +) +endif() diff --git a/contrib/libs/llvm14/lib/Analysis/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Analysis/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..d777403df808 --- /dev/null +++ b/contrib/libs/llvm14/lib/Analysis/CMakeLists.darwin-arm64.txt @@ -0,0 +1,144 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Analysis) +target_compile_options(llvm14-lib-Analysis PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Analysis PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis +) +target_link_libraries(llvm14-lib-Analysis PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + llvm14-lib-IR + llvm14-lib-Object + llvm14-lib-ProfileData + llvm14-lib-Support +) +target_sources(llvm14-lib-Analysis PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AliasAnalysisEvaluator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AliasAnalysisSummary.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AliasSetTracker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Analysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AssumeBundleQueries.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AssumptionCache.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/BasicAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/BlockFrequencyInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/BlockFrequencyInfoImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/BranchProbabilityInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CFGPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CFLAndersAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CFLSteensAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CGSCCPassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CallGraph.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CallGraphSCCPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CallPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CaptureTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CmpInstAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CodeMetrics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ConstantFolding.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ConstraintSystem.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CostModel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CycleAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DDG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DDGPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Delinearization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DemandedBits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DependenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DependenceGraphBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DevelopmentModeInlineAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DivergenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DomPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DomTreeUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DominanceFrontier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/EHPersonalities.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/FunctionPropertiesAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/GlobalsModRef.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/GuardUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/HeatUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IRSimilarityIdentifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IVDescriptors.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IVUsers.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ImportedFunctionsInliningStatistics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IndirectCallPromotionAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InlineAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InlineCost.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InlineSizeEstimatorAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InstCount.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InstructionPrecedenceTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InstructionSimplify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Interval.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IntervalPartition.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LazyBlockFrequencyInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LazyBranchProbabilityInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LazyCallGraph.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LazyValueInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LegacyDivergenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Lint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Loads.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopAccessAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopAnalysisManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopCacheAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopNestAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopUnrollAnalyzer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MLInlineAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemDepPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemDerefPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemoryBuiltins.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemoryDependenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemoryLocation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemorySSA.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemorySSAUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ModelUnderTrainingRunner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ModuleDebugInfoPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ModuleSummaryAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MustExecute.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/NoInferenceModelRunner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ObjCARCAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ObjCARCAnalysisUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ObjCARCInstKind.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/OptimizationRemarkEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/OverflowInstAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/PHITransAddr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/PhiValues.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/PostDominators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ProfileSummaryInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/PtrUseVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/RegionInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/RegionPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/RegionPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ReplayInlineAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScalarEvolution.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScalarEvolutionAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScalarEvolutionDivision.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScalarEvolutionNormalization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScopedNoAliasAA.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/StackLifetime.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/StackSafetyAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/SyncDependenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/SyntheticCountsUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TFUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TargetLibraryInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TargetTransformInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Trace.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TypeBasedAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TypeMetadataUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/VFABIDemangling.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ValueLattice.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ValueLatticeUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ValueTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/VectorUtils.cpp +) diff --git a/contrib/libs/llvm14/lib/Analysis/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Analysis/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..d777403df808 --- /dev/null +++ b/contrib/libs/llvm14/lib/Analysis/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,144 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Analysis) +target_compile_options(llvm14-lib-Analysis PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Analysis PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis +) +target_link_libraries(llvm14-lib-Analysis PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + llvm14-lib-IR + llvm14-lib-Object + llvm14-lib-ProfileData + llvm14-lib-Support +) +target_sources(llvm14-lib-Analysis PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AliasAnalysisEvaluator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AliasAnalysisSummary.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AliasSetTracker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Analysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AssumeBundleQueries.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AssumptionCache.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/BasicAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/BlockFrequencyInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/BlockFrequencyInfoImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/BranchProbabilityInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CFGPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CFLAndersAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CFLSteensAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CGSCCPassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CallGraph.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CallGraphSCCPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CallPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CaptureTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CmpInstAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CodeMetrics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ConstantFolding.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ConstraintSystem.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CostModel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CycleAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DDG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DDGPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Delinearization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DemandedBits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DependenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DependenceGraphBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DevelopmentModeInlineAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DivergenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DomPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DomTreeUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DominanceFrontier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/EHPersonalities.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/FunctionPropertiesAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/GlobalsModRef.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/GuardUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/HeatUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IRSimilarityIdentifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IVDescriptors.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IVUsers.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ImportedFunctionsInliningStatistics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IndirectCallPromotionAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InlineAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InlineCost.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InlineSizeEstimatorAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InstCount.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InstructionPrecedenceTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InstructionSimplify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Interval.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IntervalPartition.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LazyBlockFrequencyInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LazyBranchProbabilityInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LazyCallGraph.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LazyValueInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LegacyDivergenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Lint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Loads.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopAccessAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopAnalysisManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopCacheAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopNestAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopUnrollAnalyzer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MLInlineAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemDepPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemDerefPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemoryBuiltins.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemoryDependenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemoryLocation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemorySSA.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemorySSAUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ModelUnderTrainingRunner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ModuleDebugInfoPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ModuleSummaryAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MustExecute.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/NoInferenceModelRunner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ObjCARCAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ObjCARCAnalysisUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ObjCARCInstKind.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/OptimizationRemarkEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/OverflowInstAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/PHITransAddr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/PhiValues.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/PostDominators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ProfileSummaryInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/PtrUseVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/RegionInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/RegionPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/RegionPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ReplayInlineAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScalarEvolution.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScalarEvolutionAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScalarEvolutionDivision.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScalarEvolutionNormalization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScopedNoAliasAA.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/StackLifetime.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/StackSafetyAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/SyncDependenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/SyntheticCountsUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TFUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TargetLibraryInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TargetTransformInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Trace.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TypeBasedAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TypeMetadataUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/VFABIDemangling.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ValueLattice.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ValueLatticeUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ValueTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/VectorUtils.cpp +) diff --git a/contrib/libs/llvm14/lib/Analysis/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Analysis/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..d9bdffe85a3c --- /dev/null +++ b/contrib/libs/llvm14/lib/Analysis/CMakeLists.linux-aarch64.txt @@ -0,0 +1,145 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Analysis) +target_compile_options(llvm14-lib-Analysis PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Analysis PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis +) +target_link_libraries(llvm14-lib-Analysis PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + llvm14-lib-IR + llvm14-lib-Object + llvm14-lib-ProfileData + llvm14-lib-Support +) +target_sources(llvm14-lib-Analysis PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AliasAnalysisEvaluator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AliasAnalysisSummary.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AliasSetTracker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Analysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AssumeBundleQueries.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AssumptionCache.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/BasicAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/BlockFrequencyInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/BlockFrequencyInfoImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/BranchProbabilityInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CFGPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CFLAndersAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CFLSteensAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CGSCCPassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CallGraph.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CallGraphSCCPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CallPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CaptureTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CmpInstAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CodeMetrics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ConstantFolding.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ConstraintSystem.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CostModel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CycleAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DDG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DDGPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Delinearization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DemandedBits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DependenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DependenceGraphBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DevelopmentModeInlineAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DivergenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DomPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DomTreeUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DominanceFrontier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/EHPersonalities.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/FunctionPropertiesAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/GlobalsModRef.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/GuardUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/HeatUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IRSimilarityIdentifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IVDescriptors.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IVUsers.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ImportedFunctionsInliningStatistics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IndirectCallPromotionAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InlineAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InlineCost.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InlineSizeEstimatorAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InstCount.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InstructionPrecedenceTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InstructionSimplify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Interval.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IntervalPartition.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LazyBlockFrequencyInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LazyBranchProbabilityInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LazyCallGraph.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LazyValueInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LegacyDivergenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Lint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Loads.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopAccessAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopAnalysisManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopCacheAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopNestAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopUnrollAnalyzer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MLInlineAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemDepPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemDerefPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemoryBuiltins.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemoryDependenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemoryLocation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemorySSA.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemorySSAUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ModelUnderTrainingRunner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ModuleDebugInfoPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ModuleSummaryAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MustExecute.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/NoInferenceModelRunner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ObjCARCAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ObjCARCAnalysisUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ObjCARCInstKind.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/OptimizationRemarkEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/OverflowInstAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/PHITransAddr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/PhiValues.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/PostDominators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ProfileSummaryInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/PtrUseVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/RegionInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/RegionPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/RegionPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ReplayInlineAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScalarEvolution.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScalarEvolutionAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScalarEvolutionDivision.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScalarEvolutionNormalization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScopedNoAliasAA.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/StackLifetime.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/StackSafetyAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/SyncDependenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/SyntheticCountsUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TFUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TargetLibraryInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TargetTransformInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Trace.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TypeBasedAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TypeMetadataUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/VFABIDemangling.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ValueLattice.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ValueLatticeUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ValueTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/VectorUtils.cpp +) diff --git a/contrib/libs/llvm14/lib/Analysis/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Analysis/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..d9bdffe85a3c --- /dev/null +++ b/contrib/libs/llvm14/lib/Analysis/CMakeLists.linux-x86_64.txt @@ -0,0 +1,145 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Analysis) +target_compile_options(llvm14-lib-Analysis PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Analysis PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis +) +target_link_libraries(llvm14-lib-Analysis PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + llvm14-lib-IR + llvm14-lib-Object + llvm14-lib-ProfileData + llvm14-lib-Support +) +target_sources(llvm14-lib-Analysis PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AliasAnalysisEvaluator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AliasAnalysisSummary.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AliasSetTracker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Analysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AssumeBundleQueries.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AssumptionCache.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/BasicAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/BlockFrequencyInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/BlockFrequencyInfoImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/BranchProbabilityInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CFGPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CFLAndersAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CFLSteensAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CGSCCPassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CallGraph.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CallGraphSCCPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CallPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CaptureTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CmpInstAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CodeMetrics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ConstantFolding.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ConstraintSystem.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CostModel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CycleAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DDG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DDGPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Delinearization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DemandedBits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DependenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DependenceGraphBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DevelopmentModeInlineAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DivergenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DomPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DomTreeUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DominanceFrontier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/EHPersonalities.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/FunctionPropertiesAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/GlobalsModRef.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/GuardUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/HeatUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IRSimilarityIdentifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IVDescriptors.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IVUsers.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ImportedFunctionsInliningStatistics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IndirectCallPromotionAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InlineAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InlineCost.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InlineSizeEstimatorAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InstCount.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InstructionPrecedenceTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InstructionSimplify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Interval.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IntervalPartition.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LazyBlockFrequencyInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LazyBranchProbabilityInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LazyCallGraph.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LazyValueInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LegacyDivergenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Lint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Loads.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopAccessAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopAnalysisManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopCacheAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopNestAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopUnrollAnalyzer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MLInlineAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemDepPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemDerefPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemoryBuiltins.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemoryDependenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemoryLocation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemorySSA.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemorySSAUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ModelUnderTrainingRunner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ModuleDebugInfoPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ModuleSummaryAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MustExecute.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/NoInferenceModelRunner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ObjCARCAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ObjCARCAnalysisUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ObjCARCInstKind.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/OptimizationRemarkEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/OverflowInstAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/PHITransAddr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/PhiValues.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/PostDominators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ProfileSummaryInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/PtrUseVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/RegionInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/RegionPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/RegionPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ReplayInlineAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScalarEvolution.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScalarEvolutionAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScalarEvolutionDivision.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScalarEvolutionNormalization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScopedNoAliasAA.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/StackLifetime.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/StackSafetyAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/SyncDependenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/SyntheticCountsUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TFUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TargetLibraryInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TargetTransformInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Trace.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TypeBasedAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TypeMetadataUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/VFABIDemangling.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ValueLattice.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ValueLatticeUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ValueTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/VectorUtils.cpp +) diff --git a/contrib/libs/llvm14/lib/Analysis/CMakeLists.txt b/contrib/libs/llvm14/lib/Analysis/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Analysis/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Analysis/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Analysis/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..d777403df808 --- /dev/null +++ b/contrib/libs/llvm14/lib/Analysis/CMakeLists.windows-x86_64.txt @@ -0,0 +1,144 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Analysis) +target_compile_options(llvm14-lib-Analysis PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Analysis PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis +) +target_link_libraries(llvm14-lib-Analysis PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + llvm14-lib-IR + llvm14-lib-Object + llvm14-lib-ProfileData + llvm14-lib-Support +) +target_sources(llvm14-lib-Analysis PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AliasAnalysisEvaluator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AliasAnalysisSummary.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AliasSetTracker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Analysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AssumeBundleQueries.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/AssumptionCache.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/BasicAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/BlockFrequencyInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/BlockFrequencyInfoImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/BranchProbabilityInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CFGPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CFLAndersAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CFLSteensAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CGSCCPassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CallGraph.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CallGraphSCCPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CallPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CaptureTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CmpInstAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CodeMetrics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ConstantFolding.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ConstraintSystem.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CostModel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/CycleAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DDG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DDGPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Delinearization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DemandedBits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DependenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DependenceGraphBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DevelopmentModeInlineAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DivergenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DomPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DomTreeUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/DominanceFrontier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/EHPersonalities.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/FunctionPropertiesAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/GlobalsModRef.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/GuardUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/HeatUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IRSimilarityIdentifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IVDescriptors.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IVUsers.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ImportedFunctionsInliningStatistics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IndirectCallPromotionAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InlineAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InlineCost.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InlineSizeEstimatorAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InstCount.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InstructionPrecedenceTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/InstructionSimplify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Interval.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/IntervalPartition.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LazyBlockFrequencyInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LazyBranchProbabilityInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LazyCallGraph.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LazyValueInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LegacyDivergenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Lint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Loads.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopAccessAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopAnalysisManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopCacheAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopNestAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/LoopUnrollAnalyzer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MLInlineAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemDepPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemDerefPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemoryBuiltins.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemoryDependenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemoryLocation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemorySSA.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MemorySSAUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ModelUnderTrainingRunner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ModuleDebugInfoPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ModuleSummaryAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/MustExecute.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/NoInferenceModelRunner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ObjCARCAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ObjCARCAnalysisUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ObjCARCInstKind.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/OptimizationRemarkEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/OverflowInstAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/PHITransAddr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/PhiValues.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/PostDominators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ProfileSummaryInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/PtrUseVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/RegionInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/RegionPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/RegionPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ReplayInlineAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScalarEvolution.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScalarEvolutionAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScalarEvolutionDivision.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScalarEvolutionNormalization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ScopedNoAliasAA.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/StackLifetime.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/StackSafetyAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/SyncDependenceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/SyntheticCountsUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TFUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TargetLibraryInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TargetTransformInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/Trace.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TypeBasedAliasAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/TypeMetadataUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/VFABIDemangling.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ValueLattice.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ValueLatticeUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/ValueTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Analysis/VectorUtils.cpp +) diff --git a/contrib/libs/llvm14/lib/AsmParser/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/AsmParser/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..ad1f7a852750 --- /dev/null +++ b/contrib/libs/llvm14/lib/AsmParser/CMakeLists.darwin-arm64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-AsmParser) +target_compile_options(llvm14-lib-AsmParser PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-AsmParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/AsmParser +) +target_link_libraries(llvm14-lib-AsmParser PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(llvm14-lib-AsmParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/AsmParser/LLLexer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/AsmParser/LLParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/AsmParser/Parser.cpp +) diff --git a/contrib/libs/llvm14/lib/AsmParser/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/AsmParser/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..ad1f7a852750 --- /dev/null +++ b/contrib/libs/llvm14/lib/AsmParser/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-AsmParser) +target_compile_options(llvm14-lib-AsmParser PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-AsmParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/AsmParser +) +target_link_libraries(llvm14-lib-AsmParser PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(llvm14-lib-AsmParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/AsmParser/LLLexer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/AsmParser/LLParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/AsmParser/Parser.cpp +) diff --git a/contrib/libs/llvm14/lib/AsmParser/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/AsmParser/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..31d8b865b626 --- /dev/null +++ b/contrib/libs/llvm14/lib/AsmParser/CMakeLists.linux-aarch64.txt @@ -0,0 +1,30 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-AsmParser) +target_compile_options(llvm14-lib-AsmParser PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-AsmParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/AsmParser +) +target_link_libraries(llvm14-lib-AsmParser PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(llvm14-lib-AsmParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/AsmParser/LLLexer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/AsmParser/LLParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/AsmParser/Parser.cpp +) diff --git a/contrib/libs/llvm14/lib/AsmParser/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/AsmParser/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..31d8b865b626 --- /dev/null +++ b/contrib/libs/llvm14/lib/AsmParser/CMakeLists.linux-x86_64.txt @@ -0,0 +1,30 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-AsmParser) +target_compile_options(llvm14-lib-AsmParser PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-AsmParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/AsmParser +) +target_link_libraries(llvm14-lib-AsmParser PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(llvm14-lib-AsmParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/AsmParser/LLLexer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/AsmParser/LLParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/AsmParser/Parser.cpp +) diff --git a/contrib/libs/llvm14/lib/AsmParser/CMakeLists.txt b/contrib/libs/llvm14/lib/AsmParser/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/AsmParser/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/AsmParser/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/AsmParser/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..ad1f7a852750 --- /dev/null +++ b/contrib/libs/llvm14/lib/AsmParser/CMakeLists.windows-x86_64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-AsmParser) +target_compile_options(llvm14-lib-AsmParser PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-AsmParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/AsmParser +) +target_link_libraries(llvm14-lib-AsmParser PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(llvm14-lib-AsmParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/AsmParser/LLLexer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/AsmParser/LLParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/AsmParser/Parser.cpp +) diff --git a/contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..f4032add327f --- /dev/null +++ b/contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.darwin-arm64.txt @@ -0,0 +1,36 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-BinaryFormat) +target_compile_options(llvm14-lib-BinaryFormat PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-BinaryFormat PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat +) +target_link_libraries(llvm14-lib-BinaryFormat PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(llvm14-lib-BinaryFormat PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/AMDGPUMetadataVerifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/COFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/Dwarf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/ELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MachO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/Magic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/Minidump.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MsgPackDocument.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MsgPackDocumentYAML.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MsgPackReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MsgPackWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/Wasm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/XCOFF.cpp +) diff --git a/contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..f4032add327f --- /dev/null +++ b/contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,36 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-BinaryFormat) +target_compile_options(llvm14-lib-BinaryFormat PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-BinaryFormat PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat +) +target_link_libraries(llvm14-lib-BinaryFormat PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(llvm14-lib-BinaryFormat PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/AMDGPUMetadataVerifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/COFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/Dwarf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/ELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MachO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/Magic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/Minidump.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MsgPackDocument.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MsgPackDocumentYAML.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MsgPackReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MsgPackWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/Wasm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/XCOFF.cpp +) diff --git a/contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..58818499537f --- /dev/null +++ b/contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.linux-aarch64.txt @@ -0,0 +1,37 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-BinaryFormat) +target_compile_options(llvm14-lib-BinaryFormat PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-BinaryFormat PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat +) +target_link_libraries(llvm14-lib-BinaryFormat PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(llvm14-lib-BinaryFormat PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/AMDGPUMetadataVerifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/COFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/Dwarf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/ELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MachO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/Magic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/Minidump.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MsgPackDocument.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MsgPackDocumentYAML.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MsgPackReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MsgPackWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/Wasm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/XCOFF.cpp +) diff --git a/contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..58818499537f --- /dev/null +++ b/contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.linux-x86_64.txt @@ -0,0 +1,37 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-BinaryFormat) +target_compile_options(llvm14-lib-BinaryFormat PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-BinaryFormat PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat +) +target_link_libraries(llvm14-lib-BinaryFormat PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(llvm14-lib-BinaryFormat PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/AMDGPUMetadataVerifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/COFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/Dwarf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/ELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MachO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/Magic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/Minidump.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MsgPackDocument.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MsgPackDocumentYAML.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MsgPackReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MsgPackWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/Wasm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/XCOFF.cpp +) diff --git a/contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.txt b/contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..f4032add327f --- /dev/null +++ b/contrib/libs/llvm14/lib/BinaryFormat/CMakeLists.windows-x86_64.txt @@ -0,0 +1,36 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-BinaryFormat) +target_compile_options(llvm14-lib-BinaryFormat PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-BinaryFormat PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat +) +target_link_libraries(llvm14-lib-BinaryFormat PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(llvm14-lib-BinaryFormat PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/AMDGPUMetadataVerifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/COFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/Dwarf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/ELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MachO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/Magic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/Minidump.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MsgPackDocument.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MsgPackDocumentYAML.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MsgPackReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/MsgPackWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/Wasm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/BinaryFormat/XCOFF.cpp +) diff --git a/contrib/libs/llvm14/lib/Bitcode/CMakeLists.txt b/contrib/libs/llvm14/lib/Bitcode/CMakeLists.txt new file mode 100644 index 000000000000..9099f95be414 --- /dev/null +++ b/contrib/libs/llvm14/lib/Bitcode/CMakeLists.txt @@ -0,0 +1,10 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(Reader) +add_subdirectory(Writer) diff --git a/contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..b1e64bce5170 --- /dev/null +++ b/contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.darwin-arm64.txt @@ -0,0 +1,31 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Bitcode-Reader) +target_compile_options(lib-Bitcode-Reader PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Bitcode-Reader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader +) +target_link_libraries(lib-Bitcode-Reader PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + lib-Bitstream-Reader + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(lib-Bitcode-Reader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/BitReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/BitcodeAnalyzer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/BitcodeReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/MetadataLoader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/ValueList.cpp +) diff --git a/contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..b1e64bce5170 --- /dev/null +++ b/contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,31 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Bitcode-Reader) +target_compile_options(lib-Bitcode-Reader PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Bitcode-Reader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader +) +target_link_libraries(lib-Bitcode-Reader PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + lib-Bitstream-Reader + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(lib-Bitcode-Reader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/BitReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/BitcodeAnalyzer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/BitcodeReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/MetadataLoader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/ValueList.cpp +) diff --git a/contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..d277e4f7cfb5 --- /dev/null +++ b/contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.linux-aarch64.txt @@ -0,0 +1,32 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Bitcode-Reader) +target_compile_options(lib-Bitcode-Reader PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Bitcode-Reader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader +) +target_link_libraries(lib-Bitcode-Reader PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + lib-Bitstream-Reader + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(lib-Bitcode-Reader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/BitReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/BitcodeAnalyzer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/BitcodeReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/MetadataLoader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/ValueList.cpp +) diff --git a/contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..d277e4f7cfb5 --- /dev/null +++ b/contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.linux-x86_64.txt @@ -0,0 +1,32 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Bitcode-Reader) +target_compile_options(lib-Bitcode-Reader PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Bitcode-Reader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader +) +target_link_libraries(lib-Bitcode-Reader PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + lib-Bitstream-Reader + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(lib-Bitcode-Reader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/BitReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/BitcodeAnalyzer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/BitcodeReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/MetadataLoader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/ValueList.cpp +) diff --git a/contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.txt b/contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..b1e64bce5170 --- /dev/null +++ b/contrib/libs/llvm14/lib/Bitcode/Reader/CMakeLists.windows-x86_64.txt @@ -0,0 +1,31 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Bitcode-Reader) +target_compile_options(lib-Bitcode-Reader PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Bitcode-Reader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader +) +target_link_libraries(lib-Bitcode-Reader PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + lib-Bitstream-Reader + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(lib-Bitcode-Reader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/BitReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/BitcodeAnalyzer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/BitcodeReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/MetadataLoader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Reader/ValueList.cpp +) diff --git a/contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..dd0158ded790 --- /dev/null +++ b/contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.darwin-arm64.txt @@ -0,0 +1,32 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Bitcode-Writer) +target_compile_options(lib-Bitcode-Writer PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Bitcode-Writer PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer +) +target_link_libraries(lib-Bitcode-Writer PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Object + llvm14-lib-Support +) +target_sources(lib-Bitcode-Writer PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer/BitWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer/BitcodeWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer/BitcodeWriterPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer/ValueEnumerator.cpp +) diff --git a/contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..dd0158ded790 --- /dev/null +++ b/contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,32 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Bitcode-Writer) +target_compile_options(lib-Bitcode-Writer PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Bitcode-Writer PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer +) +target_link_libraries(lib-Bitcode-Writer PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Object + llvm14-lib-Support +) +target_sources(lib-Bitcode-Writer PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer/BitWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer/BitcodeWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer/BitcodeWriterPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer/ValueEnumerator.cpp +) diff --git a/contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..3c09508990e5 --- /dev/null +++ b/contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.linux-aarch64.txt @@ -0,0 +1,33 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Bitcode-Writer) +target_compile_options(lib-Bitcode-Writer PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Bitcode-Writer PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer +) +target_link_libraries(lib-Bitcode-Writer PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Object + llvm14-lib-Support +) +target_sources(lib-Bitcode-Writer PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer/BitWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer/BitcodeWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer/BitcodeWriterPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer/ValueEnumerator.cpp +) diff --git a/contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..3c09508990e5 --- /dev/null +++ b/contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.linux-x86_64.txt @@ -0,0 +1,33 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Bitcode-Writer) +target_compile_options(lib-Bitcode-Writer PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Bitcode-Writer PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer +) +target_link_libraries(lib-Bitcode-Writer PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Object + llvm14-lib-Support +) +target_sources(lib-Bitcode-Writer PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer/BitWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer/BitcodeWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer/BitcodeWriterPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer/ValueEnumerator.cpp +) diff --git a/contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.txt b/contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..dd0158ded790 --- /dev/null +++ b/contrib/libs/llvm14/lib/Bitcode/Writer/CMakeLists.windows-x86_64.txt @@ -0,0 +1,32 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Bitcode-Writer) +target_compile_options(lib-Bitcode-Writer PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Bitcode-Writer PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer +) +target_link_libraries(lib-Bitcode-Writer PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Object + llvm14-lib-Support +) +target_sources(lib-Bitcode-Writer PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer/BitWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer/BitcodeWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer/BitcodeWriterPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitcode/Writer/ValueEnumerator.cpp +) diff --git a/library/cpp/clickhouse/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Bitstream/CMakeLists.txt similarity index 94% rename from library/cpp/clickhouse/CMakeLists.darwin-arm64.txt rename to contrib/libs/llvm14/lib/Bitstream/CMakeLists.txt index 7f79107ebc79..51e0986406af 100644 --- a/library/cpp/clickhouse/CMakeLists.darwin-arm64.txt +++ b/contrib/libs/llvm14/lib/Bitstream/CMakeLists.txt @@ -6,4 +6,4 @@ # original buildsystem will not be accepted. -add_subdirectory(client) +add_subdirectory(Reader) diff --git a/contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..6f018eb0a874 --- /dev/null +++ b/contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.darwin-arm64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Bitstream-Reader) +target_compile_options(lib-Bitstream-Reader PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Bitstream-Reader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitstream/Reader +) +target_link_libraries(lib-Bitstream-Reader PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(lib-Bitstream-Reader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitstream/Reader/BitstreamReader.cpp +) diff --git a/contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..6f018eb0a874 --- /dev/null +++ b/contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Bitstream-Reader) +target_compile_options(lib-Bitstream-Reader PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Bitstream-Reader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitstream/Reader +) +target_link_libraries(lib-Bitstream-Reader PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(lib-Bitstream-Reader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitstream/Reader/BitstreamReader.cpp +) diff --git a/contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..565ada21d6b4 --- /dev/null +++ b/contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.linux-aarch64.txt @@ -0,0 +1,25 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Bitstream-Reader) +target_compile_options(lib-Bitstream-Reader PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Bitstream-Reader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitstream/Reader +) +target_link_libraries(lib-Bitstream-Reader PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(lib-Bitstream-Reader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitstream/Reader/BitstreamReader.cpp +) diff --git a/contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..565ada21d6b4 --- /dev/null +++ b/contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.linux-x86_64.txt @@ -0,0 +1,25 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Bitstream-Reader) +target_compile_options(lib-Bitstream-Reader PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Bitstream-Reader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitstream/Reader +) +target_link_libraries(lib-Bitstream-Reader PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(lib-Bitstream-Reader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitstream/Reader/BitstreamReader.cpp +) diff --git a/contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.txt b/contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..6f018eb0a874 --- /dev/null +++ b/contrib/libs/llvm14/lib/Bitstream/Reader/CMakeLists.windows-x86_64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Bitstream-Reader) +target_compile_options(lib-Bitstream-Reader PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Bitstream-Reader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitstream/Reader +) +target_link_libraries(lib-Bitstream-Reader PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(lib-Bitstream-Reader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Bitstream/Reader/BitstreamReader.cpp +) diff --git a/contrib/libs/llvm14/lib/CMakeLists.txt b/contrib/libs/llvm14/lib/CMakeLists.txt new file mode 100644 index 000000000000..d6a1483fa0cc --- /dev/null +++ b/contrib/libs/llvm14/lib/CMakeLists.txt @@ -0,0 +1,30 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(Analysis) +add_subdirectory(AsmParser) +add_subdirectory(BinaryFormat) +add_subdirectory(Bitcode) +add_subdirectory(Bitstream) +add_subdirectory(CodeGen) +add_subdirectory(DebugInfo) +add_subdirectory(Demangle) +add_subdirectory(ExecutionEngine) +add_subdirectory(Frontend) +add_subdirectory(IR) +add_subdirectory(IRReader) +add_subdirectory(Linker) +add_subdirectory(MC) +add_subdirectory(Object) +add_subdirectory(ProfileData) +add_subdirectory(Remarks) +add_subdirectory(Support) +add_subdirectory(TableGen) +add_subdirectory(Target) +add_subdirectory(TextAPI) +add_subdirectory(Transforms) diff --git a/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..7a16593bf6ba --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.darwin-arm64.txt @@ -0,0 +1,62 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-CodeGen-AsmPrinter) +target_compile_options(lib-CodeGen-AsmPrinter PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-CodeGen-AsmPrinter PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter +) +target_link_libraries(lib-CodeGen-AsmPrinter PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-BinaryFormat + llvm14-lib-CodeGen + lib-DebugInfo-CodeView + lib-DebugInfo-DWARF + lib-DebugInfo-MSF + llvm14-lib-IR + llvm14-lib-MC + lib-MC-MCParser + llvm14-lib-Remarks + llvm14-lib-Support + llvm14-lib-Target +) +target_sources(lib-CodeGen-AsmPrinter PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AIXException.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/ARMException.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AccelTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AddressPool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AsmPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AsmPrinterDwarf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AsmPrinterInlineAsm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CodeViewDebug.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DIE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DIEHash.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DbgEntityHistoryCalculator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DebugHandlerBase.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DebugLocStream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfCFIException.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfCompileUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfDebug.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfExpression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfStringPool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/EHStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/ErlangGCPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/OcamlGCPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/PseudoProbePrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/WasmException.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/WinCFGuard.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/WinException.cpp +) diff --git a/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..7a16593bf6ba --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,62 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-CodeGen-AsmPrinter) +target_compile_options(lib-CodeGen-AsmPrinter PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-CodeGen-AsmPrinter PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter +) +target_link_libraries(lib-CodeGen-AsmPrinter PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-BinaryFormat + llvm14-lib-CodeGen + lib-DebugInfo-CodeView + lib-DebugInfo-DWARF + lib-DebugInfo-MSF + llvm14-lib-IR + llvm14-lib-MC + lib-MC-MCParser + llvm14-lib-Remarks + llvm14-lib-Support + llvm14-lib-Target +) +target_sources(lib-CodeGen-AsmPrinter PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AIXException.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/ARMException.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AccelTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AddressPool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AsmPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AsmPrinterDwarf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AsmPrinterInlineAsm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CodeViewDebug.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DIE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DIEHash.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DbgEntityHistoryCalculator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DebugHandlerBase.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DebugLocStream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfCFIException.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfCompileUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfDebug.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfExpression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfStringPool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/EHStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/ErlangGCPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/OcamlGCPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/PseudoProbePrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/WasmException.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/WinCFGuard.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/WinException.cpp +) diff --git a/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..32b55a36076e --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.linux-aarch64.txt @@ -0,0 +1,63 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-CodeGen-AsmPrinter) +target_compile_options(lib-CodeGen-AsmPrinter PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-CodeGen-AsmPrinter PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter +) +target_link_libraries(lib-CodeGen-AsmPrinter PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-BinaryFormat + llvm14-lib-CodeGen + lib-DebugInfo-CodeView + lib-DebugInfo-DWARF + lib-DebugInfo-MSF + llvm14-lib-IR + llvm14-lib-MC + lib-MC-MCParser + llvm14-lib-Remarks + llvm14-lib-Support + llvm14-lib-Target +) +target_sources(lib-CodeGen-AsmPrinter PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AIXException.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/ARMException.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AccelTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AddressPool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AsmPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AsmPrinterDwarf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AsmPrinterInlineAsm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CodeViewDebug.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DIE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DIEHash.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DbgEntityHistoryCalculator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DebugHandlerBase.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DebugLocStream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfCFIException.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfCompileUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfDebug.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfExpression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfStringPool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/EHStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/ErlangGCPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/OcamlGCPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/PseudoProbePrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/WasmException.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/WinCFGuard.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/WinException.cpp +) diff --git a/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..32b55a36076e --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.linux-x86_64.txt @@ -0,0 +1,63 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-CodeGen-AsmPrinter) +target_compile_options(lib-CodeGen-AsmPrinter PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-CodeGen-AsmPrinter PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter +) +target_link_libraries(lib-CodeGen-AsmPrinter PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-BinaryFormat + llvm14-lib-CodeGen + lib-DebugInfo-CodeView + lib-DebugInfo-DWARF + lib-DebugInfo-MSF + llvm14-lib-IR + llvm14-lib-MC + lib-MC-MCParser + llvm14-lib-Remarks + llvm14-lib-Support + llvm14-lib-Target +) +target_sources(lib-CodeGen-AsmPrinter PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AIXException.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/ARMException.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AccelTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AddressPool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AsmPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AsmPrinterDwarf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AsmPrinterInlineAsm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CodeViewDebug.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DIE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DIEHash.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DbgEntityHistoryCalculator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DebugHandlerBase.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DebugLocStream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfCFIException.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfCompileUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfDebug.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfExpression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfStringPool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/EHStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/ErlangGCPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/OcamlGCPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/PseudoProbePrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/WasmException.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/WinCFGuard.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/WinException.cpp +) diff --git a/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.txt b/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..7a16593bf6ba --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CMakeLists.windows-x86_64.txt @@ -0,0 +1,62 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-CodeGen-AsmPrinter) +target_compile_options(lib-CodeGen-AsmPrinter PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-CodeGen-AsmPrinter PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter +) +target_link_libraries(lib-CodeGen-AsmPrinter PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-BinaryFormat + llvm14-lib-CodeGen + lib-DebugInfo-CodeView + lib-DebugInfo-DWARF + lib-DebugInfo-MSF + llvm14-lib-IR + llvm14-lib-MC + lib-MC-MCParser + llvm14-lib-Remarks + llvm14-lib-Support + llvm14-lib-Target +) +target_sources(lib-CodeGen-AsmPrinter PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AIXException.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/ARMException.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AccelTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AddressPool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AsmPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AsmPrinterDwarf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/AsmPrinterInlineAsm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/CodeViewDebug.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DIE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DIEHash.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DbgEntityHistoryCalculator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DebugHandlerBase.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DebugLocStream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfCFIException.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfCompileUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfDebug.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfExpression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfStringPool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/DwarfUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/EHStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/ErlangGCPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/OcamlGCPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/PseudoProbePrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/WasmException.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/WinCFGuard.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AsmPrinter/WinException.cpp +) diff --git a/contrib/libs/llvm14/lib/CodeGen/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/CodeGen/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..70993ab3c5c6 --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/CMakeLists.darwin-arm64.txt @@ -0,0 +1,239 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(AsmPrinter) +add_subdirectory(GlobalISel) +add_subdirectory(SelectionDAG) + +add_library(llvm14-lib-CodeGen) +target_compile_options(llvm14-lib-CodeGen PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-CodeGen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen +) +target_link_libraries(llvm14-lib-CodeGen PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + lib-Bitcode-Reader + lib-Bitcode-Writer + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-ProfileData + llvm14-lib-Support + llvm14-lib-Target + lib-Transforms-Scalar + lib-Transforms-Utils +) +target_sources(llvm14-lib-CodeGen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AggressiveAntiDepBreaker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AllocationOrder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/Analysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AtomicExpandPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BasicBlockSections.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BasicTargetTransformInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BranchFolding.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BranchRelaxation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BreakFalseDeps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CFGuardLongjmp.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CFIInstrInserter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CalcSpillWeights.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CallingConvLower.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CodeGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CodeGenCommonISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CodeGenPassBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CodeGenPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CommandFlags.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CriticalAntiDepBreaker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/DFAPacketizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/DeadMachineInstructionElim.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/DetectDeadLanes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/DwarfEHPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/EHContGuardCatchret.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/EarlyIfConversion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/EdgeBundles.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExecutionDomainFix.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExpandMemCmp.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExpandPostRAPseudos.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExpandReductions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExpandVectorPredication.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FEntryInserter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FaultMaps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FinalizeISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FixupStatepointCallerSaved.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FuncletLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GCMetadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GCMetadataPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GCRootLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalMerge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/HardwareLoops.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/IfConversion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ImplicitNullChecks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/IndirectBrExpandPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/InlineSpiller.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/InterferenceCache.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/InterleavedAccessPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/InterleavedLoadCombinePass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/IntrinsicLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LLVMTargetMachine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LatencyPriorityQueue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LazyMachineBlockFrequencyInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LexicalScopes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveDebugValues/InstrRefBasedImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveDebugValues/LiveDebugValues.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveDebugValues/VarLocBasedImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveDebugVariables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveInterval.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveIntervalCalc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveIntervalUnion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveIntervals.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LivePhysRegs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRangeCalc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRangeEdit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRangeShrink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRegMatrix.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRegUnits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveStacks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveVariables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LocalStackSlotAllocation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LoopTraversal.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LowLevelType.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LowerEmuTLS.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MBFIWrapper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRCanonicalizerPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRFSDiscriminator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRNamerPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRPrintingPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRSampleProfile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRVRegNamerUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRYamlMapping.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MLRegallocEvictAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineBasicBlock.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineBlockFrequencyInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineBlockPlacement.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineBranchProbabilityInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCSE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCheckDebugify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCombiner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCopyPropagation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCycleAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineDebugify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineDominanceFrontier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineDominators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFrameInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFunctionPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFunctionPrinterPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFunctionSplitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineInstr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineInstrBundle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineLICM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineLoopInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineLoopUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineModuleInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineModuleInfoImpls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineModuleSlotTracker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineOperand.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineOptimizationRemarkEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineOutliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachinePassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachinePipeliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachinePostDominators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineRegionInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineRegisterInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineSSAContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineSSAUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineScheduler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineSink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineSizeOpts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineStableHash.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineStripDebug.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineTraceMetrics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineVerifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MacroFusion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ModuloSchedule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MultiHazardRecognizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/NonRelocatableStringpool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/OptimizePHIs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PHIElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PHIEliminationUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ParallelCG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PatchableFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PeepholeOptimizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PostRAHazardRecognizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PostRASchedulerList.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PreISelIntrinsicLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ProcessImplicitDefs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PrologEpilogInserter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PseudoProbeInserter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PseudoSourceValue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RDFGraph.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RDFLiveness.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RDFRegisters.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ReachingDefAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocBase.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocBasic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocEvictionAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocFast.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocGreedy.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocPBQP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocScore.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegUsageInfoCollector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegUsageInfoPropagate.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterClassInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterCoalescer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterPressure.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterScavenging.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterUsageInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RemoveRedundantDebugValues.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RenameIndependentSubregs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ReplaceWithVeclib.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ResetMachineFunctionPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SafeStack.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SafeStackLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ScheduleDAG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ScheduleDAGInstrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ScheduleDAGPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ScoreboardHazardRecognizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ShadowStackGCLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ShrinkWrap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SjLjEHPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SlotIndexes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SpillPlacement.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SplitKit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackColoring.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackMapLivenessAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackMaps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackProtector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackSlotColoring.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SwiftErrorValueTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SwitchLoweringUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TailDuplication.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TailDuplicator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetFrameLoweringImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetInstrInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetLoweringBase.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetLoweringObjectFileImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetOptionsImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetPassConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetRegisterInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetSchedule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetSubtargetInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TwoAddressInstructionPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TypePromotion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/UnreachableBlockElim.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/VLIWMachineScheduler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ValueTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/VirtRegMap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/WasmEHPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/WinEHPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/XRayInstrumentation.cpp +) diff --git a/contrib/libs/llvm14/lib/CodeGen/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/CodeGen/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..70993ab3c5c6 --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,239 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(AsmPrinter) +add_subdirectory(GlobalISel) +add_subdirectory(SelectionDAG) + +add_library(llvm14-lib-CodeGen) +target_compile_options(llvm14-lib-CodeGen PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-CodeGen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen +) +target_link_libraries(llvm14-lib-CodeGen PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + lib-Bitcode-Reader + lib-Bitcode-Writer + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-ProfileData + llvm14-lib-Support + llvm14-lib-Target + lib-Transforms-Scalar + lib-Transforms-Utils +) +target_sources(llvm14-lib-CodeGen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AggressiveAntiDepBreaker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AllocationOrder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/Analysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AtomicExpandPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BasicBlockSections.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BasicTargetTransformInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BranchFolding.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BranchRelaxation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BreakFalseDeps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CFGuardLongjmp.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CFIInstrInserter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CalcSpillWeights.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CallingConvLower.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CodeGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CodeGenCommonISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CodeGenPassBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CodeGenPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CommandFlags.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CriticalAntiDepBreaker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/DFAPacketizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/DeadMachineInstructionElim.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/DetectDeadLanes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/DwarfEHPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/EHContGuardCatchret.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/EarlyIfConversion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/EdgeBundles.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExecutionDomainFix.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExpandMemCmp.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExpandPostRAPseudos.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExpandReductions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExpandVectorPredication.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FEntryInserter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FaultMaps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FinalizeISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FixupStatepointCallerSaved.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FuncletLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GCMetadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GCMetadataPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GCRootLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalMerge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/HardwareLoops.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/IfConversion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ImplicitNullChecks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/IndirectBrExpandPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/InlineSpiller.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/InterferenceCache.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/InterleavedAccessPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/InterleavedLoadCombinePass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/IntrinsicLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LLVMTargetMachine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LatencyPriorityQueue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LazyMachineBlockFrequencyInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LexicalScopes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveDebugValues/InstrRefBasedImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveDebugValues/LiveDebugValues.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveDebugValues/VarLocBasedImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveDebugVariables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveInterval.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveIntervalCalc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveIntervalUnion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveIntervals.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LivePhysRegs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRangeCalc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRangeEdit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRangeShrink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRegMatrix.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRegUnits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveStacks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveVariables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LocalStackSlotAllocation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LoopTraversal.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LowLevelType.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LowerEmuTLS.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MBFIWrapper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRCanonicalizerPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRFSDiscriminator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRNamerPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRPrintingPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRSampleProfile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRVRegNamerUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRYamlMapping.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MLRegallocEvictAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineBasicBlock.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineBlockFrequencyInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineBlockPlacement.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineBranchProbabilityInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCSE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCheckDebugify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCombiner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCopyPropagation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCycleAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineDebugify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineDominanceFrontier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineDominators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFrameInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFunctionPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFunctionPrinterPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFunctionSplitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineInstr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineInstrBundle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineLICM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineLoopInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineLoopUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineModuleInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineModuleInfoImpls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineModuleSlotTracker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineOperand.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineOptimizationRemarkEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineOutliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachinePassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachinePipeliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachinePostDominators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineRegionInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineRegisterInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineSSAContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineSSAUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineScheduler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineSink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineSizeOpts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineStableHash.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineStripDebug.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineTraceMetrics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineVerifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MacroFusion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ModuloSchedule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MultiHazardRecognizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/NonRelocatableStringpool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/OptimizePHIs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PHIElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PHIEliminationUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ParallelCG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PatchableFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PeepholeOptimizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PostRAHazardRecognizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PostRASchedulerList.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PreISelIntrinsicLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ProcessImplicitDefs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PrologEpilogInserter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PseudoProbeInserter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PseudoSourceValue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RDFGraph.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RDFLiveness.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RDFRegisters.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ReachingDefAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocBase.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocBasic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocEvictionAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocFast.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocGreedy.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocPBQP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocScore.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegUsageInfoCollector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegUsageInfoPropagate.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterClassInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterCoalescer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterPressure.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterScavenging.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterUsageInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RemoveRedundantDebugValues.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RenameIndependentSubregs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ReplaceWithVeclib.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ResetMachineFunctionPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SafeStack.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SafeStackLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ScheduleDAG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ScheduleDAGInstrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ScheduleDAGPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ScoreboardHazardRecognizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ShadowStackGCLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ShrinkWrap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SjLjEHPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SlotIndexes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SpillPlacement.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SplitKit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackColoring.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackMapLivenessAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackMaps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackProtector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackSlotColoring.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SwiftErrorValueTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SwitchLoweringUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TailDuplication.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TailDuplicator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetFrameLoweringImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetInstrInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetLoweringBase.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetLoweringObjectFileImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetOptionsImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetPassConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetRegisterInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetSchedule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetSubtargetInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TwoAddressInstructionPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TypePromotion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/UnreachableBlockElim.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/VLIWMachineScheduler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ValueTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/VirtRegMap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/WasmEHPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/WinEHPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/XRayInstrumentation.cpp +) diff --git a/contrib/libs/llvm14/lib/CodeGen/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/CodeGen/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..04e364985e23 --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/CMakeLists.linux-aarch64.txt @@ -0,0 +1,240 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(AsmPrinter) +add_subdirectory(GlobalISel) +add_subdirectory(SelectionDAG) + +add_library(llvm14-lib-CodeGen) +target_compile_options(llvm14-lib-CodeGen PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-CodeGen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen +) +target_link_libraries(llvm14-lib-CodeGen PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + lib-Bitcode-Reader + lib-Bitcode-Writer + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-ProfileData + llvm14-lib-Support + llvm14-lib-Target + lib-Transforms-Scalar + lib-Transforms-Utils +) +target_sources(llvm14-lib-CodeGen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AggressiveAntiDepBreaker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AllocationOrder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/Analysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AtomicExpandPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BasicBlockSections.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BasicTargetTransformInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BranchFolding.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BranchRelaxation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BreakFalseDeps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CFGuardLongjmp.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CFIInstrInserter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CalcSpillWeights.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CallingConvLower.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CodeGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CodeGenCommonISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CodeGenPassBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CodeGenPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CommandFlags.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CriticalAntiDepBreaker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/DFAPacketizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/DeadMachineInstructionElim.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/DetectDeadLanes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/DwarfEHPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/EHContGuardCatchret.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/EarlyIfConversion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/EdgeBundles.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExecutionDomainFix.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExpandMemCmp.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExpandPostRAPseudos.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExpandReductions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExpandVectorPredication.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FEntryInserter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FaultMaps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FinalizeISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FixupStatepointCallerSaved.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FuncletLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GCMetadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GCMetadataPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GCRootLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalMerge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/HardwareLoops.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/IfConversion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ImplicitNullChecks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/IndirectBrExpandPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/InlineSpiller.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/InterferenceCache.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/InterleavedAccessPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/InterleavedLoadCombinePass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/IntrinsicLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LLVMTargetMachine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LatencyPriorityQueue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LazyMachineBlockFrequencyInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LexicalScopes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveDebugValues/InstrRefBasedImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveDebugValues/LiveDebugValues.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveDebugValues/VarLocBasedImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveDebugVariables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveInterval.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveIntervalCalc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveIntervalUnion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveIntervals.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LivePhysRegs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRangeCalc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRangeEdit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRangeShrink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRegMatrix.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRegUnits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveStacks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveVariables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LocalStackSlotAllocation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LoopTraversal.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LowLevelType.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LowerEmuTLS.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MBFIWrapper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRCanonicalizerPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRFSDiscriminator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRNamerPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRPrintingPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRSampleProfile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRVRegNamerUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRYamlMapping.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MLRegallocEvictAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineBasicBlock.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineBlockFrequencyInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineBlockPlacement.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineBranchProbabilityInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCSE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCheckDebugify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCombiner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCopyPropagation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCycleAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineDebugify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineDominanceFrontier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineDominators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFrameInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFunctionPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFunctionPrinterPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFunctionSplitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineInstr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineInstrBundle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineLICM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineLoopInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineLoopUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineModuleInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineModuleInfoImpls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineModuleSlotTracker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineOperand.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineOptimizationRemarkEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineOutliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachinePassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachinePipeliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachinePostDominators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineRegionInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineRegisterInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineSSAContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineSSAUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineScheduler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineSink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineSizeOpts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineStableHash.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineStripDebug.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineTraceMetrics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineVerifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MacroFusion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ModuloSchedule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MultiHazardRecognizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/NonRelocatableStringpool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/OptimizePHIs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PHIElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PHIEliminationUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ParallelCG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PatchableFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PeepholeOptimizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PostRAHazardRecognizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PostRASchedulerList.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PreISelIntrinsicLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ProcessImplicitDefs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PrologEpilogInserter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PseudoProbeInserter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PseudoSourceValue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RDFGraph.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RDFLiveness.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RDFRegisters.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ReachingDefAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocBase.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocBasic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocEvictionAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocFast.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocGreedy.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocPBQP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocScore.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegUsageInfoCollector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegUsageInfoPropagate.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterClassInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterCoalescer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterPressure.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterScavenging.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterUsageInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RemoveRedundantDebugValues.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RenameIndependentSubregs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ReplaceWithVeclib.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ResetMachineFunctionPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SafeStack.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SafeStackLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ScheduleDAG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ScheduleDAGInstrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ScheduleDAGPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ScoreboardHazardRecognizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ShadowStackGCLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ShrinkWrap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SjLjEHPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SlotIndexes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SpillPlacement.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SplitKit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackColoring.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackMapLivenessAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackMaps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackProtector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackSlotColoring.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SwiftErrorValueTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SwitchLoweringUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TailDuplication.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TailDuplicator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetFrameLoweringImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetInstrInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetLoweringBase.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetLoweringObjectFileImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetOptionsImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetPassConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetRegisterInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetSchedule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetSubtargetInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TwoAddressInstructionPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TypePromotion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/UnreachableBlockElim.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/VLIWMachineScheduler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ValueTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/VirtRegMap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/WasmEHPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/WinEHPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/XRayInstrumentation.cpp +) diff --git a/contrib/libs/llvm14/lib/CodeGen/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/CodeGen/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..04e364985e23 --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/CMakeLists.linux-x86_64.txt @@ -0,0 +1,240 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(AsmPrinter) +add_subdirectory(GlobalISel) +add_subdirectory(SelectionDAG) + +add_library(llvm14-lib-CodeGen) +target_compile_options(llvm14-lib-CodeGen PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-CodeGen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen +) +target_link_libraries(llvm14-lib-CodeGen PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + lib-Bitcode-Reader + lib-Bitcode-Writer + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-ProfileData + llvm14-lib-Support + llvm14-lib-Target + lib-Transforms-Scalar + lib-Transforms-Utils +) +target_sources(llvm14-lib-CodeGen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AggressiveAntiDepBreaker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AllocationOrder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/Analysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AtomicExpandPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BasicBlockSections.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BasicTargetTransformInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BranchFolding.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BranchRelaxation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BreakFalseDeps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CFGuardLongjmp.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CFIInstrInserter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CalcSpillWeights.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CallingConvLower.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CodeGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CodeGenCommonISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CodeGenPassBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CodeGenPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CommandFlags.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CriticalAntiDepBreaker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/DFAPacketizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/DeadMachineInstructionElim.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/DetectDeadLanes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/DwarfEHPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/EHContGuardCatchret.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/EarlyIfConversion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/EdgeBundles.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExecutionDomainFix.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExpandMemCmp.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExpandPostRAPseudos.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExpandReductions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExpandVectorPredication.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FEntryInserter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FaultMaps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FinalizeISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FixupStatepointCallerSaved.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FuncletLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GCMetadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GCMetadataPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GCRootLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalMerge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/HardwareLoops.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/IfConversion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ImplicitNullChecks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/IndirectBrExpandPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/InlineSpiller.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/InterferenceCache.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/InterleavedAccessPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/InterleavedLoadCombinePass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/IntrinsicLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LLVMTargetMachine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LatencyPriorityQueue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LazyMachineBlockFrequencyInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LexicalScopes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveDebugValues/InstrRefBasedImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveDebugValues/LiveDebugValues.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveDebugValues/VarLocBasedImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveDebugVariables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveInterval.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveIntervalCalc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveIntervalUnion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveIntervals.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LivePhysRegs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRangeCalc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRangeEdit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRangeShrink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRegMatrix.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRegUnits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveStacks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveVariables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LocalStackSlotAllocation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LoopTraversal.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LowLevelType.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LowerEmuTLS.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MBFIWrapper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRCanonicalizerPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRFSDiscriminator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRNamerPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRPrintingPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRSampleProfile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRVRegNamerUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRYamlMapping.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MLRegallocEvictAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineBasicBlock.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineBlockFrequencyInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineBlockPlacement.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineBranchProbabilityInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCSE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCheckDebugify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCombiner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCopyPropagation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCycleAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineDebugify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineDominanceFrontier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineDominators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFrameInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFunctionPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFunctionPrinterPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFunctionSplitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineInstr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineInstrBundle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineLICM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineLoopInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineLoopUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineModuleInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineModuleInfoImpls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineModuleSlotTracker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineOperand.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineOptimizationRemarkEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineOutliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachinePassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachinePipeliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachinePostDominators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineRegionInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineRegisterInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineSSAContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineSSAUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineScheduler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineSink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineSizeOpts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineStableHash.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineStripDebug.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineTraceMetrics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineVerifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MacroFusion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ModuloSchedule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MultiHazardRecognizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/NonRelocatableStringpool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/OptimizePHIs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PHIElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PHIEliminationUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ParallelCG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PatchableFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PeepholeOptimizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PostRAHazardRecognizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PostRASchedulerList.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PreISelIntrinsicLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ProcessImplicitDefs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PrologEpilogInserter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PseudoProbeInserter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PseudoSourceValue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RDFGraph.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RDFLiveness.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RDFRegisters.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ReachingDefAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocBase.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocBasic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocEvictionAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocFast.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocGreedy.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocPBQP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocScore.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegUsageInfoCollector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegUsageInfoPropagate.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterClassInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterCoalescer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterPressure.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterScavenging.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterUsageInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RemoveRedundantDebugValues.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RenameIndependentSubregs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ReplaceWithVeclib.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ResetMachineFunctionPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SafeStack.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SafeStackLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ScheduleDAG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ScheduleDAGInstrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ScheduleDAGPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ScoreboardHazardRecognizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ShadowStackGCLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ShrinkWrap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SjLjEHPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SlotIndexes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SpillPlacement.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SplitKit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackColoring.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackMapLivenessAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackMaps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackProtector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackSlotColoring.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SwiftErrorValueTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SwitchLoweringUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TailDuplication.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TailDuplicator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetFrameLoweringImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetInstrInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetLoweringBase.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetLoweringObjectFileImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetOptionsImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetPassConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetRegisterInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetSchedule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetSubtargetInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TwoAddressInstructionPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TypePromotion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/UnreachableBlockElim.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/VLIWMachineScheduler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ValueTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/VirtRegMap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/WasmEHPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/WinEHPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/XRayInstrumentation.cpp +) diff --git a/contrib/libs/llvm14/lib/CodeGen/CMakeLists.txt b/contrib/libs/llvm14/lib/CodeGen/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/CodeGen/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/CodeGen/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..70993ab3c5c6 --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/CMakeLists.windows-x86_64.txt @@ -0,0 +1,239 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(AsmPrinter) +add_subdirectory(GlobalISel) +add_subdirectory(SelectionDAG) + +add_library(llvm14-lib-CodeGen) +target_compile_options(llvm14-lib-CodeGen PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-CodeGen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen +) +target_link_libraries(llvm14-lib-CodeGen PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + lib-Bitcode-Reader + lib-Bitcode-Writer + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-ProfileData + llvm14-lib-Support + llvm14-lib-Target + lib-Transforms-Scalar + lib-Transforms-Utils +) +target_sources(llvm14-lib-CodeGen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AggressiveAntiDepBreaker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AllocationOrder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/Analysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/AtomicExpandPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BasicBlockSections.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BasicTargetTransformInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BranchFolding.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BranchRelaxation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/BreakFalseDeps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CFGuardLongjmp.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CFIInstrInserter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CalcSpillWeights.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CallingConvLower.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CodeGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CodeGenCommonISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CodeGenPassBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CodeGenPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CommandFlags.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/CriticalAntiDepBreaker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/DFAPacketizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/DeadMachineInstructionElim.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/DetectDeadLanes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/DwarfEHPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/EHContGuardCatchret.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/EarlyIfConversion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/EdgeBundles.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExecutionDomainFix.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExpandMemCmp.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExpandPostRAPseudos.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExpandReductions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ExpandVectorPredication.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FEntryInserter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FaultMaps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FinalizeISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FixupStatepointCallerSaved.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/FuncletLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GCMetadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GCMetadataPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GCRootLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalMerge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/HardwareLoops.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/IfConversion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ImplicitNullChecks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/IndirectBrExpandPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/InlineSpiller.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/InterferenceCache.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/InterleavedAccessPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/InterleavedLoadCombinePass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/IntrinsicLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LLVMTargetMachine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LatencyPriorityQueue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LazyMachineBlockFrequencyInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LexicalScopes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveDebugValues/InstrRefBasedImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveDebugValues/LiveDebugValues.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveDebugValues/VarLocBasedImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveDebugVariables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveInterval.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveIntervalCalc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveIntervalUnion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveIntervals.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LivePhysRegs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRangeCalc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRangeEdit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRangeShrink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRegMatrix.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveRegUnits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveStacks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LiveVariables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LocalStackSlotAllocation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LoopTraversal.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LowLevelType.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/LowerEmuTLS.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MBFIWrapper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRCanonicalizerPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRFSDiscriminator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRNamerPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRPrintingPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRSampleProfile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRVRegNamerUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MIRYamlMapping.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MLRegallocEvictAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineBasicBlock.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineBlockFrequencyInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineBlockPlacement.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineBranchProbabilityInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCSE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCheckDebugify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCombiner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCopyPropagation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineCycleAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineDebugify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineDominanceFrontier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineDominators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFrameInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFunctionPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFunctionPrinterPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineFunctionSplitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineInstr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineInstrBundle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineLICM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineLoopInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineLoopUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineModuleInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineModuleInfoImpls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineModuleSlotTracker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineOperand.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineOptimizationRemarkEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineOutliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachinePassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachinePipeliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachinePostDominators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineRegionInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineRegisterInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineSSAContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineSSAUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineScheduler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineSink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineSizeOpts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineStableHash.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineStripDebug.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineTraceMetrics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MachineVerifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MacroFusion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ModuloSchedule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/MultiHazardRecognizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/NonRelocatableStringpool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/OptimizePHIs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PHIElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PHIEliminationUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ParallelCG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PatchableFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PeepholeOptimizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PostRAHazardRecognizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PostRASchedulerList.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PreISelIntrinsicLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ProcessImplicitDefs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PrologEpilogInserter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PseudoProbeInserter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/PseudoSourceValue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RDFGraph.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RDFLiveness.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RDFRegisters.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ReachingDefAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocBase.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocBasic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocEvictionAdvisor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocFast.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocGreedy.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocPBQP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegAllocScore.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegUsageInfoCollector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegUsageInfoPropagate.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterClassInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterCoalescer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterPressure.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterScavenging.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RegisterUsageInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RemoveRedundantDebugValues.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/RenameIndependentSubregs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ReplaceWithVeclib.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ResetMachineFunctionPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SafeStack.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SafeStackLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ScheduleDAG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ScheduleDAGInstrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ScheduleDAGPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ScoreboardHazardRecognizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ShadowStackGCLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ShrinkWrap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SjLjEHPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SlotIndexes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SpillPlacement.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SplitKit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackColoring.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackMapLivenessAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackMaps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackProtector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/StackSlotColoring.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SwiftErrorValueTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SwitchLoweringUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TailDuplication.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TailDuplicator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetFrameLoweringImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetInstrInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetLoweringBase.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetLoweringObjectFileImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetOptionsImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetPassConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetRegisterInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetSchedule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TargetSubtargetInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TwoAddressInstructionPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/TypePromotion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/UnreachableBlockElim.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/VLIWMachineScheduler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/ValueTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/VirtRegMap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/WasmEHPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/WinEHPrepare.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/XRayInstrumentation.cpp +) diff --git a/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..514c2baa2f58 --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.darwin-arm64.txt @@ -0,0 +1,57 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-CodeGen-GlobalISel) +target_compile_options(lib-CodeGen-GlobalISel PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-CodeGen-GlobalISel PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel +) +target_link_libraries(lib-CodeGen-GlobalISel PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-CodeGen + lib-CodeGen-SelectionDAG + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Support + llvm14-lib-Target + lib-Transforms-Utils +) +target_sources(lib-CodeGen-GlobalISel PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CSEInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CSEMIRBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CallLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/Combiner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CombinerHelper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/GISelChangeObserver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/GISelKnownBits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/GlobalISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/IRTranslator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/InlineAsmLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/InstructionSelect.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/InstructionSelector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegacyLegalizerInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegalityPredicates.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegalizeMutations.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/Legalizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegalizerHelper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegalizerInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LoadStoreOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/Localizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LostDebugLocObserver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/MachineIRBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/RegBankSelect.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/RegisterBank.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/RegisterBankInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/Utils.cpp +) diff --git a/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..514c2baa2f58 --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,57 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-CodeGen-GlobalISel) +target_compile_options(lib-CodeGen-GlobalISel PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-CodeGen-GlobalISel PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel +) +target_link_libraries(lib-CodeGen-GlobalISel PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-CodeGen + lib-CodeGen-SelectionDAG + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Support + llvm14-lib-Target + lib-Transforms-Utils +) +target_sources(lib-CodeGen-GlobalISel PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CSEInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CSEMIRBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CallLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/Combiner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CombinerHelper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/GISelChangeObserver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/GISelKnownBits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/GlobalISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/IRTranslator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/InlineAsmLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/InstructionSelect.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/InstructionSelector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegacyLegalizerInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegalityPredicates.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegalizeMutations.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/Legalizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegalizerHelper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegalizerInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LoadStoreOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/Localizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LostDebugLocObserver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/MachineIRBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/RegBankSelect.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/RegisterBank.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/RegisterBankInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/Utils.cpp +) diff --git a/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..ed55f6e511a0 --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.linux-aarch64.txt @@ -0,0 +1,58 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-CodeGen-GlobalISel) +target_compile_options(lib-CodeGen-GlobalISel PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-CodeGen-GlobalISel PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel +) +target_link_libraries(lib-CodeGen-GlobalISel PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-CodeGen + lib-CodeGen-SelectionDAG + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Support + llvm14-lib-Target + lib-Transforms-Utils +) +target_sources(lib-CodeGen-GlobalISel PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CSEInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CSEMIRBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CallLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/Combiner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CombinerHelper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/GISelChangeObserver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/GISelKnownBits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/GlobalISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/IRTranslator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/InlineAsmLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/InstructionSelect.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/InstructionSelector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegacyLegalizerInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegalityPredicates.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegalizeMutations.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/Legalizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegalizerHelper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegalizerInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LoadStoreOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/Localizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LostDebugLocObserver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/MachineIRBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/RegBankSelect.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/RegisterBank.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/RegisterBankInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/Utils.cpp +) diff --git a/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..ed55f6e511a0 --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.linux-x86_64.txt @@ -0,0 +1,58 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-CodeGen-GlobalISel) +target_compile_options(lib-CodeGen-GlobalISel PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-CodeGen-GlobalISel PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel +) +target_link_libraries(lib-CodeGen-GlobalISel PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-CodeGen + lib-CodeGen-SelectionDAG + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Support + llvm14-lib-Target + lib-Transforms-Utils +) +target_sources(lib-CodeGen-GlobalISel PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CSEInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CSEMIRBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CallLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/Combiner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CombinerHelper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/GISelChangeObserver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/GISelKnownBits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/GlobalISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/IRTranslator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/InlineAsmLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/InstructionSelect.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/InstructionSelector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegacyLegalizerInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegalityPredicates.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegalizeMutations.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/Legalizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegalizerHelper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegalizerInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LoadStoreOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/Localizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LostDebugLocObserver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/MachineIRBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/RegBankSelect.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/RegisterBank.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/RegisterBankInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/Utils.cpp +) diff --git a/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.txt b/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..514c2baa2f58 --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CMakeLists.windows-x86_64.txt @@ -0,0 +1,57 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-CodeGen-GlobalISel) +target_compile_options(lib-CodeGen-GlobalISel PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-CodeGen-GlobalISel PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel +) +target_link_libraries(lib-CodeGen-GlobalISel PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-CodeGen + lib-CodeGen-SelectionDAG + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Support + llvm14-lib-Target + lib-Transforms-Utils +) +target_sources(lib-CodeGen-GlobalISel PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CSEInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CSEMIRBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CallLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/Combiner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/CombinerHelper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/GISelChangeObserver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/GISelKnownBits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/GlobalISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/IRTranslator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/InlineAsmLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/InstructionSelect.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/InstructionSelector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegacyLegalizerInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegalityPredicates.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegalizeMutations.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/Legalizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegalizerHelper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LegalizerInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LoadStoreOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/Localizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/LostDebugLocObserver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/MachineIRBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/RegBankSelect.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/RegisterBank.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/RegisterBankInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/GlobalISel/Utils.cpp +) diff --git a/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..4690a1148401 --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.darwin-arm64.txt @@ -0,0 +1,55 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-CodeGen-SelectionDAG) +target_compile_options(lib-CodeGen-SelectionDAG PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-CodeGen-SelectionDAG PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG +) +target_link_libraries(lib-CodeGen-SelectionDAG PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-CodeGen + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Support + llvm14-lib-Target + lib-Transforms-Utils +) +target_sources(lib-CodeGen-SelectionDAG PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/DAGCombiner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/FastISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/FunctionLoweringInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/InstrEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeDAG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeFloatTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeIntegerTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeTypesGeneric.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeVectorOps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeVectorTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ResourcePriorityQueue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ScheduleDAGFast.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ScheduleDAGRRList.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ScheduleDAGSDNodes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ScheduleDAGVLIW.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGAddressAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGDumper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGTargetInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/StatepointLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/TargetLowering.cpp +) diff --git a/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..4690a1148401 --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,55 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-CodeGen-SelectionDAG) +target_compile_options(lib-CodeGen-SelectionDAG PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-CodeGen-SelectionDAG PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG +) +target_link_libraries(lib-CodeGen-SelectionDAG PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-CodeGen + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Support + llvm14-lib-Target + lib-Transforms-Utils +) +target_sources(lib-CodeGen-SelectionDAG PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/DAGCombiner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/FastISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/FunctionLoweringInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/InstrEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeDAG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeFloatTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeIntegerTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeTypesGeneric.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeVectorOps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeVectorTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ResourcePriorityQueue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ScheduleDAGFast.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ScheduleDAGRRList.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ScheduleDAGSDNodes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ScheduleDAGVLIW.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGAddressAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGDumper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGTargetInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/StatepointLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/TargetLowering.cpp +) diff --git a/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..b85c8b90245c --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.linux-aarch64.txt @@ -0,0 +1,56 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-CodeGen-SelectionDAG) +target_compile_options(lib-CodeGen-SelectionDAG PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-CodeGen-SelectionDAG PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG +) +target_link_libraries(lib-CodeGen-SelectionDAG PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-CodeGen + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Support + llvm14-lib-Target + lib-Transforms-Utils +) +target_sources(lib-CodeGen-SelectionDAG PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/DAGCombiner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/FastISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/FunctionLoweringInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/InstrEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeDAG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeFloatTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeIntegerTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeTypesGeneric.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeVectorOps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeVectorTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ResourcePriorityQueue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ScheduleDAGFast.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ScheduleDAGRRList.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ScheduleDAGSDNodes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ScheduleDAGVLIW.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGAddressAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGDumper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGTargetInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/StatepointLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/TargetLowering.cpp +) diff --git a/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..b85c8b90245c --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.linux-x86_64.txt @@ -0,0 +1,56 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-CodeGen-SelectionDAG) +target_compile_options(lib-CodeGen-SelectionDAG PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-CodeGen-SelectionDAG PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG +) +target_link_libraries(lib-CodeGen-SelectionDAG PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-CodeGen + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Support + llvm14-lib-Target + lib-Transforms-Utils +) +target_sources(lib-CodeGen-SelectionDAG PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/DAGCombiner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/FastISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/FunctionLoweringInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/InstrEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeDAG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeFloatTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeIntegerTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeTypesGeneric.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeVectorOps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeVectorTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ResourcePriorityQueue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ScheduleDAGFast.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ScheduleDAGRRList.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ScheduleDAGSDNodes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ScheduleDAGVLIW.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGAddressAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGDumper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGTargetInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/StatepointLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/TargetLowering.cpp +) diff --git a/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.txt b/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..4690a1148401 --- /dev/null +++ b/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/CMakeLists.windows-x86_64.txt @@ -0,0 +1,55 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-CodeGen-SelectionDAG) +target_compile_options(lib-CodeGen-SelectionDAG PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-CodeGen-SelectionDAG PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG +) +target_link_libraries(lib-CodeGen-SelectionDAG PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-CodeGen + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Support + llvm14-lib-Target + lib-Transforms-Utils +) +target_sources(lib-CodeGen-SelectionDAG PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/DAGCombiner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/FastISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/FunctionLoweringInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/InstrEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeDAG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeFloatTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeIntegerTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeTypesGeneric.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeVectorOps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/LegalizeVectorTypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ResourcePriorityQueue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ScheduleDAGFast.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ScheduleDAGRRList.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ScheduleDAGSDNodes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/ScheduleDAGVLIW.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGAddressAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGDumper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/SelectionDAGTargetInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/StatepointLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/CodeGen/SelectionDAG/TargetLowering.cpp +) diff --git a/contrib/libs/llvm14/lib/DebugInfo/CMakeLists.txt b/contrib/libs/llvm14/lib/DebugInfo/CMakeLists.txt new file mode 100644 index 000000000000..705bb739960c --- /dev/null +++ b/contrib/libs/llvm14/lib/DebugInfo/CMakeLists.txt @@ -0,0 +1,11 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(CodeView) +add_subdirectory(DWARF) +add_subdirectory(MSF) diff --git a/contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..205c53b4e2c8 --- /dev/null +++ b/contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.darwin-arm64.txt @@ -0,0 +1,63 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-DebugInfo-CodeView) +target_compile_options(lib-DebugInfo-CodeView PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-DebugInfo-CodeView PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView +) +target_link_libraries(lib-DebugInfo-CodeView PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(lib-DebugInfo-CodeView PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/AppendingTypeTableBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/CVSymbolVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/CVTypeVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/CodeViewError.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/CodeViewRecordIO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/ContinuationRecordBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugChecksumsSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugCrossExSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugCrossImpSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugFrameDataSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugInlineeLinesSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugLinesSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugStringTableSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSubsectionRecord.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSubsectionVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSymbolRVASubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSymbolsSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/EnumTables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/Formatters.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/GlobalTypeTableBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/LazyRandomTypeCollection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/Line.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/MergingTypeTableBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/RecordName.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/RecordSerialization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SimpleTypeSerializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/StringsAndChecksums.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SymbolDumper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SymbolRecordHelpers.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SymbolRecordMapping.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SymbolSerializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeDumpVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeHashing.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeIndexDiscovery.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeRecordHelpers.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeRecordMapping.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeStreamMerger.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeTableCollection.cpp +) diff --git a/contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..205c53b4e2c8 --- /dev/null +++ b/contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,63 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-DebugInfo-CodeView) +target_compile_options(lib-DebugInfo-CodeView PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-DebugInfo-CodeView PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView +) +target_link_libraries(lib-DebugInfo-CodeView PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(lib-DebugInfo-CodeView PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/AppendingTypeTableBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/CVSymbolVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/CVTypeVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/CodeViewError.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/CodeViewRecordIO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/ContinuationRecordBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugChecksumsSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugCrossExSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugCrossImpSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugFrameDataSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugInlineeLinesSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugLinesSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugStringTableSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSubsectionRecord.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSubsectionVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSymbolRVASubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSymbolsSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/EnumTables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/Formatters.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/GlobalTypeTableBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/LazyRandomTypeCollection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/Line.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/MergingTypeTableBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/RecordName.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/RecordSerialization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SimpleTypeSerializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/StringsAndChecksums.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SymbolDumper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SymbolRecordHelpers.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SymbolRecordMapping.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SymbolSerializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeDumpVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeHashing.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeIndexDiscovery.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeRecordHelpers.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeRecordMapping.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeStreamMerger.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeTableCollection.cpp +) diff --git a/contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..f3cfd2dde253 --- /dev/null +++ b/contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.linux-aarch64.txt @@ -0,0 +1,64 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-DebugInfo-CodeView) +target_compile_options(lib-DebugInfo-CodeView PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-DebugInfo-CodeView PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView +) +target_link_libraries(lib-DebugInfo-CodeView PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(lib-DebugInfo-CodeView PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/AppendingTypeTableBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/CVSymbolVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/CVTypeVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/CodeViewError.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/CodeViewRecordIO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/ContinuationRecordBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugChecksumsSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugCrossExSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugCrossImpSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugFrameDataSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugInlineeLinesSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugLinesSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugStringTableSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSubsectionRecord.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSubsectionVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSymbolRVASubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSymbolsSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/EnumTables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/Formatters.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/GlobalTypeTableBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/LazyRandomTypeCollection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/Line.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/MergingTypeTableBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/RecordName.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/RecordSerialization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SimpleTypeSerializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/StringsAndChecksums.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SymbolDumper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SymbolRecordHelpers.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SymbolRecordMapping.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SymbolSerializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeDumpVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeHashing.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeIndexDiscovery.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeRecordHelpers.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeRecordMapping.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeStreamMerger.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeTableCollection.cpp +) diff --git a/contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..f3cfd2dde253 --- /dev/null +++ b/contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.linux-x86_64.txt @@ -0,0 +1,64 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-DebugInfo-CodeView) +target_compile_options(lib-DebugInfo-CodeView PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-DebugInfo-CodeView PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView +) +target_link_libraries(lib-DebugInfo-CodeView PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(lib-DebugInfo-CodeView PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/AppendingTypeTableBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/CVSymbolVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/CVTypeVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/CodeViewError.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/CodeViewRecordIO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/ContinuationRecordBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugChecksumsSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugCrossExSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugCrossImpSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugFrameDataSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugInlineeLinesSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugLinesSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugStringTableSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSubsectionRecord.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSubsectionVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSymbolRVASubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSymbolsSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/EnumTables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/Formatters.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/GlobalTypeTableBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/LazyRandomTypeCollection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/Line.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/MergingTypeTableBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/RecordName.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/RecordSerialization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SimpleTypeSerializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/StringsAndChecksums.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SymbolDumper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SymbolRecordHelpers.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SymbolRecordMapping.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SymbolSerializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeDumpVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeHashing.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeIndexDiscovery.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeRecordHelpers.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeRecordMapping.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeStreamMerger.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeTableCollection.cpp +) diff --git a/contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.txt b/contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..205c53b4e2c8 --- /dev/null +++ b/contrib/libs/llvm14/lib/DebugInfo/CodeView/CMakeLists.windows-x86_64.txt @@ -0,0 +1,63 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-DebugInfo-CodeView) +target_compile_options(lib-DebugInfo-CodeView PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-DebugInfo-CodeView PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView +) +target_link_libraries(lib-DebugInfo-CodeView PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(lib-DebugInfo-CodeView PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/AppendingTypeTableBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/CVSymbolVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/CVTypeVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/CodeViewError.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/CodeViewRecordIO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/ContinuationRecordBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugChecksumsSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugCrossExSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugCrossImpSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugFrameDataSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugInlineeLinesSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugLinesSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugStringTableSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSubsectionRecord.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSubsectionVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSymbolRVASubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/DebugSymbolsSubsection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/EnumTables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/Formatters.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/GlobalTypeTableBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/LazyRandomTypeCollection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/Line.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/MergingTypeTableBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/RecordName.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/RecordSerialization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SimpleTypeSerializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/StringsAndChecksums.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SymbolDumper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SymbolRecordHelpers.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SymbolRecordMapping.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/SymbolSerializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeDumpVisitor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeHashing.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeIndexDiscovery.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeRecordHelpers.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeRecordMapping.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeStreamMerger.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/CodeView/TypeTableCollection.cpp +) diff --git a/contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..0706657462c0 --- /dev/null +++ b/contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.darwin-arm64.txt @@ -0,0 +1,54 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-DebugInfo-DWARF) +target_compile_options(lib-DebugInfo-DWARF PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-DebugInfo-DWARF PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF +) +target_link_libraries(lib-DebugInfo-DWARF PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-BinaryFormat + llvm14-lib-MC + llvm14-lib-Object + llvm14-lib-Support +) +target_sources(lib-DebugInfo-DWARF PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFAbbreviationDeclaration.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFAcceleratorTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFAddressRange.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFCompileUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDataExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugAbbrev.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugAddr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugArangeSet.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugAranges.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugFrame.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugInfoEntry.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugLine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugLoc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugMacro.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugPubTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugRangeList.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugRnglists.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDie.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFExpression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFFormValue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFGdbIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFListTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFLocationExpression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFTypeUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFUnitIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFVerifier.cpp +) diff --git a/contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..0706657462c0 --- /dev/null +++ b/contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,54 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-DebugInfo-DWARF) +target_compile_options(lib-DebugInfo-DWARF PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-DebugInfo-DWARF PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF +) +target_link_libraries(lib-DebugInfo-DWARF PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-BinaryFormat + llvm14-lib-MC + llvm14-lib-Object + llvm14-lib-Support +) +target_sources(lib-DebugInfo-DWARF PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFAbbreviationDeclaration.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFAcceleratorTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFAddressRange.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFCompileUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDataExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugAbbrev.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugAddr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugArangeSet.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugAranges.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugFrame.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugInfoEntry.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugLine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugLoc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugMacro.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugPubTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugRangeList.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugRnglists.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDie.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFExpression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFFormValue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFGdbIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFListTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFLocationExpression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFTypeUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFUnitIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFVerifier.cpp +) diff --git a/contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..9622ab8887e7 --- /dev/null +++ b/contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.linux-aarch64.txt @@ -0,0 +1,55 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-DebugInfo-DWARF) +target_compile_options(lib-DebugInfo-DWARF PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-DebugInfo-DWARF PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF +) +target_link_libraries(lib-DebugInfo-DWARF PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-BinaryFormat + llvm14-lib-MC + llvm14-lib-Object + llvm14-lib-Support +) +target_sources(lib-DebugInfo-DWARF PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFAbbreviationDeclaration.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFAcceleratorTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFAddressRange.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFCompileUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDataExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugAbbrev.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugAddr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugArangeSet.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugAranges.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugFrame.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugInfoEntry.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugLine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugLoc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugMacro.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugPubTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugRangeList.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugRnglists.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDie.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFExpression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFFormValue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFGdbIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFListTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFLocationExpression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFTypeUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFUnitIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFVerifier.cpp +) diff --git a/contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..9622ab8887e7 --- /dev/null +++ b/contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.linux-x86_64.txt @@ -0,0 +1,55 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-DebugInfo-DWARF) +target_compile_options(lib-DebugInfo-DWARF PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-DebugInfo-DWARF PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF +) +target_link_libraries(lib-DebugInfo-DWARF PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-BinaryFormat + llvm14-lib-MC + llvm14-lib-Object + llvm14-lib-Support +) +target_sources(lib-DebugInfo-DWARF PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFAbbreviationDeclaration.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFAcceleratorTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFAddressRange.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFCompileUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDataExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugAbbrev.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugAddr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugArangeSet.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugAranges.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugFrame.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugInfoEntry.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugLine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugLoc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugMacro.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugPubTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugRangeList.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugRnglists.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDie.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFExpression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFFormValue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFGdbIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFListTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFLocationExpression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFTypeUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFUnitIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFVerifier.cpp +) diff --git a/contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.txt b/contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..0706657462c0 --- /dev/null +++ b/contrib/libs/llvm14/lib/DebugInfo/DWARF/CMakeLists.windows-x86_64.txt @@ -0,0 +1,54 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-DebugInfo-DWARF) +target_compile_options(lib-DebugInfo-DWARF PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-DebugInfo-DWARF PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF +) +target_link_libraries(lib-DebugInfo-DWARF PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-BinaryFormat + llvm14-lib-MC + llvm14-lib-Object + llvm14-lib-Support +) +target_sources(lib-DebugInfo-DWARF PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFAbbreviationDeclaration.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFAcceleratorTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFAddressRange.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFCompileUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDataExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugAbbrev.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugAddr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugArangeSet.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugAranges.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugFrame.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugInfoEntry.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugLine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugLoc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugMacro.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugPubTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugRangeList.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDebugRnglists.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFDie.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFExpression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFFormValue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFGdbIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFListTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFLocationExpression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFTypeUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFUnit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFUnitIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/DWARF/DWARFVerifier.cpp +) diff --git a/contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..bd654324b7a8 --- /dev/null +++ b/contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.darwin-arm64.txt @@ -0,0 +1,27 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-DebugInfo-MSF) +target_compile_options(lib-DebugInfo-MSF PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-DebugInfo-MSF PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF +) +target_link_libraries(lib-DebugInfo-MSF PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(lib-DebugInfo-MSF PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF/MSFBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF/MSFCommon.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF/MSFError.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF/MappedBlockStream.cpp +) diff --git a/contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..bd654324b7a8 --- /dev/null +++ b/contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,27 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-DebugInfo-MSF) +target_compile_options(lib-DebugInfo-MSF PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-DebugInfo-MSF PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF +) +target_link_libraries(lib-DebugInfo-MSF PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(lib-DebugInfo-MSF PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF/MSFBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF/MSFCommon.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF/MSFError.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF/MappedBlockStream.cpp +) diff --git a/contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..1a9e4ab85a4a --- /dev/null +++ b/contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.linux-aarch64.txt @@ -0,0 +1,28 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-DebugInfo-MSF) +target_compile_options(lib-DebugInfo-MSF PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-DebugInfo-MSF PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF +) +target_link_libraries(lib-DebugInfo-MSF PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(lib-DebugInfo-MSF PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF/MSFBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF/MSFCommon.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF/MSFError.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF/MappedBlockStream.cpp +) diff --git a/contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..1a9e4ab85a4a --- /dev/null +++ b/contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.linux-x86_64.txt @@ -0,0 +1,28 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-DebugInfo-MSF) +target_compile_options(lib-DebugInfo-MSF PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-DebugInfo-MSF PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF +) +target_link_libraries(lib-DebugInfo-MSF PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(lib-DebugInfo-MSF PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF/MSFBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF/MSFCommon.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF/MSFError.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF/MappedBlockStream.cpp +) diff --git a/contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.txt b/contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..bd654324b7a8 --- /dev/null +++ b/contrib/libs/llvm14/lib/DebugInfo/MSF/CMakeLists.windows-x86_64.txt @@ -0,0 +1,27 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-DebugInfo-MSF) +target_compile_options(lib-DebugInfo-MSF PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-DebugInfo-MSF PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF +) +target_link_libraries(lib-DebugInfo-MSF PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(lib-DebugInfo-MSF PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF/MSFBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF/MSFCommon.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF/MSFError.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/DebugInfo/MSF/MappedBlockStream.cpp +) diff --git a/contrib/libs/llvm14/lib/Demangle/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Demangle/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..c5555bbab0fe --- /dev/null +++ b/contrib/libs/llvm14/lib/Demangle/CMakeLists.darwin-arm64.txt @@ -0,0 +1,28 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Demangle) +target_compile_options(llvm14-lib-Demangle PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Demangle PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle +) +target_link_libraries(llvm14-lib-Demangle PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 +) +target_sources(llvm14-lib-Demangle PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/DLangDemangle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/Demangle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/ItaniumDemangle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/MicrosoftDemangle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/MicrosoftDemangleNodes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/RustDemangle.cpp +) diff --git a/contrib/libs/llvm14/lib/Demangle/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Demangle/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..c5555bbab0fe --- /dev/null +++ b/contrib/libs/llvm14/lib/Demangle/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,28 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Demangle) +target_compile_options(llvm14-lib-Demangle PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Demangle PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle +) +target_link_libraries(llvm14-lib-Demangle PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 +) +target_sources(llvm14-lib-Demangle PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/DLangDemangle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/Demangle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/ItaniumDemangle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/MicrosoftDemangle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/MicrosoftDemangleNodes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/RustDemangle.cpp +) diff --git a/contrib/libs/llvm14/lib/Demangle/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Demangle/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..87c499e92ffd --- /dev/null +++ b/contrib/libs/llvm14/lib/Demangle/CMakeLists.linux-aarch64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Demangle) +target_compile_options(llvm14-lib-Demangle PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Demangle PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle +) +target_link_libraries(llvm14-lib-Demangle PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 +) +target_sources(llvm14-lib-Demangle PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/DLangDemangle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/Demangle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/ItaniumDemangle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/MicrosoftDemangle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/MicrosoftDemangleNodes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/RustDemangle.cpp +) diff --git a/contrib/libs/llvm14/lib/Demangle/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Demangle/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..87c499e92ffd --- /dev/null +++ b/contrib/libs/llvm14/lib/Demangle/CMakeLists.linux-x86_64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Demangle) +target_compile_options(llvm14-lib-Demangle PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Demangle PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle +) +target_link_libraries(llvm14-lib-Demangle PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 +) +target_sources(llvm14-lib-Demangle PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/DLangDemangle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/Demangle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/ItaniumDemangle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/MicrosoftDemangle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/MicrosoftDemangleNodes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/RustDemangle.cpp +) diff --git a/contrib/libs/llvm14/lib/Demangle/CMakeLists.txt b/contrib/libs/llvm14/lib/Demangle/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Demangle/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Demangle/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Demangle/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..c5555bbab0fe --- /dev/null +++ b/contrib/libs/llvm14/lib/Demangle/CMakeLists.windows-x86_64.txt @@ -0,0 +1,28 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Demangle) +target_compile_options(llvm14-lib-Demangle PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Demangle PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle +) +target_link_libraries(llvm14-lib-Demangle PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 +) +target_sources(llvm14-lib-Demangle PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/DLangDemangle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/Demangle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/ItaniumDemangle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/MicrosoftDemangle.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/MicrosoftDemangleNodes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Demangle/RustDemangle.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..9296b409e5fa --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.darwin-arm64.txt @@ -0,0 +1,38 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(MCJIT) +add_subdirectory(Orc) +add_subdirectory(RuntimeDyld) + +add_library(llvm14-lib-ExecutionEngine) +target_compile_options(llvm14-lib-ExecutionEngine PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-ExecutionEngine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine +) +target_link_libraries(llvm14-lib-ExecutionEngine PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + ExecutionEngine-Orc-TargetProcess + lib-ExecutionEngine-RuntimeDyld + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Object + llvm14-lib-Support + llvm14-lib-Target +) +target_sources(llvm14-lib-ExecutionEngine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/ExecutionEngine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/ExecutionEngineBindings.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/GDBRegistrationListener.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/SectionMemoryManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/TargetSelect.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..9296b409e5fa --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,38 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(MCJIT) +add_subdirectory(Orc) +add_subdirectory(RuntimeDyld) + +add_library(llvm14-lib-ExecutionEngine) +target_compile_options(llvm14-lib-ExecutionEngine PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-ExecutionEngine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine +) +target_link_libraries(llvm14-lib-ExecutionEngine PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + ExecutionEngine-Orc-TargetProcess + lib-ExecutionEngine-RuntimeDyld + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Object + llvm14-lib-Support + llvm14-lib-Target +) +target_sources(llvm14-lib-ExecutionEngine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/ExecutionEngine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/ExecutionEngineBindings.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/GDBRegistrationListener.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/SectionMemoryManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/TargetSelect.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..2654c1046b43 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.linux-aarch64.txt @@ -0,0 +1,40 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(MCJIT) +add_subdirectory(Orc) +add_subdirectory(PerfJITEvents) +add_subdirectory(RuntimeDyld) + +add_library(llvm14-lib-ExecutionEngine) +target_compile_options(llvm14-lib-ExecutionEngine PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-ExecutionEngine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine +) +target_link_libraries(llvm14-lib-ExecutionEngine PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + ExecutionEngine-Orc-TargetProcess + lib-ExecutionEngine-RuntimeDyld + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Object + llvm14-lib-Support + llvm14-lib-Target +) +target_sources(llvm14-lib-ExecutionEngine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/ExecutionEngine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/ExecutionEngineBindings.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/GDBRegistrationListener.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/SectionMemoryManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/TargetSelect.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..2654c1046b43 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.linux-x86_64.txt @@ -0,0 +1,40 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(MCJIT) +add_subdirectory(Orc) +add_subdirectory(PerfJITEvents) +add_subdirectory(RuntimeDyld) + +add_library(llvm14-lib-ExecutionEngine) +target_compile_options(llvm14-lib-ExecutionEngine PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-ExecutionEngine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine +) +target_link_libraries(llvm14-lib-ExecutionEngine PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + ExecutionEngine-Orc-TargetProcess + lib-ExecutionEngine-RuntimeDyld + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Object + llvm14-lib-Support + llvm14-lib-Target +) +target_sources(llvm14-lib-ExecutionEngine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/ExecutionEngine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/ExecutionEngineBindings.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/GDBRegistrationListener.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/SectionMemoryManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/TargetSelect.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.txt b/contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..9296b409e5fa --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/CMakeLists.windows-x86_64.txt @@ -0,0 +1,38 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(MCJIT) +add_subdirectory(Orc) +add_subdirectory(RuntimeDyld) + +add_library(llvm14-lib-ExecutionEngine) +target_compile_options(llvm14-lib-ExecutionEngine PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-ExecutionEngine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine +) +target_link_libraries(llvm14-lib-ExecutionEngine PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + ExecutionEngine-Orc-TargetProcess + lib-ExecutionEngine-RuntimeDyld + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Object + llvm14-lib-Support + llvm14-lib-Target +) +target_sources(llvm14-lib-ExecutionEngine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/ExecutionEngine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/ExecutionEngineBindings.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/GDBRegistrationListener.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/SectionMemoryManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/TargetSelect.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..c198fef469e7 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.darwin-arm64.txt @@ -0,0 +1,30 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-ExecutionEngine-MCJIT) +target_compile_options(lib-ExecutionEngine-MCJIT PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-ExecutionEngine-MCJIT PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT +) +target_link_libraries(lib-ExecutionEngine-MCJIT PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-ExecutionEngine + lib-ExecutionEngine-RuntimeDyld + llvm14-lib-IR + llvm14-lib-Object + llvm14-lib-Support + llvm14-lib-Target +) +target_sources(lib-ExecutionEngine-MCJIT PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/MCJIT.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..c198fef469e7 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,30 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-ExecutionEngine-MCJIT) +target_compile_options(lib-ExecutionEngine-MCJIT PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-ExecutionEngine-MCJIT PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT +) +target_link_libraries(lib-ExecutionEngine-MCJIT PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-ExecutionEngine + lib-ExecutionEngine-RuntimeDyld + llvm14-lib-IR + llvm14-lib-Object + llvm14-lib-Support + llvm14-lib-Target +) +target_sources(lib-ExecutionEngine-MCJIT PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/MCJIT.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..71a6b55b9af4 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.linux-aarch64.txt @@ -0,0 +1,31 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-ExecutionEngine-MCJIT) +target_compile_options(lib-ExecutionEngine-MCJIT PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-ExecutionEngine-MCJIT PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT +) +target_link_libraries(lib-ExecutionEngine-MCJIT PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-ExecutionEngine + lib-ExecutionEngine-RuntimeDyld + llvm14-lib-IR + llvm14-lib-Object + llvm14-lib-Support + llvm14-lib-Target +) +target_sources(lib-ExecutionEngine-MCJIT PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/MCJIT.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..71a6b55b9af4 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.linux-x86_64.txt @@ -0,0 +1,31 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-ExecutionEngine-MCJIT) +target_compile_options(lib-ExecutionEngine-MCJIT PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-ExecutionEngine-MCJIT PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT +) +target_link_libraries(lib-ExecutionEngine-MCJIT PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-ExecutionEngine + lib-ExecutionEngine-RuntimeDyld + llvm14-lib-IR + llvm14-lib-Object + llvm14-lib-Support + llvm14-lib-Target +) +target_sources(lib-ExecutionEngine-MCJIT PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/MCJIT.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.txt b/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..c198fef469e7 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/CMakeLists.windows-x86_64.txt @@ -0,0 +1,30 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-ExecutionEngine-MCJIT) +target_compile_options(lib-ExecutionEngine-MCJIT PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-ExecutionEngine-MCJIT PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT +) +target_link_libraries(lib-ExecutionEngine-MCJIT PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-ExecutionEngine + lib-ExecutionEngine-RuntimeDyld + llvm14-lib-IR + llvm14-lib-Object + llvm14-lib-Support + llvm14-lib-Target +) +target_sources(lib-ExecutionEngine-MCJIT PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/MCJIT/MCJIT.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/Orc/CMakeLists.txt b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/CMakeLists.txt new file mode 100644 index 000000000000..6ce684aa0a47 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/CMakeLists.txt @@ -0,0 +1,10 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(Shared) +add_subdirectory(TargetProcess) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..bb133cbb7765 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.darwin-arm64.txt @@ -0,0 +1,27 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(ExecutionEngine-Orc-Shared) +target_compile_options(ExecutionEngine-Orc-Shared PRIVATE + $,,-Wno-everything> +) +target_include_directories(ExecutionEngine-Orc-Shared PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared +) +target_link_libraries(ExecutionEngine-Orc-Shared PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(ExecutionEngine-Orc-Shared PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/AllocationActions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/OrcError.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/OrcRTBridge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/SimpleRemoteEPCUtils.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..bb133cbb7765 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,27 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(ExecutionEngine-Orc-Shared) +target_compile_options(ExecutionEngine-Orc-Shared PRIVATE + $,,-Wno-everything> +) +target_include_directories(ExecutionEngine-Orc-Shared PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared +) +target_link_libraries(ExecutionEngine-Orc-Shared PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(ExecutionEngine-Orc-Shared PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/AllocationActions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/OrcError.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/OrcRTBridge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/SimpleRemoteEPCUtils.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..715d2dd7a1b3 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.linux-aarch64.txt @@ -0,0 +1,28 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(ExecutionEngine-Orc-Shared) +target_compile_options(ExecutionEngine-Orc-Shared PRIVATE + $,,-Wno-everything> +) +target_include_directories(ExecutionEngine-Orc-Shared PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared +) +target_link_libraries(ExecutionEngine-Orc-Shared PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(ExecutionEngine-Orc-Shared PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/AllocationActions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/OrcError.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/OrcRTBridge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/SimpleRemoteEPCUtils.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..715d2dd7a1b3 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.linux-x86_64.txt @@ -0,0 +1,28 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(ExecutionEngine-Orc-Shared) +target_compile_options(ExecutionEngine-Orc-Shared PRIVATE + $,,-Wno-everything> +) +target_include_directories(ExecutionEngine-Orc-Shared PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared +) +target_link_libraries(ExecutionEngine-Orc-Shared PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(ExecutionEngine-Orc-Shared PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/AllocationActions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/OrcError.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/OrcRTBridge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/SimpleRemoteEPCUtils.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.txt b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..bb133cbb7765 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/CMakeLists.windows-x86_64.txt @@ -0,0 +1,27 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(ExecutionEngine-Orc-Shared) +target_compile_options(ExecutionEngine-Orc-Shared PRIVATE + $,,-Wno-everything> +) +target_include_directories(ExecutionEngine-Orc-Shared PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared +) +target_link_libraries(ExecutionEngine-Orc-Shared PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(ExecutionEngine-Orc-Shared PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/AllocationActions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/OrcError.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/OrcRTBridge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/Shared/SimpleRemoteEPCUtils.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..ff3144cc9dce --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.darwin-arm64.txt @@ -0,0 +1,31 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(ExecutionEngine-Orc-TargetProcess) +target_compile_options(ExecutionEngine-Orc-TargetProcess PRIVATE + $,,-Wno-everything> +) +target_include_directories(ExecutionEngine-Orc-TargetProcess PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess +) +target_link_libraries(ExecutionEngine-Orc-TargetProcess PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + ExecutionEngine-Orc-Shared + llvm14-lib-Support +) +target_sources(ExecutionEngine-Orc-TargetProcess PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/JITLoaderGDB.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/OrcRTBootstrap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/RegisterEHFrames.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/SimpleExecutorDylibManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/SimpleExecutorMemoryManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/SimpleRemoteEPCServer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/TargetExecutionUtils.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..ff3144cc9dce --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,31 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(ExecutionEngine-Orc-TargetProcess) +target_compile_options(ExecutionEngine-Orc-TargetProcess PRIVATE + $,,-Wno-everything> +) +target_include_directories(ExecutionEngine-Orc-TargetProcess PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess +) +target_link_libraries(ExecutionEngine-Orc-TargetProcess PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + ExecutionEngine-Orc-Shared + llvm14-lib-Support +) +target_sources(ExecutionEngine-Orc-TargetProcess PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/JITLoaderGDB.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/OrcRTBootstrap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/RegisterEHFrames.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/SimpleExecutorDylibManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/SimpleExecutorMemoryManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/SimpleRemoteEPCServer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/TargetExecutionUtils.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..c5206f3b0bcb --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.linux-aarch64.txt @@ -0,0 +1,32 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(ExecutionEngine-Orc-TargetProcess) +target_compile_options(ExecutionEngine-Orc-TargetProcess PRIVATE + $,,-Wno-everything> +) +target_include_directories(ExecutionEngine-Orc-TargetProcess PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess +) +target_link_libraries(ExecutionEngine-Orc-TargetProcess PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + ExecutionEngine-Orc-Shared + llvm14-lib-Support +) +target_sources(ExecutionEngine-Orc-TargetProcess PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/JITLoaderGDB.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/OrcRTBootstrap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/RegisterEHFrames.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/SimpleExecutorDylibManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/SimpleExecutorMemoryManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/SimpleRemoteEPCServer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/TargetExecutionUtils.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..c5206f3b0bcb --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.linux-x86_64.txt @@ -0,0 +1,32 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(ExecutionEngine-Orc-TargetProcess) +target_compile_options(ExecutionEngine-Orc-TargetProcess PRIVATE + $,,-Wno-everything> +) +target_include_directories(ExecutionEngine-Orc-TargetProcess PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess +) +target_link_libraries(ExecutionEngine-Orc-TargetProcess PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + ExecutionEngine-Orc-Shared + llvm14-lib-Support +) +target_sources(ExecutionEngine-Orc-TargetProcess PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/JITLoaderGDB.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/OrcRTBootstrap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/RegisterEHFrames.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/SimpleExecutorDylibManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/SimpleExecutorMemoryManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/SimpleRemoteEPCServer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/TargetExecutionUtils.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.txt b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..ff3144cc9dce --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/CMakeLists.windows-x86_64.txt @@ -0,0 +1,31 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(ExecutionEngine-Orc-TargetProcess) +target_compile_options(ExecutionEngine-Orc-TargetProcess PRIVATE + $,,-Wno-everything> +) +target_include_directories(ExecutionEngine-Orc-TargetProcess PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess +) +target_link_libraries(ExecutionEngine-Orc-TargetProcess PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + ExecutionEngine-Orc-Shared + llvm14-lib-Support +) +target_sources(ExecutionEngine-Orc-TargetProcess PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/JITLoaderGDB.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/OrcRTBootstrap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/RegisterEHFrames.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/SimpleExecutorDylibManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/SimpleExecutorMemoryManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/SimpleRemoteEPCServer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/Orc/TargetProcess/TargetExecutionUtils.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/PerfJITEvents/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/PerfJITEvents/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..8444459360f3 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/PerfJITEvents/CMakeLists.linux-aarch64.txt @@ -0,0 +1,31 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-ExecutionEngine-PerfJITEvents) +target_compile_options(lib-ExecutionEngine-PerfJITEvents PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-ExecutionEngine-PerfJITEvents PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/PerfJITEvents +) +target_link_libraries(lib-ExecutionEngine-PerfJITEvents PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-CodeGen + lib-DebugInfo-DWARF + llvm14-lib-ExecutionEngine + lib-ExecutionEngine-RuntimeDyld + llvm14-lib-IR + llvm14-lib-Object + llvm14-lib-Support +) +target_sources(lib-ExecutionEngine-PerfJITEvents PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/PerfJITEvents/PerfJITEventListener.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/PerfJITEvents/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/PerfJITEvents/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..8444459360f3 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/PerfJITEvents/CMakeLists.linux-x86_64.txt @@ -0,0 +1,31 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-ExecutionEngine-PerfJITEvents) +target_compile_options(lib-ExecutionEngine-PerfJITEvents PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-ExecutionEngine-PerfJITEvents PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/PerfJITEvents +) +target_link_libraries(lib-ExecutionEngine-PerfJITEvents PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-CodeGen + lib-DebugInfo-DWARF + llvm14-lib-ExecutionEngine + lib-ExecutionEngine-RuntimeDyld + llvm14-lib-IR + llvm14-lib-Object + llvm14-lib-Support +) +target_sources(lib-ExecutionEngine-PerfJITEvents PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/PerfJITEvents/PerfJITEventListener.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/PerfJITEvents/CMakeLists.txt b/contrib/libs/llvm14/lib/ExecutionEngine/PerfJITEvents/CMakeLists.txt new file mode 100644 index 000000000000..d6c5c0bbeb44 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/PerfJITEvents/CMakeLists.txt @@ -0,0 +1,13 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..2a8da1b66cf6 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.darwin-arm64.txt @@ -0,0 +1,35 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-ExecutionEngine-RuntimeDyld) +target_compile_options(lib-ExecutionEngine-RuntimeDyld PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-ExecutionEngine-RuntimeDyld PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld +) +target_link_libraries(lib-ExecutionEngine-RuntimeDyld PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Object + llvm14-lib-Support +) +target_sources(lib-ExecutionEngine-RuntimeDyld PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/JITSymbol.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RTDyldMemoryManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyld.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyldCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyldChecker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyldELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyldMachO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/Targets/RuntimeDyldELFMips.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..2a8da1b66cf6 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,35 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-ExecutionEngine-RuntimeDyld) +target_compile_options(lib-ExecutionEngine-RuntimeDyld PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-ExecutionEngine-RuntimeDyld PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld +) +target_link_libraries(lib-ExecutionEngine-RuntimeDyld PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Object + llvm14-lib-Support +) +target_sources(lib-ExecutionEngine-RuntimeDyld PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/JITSymbol.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RTDyldMemoryManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyld.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyldCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyldChecker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyldELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyldMachO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/Targets/RuntimeDyldELFMips.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..455fbc159542 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.linux-aarch64.txt @@ -0,0 +1,36 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-ExecutionEngine-RuntimeDyld) +target_compile_options(lib-ExecutionEngine-RuntimeDyld PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-ExecutionEngine-RuntimeDyld PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld +) +target_link_libraries(lib-ExecutionEngine-RuntimeDyld PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Object + llvm14-lib-Support +) +target_sources(lib-ExecutionEngine-RuntimeDyld PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/JITSymbol.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RTDyldMemoryManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyld.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyldCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyldChecker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyldELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyldMachO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/Targets/RuntimeDyldELFMips.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..455fbc159542 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.linux-x86_64.txt @@ -0,0 +1,36 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-ExecutionEngine-RuntimeDyld) +target_compile_options(lib-ExecutionEngine-RuntimeDyld PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-ExecutionEngine-RuntimeDyld PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld +) +target_link_libraries(lib-ExecutionEngine-RuntimeDyld PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Object + llvm14-lib-Support +) +target_sources(lib-ExecutionEngine-RuntimeDyld PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/JITSymbol.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RTDyldMemoryManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyld.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyldCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyldChecker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyldELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyldMachO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/Targets/RuntimeDyldELFMips.cpp +) diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.txt b/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..2a8da1b66cf6 --- /dev/null +++ b/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/CMakeLists.windows-x86_64.txt @@ -0,0 +1,35 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-ExecutionEngine-RuntimeDyld) +target_compile_options(lib-ExecutionEngine-RuntimeDyld PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-ExecutionEngine-RuntimeDyld PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld +) +target_link_libraries(lib-ExecutionEngine-RuntimeDyld PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Object + llvm14-lib-Support +) +target_sources(lib-ExecutionEngine-RuntimeDyld PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/JITSymbol.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RTDyldMemoryManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyld.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyldCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyldChecker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyldELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/RuntimeDyldMachO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ExecutionEngine/RuntimeDyld/Targets/RuntimeDyldELFMips.cpp +) diff --git a/library/cpp/clickhouse/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Frontend/CMakeLists.txt similarity index 94% rename from library/cpp/clickhouse/CMakeLists.darwin-x86_64.txt rename to contrib/libs/llvm14/lib/Frontend/CMakeLists.txt index 7f79107ebc79..2f3f84b97767 100644 --- a/library/cpp/clickhouse/CMakeLists.darwin-x86_64.txt +++ b/contrib/libs/llvm14/lib/Frontend/CMakeLists.txt @@ -6,4 +6,4 @@ # original buildsystem will not be accepted. -add_subdirectory(client) +add_subdirectory(OpenMP) diff --git a/contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..e16d150dc18a --- /dev/null +++ b/contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.darwin-arm64.txt @@ -0,0 +1,32 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Frontend-OpenMP) +target_compile_options(lib-Frontend-OpenMP PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Frontend-OpenMP PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Frontend/OpenMP +) +target_link_libraries(lib-Frontend-OpenMP PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Support + lib-Transforms-Scalar + lib-Transforms-Utils +) +target_sources(lib-Frontend-OpenMP PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Frontend/OpenMP/OMP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Frontend/OpenMP/OMPContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Frontend/OpenMP/OMPIRBuilder.cpp +) diff --git a/contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..e16d150dc18a --- /dev/null +++ b/contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,32 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Frontend-OpenMP) +target_compile_options(lib-Frontend-OpenMP PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Frontend-OpenMP PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Frontend/OpenMP +) +target_link_libraries(lib-Frontend-OpenMP PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Support + lib-Transforms-Scalar + lib-Transforms-Utils +) +target_sources(lib-Frontend-OpenMP PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Frontend/OpenMP/OMP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Frontend/OpenMP/OMPContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Frontend/OpenMP/OMPIRBuilder.cpp +) diff --git a/contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..61a99b1331ee --- /dev/null +++ b/contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.linux-aarch64.txt @@ -0,0 +1,33 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Frontend-OpenMP) +target_compile_options(lib-Frontend-OpenMP PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Frontend-OpenMP PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Frontend/OpenMP +) +target_link_libraries(lib-Frontend-OpenMP PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Support + lib-Transforms-Scalar + lib-Transforms-Utils +) +target_sources(lib-Frontend-OpenMP PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Frontend/OpenMP/OMP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Frontend/OpenMP/OMPContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Frontend/OpenMP/OMPIRBuilder.cpp +) diff --git a/contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..61a99b1331ee --- /dev/null +++ b/contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.linux-x86_64.txt @@ -0,0 +1,33 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Frontend-OpenMP) +target_compile_options(lib-Frontend-OpenMP PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Frontend-OpenMP PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Frontend/OpenMP +) +target_link_libraries(lib-Frontend-OpenMP PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Support + lib-Transforms-Scalar + lib-Transforms-Utils +) +target_sources(lib-Frontend-OpenMP PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Frontend/OpenMP/OMP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Frontend/OpenMP/OMPContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Frontend/OpenMP/OMPIRBuilder.cpp +) diff --git a/contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.txt b/contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..e16d150dc18a --- /dev/null +++ b/contrib/libs/llvm14/lib/Frontend/OpenMP/CMakeLists.windows-x86_64.txt @@ -0,0 +1,32 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Frontend-OpenMP) +target_compile_options(lib-Frontend-OpenMP PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Frontend-OpenMP PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Frontend/OpenMP +) +target_link_libraries(lib-Frontend-OpenMP PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Support + lib-Transforms-Scalar + lib-Transforms-Utils +) +target_sources(lib-Frontend-OpenMP PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Frontend/OpenMP/OMP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Frontend/OpenMP/OMPContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Frontend/OpenMP/OMPIRBuilder.cpp +) diff --git a/contrib/libs/llvm14/lib/IR/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/IR/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..ae3ebd8a1505 --- /dev/null +++ b/contrib/libs/llvm14/lib/IR/CMakeLists.darwin-arm64.txt @@ -0,0 +1,89 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-IR) +target_compile_options(llvm14-lib-IR PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-IR PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR +) +target_link_libraries(llvm14-lib-IR PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + llvm14-lib-Remarks + llvm14-lib-Support +) +target_sources(llvm14-lib-IR PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/AbstractCallSite.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/AsmWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Assumptions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Attributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/AutoUpgrade.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/BasicBlock.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/BuiltinGCs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Comdat.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ConstantFold.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ConstantRange.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Constants.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Core.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DIBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DataLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DebugInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DebugInfoMetadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DebugLoc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DiagnosticHandler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DiagnosticInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DiagnosticPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Dominators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/FPEnv.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Function.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/GCStrategy.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/GVMaterializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Globals.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/IRBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/IRPrintingPasses.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/InlineAsm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Instruction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Instructions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/IntrinsicInst.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/LLVMContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/LLVMContextImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/LLVMRemarkStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/LegacyPassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/MDBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Mangler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Metadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Module.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ModuleSummaryIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Operator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/OptBisect.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Pass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PassInstrumentation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PassRegistry.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PassTimingInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PrintPasses.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ProfileSummary.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PseudoProbe.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ReplaceConstant.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/SSAContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/SafepointIRVerifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Statepoint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/StructuralHash.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Type.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/TypeFinder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Use.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/User.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Value.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ValueSymbolTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Verifier.cpp +) diff --git a/contrib/libs/llvm14/lib/IR/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/IR/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..ae3ebd8a1505 --- /dev/null +++ b/contrib/libs/llvm14/lib/IR/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,89 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-IR) +target_compile_options(llvm14-lib-IR PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-IR PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR +) +target_link_libraries(llvm14-lib-IR PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + llvm14-lib-Remarks + llvm14-lib-Support +) +target_sources(llvm14-lib-IR PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/AbstractCallSite.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/AsmWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Assumptions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Attributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/AutoUpgrade.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/BasicBlock.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/BuiltinGCs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Comdat.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ConstantFold.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ConstantRange.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Constants.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Core.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DIBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DataLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DebugInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DebugInfoMetadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DebugLoc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DiagnosticHandler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DiagnosticInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DiagnosticPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Dominators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/FPEnv.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Function.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/GCStrategy.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/GVMaterializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Globals.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/IRBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/IRPrintingPasses.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/InlineAsm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Instruction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Instructions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/IntrinsicInst.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/LLVMContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/LLVMContextImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/LLVMRemarkStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/LegacyPassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/MDBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Mangler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Metadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Module.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ModuleSummaryIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Operator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/OptBisect.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Pass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PassInstrumentation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PassRegistry.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PassTimingInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PrintPasses.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ProfileSummary.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PseudoProbe.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ReplaceConstant.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/SSAContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/SafepointIRVerifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Statepoint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/StructuralHash.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Type.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/TypeFinder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Use.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/User.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Value.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ValueSymbolTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Verifier.cpp +) diff --git a/contrib/libs/llvm14/lib/IR/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/IR/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..10e4eb21e124 --- /dev/null +++ b/contrib/libs/llvm14/lib/IR/CMakeLists.linux-aarch64.txt @@ -0,0 +1,90 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-IR) +target_compile_options(llvm14-lib-IR PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-IR PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR +) +target_link_libraries(llvm14-lib-IR PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + llvm14-lib-Remarks + llvm14-lib-Support +) +target_sources(llvm14-lib-IR PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/AbstractCallSite.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/AsmWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Assumptions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Attributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/AutoUpgrade.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/BasicBlock.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/BuiltinGCs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Comdat.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ConstantFold.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ConstantRange.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Constants.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Core.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DIBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DataLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DebugInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DebugInfoMetadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DebugLoc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DiagnosticHandler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DiagnosticInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DiagnosticPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Dominators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/FPEnv.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Function.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/GCStrategy.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/GVMaterializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Globals.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/IRBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/IRPrintingPasses.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/InlineAsm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Instruction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Instructions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/IntrinsicInst.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/LLVMContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/LLVMContextImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/LLVMRemarkStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/LegacyPassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/MDBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Mangler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Metadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Module.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ModuleSummaryIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Operator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/OptBisect.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Pass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PassInstrumentation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PassRegistry.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PassTimingInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PrintPasses.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ProfileSummary.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PseudoProbe.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ReplaceConstant.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/SSAContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/SafepointIRVerifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Statepoint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/StructuralHash.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Type.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/TypeFinder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Use.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/User.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Value.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ValueSymbolTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Verifier.cpp +) diff --git a/contrib/libs/llvm14/lib/IR/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/IR/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..10e4eb21e124 --- /dev/null +++ b/contrib/libs/llvm14/lib/IR/CMakeLists.linux-x86_64.txt @@ -0,0 +1,90 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-IR) +target_compile_options(llvm14-lib-IR PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-IR PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR +) +target_link_libraries(llvm14-lib-IR PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + llvm14-lib-Remarks + llvm14-lib-Support +) +target_sources(llvm14-lib-IR PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/AbstractCallSite.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/AsmWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Assumptions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Attributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/AutoUpgrade.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/BasicBlock.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/BuiltinGCs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Comdat.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ConstantFold.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ConstantRange.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Constants.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Core.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DIBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DataLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DebugInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DebugInfoMetadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DebugLoc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DiagnosticHandler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DiagnosticInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DiagnosticPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Dominators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/FPEnv.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Function.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/GCStrategy.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/GVMaterializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Globals.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/IRBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/IRPrintingPasses.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/InlineAsm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Instruction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Instructions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/IntrinsicInst.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/LLVMContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/LLVMContextImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/LLVMRemarkStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/LegacyPassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/MDBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Mangler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Metadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Module.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ModuleSummaryIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Operator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/OptBisect.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Pass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PassInstrumentation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PassRegistry.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PassTimingInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PrintPasses.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ProfileSummary.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PseudoProbe.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ReplaceConstant.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/SSAContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/SafepointIRVerifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Statepoint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/StructuralHash.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Type.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/TypeFinder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Use.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/User.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Value.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ValueSymbolTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Verifier.cpp +) diff --git a/contrib/libs/llvm14/lib/IR/CMakeLists.txt b/contrib/libs/llvm14/lib/IR/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/IR/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/IR/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/IR/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..ae3ebd8a1505 --- /dev/null +++ b/contrib/libs/llvm14/lib/IR/CMakeLists.windows-x86_64.txt @@ -0,0 +1,89 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-IR) +target_compile_options(llvm14-lib-IR PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-IR PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR +) +target_link_libraries(llvm14-lib-IR PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + llvm14-lib-Remarks + llvm14-lib-Support +) +target_sources(llvm14-lib-IR PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/AbstractCallSite.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/AsmWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Assumptions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Attributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/AutoUpgrade.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/BasicBlock.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/BuiltinGCs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Comdat.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ConstantFold.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ConstantRange.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Constants.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Core.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DIBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DataLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DebugInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DebugInfoMetadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DebugLoc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DiagnosticHandler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DiagnosticInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/DiagnosticPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Dominators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/FPEnv.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Function.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/GCStrategy.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/GVMaterializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Globals.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/IRBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/IRPrintingPasses.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/InlineAsm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Instruction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Instructions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/IntrinsicInst.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/LLVMContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/LLVMContextImpl.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/LLVMRemarkStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/LegacyPassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/MDBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Mangler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Metadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Module.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ModuleSummaryIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Operator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/OptBisect.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Pass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PassInstrumentation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PassRegistry.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PassTimingInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PrintPasses.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ProfileSummary.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/PseudoProbe.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ReplaceConstant.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/SSAContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/SafepointIRVerifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Statepoint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/StructuralHash.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Type.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/TypeFinder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Use.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/User.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Value.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/ValueSymbolTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IR/Verifier.cpp +) diff --git a/contrib/libs/llvm14/lib/IRReader/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/IRReader/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..e43858882e31 --- /dev/null +++ b/contrib/libs/llvm14/lib/IRReader/CMakeLists.darwin-arm64.txt @@ -0,0 +1,28 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-IRReader) +target_compile_options(llvm14-lib-IRReader PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-IRReader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IRReader +) +target_link_libraries(llvm14-lib-IRReader PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-AsmParser + lib-Bitcode-Reader + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(llvm14-lib-IRReader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IRReader/IRReader.cpp +) diff --git a/contrib/libs/llvm14/lib/IRReader/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/IRReader/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..e43858882e31 --- /dev/null +++ b/contrib/libs/llvm14/lib/IRReader/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,28 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-IRReader) +target_compile_options(llvm14-lib-IRReader PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-IRReader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IRReader +) +target_link_libraries(llvm14-lib-IRReader PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-AsmParser + lib-Bitcode-Reader + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(llvm14-lib-IRReader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IRReader/IRReader.cpp +) diff --git a/contrib/libs/llvm14/lib/IRReader/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/IRReader/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..814a19102f3c --- /dev/null +++ b/contrib/libs/llvm14/lib/IRReader/CMakeLists.linux-aarch64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-IRReader) +target_compile_options(llvm14-lib-IRReader PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-IRReader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IRReader +) +target_link_libraries(llvm14-lib-IRReader PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-AsmParser + lib-Bitcode-Reader + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(llvm14-lib-IRReader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IRReader/IRReader.cpp +) diff --git a/contrib/libs/llvm14/lib/IRReader/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/IRReader/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..814a19102f3c --- /dev/null +++ b/contrib/libs/llvm14/lib/IRReader/CMakeLists.linux-x86_64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-IRReader) +target_compile_options(llvm14-lib-IRReader PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-IRReader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IRReader +) +target_link_libraries(llvm14-lib-IRReader PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-AsmParser + lib-Bitcode-Reader + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(llvm14-lib-IRReader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IRReader/IRReader.cpp +) diff --git a/contrib/libs/llvm14/lib/IRReader/CMakeLists.txt b/contrib/libs/llvm14/lib/IRReader/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/IRReader/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/IRReader/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/IRReader/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..e43858882e31 --- /dev/null +++ b/contrib/libs/llvm14/lib/IRReader/CMakeLists.windows-x86_64.txt @@ -0,0 +1,28 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-IRReader) +target_compile_options(llvm14-lib-IRReader PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-IRReader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IRReader +) +target_link_libraries(llvm14-lib-IRReader PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-AsmParser + lib-Bitcode-Reader + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(llvm14-lib-IRReader PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/IRReader/IRReader.cpp +) diff --git a/contrib/libs/llvm14/lib/Linker/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Linker/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..a9fbd64b68f8 --- /dev/null +++ b/contrib/libs/llvm14/lib/Linker/CMakeLists.darwin-arm64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Linker) +target_compile_options(llvm14-lib-Linker PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Linker PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Linker +) +target_link_libraries(llvm14-lib-Linker PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-IR + llvm14-lib-Object + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(llvm14-lib-Linker PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Linker/IRMover.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Linker/LinkModules.cpp +) diff --git a/contrib/libs/llvm14/lib/Linker/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Linker/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..a9fbd64b68f8 --- /dev/null +++ b/contrib/libs/llvm14/lib/Linker/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Linker) +target_compile_options(llvm14-lib-Linker PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Linker PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Linker +) +target_link_libraries(llvm14-lib-Linker PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-IR + llvm14-lib-Object + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(llvm14-lib-Linker PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Linker/IRMover.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Linker/LinkModules.cpp +) diff --git a/contrib/libs/llvm14/lib/Linker/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Linker/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..b0456f1bcead --- /dev/null +++ b/contrib/libs/llvm14/lib/Linker/CMakeLists.linux-aarch64.txt @@ -0,0 +1,30 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Linker) +target_compile_options(llvm14-lib-Linker PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Linker PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Linker +) +target_link_libraries(llvm14-lib-Linker PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-IR + llvm14-lib-Object + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(llvm14-lib-Linker PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Linker/IRMover.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Linker/LinkModules.cpp +) diff --git a/contrib/libs/llvm14/lib/Linker/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Linker/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..b0456f1bcead --- /dev/null +++ b/contrib/libs/llvm14/lib/Linker/CMakeLists.linux-x86_64.txt @@ -0,0 +1,30 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Linker) +target_compile_options(llvm14-lib-Linker PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Linker PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Linker +) +target_link_libraries(llvm14-lib-Linker PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-IR + llvm14-lib-Object + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(llvm14-lib-Linker PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Linker/IRMover.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Linker/LinkModules.cpp +) diff --git a/contrib/libs/llvm14/lib/Linker/CMakeLists.txt b/contrib/libs/llvm14/lib/Linker/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Linker/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Linker/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Linker/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..a9fbd64b68f8 --- /dev/null +++ b/contrib/libs/llvm14/lib/Linker/CMakeLists.windows-x86_64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Linker) +target_compile_options(llvm14-lib-Linker PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Linker PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Linker +) +target_link_libraries(llvm14-lib-Linker PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-IR + llvm14-lib-Object + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(llvm14-lib-Linker PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Linker/IRMover.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Linker/LinkModules.cpp +) diff --git a/contrib/libs/llvm14/lib/MC/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/MC/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..06bbcfc20eab --- /dev/null +++ b/contrib/libs/llvm14/lib/MC/CMakeLists.darwin-arm64.txt @@ -0,0 +1,92 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(MCDisassembler) +add_subdirectory(MCParser) + +add_library(llvm14-lib-MC) +target_compile_options(llvm14-lib-MC PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-MC PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC +) +target_link_libraries(llvm14-lib-MC PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-BinaryFormat + lib-DebugInfo-CodeView + llvm14-lib-Support +) +target_sources(llvm14-lib-MC PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/ConstantPools.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/ELFObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoDarwin.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoGOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoWasm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoXCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmMacro.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAssembler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCCodeEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCCodeView.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDwarf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCELFObjectTargetWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCELFStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCExpr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCFragment.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInst.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInstPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInstrAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInstrDesc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInstrInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCLabel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCLinkerOptimizationHint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCMachOStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCMachObjectTargetWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCNullStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCObjectFileInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCObjectStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCPseudoProbe.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCRegisterInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSchedule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionMachO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionWasm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionXCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSubtargetInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSymbol.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSymbolELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSymbolXCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCTargetOptions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCTargetOptionsCommandFlags.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCValue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWasmObjectTargetWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWasmStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWin64EH.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWinCOFFStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWinEH.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCXCOFFObjectTargetWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCXCOFFStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MachObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/StringTableBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/SubtargetFeature.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/TargetRegistry.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/WasmObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/WinCOFFObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/XCOFFObjectWriter.cpp +) diff --git a/contrib/libs/llvm14/lib/MC/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/MC/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..06bbcfc20eab --- /dev/null +++ b/contrib/libs/llvm14/lib/MC/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,92 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(MCDisassembler) +add_subdirectory(MCParser) + +add_library(llvm14-lib-MC) +target_compile_options(llvm14-lib-MC PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-MC PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC +) +target_link_libraries(llvm14-lib-MC PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-BinaryFormat + lib-DebugInfo-CodeView + llvm14-lib-Support +) +target_sources(llvm14-lib-MC PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/ConstantPools.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/ELFObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoDarwin.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoGOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoWasm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoXCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmMacro.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAssembler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCCodeEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCCodeView.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDwarf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCELFObjectTargetWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCELFStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCExpr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCFragment.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInst.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInstPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInstrAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInstrDesc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInstrInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCLabel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCLinkerOptimizationHint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCMachOStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCMachObjectTargetWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCNullStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCObjectFileInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCObjectStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCPseudoProbe.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCRegisterInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSchedule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionMachO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionWasm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionXCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSubtargetInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSymbol.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSymbolELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSymbolXCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCTargetOptions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCTargetOptionsCommandFlags.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCValue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWasmObjectTargetWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWasmStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWin64EH.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWinCOFFStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWinEH.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCXCOFFObjectTargetWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCXCOFFStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MachObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/StringTableBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/SubtargetFeature.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/TargetRegistry.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/WasmObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/WinCOFFObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/XCOFFObjectWriter.cpp +) diff --git a/contrib/libs/llvm14/lib/MC/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/MC/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..1aada8620f3d --- /dev/null +++ b/contrib/libs/llvm14/lib/MC/CMakeLists.linux-aarch64.txt @@ -0,0 +1,93 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(MCDisassembler) +add_subdirectory(MCParser) + +add_library(llvm14-lib-MC) +target_compile_options(llvm14-lib-MC PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-MC PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC +) +target_link_libraries(llvm14-lib-MC PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-BinaryFormat + lib-DebugInfo-CodeView + llvm14-lib-Support +) +target_sources(llvm14-lib-MC PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/ConstantPools.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/ELFObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoDarwin.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoGOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoWasm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoXCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmMacro.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAssembler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCCodeEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCCodeView.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDwarf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCELFObjectTargetWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCELFStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCExpr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCFragment.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInst.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInstPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInstrAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInstrDesc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInstrInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCLabel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCLinkerOptimizationHint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCMachOStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCMachObjectTargetWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCNullStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCObjectFileInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCObjectStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCPseudoProbe.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCRegisterInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSchedule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionMachO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionWasm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionXCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSubtargetInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSymbol.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSymbolELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSymbolXCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCTargetOptions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCTargetOptionsCommandFlags.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCValue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWasmObjectTargetWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWasmStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWin64EH.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWinCOFFStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWinEH.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCXCOFFObjectTargetWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCXCOFFStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MachObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/StringTableBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/SubtargetFeature.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/TargetRegistry.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/WasmObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/WinCOFFObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/XCOFFObjectWriter.cpp +) diff --git a/contrib/libs/llvm14/lib/MC/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/MC/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..1aada8620f3d --- /dev/null +++ b/contrib/libs/llvm14/lib/MC/CMakeLists.linux-x86_64.txt @@ -0,0 +1,93 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(MCDisassembler) +add_subdirectory(MCParser) + +add_library(llvm14-lib-MC) +target_compile_options(llvm14-lib-MC PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-MC PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC +) +target_link_libraries(llvm14-lib-MC PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-BinaryFormat + lib-DebugInfo-CodeView + llvm14-lib-Support +) +target_sources(llvm14-lib-MC PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/ConstantPools.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/ELFObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoDarwin.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoGOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoWasm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoXCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmMacro.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAssembler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCCodeEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCCodeView.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDwarf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCELFObjectTargetWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCELFStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCExpr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCFragment.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInst.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInstPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInstrAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInstrDesc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInstrInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCLabel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCLinkerOptimizationHint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCMachOStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCMachObjectTargetWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCNullStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCObjectFileInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCObjectStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCPseudoProbe.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCRegisterInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSchedule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionMachO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionWasm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionXCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSubtargetInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSymbol.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSymbolELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSymbolXCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCTargetOptions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCTargetOptionsCommandFlags.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCValue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWasmObjectTargetWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWasmStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWin64EH.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWinCOFFStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWinEH.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCXCOFFObjectTargetWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCXCOFFStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MachObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/StringTableBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/SubtargetFeature.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/TargetRegistry.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/WasmObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/WinCOFFObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/XCOFFObjectWriter.cpp +) diff --git a/contrib/libs/llvm14/lib/MC/CMakeLists.txt b/contrib/libs/llvm14/lib/MC/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/MC/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/MC/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/MC/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..06bbcfc20eab --- /dev/null +++ b/contrib/libs/llvm14/lib/MC/CMakeLists.windows-x86_64.txt @@ -0,0 +1,92 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(MCDisassembler) +add_subdirectory(MCParser) + +add_library(llvm14-lib-MC) +target_compile_options(llvm14-lib-MC PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-MC PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC +) +target_link_libraries(llvm14-lib-MC PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-BinaryFormat + lib-DebugInfo-CodeView + llvm14-lib-Support +) +target_sources(llvm14-lib-MC PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/ConstantPools.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/ELFObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoDarwin.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoGOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoWasm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmInfoXCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmMacro.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAsmStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCAssembler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCCodeEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCCodeView.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDwarf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCELFObjectTargetWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCELFStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCExpr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCFragment.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInst.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInstPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInstrAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInstrDesc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCInstrInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCLabel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCLinkerOptimizationHint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCMachOStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCMachObjectTargetWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCNullStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCObjectFileInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCObjectStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCPseudoProbe.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCRegisterInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSchedule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSection.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionMachO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionWasm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSectionXCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSubtargetInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSymbol.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSymbolELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCSymbolXCOFF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCTargetOptions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCTargetOptionsCommandFlags.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCValue.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWasmObjectTargetWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWasmStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWin64EH.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWinCOFFStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCWinEH.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCXCOFFObjectTargetWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCXCOFFStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MachObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/StringTableBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/SubtargetFeature.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/TargetRegistry.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/WasmObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/WinCOFFObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/XCOFFObjectWriter.cpp +) diff --git a/contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..b9fe49fdcdd3 --- /dev/null +++ b/contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.darwin-arm64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-MC-MCDisassembler) +target_compile_options(lib-MC-MCDisassembler PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-MC-MCDisassembler PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler +) +target_link_libraries(lib-MC-MCDisassembler PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-MC + llvm14-lib-Support +) +target_sources(lib-MC-MCDisassembler PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/Disassembler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/MCDisassembler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/MCExternalSymbolizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/MCRelocationInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/MCSymbolizer.cpp +) diff --git a/contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..b9fe49fdcdd3 --- /dev/null +++ b/contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-MC-MCDisassembler) +target_compile_options(lib-MC-MCDisassembler PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-MC-MCDisassembler PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler +) +target_link_libraries(lib-MC-MCDisassembler PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-MC + llvm14-lib-Support +) +target_sources(lib-MC-MCDisassembler PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/Disassembler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/MCDisassembler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/MCExternalSymbolizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/MCRelocationInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/MCSymbolizer.cpp +) diff --git a/contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..095467d9075c --- /dev/null +++ b/contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.linux-aarch64.txt @@ -0,0 +1,30 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-MC-MCDisassembler) +target_compile_options(lib-MC-MCDisassembler PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-MC-MCDisassembler PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler +) +target_link_libraries(lib-MC-MCDisassembler PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-MC + llvm14-lib-Support +) +target_sources(lib-MC-MCDisassembler PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/Disassembler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/MCDisassembler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/MCExternalSymbolizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/MCRelocationInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/MCSymbolizer.cpp +) diff --git a/contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..095467d9075c --- /dev/null +++ b/contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.linux-x86_64.txt @@ -0,0 +1,30 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-MC-MCDisassembler) +target_compile_options(lib-MC-MCDisassembler PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-MC-MCDisassembler PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler +) +target_link_libraries(lib-MC-MCDisassembler PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-MC + llvm14-lib-Support +) +target_sources(lib-MC-MCDisassembler PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/Disassembler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/MCDisassembler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/MCExternalSymbolizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/MCRelocationInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/MCSymbolizer.cpp +) diff --git a/contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.txt b/contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..b9fe49fdcdd3 --- /dev/null +++ b/contrib/libs/llvm14/lib/MC/MCDisassembler/CMakeLists.windows-x86_64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-MC-MCDisassembler) +target_compile_options(lib-MC-MCDisassembler PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-MC-MCDisassembler PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler +) +target_link_libraries(lib-MC-MCDisassembler PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-MC + llvm14-lib-Support +) +target_sources(lib-MC-MCDisassembler PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/Disassembler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/MCDisassembler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/MCExternalSymbolizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/MCRelocationInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCDisassembler/MCSymbolizer.cpp +) diff --git a/contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..401c179ee88a --- /dev/null +++ b/contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.darwin-arm64.txt @@ -0,0 +1,38 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-MC-MCParser) +target_compile_options(lib-MC-MCParser PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-MC-MCParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser +) +target_link_libraries(lib-MC-MCParser PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-MC + llvm14-lib-Support +) +target_sources(lib-MC-MCParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/AsmLexer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/AsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/COFFAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/COFFMasmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/DarwinAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/ELFAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/GOFFAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MCAsmLexer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MCAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MCAsmParserExtension.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MCTargetAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MasmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/WasmAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/XCOFFAsmParser.cpp +) diff --git a/contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..401c179ee88a --- /dev/null +++ b/contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,38 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-MC-MCParser) +target_compile_options(lib-MC-MCParser PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-MC-MCParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser +) +target_link_libraries(lib-MC-MCParser PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-MC + llvm14-lib-Support +) +target_sources(lib-MC-MCParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/AsmLexer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/AsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/COFFAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/COFFMasmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/DarwinAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/ELFAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/GOFFAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MCAsmLexer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MCAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MCAsmParserExtension.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MCTargetAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MasmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/WasmAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/XCOFFAsmParser.cpp +) diff --git a/contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..3d79d4a27434 --- /dev/null +++ b/contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.linux-aarch64.txt @@ -0,0 +1,39 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-MC-MCParser) +target_compile_options(lib-MC-MCParser PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-MC-MCParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser +) +target_link_libraries(lib-MC-MCParser PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-MC + llvm14-lib-Support +) +target_sources(lib-MC-MCParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/AsmLexer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/AsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/COFFAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/COFFMasmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/DarwinAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/ELFAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/GOFFAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MCAsmLexer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MCAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MCAsmParserExtension.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MCTargetAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MasmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/WasmAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/XCOFFAsmParser.cpp +) diff --git a/contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..3d79d4a27434 --- /dev/null +++ b/contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.linux-x86_64.txt @@ -0,0 +1,39 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-MC-MCParser) +target_compile_options(lib-MC-MCParser PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-MC-MCParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser +) +target_link_libraries(lib-MC-MCParser PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-MC + llvm14-lib-Support +) +target_sources(lib-MC-MCParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/AsmLexer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/AsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/COFFAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/COFFMasmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/DarwinAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/ELFAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/GOFFAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MCAsmLexer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MCAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MCAsmParserExtension.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MCTargetAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MasmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/WasmAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/XCOFFAsmParser.cpp +) diff --git a/contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.txt b/contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..401c179ee88a --- /dev/null +++ b/contrib/libs/llvm14/lib/MC/MCParser/CMakeLists.windows-x86_64.txt @@ -0,0 +1,38 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-MC-MCParser) +target_compile_options(lib-MC-MCParser PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-MC-MCParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser +) +target_link_libraries(lib-MC-MCParser PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-MC + llvm14-lib-Support +) +target_sources(lib-MC-MCParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/AsmLexer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/AsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/COFFAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/COFFMasmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/DarwinAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/ELFAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/GOFFAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MCAsmLexer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MCAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MCAsmParserExtension.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MCTargetAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/MasmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/WasmAsmParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/MC/MCParser/XCOFFAsmParser.cpp +) diff --git a/contrib/libs/llvm14/lib/Object/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Object/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..53c7496168b2 --- /dev/null +++ b/contrib/libs/llvm14/lib/Object/CMakeLists.darwin-arm64.txt @@ -0,0 +1,60 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Object) +target_compile_options(llvm14-lib-Object PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Object PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object +) +target_link_libraries(llvm14-lib-Object PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + lib-Bitcode-Reader + llvm14-lib-IR + llvm14-lib-MC + lib-MC-MCParser + llvm14-lib-Support + llvm14-lib-TextAPI +) +target_sources(llvm14-lib-Object PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Archive.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ArchiveWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Binary.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/COFFImportFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/COFFModuleDefinition.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/COFFObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Decompressor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ELFObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Error.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/FaultMapParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/IRObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/IRSymtab.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/MachOObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/MachOUniversal.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/MachOUniversalWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Minidump.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ModuleSymbolTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Object.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/RecordStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/RelocationResolver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/SymbolSize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/SymbolicFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/TapiFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/TapiUniversal.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/WasmObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/WindowsMachineFlag.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/WindowsResource.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/XCOFFObjectFile.cpp +) diff --git a/contrib/libs/llvm14/lib/Object/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Object/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..53c7496168b2 --- /dev/null +++ b/contrib/libs/llvm14/lib/Object/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,60 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Object) +target_compile_options(llvm14-lib-Object PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Object PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object +) +target_link_libraries(llvm14-lib-Object PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + lib-Bitcode-Reader + llvm14-lib-IR + llvm14-lib-MC + lib-MC-MCParser + llvm14-lib-Support + llvm14-lib-TextAPI +) +target_sources(llvm14-lib-Object PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Archive.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ArchiveWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Binary.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/COFFImportFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/COFFModuleDefinition.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/COFFObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Decompressor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ELFObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Error.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/FaultMapParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/IRObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/IRSymtab.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/MachOObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/MachOUniversal.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/MachOUniversalWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Minidump.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ModuleSymbolTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Object.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/RecordStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/RelocationResolver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/SymbolSize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/SymbolicFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/TapiFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/TapiUniversal.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/WasmObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/WindowsMachineFlag.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/WindowsResource.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/XCOFFObjectFile.cpp +) diff --git a/contrib/libs/llvm14/lib/Object/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Object/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..750c087a34ce --- /dev/null +++ b/contrib/libs/llvm14/lib/Object/CMakeLists.linux-aarch64.txt @@ -0,0 +1,61 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Object) +target_compile_options(llvm14-lib-Object PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Object PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object +) +target_link_libraries(llvm14-lib-Object PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + lib-Bitcode-Reader + llvm14-lib-IR + llvm14-lib-MC + lib-MC-MCParser + llvm14-lib-Support + llvm14-lib-TextAPI +) +target_sources(llvm14-lib-Object PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Archive.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ArchiveWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Binary.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/COFFImportFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/COFFModuleDefinition.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/COFFObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Decompressor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ELFObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Error.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/FaultMapParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/IRObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/IRSymtab.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/MachOObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/MachOUniversal.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/MachOUniversalWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Minidump.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ModuleSymbolTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Object.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/RecordStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/RelocationResolver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/SymbolSize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/SymbolicFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/TapiFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/TapiUniversal.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/WasmObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/WindowsMachineFlag.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/WindowsResource.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/XCOFFObjectFile.cpp +) diff --git a/contrib/libs/llvm14/lib/Object/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Object/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..750c087a34ce --- /dev/null +++ b/contrib/libs/llvm14/lib/Object/CMakeLists.linux-x86_64.txt @@ -0,0 +1,61 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Object) +target_compile_options(llvm14-lib-Object PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Object PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object +) +target_link_libraries(llvm14-lib-Object PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + lib-Bitcode-Reader + llvm14-lib-IR + llvm14-lib-MC + lib-MC-MCParser + llvm14-lib-Support + llvm14-lib-TextAPI +) +target_sources(llvm14-lib-Object PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Archive.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ArchiveWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Binary.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/COFFImportFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/COFFModuleDefinition.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/COFFObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Decompressor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ELFObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Error.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/FaultMapParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/IRObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/IRSymtab.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/MachOObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/MachOUniversal.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/MachOUniversalWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Minidump.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ModuleSymbolTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Object.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/RecordStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/RelocationResolver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/SymbolSize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/SymbolicFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/TapiFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/TapiUniversal.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/WasmObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/WindowsMachineFlag.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/WindowsResource.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/XCOFFObjectFile.cpp +) diff --git a/contrib/libs/llvm14/lib/Object/CMakeLists.txt b/contrib/libs/llvm14/lib/Object/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Object/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Object/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Object/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..53c7496168b2 --- /dev/null +++ b/contrib/libs/llvm14/lib/Object/CMakeLists.windows-x86_64.txt @@ -0,0 +1,60 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Object) +target_compile_options(llvm14-lib-Object PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Object PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object +) +target_link_libraries(llvm14-lib-Object PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + lib-Bitcode-Reader + llvm14-lib-IR + llvm14-lib-MC + lib-MC-MCParser + llvm14-lib-Support + llvm14-lib-TextAPI +) +target_sources(llvm14-lib-Object PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Archive.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ArchiveWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Binary.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/COFFImportFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/COFFModuleDefinition.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/COFFObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Decompressor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ELF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ELFObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Error.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/FaultMapParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/IRObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/IRSymtab.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/MachOObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/MachOUniversal.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/MachOUniversalWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Minidump.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ModuleSymbolTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/Object.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/ObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/RecordStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/RelocationResolver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/SymbolSize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/SymbolicFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/TapiFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/TapiUniversal.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/WasmObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/WindowsMachineFlag.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/WindowsResource.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Object/XCOFFObjectFile.cpp +) diff --git a/contrib/libs/llvm14/lib/ProfileData/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/ProfileData/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..59de7575b123 --- /dev/null +++ b/contrib/libs/llvm14/lib/ProfileData/CMakeLists.darwin-arm64.txt @@ -0,0 +1,38 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-ProfileData) +target_compile_options(llvm14-lib-ProfileData PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-ProfileData PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData +) +target_link_libraries(llvm14-lib-ProfileData PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + lib-DebugInfo-DWARF + llvm14-lib-Demangle + llvm14-lib-IR + llvm14-lib-Object + llvm14-lib-Support +) +target_sources(llvm14-lib-ProfileData PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/GCOV.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/InstrProf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/InstrProfCorrelator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/InstrProfReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/InstrProfWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/ProfileSummaryBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/RawMemProfReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/SampleProf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/SampleProfReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/SampleProfWriter.cpp +) diff --git a/contrib/libs/llvm14/lib/ProfileData/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/ProfileData/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..59de7575b123 --- /dev/null +++ b/contrib/libs/llvm14/lib/ProfileData/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,38 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-ProfileData) +target_compile_options(llvm14-lib-ProfileData PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-ProfileData PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData +) +target_link_libraries(llvm14-lib-ProfileData PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + lib-DebugInfo-DWARF + llvm14-lib-Demangle + llvm14-lib-IR + llvm14-lib-Object + llvm14-lib-Support +) +target_sources(llvm14-lib-ProfileData PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/GCOV.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/InstrProf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/InstrProfCorrelator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/InstrProfReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/InstrProfWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/ProfileSummaryBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/RawMemProfReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/SampleProf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/SampleProfReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/SampleProfWriter.cpp +) diff --git a/contrib/libs/llvm14/lib/ProfileData/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/ProfileData/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..f3fb87b8f237 --- /dev/null +++ b/contrib/libs/llvm14/lib/ProfileData/CMakeLists.linux-aarch64.txt @@ -0,0 +1,39 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-ProfileData) +target_compile_options(llvm14-lib-ProfileData PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-ProfileData PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData +) +target_link_libraries(llvm14-lib-ProfileData PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + lib-DebugInfo-DWARF + llvm14-lib-Demangle + llvm14-lib-IR + llvm14-lib-Object + llvm14-lib-Support +) +target_sources(llvm14-lib-ProfileData PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/GCOV.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/InstrProf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/InstrProfCorrelator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/InstrProfReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/InstrProfWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/ProfileSummaryBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/RawMemProfReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/SampleProf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/SampleProfReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/SampleProfWriter.cpp +) diff --git a/contrib/libs/llvm14/lib/ProfileData/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/ProfileData/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..f3fb87b8f237 --- /dev/null +++ b/contrib/libs/llvm14/lib/ProfileData/CMakeLists.linux-x86_64.txt @@ -0,0 +1,39 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-ProfileData) +target_compile_options(llvm14-lib-ProfileData PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-ProfileData PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData +) +target_link_libraries(llvm14-lib-ProfileData PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + lib-DebugInfo-DWARF + llvm14-lib-Demangle + llvm14-lib-IR + llvm14-lib-Object + llvm14-lib-Support +) +target_sources(llvm14-lib-ProfileData PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/GCOV.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/InstrProf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/InstrProfCorrelator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/InstrProfReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/InstrProfWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/ProfileSummaryBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/RawMemProfReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/SampleProf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/SampleProfReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/SampleProfWriter.cpp +) diff --git a/contrib/libs/llvm14/lib/ProfileData/CMakeLists.txt b/contrib/libs/llvm14/lib/ProfileData/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/ProfileData/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/ProfileData/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/ProfileData/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..59de7575b123 --- /dev/null +++ b/contrib/libs/llvm14/lib/ProfileData/CMakeLists.windows-x86_64.txt @@ -0,0 +1,38 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-ProfileData) +target_compile_options(llvm14-lib-ProfileData PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-ProfileData PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData +) +target_link_libraries(llvm14-lib-ProfileData PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + lib-DebugInfo-DWARF + llvm14-lib-Demangle + llvm14-lib-IR + llvm14-lib-Object + llvm14-lib-Support +) +target_sources(llvm14-lib-ProfileData PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/GCOV.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/InstrProf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/InstrProfCorrelator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/InstrProfReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/InstrProfWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/ProfileSummaryBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/RawMemProfReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/SampleProf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/SampleProfReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/ProfileData/SampleProfWriter.cpp +) diff --git a/contrib/libs/llvm14/lib/Remarks/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Remarks/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..59ec252e813f --- /dev/null +++ b/contrib/libs/llvm14/lib/Remarks/CMakeLists.darwin-arm64.txt @@ -0,0 +1,35 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Remarks) +target_compile_options(llvm14-lib-Remarks PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Remarks PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks +) +target_link_libraries(llvm14-lib-Remarks PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + lib-Bitstream-Reader + llvm14-lib-Support +) +target_sources(llvm14-lib-Remarks PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/BitstreamRemarkParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/BitstreamRemarkSerializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/Remark.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkFormat.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkLinker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkSerializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkStringTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/YAMLRemarkParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/YAMLRemarkSerializer.cpp +) diff --git a/contrib/libs/llvm14/lib/Remarks/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Remarks/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..59ec252e813f --- /dev/null +++ b/contrib/libs/llvm14/lib/Remarks/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,35 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Remarks) +target_compile_options(llvm14-lib-Remarks PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Remarks PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks +) +target_link_libraries(llvm14-lib-Remarks PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + lib-Bitstream-Reader + llvm14-lib-Support +) +target_sources(llvm14-lib-Remarks PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/BitstreamRemarkParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/BitstreamRemarkSerializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/Remark.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkFormat.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkLinker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkSerializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkStringTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/YAMLRemarkParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/YAMLRemarkSerializer.cpp +) diff --git a/contrib/libs/llvm14/lib/Remarks/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Remarks/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..b06557b9a751 --- /dev/null +++ b/contrib/libs/llvm14/lib/Remarks/CMakeLists.linux-aarch64.txt @@ -0,0 +1,36 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Remarks) +target_compile_options(llvm14-lib-Remarks PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Remarks PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks +) +target_link_libraries(llvm14-lib-Remarks PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + lib-Bitstream-Reader + llvm14-lib-Support +) +target_sources(llvm14-lib-Remarks PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/BitstreamRemarkParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/BitstreamRemarkSerializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/Remark.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkFormat.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkLinker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkSerializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkStringTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/YAMLRemarkParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/YAMLRemarkSerializer.cpp +) diff --git a/contrib/libs/llvm14/lib/Remarks/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Remarks/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..b06557b9a751 --- /dev/null +++ b/contrib/libs/llvm14/lib/Remarks/CMakeLists.linux-x86_64.txt @@ -0,0 +1,36 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Remarks) +target_compile_options(llvm14-lib-Remarks PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Remarks PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks +) +target_link_libraries(llvm14-lib-Remarks PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + lib-Bitstream-Reader + llvm14-lib-Support +) +target_sources(llvm14-lib-Remarks PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/BitstreamRemarkParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/BitstreamRemarkSerializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/Remark.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkFormat.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkLinker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkSerializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkStringTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/YAMLRemarkParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/YAMLRemarkSerializer.cpp +) diff --git a/contrib/libs/llvm14/lib/Remarks/CMakeLists.txt b/contrib/libs/llvm14/lib/Remarks/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Remarks/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Remarks/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Remarks/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..59ec252e813f --- /dev/null +++ b/contrib/libs/llvm14/lib/Remarks/CMakeLists.windows-x86_64.txt @@ -0,0 +1,35 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Remarks) +target_compile_options(llvm14-lib-Remarks PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Remarks PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks +) +target_link_libraries(llvm14-lib-Remarks PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + lib-Bitstream-Reader + llvm14-lib-Support +) +target_sources(llvm14-lib-Remarks PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/BitstreamRemarkParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/BitstreamRemarkSerializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/Remark.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkFormat.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkLinker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkSerializer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/RemarkStringTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/YAMLRemarkParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Remarks/YAMLRemarkSerializer.cpp +) diff --git a/contrib/libs/llvm14/lib/Support/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Support/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..aa385fbe2416 --- /dev/null +++ b/contrib/libs/llvm14/lib/Support/CMakeLists.darwin-arm64.txt @@ -0,0 +1,167 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Support) +target_compile_options(llvm14-lib-Support PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Support PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support +) +target_link_libraries(llvm14-lib-Support PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Demangle + contrib-libs-zlib + cpp-sanitizer-include +) +target_sources(llvm14-lib-Support PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/AArch64TargetParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ABIBreak.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/AMDGPUMetadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/APFixedPoint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/APFloat.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/APInt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/APSInt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ARMAttributeParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ARMBuildAttrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ARMTargetParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ARMWinEH.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Allocator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Atomic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/AutoConvert.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BinaryStreamError.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BinaryStreamReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BinaryStreamRef.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BinaryStreamWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BlockFrequency.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BranchProbability.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BuryPointer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/COM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CRC.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CachePruning.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Caching.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Chrono.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CodeGenCoverage.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CommandLine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Compression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ConvertUTF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ConvertUTFWrapper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CrashRecoveryContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DAGDeltaAlgorithm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DJB.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DataExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Debug.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DebugCounter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DeltaAlgorithm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DivisionByConstantInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DynamicLibrary.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ELFAttributeParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ELFAttributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Errno.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Error.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ErrorHandling.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ExtensibleRTTI.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FileCollector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FileOutputBuffer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FileUtilities.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FoldingSet.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FormatVariadic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FormattedStream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/GlobPattern.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/GraphWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Hashing.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Host.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/InitLLVM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/InstructionCost.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/IntEqClasses.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/IntervalMap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ItaniumManglingCanonicalizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/JSON.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/KnownBits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/LEB128.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/LineIterator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Locale.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/LockFileManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/LowLevelType.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MD5.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MSP430AttributeParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MSP430Attributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ManagedStatic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MathExtras.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MemAlloc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Memory.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MemoryBuffer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MemoryBufferRef.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/NativeFormatting.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/OptimizedStructLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Optional.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Parallel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Path.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/PluginLoader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/PrettyStackTrace.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Process.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Program.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RISCVAttributeParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RISCVAttributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RISCVISAInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RWMutex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RandomNumberGenerator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Regex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SHA1.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SHA256.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ScaledNumber.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ScopedPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Signals.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Signposts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SmallPtrSet.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SmallVector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SourceMgr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SpecialCaseList.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Statistic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/StringExtras.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/StringMap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/StringRef.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/StringSaver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SuffixTree.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SymbolRemappingReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SystemUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TarWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TargetParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ThreadLocal.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ThreadPool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Threading.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TimeProfiler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Timer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ToolOutputFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TrigramIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Triple.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Twine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TypeSize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Unicode.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/UnicodeCaseFold.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Valgrind.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/VersionTuple.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/VirtualFileSystem.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Watchdog.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/WithColor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/X86TargetParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/YAMLParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/YAMLTraits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Z3Solver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/circular_raw_ostream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/raw_os_ostream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/raw_ostream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regcomp.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regerror.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regexec.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regfree.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regstrlcpy.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/xxhash.cpp +) diff --git a/contrib/libs/llvm14/lib/Support/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Support/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..aa385fbe2416 --- /dev/null +++ b/contrib/libs/llvm14/lib/Support/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,167 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Support) +target_compile_options(llvm14-lib-Support PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Support PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support +) +target_link_libraries(llvm14-lib-Support PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Demangle + contrib-libs-zlib + cpp-sanitizer-include +) +target_sources(llvm14-lib-Support PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/AArch64TargetParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ABIBreak.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/AMDGPUMetadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/APFixedPoint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/APFloat.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/APInt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/APSInt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ARMAttributeParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ARMBuildAttrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ARMTargetParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ARMWinEH.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Allocator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Atomic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/AutoConvert.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BinaryStreamError.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BinaryStreamReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BinaryStreamRef.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BinaryStreamWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BlockFrequency.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BranchProbability.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BuryPointer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/COM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CRC.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CachePruning.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Caching.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Chrono.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CodeGenCoverage.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CommandLine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Compression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ConvertUTF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ConvertUTFWrapper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CrashRecoveryContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DAGDeltaAlgorithm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DJB.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DataExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Debug.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DebugCounter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DeltaAlgorithm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DivisionByConstantInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DynamicLibrary.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ELFAttributeParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ELFAttributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Errno.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Error.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ErrorHandling.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ExtensibleRTTI.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FileCollector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FileOutputBuffer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FileUtilities.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FoldingSet.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FormatVariadic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FormattedStream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/GlobPattern.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/GraphWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Hashing.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Host.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/InitLLVM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/InstructionCost.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/IntEqClasses.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/IntervalMap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ItaniumManglingCanonicalizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/JSON.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/KnownBits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/LEB128.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/LineIterator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Locale.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/LockFileManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/LowLevelType.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MD5.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MSP430AttributeParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MSP430Attributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ManagedStatic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MathExtras.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MemAlloc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Memory.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MemoryBuffer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MemoryBufferRef.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/NativeFormatting.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/OptimizedStructLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Optional.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Parallel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Path.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/PluginLoader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/PrettyStackTrace.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Process.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Program.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RISCVAttributeParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RISCVAttributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RISCVISAInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RWMutex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RandomNumberGenerator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Regex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SHA1.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SHA256.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ScaledNumber.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ScopedPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Signals.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Signposts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SmallPtrSet.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SmallVector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SourceMgr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SpecialCaseList.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Statistic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/StringExtras.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/StringMap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/StringRef.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/StringSaver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SuffixTree.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SymbolRemappingReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SystemUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TarWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TargetParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ThreadLocal.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ThreadPool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Threading.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TimeProfiler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Timer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ToolOutputFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TrigramIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Triple.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Twine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TypeSize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Unicode.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/UnicodeCaseFold.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Valgrind.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/VersionTuple.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/VirtualFileSystem.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Watchdog.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/WithColor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/X86TargetParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/YAMLParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/YAMLTraits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Z3Solver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/circular_raw_ostream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/raw_os_ostream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/raw_ostream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regcomp.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regerror.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regexec.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regfree.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regstrlcpy.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/xxhash.cpp +) diff --git a/contrib/libs/llvm14/lib/Support/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Support/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..b9378d53bfc7 --- /dev/null +++ b/contrib/libs/llvm14/lib/Support/CMakeLists.linux-aarch64.txt @@ -0,0 +1,168 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Support) +target_compile_options(llvm14-lib-Support PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Support PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support +) +target_link_libraries(llvm14-lib-Support PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Demangle + contrib-libs-zlib + cpp-sanitizer-include +) +target_sources(llvm14-lib-Support PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/AArch64TargetParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ABIBreak.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/AMDGPUMetadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/APFixedPoint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/APFloat.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/APInt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/APSInt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ARMAttributeParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ARMBuildAttrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ARMTargetParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ARMWinEH.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Allocator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Atomic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/AutoConvert.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BinaryStreamError.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BinaryStreamReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BinaryStreamRef.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BinaryStreamWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BlockFrequency.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BranchProbability.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BuryPointer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/COM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CRC.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CachePruning.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Caching.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Chrono.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CodeGenCoverage.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CommandLine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Compression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ConvertUTF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ConvertUTFWrapper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CrashRecoveryContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DAGDeltaAlgorithm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DJB.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DataExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Debug.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DebugCounter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DeltaAlgorithm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DivisionByConstantInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DynamicLibrary.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ELFAttributeParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ELFAttributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Errno.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Error.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ErrorHandling.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ExtensibleRTTI.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FileCollector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FileOutputBuffer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FileUtilities.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FoldingSet.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FormatVariadic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FormattedStream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/GlobPattern.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/GraphWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Hashing.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Host.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/InitLLVM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/InstructionCost.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/IntEqClasses.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/IntervalMap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ItaniumManglingCanonicalizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/JSON.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/KnownBits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/LEB128.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/LineIterator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Locale.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/LockFileManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/LowLevelType.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MD5.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MSP430AttributeParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MSP430Attributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ManagedStatic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MathExtras.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MemAlloc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Memory.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MemoryBuffer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MemoryBufferRef.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/NativeFormatting.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/OptimizedStructLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Optional.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Parallel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Path.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/PluginLoader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/PrettyStackTrace.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Process.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Program.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RISCVAttributeParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RISCVAttributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RISCVISAInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RWMutex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RandomNumberGenerator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Regex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SHA1.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SHA256.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ScaledNumber.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ScopedPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Signals.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Signposts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SmallPtrSet.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SmallVector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SourceMgr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SpecialCaseList.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Statistic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/StringExtras.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/StringMap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/StringRef.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/StringSaver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SuffixTree.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SymbolRemappingReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SystemUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TarWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TargetParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ThreadLocal.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ThreadPool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Threading.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TimeProfiler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Timer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ToolOutputFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TrigramIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Triple.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Twine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TypeSize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Unicode.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/UnicodeCaseFold.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Valgrind.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/VersionTuple.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/VirtualFileSystem.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Watchdog.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/WithColor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/X86TargetParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/YAMLParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/YAMLTraits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Z3Solver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/circular_raw_ostream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/raw_os_ostream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/raw_ostream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regcomp.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regerror.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regexec.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regfree.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regstrlcpy.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/xxhash.cpp +) diff --git a/contrib/libs/llvm14/lib/Support/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Support/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..b9378d53bfc7 --- /dev/null +++ b/contrib/libs/llvm14/lib/Support/CMakeLists.linux-x86_64.txt @@ -0,0 +1,168 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Support) +target_compile_options(llvm14-lib-Support PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Support PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support +) +target_link_libraries(llvm14-lib-Support PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Demangle + contrib-libs-zlib + cpp-sanitizer-include +) +target_sources(llvm14-lib-Support PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/AArch64TargetParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ABIBreak.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/AMDGPUMetadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/APFixedPoint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/APFloat.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/APInt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/APSInt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ARMAttributeParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ARMBuildAttrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ARMTargetParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ARMWinEH.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Allocator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Atomic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/AutoConvert.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BinaryStreamError.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BinaryStreamReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BinaryStreamRef.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BinaryStreamWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BlockFrequency.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BranchProbability.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BuryPointer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/COM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CRC.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CachePruning.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Caching.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Chrono.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CodeGenCoverage.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CommandLine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Compression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ConvertUTF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ConvertUTFWrapper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CrashRecoveryContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DAGDeltaAlgorithm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DJB.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DataExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Debug.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DebugCounter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DeltaAlgorithm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DivisionByConstantInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DynamicLibrary.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ELFAttributeParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ELFAttributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Errno.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Error.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ErrorHandling.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ExtensibleRTTI.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FileCollector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FileOutputBuffer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FileUtilities.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FoldingSet.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FormatVariadic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FormattedStream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/GlobPattern.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/GraphWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Hashing.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Host.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/InitLLVM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/InstructionCost.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/IntEqClasses.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/IntervalMap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ItaniumManglingCanonicalizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/JSON.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/KnownBits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/LEB128.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/LineIterator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Locale.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/LockFileManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/LowLevelType.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MD5.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MSP430AttributeParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MSP430Attributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ManagedStatic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MathExtras.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MemAlloc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Memory.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MemoryBuffer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MemoryBufferRef.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/NativeFormatting.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/OptimizedStructLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Optional.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Parallel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Path.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/PluginLoader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/PrettyStackTrace.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Process.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Program.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RISCVAttributeParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RISCVAttributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RISCVISAInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RWMutex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RandomNumberGenerator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Regex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SHA1.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SHA256.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ScaledNumber.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ScopedPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Signals.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Signposts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SmallPtrSet.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SmallVector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SourceMgr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SpecialCaseList.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Statistic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/StringExtras.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/StringMap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/StringRef.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/StringSaver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SuffixTree.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SymbolRemappingReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SystemUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TarWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TargetParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ThreadLocal.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ThreadPool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Threading.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TimeProfiler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Timer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ToolOutputFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TrigramIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Triple.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Twine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TypeSize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Unicode.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/UnicodeCaseFold.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Valgrind.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/VersionTuple.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/VirtualFileSystem.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Watchdog.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/WithColor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/X86TargetParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/YAMLParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/YAMLTraits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Z3Solver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/circular_raw_ostream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/raw_os_ostream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/raw_ostream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regcomp.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regerror.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regexec.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regfree.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regstrlcpy.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/xxhash.cpp +) diff --git a/contrib/libs/llvm14/lib/Support/CMakeLists.txt b/contrib/libs/llvm14/lib/Support/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Support/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Support/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Support/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..aa385fbe2416 --- /dev/null +++ b/contrib/libs/llvm14/lib/Support/CMakeLists.windows-x86_64.txt @@ -0,0 +1,167 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-Support) +target_compile_options(llvm14-lib-Support PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Support PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support +) +target_link_libraries(llvm14-lib-Support PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Demangle + contrib-libs-zlib + cpp-sanitizer-include +) +target_sources(llvm14-lib-Support PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/AArch64TargetParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ABIBreak.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/AMDGPUMetadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/APFixedPoint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/APFloat.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/APInt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/APSInt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ARMAttributeParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ARMBuildAttrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ARMTargetParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ARMWinEH.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Allocator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Atomic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/AutoConvert.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BinaryStreamError.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BinaryStreamReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BinaryStreamRef.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BinaryStreamWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BlockFrequency.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BranchProbability.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/BuryPointer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/COM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CRC.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CachePruning.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Caching.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Chrono.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CodeGenCoverage.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CommandLine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Compression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ConvertUTF.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ConvertUTFWrapper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/CrashRecoveryContext.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DAGDeltaAlgorithm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DJB.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DataExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Debug.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DebugCounter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DeltaAlgorithm.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DivisionByConstantInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/DynamicLibrary.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ELFAttributeParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ELFAttributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Errno.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Error.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ErrorHandling.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ExtensibleRTTI.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FileCollector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FileOutputBuffer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FileUtilities.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FoldingSet.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FormatVariadic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/FormattedStream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/GlobPattern.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/GraphWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Hashing.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Host.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/InitLLVM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/InstructionCost.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/IntEqClasses.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/IntervalMap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ItaniumManglingCanonicalizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/JSON.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/KnownBits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/LEB128.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/LineIterator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Locale.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/LockFileManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/LowLevelType.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MD5.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MSP430AttributeParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MSP430Attributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ManagedStatic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MathExtras.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MemAlloc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Memory.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MemoryBuffer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/MemoryBufferRef.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/NativeFormatting.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/OptimizedStructLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Optional.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Parallel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Path.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/PluginLoader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/PrettyStackTrace.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Process.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Program.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RISCVAttributeParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RISCVAttributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RISCVISAInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RWMutex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/RandomNumberGenerator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Regex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SHA1.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SHA256.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ScaledNumber.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ScopedPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Signals.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Signposts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SmallPtrSet.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SmallVector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SourceMgr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SpecialCaseList.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Statistic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/StringExtras.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/StringMap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/StringRef.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/StringSaver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SuffixTree.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SymbolRemappingReader.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/SystemUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TarWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TargetParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ThreadLocal.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ThreadPool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Threading.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TimeProfiler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Timer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/ToolOutputFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TrigramIndex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Triple.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Twine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/TypeSize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Unicode.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/UnicodeCaseFold.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Valgrind.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/VersionTuple.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/VirtualFileSystem.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Watchdog.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/WithColor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/X86TargetParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/YAMLParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/YAMLTraits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/Z3Solver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/circular_raw_ostream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/raw_os_ostream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/raw_ostream.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regcomp.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regerror.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regexec.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regfree.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/regstrlcpy.c + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Support/xxhash.cpp +) diff --git a/contrib/libs/llvm14/lib/TableGen/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/TableGen/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..d677125538d8 --- /dev/null +++ b/contrib/libs/llvm14/lib/TableGen/CMakeLists.darwin-arm64.txt @@ -0,0 +1,34 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-TableGen) +target_compile_options(llvm14-lib-TableGen PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-TableGen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen +) +target_link_libraries(llvm14-lib-TableGen PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(llvm14-lib-TableGen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/DetailedRecordsBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/Error.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/JSONBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/Main.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/Record.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/SetTheory.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/StringMatcher.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/TGLexer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/TGParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/TableGenBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/TableGenBackendSkeleton.cpp +) diff --git a/contrib/libs/llvm14/lib/TableGen/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/TableGen/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..d677125538d8 --- /dev/null +++ b/contrib/libs/llvm14/lib/TableGen/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,34 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-TableGen) +target_compile_options(llvm14-lib-TableGen PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-TableGen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen +) +target_link_libraries(llvm14-lib-TableGen PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(llvm14-lib-TableGen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/DetailedRecordsBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/Error.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/JSONBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/Main.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/Record.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/SetTheory.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/StringMatcher.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/TGLexer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/TGParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/TableGenBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/TableGenBackendSkeleton.cpp +) diff --git a/contrib/libs/llvm14/lib/TableGen/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/TableGen/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..77c91520da4f --- /dev/null +++ b/contrib/libs/llvm14/lib/TableGen/CMakeLists.linux-aarch64.txt @@ -0,0 +1,35 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-TableGen) +target_compile_options(llvm14-lib-TableGen PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-TableGen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen +) +target_link_libraries(llvm14-lib-TableGen PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(llvm14-lib-TableGen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/DetailedRecordsBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/Error.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/JSONBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/Main.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/Record.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/SetTheory.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/StringMatcher.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/TGLexer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/TGParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/TableGenBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/TableGenBackendSkeleton.cpp +) diff --git a/contrib/libs/llvm14/lib/TableGen/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/TableGen/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..77c91520da4f --- /dev/null +++ b/contrib/libs/llvm14/lib/TableGen/CMakeLists.linux-x86_64.txt @@ -0,0 +1,35 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-TableGen) +target_compile_options(llvm14-lib-TableGen PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-TableGen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen +) +target_link_libraries(llvm14-lib-TableGen PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(llvm14-lib-TableGen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/DetailedRecordsBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/Error.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/JSONBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/Main.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/Record.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/SetTheory.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/StringMatcher.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/TGLexer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/TGParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/TableGenBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/TableGenBackendSkeleton.cpp +) diff --git a/contrib/libs/llvm14/lib/TableGen/CMakeLists.txt b/contrib/libs/llvm14/lib/TableGen/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/TableGen/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/TableGen/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/TableGen/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..d677125538d8 --- /dev/null +++ b/contrib/libs/llvm14/lib/TableGen/CMakeLists.windows-x86_64.txt @@ -0,0 +1,34 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-TableGen) +target_compile_options(llvm14-lib-TableGen PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-TableGen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen +) +target_link_libraries(llvm14-lib-TableGen PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support +) +target_sources(llvm14-lib-TableGen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/DetailedRecordsBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/Error.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/JSONBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/Main.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/Record.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/SetTheory.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/StringMatcher.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/TGLexer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/TGParser.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/TableGenBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TableGen/TableGenBackendSkeleton.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Target/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..ba7f47a3c1cb --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/CMakeLists.darwin-arm64.txt @@ -0,0 +1,33 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(X86) + +add_library(llvm14-lib-Target) +target_compile_options(llvm14-lib-Target PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Target PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target +) +target_link_libraries(llvm14-lib-Target PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Support +) +target_sources(llvm14-lib-Target PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/Target.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/TargetIntrinsicInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/TargetLoweringObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/TargetMachine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/TargetMachineC.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Target/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..ba7f47a3c1cb --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,33 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(X86) + +add_library(llvm14-lib-Target) +target_compile_options(llvm14-lib-Target PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Target PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target +) +target_link_libraries(llvm14-lib-Target PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Support +) +target_sources(llvm14-lib-Target PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/Target.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/TargetIntrinsicInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/TargetLoweringObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/TargetMachine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/TargetMachineC.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Target/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..d5ab937935ac --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/CMakeLists.linux-aarch64.txt @@ -0,0 +1,34 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(X86) + +add_library(llvm14-lib-Target) +target_compile_options(llvm14-lib-Target PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Target PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target +) +target_link_libraries(llvm14-lib-Target PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Support +) +target_sources(llvm14-lib-Target PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/Target.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/TargetIntrinsicInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/TargetLoweringObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/TargetMachine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/TargetMachineC.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Target/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..d5ab937935ac --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/CMakeLists.linux-x86_64.txt @@ -0,0 +1,34 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(X86) + +add_library(llvm14-lib-Target) +target_compile_options(llvm14-lib-Target PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Target PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target +) +target_link_libraries(llvm14-lib-Target PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Support +) +target_sources(llvm14-lib-Target PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/Target.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/TargetIntrinsicInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/TargetLoweringObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/TargetMachine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/TargetMachineC.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/CMakeLists.txt b/contrib/libs/llvm14/lib/Target/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Target/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Target/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..ba7f47a3c1cb --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/CMakeLists.windows-x86_64.txt @@ -0,0 +1,33 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(X86) + +add_library(llvm14-lib-Target) +target_compile_options(llvm14-lib-Target PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-Target PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target +) +target_link_libraries(llvm14-lib-Target PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-Support +) +target_sources(llvm14-lib-Target PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/Target.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/TargetIntrinsicInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/TargetLoweringObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/TargetMachine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/TargetMachineC.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..cb4c64a01f44 --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.darwin-arm64.txt @@ -0,0 +1,31 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(Target-X86-AsmParser) +target_compile_options(Target-X86-AsmParser PRIVATE + $,,-Wno-everything> +) +target_include_directories(Target-X86-AsmParser PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/AsmParser +) +target_link_libraries(Target-X86-AsmParser PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-MC + lib-MC-MCParser + llvm14-lib-Support + Target-X86-MCTargetDesc + Target-X86-TargetInfo +) +target_sources(Target-X86-AsmParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/AsmParser/X86AsmParser.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..cb4c64a01f44 --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,31 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(Target-X86-AsmParser) +target_compile_options(Target-X86-AsmParser PRIVATE + $,,-Wno-everything> +) +target_include_directories(Target-X86-AsmParser PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/AsmParser +) +target_link_libraries(Target-X86-AsmParser PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-MC + lib-MC-MCParser + llvm14-lib-Support + Target-X86-MCTargetDesc + Target-X86-TargetInfo +) +target_sources(Target-X86-AsmParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/AsmParser/X86AsmParser.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..063058f4f46e --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.linux-aarch64.txt @@ -0,0 +1,32 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(Target-X86-AsmParser) +target_compile_options(Target-X86-AsmParser PRIVATE + $,,-Wno-everything> +) +target_include_directories(Target-X86-AsmParser PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/AsmParser +) +target_link_libraries(Target-X86-AsmParser PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-MC + lib-MC-MCParser + llvm14-lib-Support + Target-X86-MCTargetDesc + Target-X86-TargetInfo +) +target_sources(Target-X86-AsmParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/AsmParser/X86AsmParser.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..063058f4f46e --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.linux-x86_64.txt @@ -0,0 +1,32 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(Target-X86-AsmParser) +target_compile_options(Target-X86-AsmParser PRIVATE + $,,-Wno-everything> +) +target_include_directories(Target-X86-AsmParser PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/AsmParser +) +target_link_libraries(Target-X86-AsmParser PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-MC + lib-MC-MCParser + llvm14-lib-Support + Target-X86-MCTargetDesc + Target-X86-TargetInfo +) +target_sources(Target-X86-AsmParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/AsmParser/X86AsmParser.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.txt b/contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..cb4c64a01f44 --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/AsmParser/CMakeLists.windows-x86_64.txt @@ -0,0 +1,31 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(Target-X86-AsmParser) +target_compile_options(Target-X86-AsmParser PRIVATE + $,,-Wno-everything> +) +target_include_directories(Target-X86-AsmParser PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/AsmParser +) +target_link_libraries(Target-X86-AsmParser PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-MC + lib-MC-MCParser + llvm14-lib-Support + Target-X86-MCTargetDesc + Target-X86-TargetInfo +) +target_sources(Target-X86-AsmParser PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/AsmParser/X86AsmParser.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Target/X86/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..d5725916fddf --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/CMakeLists.darwin-arm64.txt @@ -0,0 +1,102 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(AsmParser) +add_subdirectory(Disassembler) +add_subdirectory(MCTargetDesc) +add_subdirectory(TargetInfo) + +add_library(lib-Target-X86) +target_compile_options(lib-Target-X86 PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Target-X86 PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 +) +target_link_libraries(lib-Target-X86 PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-CodeGen + lib-CodeGen-AsmPrinter + lib-CodeGen-GlobalISel + lib-CodeGen-SelectionDAG + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-ProfileData + llvm14-lib-Support + llvm14-lib-Target + Target-X86-MCTargetDesc + Target-X86-TargetInfo + lib-Transforms-CFGuard + lib-Transforms-Instrumentation + lib-Transforms-Utils +) +target_sources(lib-Target-X86 PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86AsmPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86AvoidStoreForwardingBlocks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86AvoidTrailingCall.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallFrameOptimization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CmovConversion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86DiscriminateMemOps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86DomainReassignment.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86DynAllocaExpander.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86EvexToVex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ExpandPseudo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FastISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FastTileConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FixupBWInsts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FixupLEAs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FixupSetCC.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FlagsCopyLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FloatingPoint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FrameLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ISelDAGToDAG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ISelLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86IndirectBranchTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86IndirectThunks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InsertPrefetch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InsertWait.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstCombineIntrinsic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA3Info.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFoldTables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstructionSelector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InterleavedAccess.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LegalizerInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LoadValueInjectionLoadHardening.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LoadValueInjectionRetHardening.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LowerAMXIntrinsics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LowerAMXType.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LowerTileCopy.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86MCInstLower.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86MachineFunctionInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86MacroFusion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86OptimizeLEAs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PadShortFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PartialReduction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PreAMXConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PreTileConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBankInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SelectionDAGInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ShuffleDecodeConstantPool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SpeculativeExecutionSideEffectSuppression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SpeculativeLoadHardening.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Subtarget.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86TargetMachine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86TargetObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86TargetTransformInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86TileConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86VZeroUpper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86WinEHState.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Target/X86/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..d5725916fddf --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,102 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(AsmParser) +add_subdirectory(Disassembler) +add_subdirectory(MCTargetDesc) +add_subdirectory(TargetInfo) + +add_library(lib-Target-X86) +target_compile_options(lib-Target-X86 PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Target-X86 PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 +) +target_link_libraries(lib-Target-X86 PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-CodeGen + lib-CodeGen-AsmPrinter + lib-CodeGen-GlobalISel + lib-CodeGen-SelectionDAG + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-ProfileData + llvm14-lib-Support + llvm14-lib-Target + Target-X86-MCTargetDesc + Target-X86-TargetInfo + lib-Transforms-CFGuard + lib-Transforms-Instrumentation + lib-Transforms-Utils +) +target_sources(lib-Target-X86 PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86AsmPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86AvoidStoreForwardingBlocks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86AvoidTrailingCall.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallFrameOptimization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CmovConversion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86DiscriminateMemOps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86DomainReassignment.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86DynAllocaExpander.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86EvexToVex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ExpandPseudo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FastISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FastTileConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FixupBWInsts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FixupLEAs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FixupSetCC.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FlagsCopyLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FloatingPoint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FrameLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ISelDAGToDAG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ISelLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86IndirectBranchTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86IndirectThunks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InsertPrefetch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InsertWait.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstCombineIntrinsic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA3Info.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFoldTables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstructionSelector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InterleavedAccess.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LegalizerInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LoadValueInjectionLoadHardening.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LoadValueInjectionRetHardening.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LowerAMXIntrinsics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LowerAMXType.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LowerTileCopy.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86MCInstLower.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86MachineFunctionInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86MacroFusion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86OptimizeLEAs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PadShortFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PartialReduction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PreAMXConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PreTileConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBankInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SelectionDAGInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ShuffleDecodeConstantPool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SpeculativeExecutionSideEffectSuppression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SpeculativeLoadHardening.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Subtarget.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86TargetMachine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86TargetObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86TargetTransformInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86TileConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86VZeroUpper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86WinEHState.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Target/X86/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..8b9a48b3cccc --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/CMakeLists.linux-aarch64.txt @@ -0,0 +1,103 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(AsmParser) +add_subdirectory(Disassembler) +add_subdirectory(MCTargetDesc) +add_subdirectory(TargetInfo) + +add_library(lib-Target-X86) +target_compile_options(lib-Target-X86 PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Target-X86 PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 +) +target_link_libraries(lib-Target-X86 PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-CodeGen + lib-CodeGen-AsmPrinter + lib-CodeGen-GlobalISel + lib-CodeGen-SelectionDAG + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-ProfileData + llvm14-lib-Support + llvm14-lib-Target + Target-X86-MCTargetDesc + Target-X86-TargetInfo + lib-Transforms-CFGuard + lib-Transforms-Instrumentation + lib-Transforms-Utils +) +target_sources(lib-Target-X86 PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86AsmPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86AvoidStoreForwardingBlocks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86AvoidTrailingCall.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallFrameOptimization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CmovConversion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86DiscriminateMemOps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86DomainReassignment.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86DynAllocaExpander.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86EvexToVex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ExpandPseudo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FastISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FastTileConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FixupBWInsts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FixupLEAs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FixupSetCC.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FlagsCopyLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FloatingPoint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FrameLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ISelDAGToDAG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ISelLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86IndirectBranchTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86IndirectThunks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InsertPrefetch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InsertWait.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstCombineIntrinsic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA3Info.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFoldTables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstructionSelector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InterleavedAccess.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LegalizerInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LoadValueInjectionLoadHardening.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LoadValueInjectionRetHardening.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LowerAMXIntrinsics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LowerAMXType.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LowerTileCopy.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86MCInstLower.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86MachineFunctionInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86MacroFusion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86OptimizeLEAs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PadShortFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PartialReduction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PreAMXConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PreTileConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBankInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SelectionDAGInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ShuffleDecodeConstantPool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SpeculativeExecutionSideEffectSuppression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SpeculativeLoadHardening.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Subtarget.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86TargetMachine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86TargetObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86TargetTransformInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86TileConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86VZeroUpper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86WinEHState.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Target/X86/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..8b9a48b3cccc --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/CMakeLists.linux-x86_64.txt @@ -0,0 +1,103 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(AsmParser) +add_subdirectory(Disassembler) +add_subdirectory(MCTargetDesc) +add_subdirectory(TargetInfo) + +add_library(lib-Target-X86) +target_compile_options(lib-Target-X86 PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Target-X86 PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 +) +target_link_libraries(lib-Target-X86 PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-CodeGen + lib-CodeGen-AsmPrinter + lib-CodeGen-GlobalISel + lib-CodeGen-SelectionDAG + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-ProfileData + llvm14-lib-Support + llvm14-lib-Target + Target-X86-MCTargetDesc + Target-X86-TargetInfo + lib-Transforms-CFGuard + lib-Transforms-Instrumentation + lib-Transforms-Utils +) +target_sources(lib-Target-X86 PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86AsmPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86AvoidStoreForwardingBlocks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86AvoidTrailingCall.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallFrameOptimization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CmovConversion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86DiscriminateMemOps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86DomainReassignment.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86DynAllocaExpander.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86EvexToVex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ExpandPseudo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FastISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FastTileConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FixupBWInsts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FixupLEAs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FixupSetCC.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FlagsCopyLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FloatingPoint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FrameLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ISelDAGToDAG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ISelLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86IndirectBranchTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86IndirectThunks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InsertPrefetch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InsertWait.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstCombineIntrinsic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA3Info.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFoldTables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstructionSelector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InterleavedAccess.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LegalizerInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LoadValueInjectionLoadHardening.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LoadValueInjectionRetHardening.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LowerAMXIntrinsics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LowerAMXType.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LowerTileCopy.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86MCInstLower.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86MachineFunctionInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86MacroFusion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86OptimizeLEAs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PadShortFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PartialReduction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PreAMXConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PreTileConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBankInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SelectionDAGInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ShuffleDecodeConstantPool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SpeculativeExecutionSideEffectSuppression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SpeculativeLoadHardening.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Subtarget.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86TargetMachine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86TargetObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86TargetTransformInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86TileConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86VZeroUpper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86WinEHState.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/CMakeLists.txt b/contrib/libs/llvm14/lib/Target/X86/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Target/X86/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Target/X86/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..d5725916fddf --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/CMakeLists.windows-x86_64.txt @@ -0,0 +1,102 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(AsmParser) +add_subdirectory(Disassembler) +add_subdirectory(MCTargetDesc) +add_subdirectory(TargetInfo) + +add_library(lib-Target-X86) +target_compile_options(lib-Target-X86 PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Target-X86 PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 +) +target_link_libraries(lib-Target-X86 PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-CodeGen + lib-CodeGen-AsmPrinter + lib-CodeGen-GlobalISel + lib-CodeGen-SelectionDAG + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-ProfileData + llvm14-lib-Support + llvm14-lib-Target + Target-X86-MCTargetDesc + Target-X86-TargetInfo + lib-Transforms-CFGuard + lib-Transforms-Instrumentation + lib-Transforms-Utils +) +target_sources(lib-Target-X86 PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86AsmPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86AvoidStoreForwardingBlocks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86AvoidTrailingCall.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallFrameOptimization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CallingConv.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86CmovConversion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86DiscriminateMemOps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86DomainReassignment.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86DynAllocaExpander.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86EvexToVex.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ExpandPseudo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FastISel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FastTileConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FixupBWInsts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FixupLEAs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FixupSetCC.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FlagsCopyLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FloatingPoint.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86FrameLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ISelDAGToDAG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ISelLowering.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86IndirectBranchTracking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86IndirectThunks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InsertPrefetch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InsertWait.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstCombineIntrinsic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFMA3Info.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrFoldTables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstrInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InstructionSelector.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86InterleavedAccess.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LegalizerInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LoadValueInjectionLoadHardening.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LoadValueInjectionRetHardening.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LowerAMXIntrinsics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LowerAMXType.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86LowerTileCopy.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86MCInstLower.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86MachineFunctionInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86MacroFusion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86OptimizeLEAs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PadShortFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PartialReduction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PreAMXConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86PreTileConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterBankInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86RegisterInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SelectionDAGInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86ShuffleDecodeConstantPool.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SpeculativeExecutionSideEffectSuppression.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86SpeculativeLoadHardening.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86Subtarget.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86TargetMachine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86TargetObjectFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86TargetTransformInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86TileConfig.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86VZeroUpper.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/X86WinEHState.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..1e8c66c7a0b0 --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.darwin-arm64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(Target-X86-Disassembler) +target_compile_options(Target-X86-Disassembler PRIVATE + $,,-Wno-everything> +) +target_include_directories(Target-X86-Disassembler PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/Disassembler +) +target_link_libraries(Target-X86-Disassembler PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + lib-MC-MCDisassembler + llvm14-lib-Support + Target-X86-TargetInfo +) +target_sources(Target-X86-Disassembler PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/Disassembler/X86Disassembler.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..1e8c66c7a0b0 --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(Target-X86-Disassembler) +target_compile_options(Target-X86-Disassembler PRIVATE + $,,-Wno-everything> +) +target_include_directories(Target-X86-Disassembler PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/Disassembler +) +target_link_libraries(Target-X86-Disassembler PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + lib-MC-MCDisassembler + llvm14-lib-Support + Target-X86-TargetInfo +) +target_sources(Target-X86-Disassembler PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/Disassembler/X86Disassembler.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..9f59dd15364b --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.linux-aarch64.txt @@ -0,0 +1,30 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(Target-X86-Disassembler) +target_compile_options(Target-X86-Disassembler PRIVATE + $,,-Wno-everything> +) +target_include_directories(Target-X86-Disassembler PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/Disassembler +) +target_link_libraries(Target-X86-Disassembler PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + lib-MC-MCDisassembler + llvm14-lib-Support + Target-X86-TargetInfo +) +target_sources(Target-X86-Disassembler PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/Disassembler/X86Disassembler.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..9f59dd15364b --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.linux-x86_64.txt @@ -0,0 +1,30 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(Target-X86-Disassembler) +target_compile_options(Target-X86-Disassembler PRIVATE + $,,-Wno-everything> +) +target_include_directories(Target-X86-Disassembler PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/Disassembler +) +target_link_libraries(Target-X86-Disassembler PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + lib-MC-MCDisassembler + llvm14-lib-Support + Target-X86-TargetInfo +) +target_sources(Target-X86-Disassembler PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/Disassembler/X86Disassembler.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.txt b/contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..1e8c66c7a0b0 --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/Disassembler/CMakeLists.windows-x86_64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(Target-X86-Disassembler) +target_compile_options(Target-X86-Disassembler PRIVATE + $,,-Wno-everything> +) +target_include_directories(Target-X86-Disassembler PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/Disassembler +) +target_link_libraries(Target-X86-Disassembler PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + lib-MC-MCDisassembler + llvm14-lib-Support + Target-X86-TargetInfo +) +target_sources(Target-X86-Disassembler PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/Disassembler/X86Disassembler.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..ecc1a34cef4f --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.darwin-arm64.txt @@ -0,0 +1,44 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(Target-X86-MCTargetDesc) +target_compile_options(Target-X86-MCTargetDesc PRIVATE + $,,-Wno-everything> +) +target_include_directories(Target-X86-MCTargetDesc PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc +) +target_link_libraries(Target-X86-MCTargetDesc PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + llvm14-lib-MC + lib-MC-MCDisassembler + llvm14-lib-Support + Target-X86-TargetInfo +) +target_sources(Target-X86-MCTargetDesc PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86ATTInstPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86AsmBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86ELFObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86InstComments.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86InstPrinterCommon.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86IntelInstPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86MCAsmInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86MCCodeEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86MCTargetDesc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86MachObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86ShuffleDecode.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86WinCOFFObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86WinCOFFStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86WinCOFFTargetStreamer.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..ecc1a34cef4f --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,44 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(Target-X86-MCTargetDesc) +target_compile_options(Target-X86-MCTargetDesc PRIVATE + $,,-Wno-everything> +) +target_include_directories(Target-X86-MCTargetDesc PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc +) +target_link_libraries(Target-X86-MCTargetDesc PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + llvm14-lib-MC + lib-MC-MCDisassembler + llvm14-lib-Support + Target-X86-TargetInfo +) +target_sources(Target-X86-MCTargetDesc PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86ATTInstPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86AsmBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86ELFObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86InstComments.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86InstPrinterCommon.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86IntelInstPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86MCAsmInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86MCCodeEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86MCTargetDesc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86MachObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86ShuffleDecode.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86WinCOFFObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86WinCOFFStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86WinCOFFTargetStreamer.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..9756eaf945e3 --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.linux-aarch64.txt @@ -0,0 +1,45 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(Target-X86-MCTargetDesc) +target_compile_options(Target-X86-MCTargetDesc PRIVATE + $,,-Wno-everything> +) +target_include_directories(Target-X86-MCTargetDesc PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc +) +target_link_libraries(Target-X86-MCTargetDesc PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + llvm14-lib-MC + lib-MC-MCDisassembler + llvm14-lib-Support + Target-X86-TargetInfo +) +target_sources(Target-X86-MCTargetDesc PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86ATTInstPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86AsmBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86ELFObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86InstComments.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86InstPrinterCommon.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86IntelInstPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86MCAsmInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86MCCodeEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86MCTargetDesc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86MachObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86ShuffleDecode.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86WinCOFFObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86WinCOFFStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86WinCOFFTargetStreamer.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..9756eaf945e3 --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.linux-x86_64.txt @@ -0,0 +1,45 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(Target-X86-MCTargetDesc) +target_compile_options(Target-X86-MCTargetDesc PRIVATE + $,,-Wno-everything> +) +target_include_directories(Target-X86-MCTargetDesc PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc +) +target_link_libraries(Target-X86-MCTargetDesc PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + llvm14-lib-MC + lib-MC-MCDisassembler + llvm14-lib-Support + Target-X86-TargetInfo +) +target_sources(Target-X86-MCTargetDesc PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86ATTInstPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86AsmBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86ELFObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86InstComments.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86InstPrinterCommon.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86IntelInstPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86MCAsmInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86MCCodeEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86MCTargetDesc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86MachObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86ShuffleDecode.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86WinCOFFObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86WinCOFFStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86WinCOFFTargetStreamer.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.txt b/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..ecc1a34cef4f --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/CMakeLists.windows-x86_64.txt @@ -0,0 +1,44 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(Target-X86-MCTargetDesc) +target_compile_options(Target-X86-MCTargetDesc PRIVATE + $,,-Wno-everything> +) +target_include_directories(Target-X86-MCTargetDesc PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc +) +target_link_libraries(Target-X86-MCTargetDesc PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-BinaryFormat + llvm14-lib-MC + lib-MC-MCDisassembler + llvm14-lib-Support + Target-X86-TargetInfo +) +target_sources(Target-X86-MCTargetDesc PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86ATTInstPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86AsmBackend.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86ELFObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86InstComments.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86InstPrinterCommon.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86IntelInstPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86MCAsmInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86MCCodeEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86MCTargetDesc.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86MachObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86ShuffleDecode.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86WinCOFFObjectWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86WinCOFFStreamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/MCTargetDesc/X86WinCOFFTargetStreamer.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..d0cb99814e47 --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.darwin-arm64.txt @@ -0,0 +1,26 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(Target-X86-TargetInfo) +target_compile_options(Target-X86-TargetInfo PRIVATE + $,,-Wno-everything> +) +target_include_directories(Target-X86-TargetInfo PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/TargetInfo +) +target_link_libraries(Target-X86-TargetInfo PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-MC + llvm14-lib-Support +) +target_sources(Target-X86-TargetInfo PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/TargetInfo/X86TargetInfo.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..d0cb99814e47 --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,26 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(Target-X86-TargetInfo) +target_compile_options(Target-X86-TargetInfo PRIVATE + $,,-Wno-everything> +) +target_include_directories(Target-X86-TargetInfo PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/TargetInfo +) +target_link_libraries(Target-X86-TargetInfo PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-MC + llvm14-lib-Support +) +target_sources(Target-X86-TargetInfo PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/TargetInfo/X86TargetInfo.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..5c8860f4f3ed --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.linux-aarch64.txt @@ -0,0 +1,27 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(Target-X86-TargetInfo) +target_compile_options(Target-X86-TargetInfo PRIVATE + $,,-Wno-everything> +) +target_include_directories(Target-X86-TargetInfo PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/TargetInfo +) +target_link_libraries(Target-X86-TargetInfo PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-MC + llvm14-lib-Support +) +target_sources(Target-X86-TargetInfo PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/TargetInfo/X86TargetInfo.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..5c8860f4f3ed --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.linux-x86_64.txt @@ -0,0 +1,27 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(Target-X86-TargetInfo) +target_compile_options(Target-X86-TargetInfo PRIVATE + $,,-Wno-everything> +) +target_include_directories(Target-X86-TargetInfo PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/TargetInfo +) +target_link_libraries(Target-X86-TargetInfo PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-MC + llvm14-lib-Support +) +target_sources(Target-X86-TargetInfo PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/TargetInfo/X86TargetInfo.cpp +) diff --git a/contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.txt b/contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..d0cb99814e47 --- /dev/null +++ b/contrib/libs/llvm14/lib/Target/X86/TargetInfo/CMakeLists.windows-x86_64.txt @@ -0,0 +1,26 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(Target-X86-TargetInfo) +target_compile_options(Target-X86-TargetInfo PRIVATE + $,,-Wno-everything> +) +target_include_directories(Target-X86-TargetInfo PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86 + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/TargetInfo +) +target_link_libraries(Target-X86-TargetInfo PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-MC + llvm14-lib-Support +) +target_sources(Target-X86-TargetInfo PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Target/X86/TargetInfo/X86TargetInfo.cpp +) diff --git a/contrib/libs/llvm14/lib/TextAPI/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/TextAPI/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..b7deb7ed46f2 --- /dev/null +++ b/contrib/libs/llvm14/lib/TextAPI/CMakeLists.darwin-arm64.txt @@ -0,0 +1,33 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-TextAPI) +target_compile_options(llvm14-lib-TextAPI PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-TextAPI PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI +) +target_link_libraries(llvm14-lib-TextAPI PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-BinaryFormat + llvm14-lib-Support +) +target_sources(llvm14-lib-TextAPI PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/Architecture.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/ArchitectureSet.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/InterfaceFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/PackedVersion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/Platform.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/Symbol.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/Target.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/TextStub.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/TextStubCommon.cpp +) diff --git a/contrib/libs/llvm14/lib/TextAPI/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/TextAPI/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..b7deb7ed46f2 --- /dev/null +++ b/contrib/libs/llvm14/lib/TextAPI/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,33 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-TextAPI) +target_compile_options(llvm14-lib-TextAPI PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-TextAPI PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI +) +target_link_libraries(llvm14-lib-TextAPI PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-BinaryFormat + llvm14-lib-Support +) +target_sources(llvm14-lib-TextAPI PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/Architecture.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/ArchitectureSet.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/InterfaceFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/PackedVersion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/Platform.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/Symbol.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/Target.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/TextStub.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/TextStubCommon.cpp +) diff --git a/contrib/libs/llvm14/lib/TextAPI/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/TextAPI/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..895b2cd23699 --- /dev/null +++ b/contrib/libs/llvm14/lib/TextAPI/CMakeLists.linux-aarch64.txt @@ -0,0 +1,34 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-TextAPI) +target_compile_options(llvm14-lib-TextAPI PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-TextAPI PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI +) +target_link_libraries(llvm14-lib-TextAPI PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-BinaryFormat + llvm14-lib-Support +) +target_sources(llvm14-lib-TextAPI PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/Architecture.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/ArchitectureSet.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/InterfaceFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/PackedVersion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/Platform.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/Symbol.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/Target.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/TextStub.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/TextStubCommon.cpp +) diff --git a/contrib/libs/llvm14/lib/TextAPI/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/TextAPI/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..895b2cd23699 --- /dev/null +++ b/contrib/libs/llvm14/lib/TextAPI/CMakeLists.linux-x86_64.txt @@ -0,0 +1,34 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-TextAPI) +target_compile_options(llvm14-lib-TextAPI PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-TextAPI PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI +) +target_link_libraries(llvm14-lib-TextAPI PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-BinaryFormat + llvm14-lib-Support +) +target_sources(llvm14-lib-TextAPI PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/Architecture.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/ArchitectureSet.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/InterfaceFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/PackedVersion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/Platform.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/Symbol.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/Target.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/TextStub.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/TextStubCommon.cpp +) diff --git a/contrib/libs/llvm14/lib/TextAPI/CMakeLists.txt b/contrib/libs/llvm14/lib/TextAPI/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/TextAPI/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/TextAPI/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/TextAPI/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..b7deb7ed46f2 --- /dev/null +++ b/contrib/libs/llvm14/lib/TextAPI/CMakeLists.windows-x86_64.txt @@ -0,0 +1,33 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(llvm14-lib-TextAPI) +target_compile_options(llvm14-lib-TextAPI PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm14-lib-TextAPI PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI +) +target_link_libraries(llvm14-lib-TextAPI PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-BinaryFormat + llvm14-lib-Support +) +target_sources(llvm14-lib-TextAPI PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/Architecture.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/ArchitectureSet.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/InterfaceFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/PackedVersion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/Platform.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/Symbol.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/Target.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/TextStub.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/TextAPI/TextStubCommon.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..e93ebb147929 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.darwin-arm64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-AggressiveInstCombine) +target_compile_options(lib-Transforms-AggressiveInstCombine PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-AggressiveInstCombine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine +) +target_link_libraries(lib-Transforms-AggressiveInstCombine PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-AggressiveInstCombine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/AggressiveInstCombine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/TruncInstCombine.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..e93ebb147929 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-AggressiveInstCombine) +target_compile_options(lib-Transforms-AggressiveInstCombine PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-AggressiveInstCombine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine +) +target_link_libraries(lib-Transforms-AggressiveInstCombine PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-AggressiveInstCombine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/AggressiveInstCombine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/TruncInstCombine.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..0db0cee3d683 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.linux-aarch64.txt @@ -0,0 +1,30 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-AggressiveInstCombine) +target_compile_options(lib-Transforms-AggressiveInstCombine PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-AggressiveInstCombine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine +) +target_link_libraries(lib-Transforms-AggressiveInstCombine PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-AggressiveInstCombine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/AggressiveInstCombine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/TruncInstCombine.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..0db0cee3d683 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.linux-x86_64.txt @@ -0,0 +1,30 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-AggressiveInstCombine) +target_compile_options(lib-Transforms-AggressiveInstCombine PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-AggressiveInstCombine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine +) +target_link_libraries(lib-Transforms-AggressiveInstCombine PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-AggressiveInstCombine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/AggressiveInstCombine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/TruncInstCombine.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.txt b/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..e93ebb147929 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/CMakeLists.windows-x86_64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-AggressiveInstCombine) +target_compile_options(lib-Transforms-AggressiveInstCombine PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-AggressiveInstCombine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine +) +target_link_libraries(lib-Transforms-AggressiveInstCombine PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-AggressiveInstCombine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/AggressiveInstCombine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/AggressiveInstCombine/TruncInstCombine.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..94b81361e296 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.darwin-arm64.txt @@ -0,0 +1,26 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-CFGuard) +target_compile_options(lib-Transforms-CFGuard PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-CFGuard PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/CFGuard +) +target_link_libraries(lib-Transforms-CFGuard PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(lib-Transforms-CFGuard PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/CFGuard/CFGuard.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..94b81361e296 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,26 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-CFGuard) +target_compile_options(lib-Transforms-CFGuard PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-CFGuard PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/CFGuard +) +target_link_libraries(lib-Transforms-CFGuard PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(lib-Transforms-CFGuard PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/CFGuard/CFGuard.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..0c4d50c12268 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.linux-aarch64.txt @@ -0,0 +1,27 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-CFGuard) +target_compile_options(lib-Transforms-CFGuard PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-CFGuard PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/CFGuard +) +target_link_libraries(lib-Transforms-CFGuard PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(lib-Transforms-CFGuard PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/CFGuard/CFGuard.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..0c4d50c12268 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.linux-x86_64.txt @@ -0,0 +1,27 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-CFGuard) +target_compile_options(lib-Transforms-CFGuard PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-CFGuard PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/CFGuard +) +target_link_libraries(lib-Transforms-CFGuard PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(lib-Transforms-CFGuard PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/CFGuard/CFGuard.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.txt b/contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..94b81361e296 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/CFGuard/CMakeLists.windows-x86_64.txt @@ -0,0 +1,26 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-CFGuard) +target_compile_options(lib-Transforms-CFGuard PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-CFGuard PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/CFGuard +) +target_link_libraries(lib-Transforms-CFGuard PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(lib-Transforms-CFGuard PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/CFGuard/CFGuard.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/CMakeLists.txt b/contrib/libs/llvm14/lib/Transforms/CMakeLists.txt new file mode 100644 index 000000000000..3b48fccabd65 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/CMakeLists.txt @@ -0,0 +1,17 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(AggressiveInstCombine) +add_subdirectory(CFGuard) +add_subdirectory(IPO) +add_subdirectory(InstCombine) +add_subdirectory(Instrumentation) +add_subdirectory(ObjCARC) +add_subdirectory(Scalar) +add_subdirectory(Utils) +add_subdirectory(Vectorize) diff --git a/contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..bd58904628d6 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.darwin-arm64.txt @@ -0,0 +1,83 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-IPO) +target_compile_options(lib-Transforms-IPO PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-IPO PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO +) +target_link_libraries(lib-Transforms-IPO PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + lib-Bitcode-Reader + lib-Bitcode-Writer + lib-Frontend-OpenMP + llvm14-lib-IR + llvm14-lib-IRReader + llvm14-lib-Linker + llvm14-lib-Object + llvm14-lib-ProfileData + llvm14-lib-Support + lib-Transforms-AggressiveInstCombine + lib-Transforms-InstCombine + lib-Transforms-Instrumentation + lib-Transforms-Scalar + lib-Transforms-Utils + lib-Transforms-Vectorize +) +target_sources(lib-Transforms-IPO PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/AlwaysInliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/Annotation2Metadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ArgumentPromotion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/Attributor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/AttributorAttributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/BarrierNoopPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/BlockExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/CalledValuePropagation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ConstantMerge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/CrossDSOCFI.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/DeadArgumentElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ElimAvailExtern.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ExtractGV.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ForceFunctionAttrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/FunctionAttrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/FunctionImport.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/FunctionSpecialization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/GlobalDCE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/GlobalOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/GlobalSplit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/HotColdSplitting.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/IPO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/IROutliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/InferFunctionAttrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/InlineSimple.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/Inliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/Internalize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/LoopExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/LowerTypeTests.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/MergeFunctions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ModuleInliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/OpenMPOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/PartialInlining.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/PassManagerBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/PruneEH.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SCCP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SampleContextTracker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SampleProfile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SampleProfileProbe.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/StripDeadPrototypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/StripSymbols.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SyntheticCountsPropagation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ThinLTOBitcodeWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/WholeProgramDevirt.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..bd58904628d6 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,83 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-IPO) +target_compile_options(lib-Transforms-IPO PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-IPO PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO +) +target_link_libraries(lib-Transforms-IPO PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + lib-Bitcode-Reader + lib-Bitcode-Writer + lib-Frontend-OpenMP + llvm14-lib-IR + llvm14-lib-IRReader + llvm14-lib-Linker + llvm14-lib-Object + llvm14-lib-ProfileData + llvm14-lib-Support + lib-Transforms-AggressiveInstCombine + lib-Transforms-InstCombine + lib-Transforms-Instrumentation + lib-Transforms-Scalar + lib-Transforms-Utils + lib-Transforms-Vectorize +) +target_sources(lib-Transforms-IPO PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/AlwaysInliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/Annotation2Metadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ArgumentPromotion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/Attributor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/AttributorAttributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/BarrierNoopPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/BlockExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/CalledValuePropagation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ConstantMerge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/CrossDSOCFI.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/DeadArgumentElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ElimAvailExtern.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ExtractGV.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ForceFunctionAttrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/FunctionAttrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/FunctionImport.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/FunctionSpecialization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/GlobalDCE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/GlobalOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/GlobalSplit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/HotColdSplitting.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/IPO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/IROutliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/InferFunctionAttrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/InlineSimple.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/Inliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/Internalize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/LoopExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/LowerTypeTests.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/MergeFunctions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ModuleInliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/OpenMPOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/PartialInlining.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/PassManagerBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/PruneEH.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SCCP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SampleContextTracker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SampleProfile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SampleProfileProbe.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/StripDeadPrototypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/StripSymbols.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SyntheticCountsPropagation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ThinLTOBitcodeWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/WholeProgramDevirt.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..c1ef12dd7d05 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.linux-aarch64.txt @@ -0,0 +1,84 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-IPO) +target_compile_options(lib-Transforms-IPO PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-IPO PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO +) +target_link_libraries(lib-Transforms-IPO PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + lib-Bitcode-Reader + lib-Bitcode-Writer + lib-Frontend-OpenMP + llvm14-lib-IR + llvm14-lib-IRReader + llvm14-lib-Linker + llvm14-lib-Object + llvm14-lib-ProfileData + llvm14-lib-Support + lib-Transforms-AggressiveInstCombine + lib-Transforms-InstCombine + lib-Transforms-Instrumentation + lib-Transforms-Scalar + lib-Transforms-Utils + lib-Transforms-Vectorize +) +target_sources(lib-Transforms-IPO PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/AlwaysInliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/Annotation2Metadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ArgumentPromotion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/Attributor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/AttributorAttributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/BarrierNoopPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/BlockExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/CalledValuePropagation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ConstantMerge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/CrossDSOCFI.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/DeadArgumentElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ElimAvailExtern.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ExtractGV.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ForceFunctionAttrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/FunctionAttrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/FunctionImport.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/FunctionSpecialization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/GlobalDCE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/GlobalOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/GlobalSplit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/HotColdSplitting.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/IPO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/IROutliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/InferFunctionAttrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/InlineSimple.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/Inliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/Internalize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/LoopExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/LowerTypeTests.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/MergeFunctions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ModuleInliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/OpenMPOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/PartialInlining.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/PassManagerBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/PruneEH.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SCCP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SampleContextTracker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SampleProfile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SampleProfileProbe.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/StripDeadPrototypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/StripSymbols.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SyntheticCountsPropagation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ThinLTOBitcodeWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/WholeProgramDevirt.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..c1ef12dd7d05 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.linux-x86_64.txt @@ -0,0 +1,84 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-IPO) +target_compile_options(lib-Transforms-IPO PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-IPO PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO +) +target_link_libraries(lib-Transforms-IPO PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + lib-Bitcode-Reader + lib-Bitcode-Writer + lib-Frontend-OpenMP + llvm14-lib-IR + llvm14-lib-IRReader + llvm14-lib-Linker + llvm14-lib-Object + llvm14-lib-ProfileData + llvm14-lib-Support + lib-Transforms-AggressiveInstCombine + lib-Transforms-InstCombine + lib-Transforms-Instrumentation + lib-Transforms-Scalar + lib-Transforms-Utils + lib-Transforms-Vectorize +) +target_sources(lib-Transforms-IPO PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/AlwaysInliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/Annotation2Metadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ArgumentPromotion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/Attributor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/AttributorAttributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/BarrierNoopPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/BlockExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/CalledValuePropagation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ConstantMerge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/CrossDSOCFI.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/DeadArgumentElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ElimAvailExtern.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ExtractGV.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ForceFunctionAttrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/FunctionAttrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/FunctionImport.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/FunctionSpecialization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/GlobalDCE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/GlobalOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/GlobalSplit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/HotColdSplitting.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/IPO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/IROutliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/InferFunctionAttrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/InlineSimple.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/Inliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/Internalize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/LoopExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/LowerTypeTests.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/MergeFunctions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ModuleInliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/OpenMPOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/PartialInlining.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/PassManagerBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/PruneEH.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SCCP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SampleContextTracker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SampleProfile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SampleProfileProbe.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/StripDeadPrototypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/StripSymbols.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SyntheticCountsPropagation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ThinLTOBitcodeWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/WholeProgramDevirt.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.txt b/contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..bd58904628d6 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/IPO/CMakeLists.windows-x86_64.txt @@ -0,0 +1,83 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-IPO) +target_compile_options(lib-Transforms-IPO PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-IPO PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO +) +target_link_libraries(lib-Transforms-IPO PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + lib-Bitcode-Reader + lib-Bitcode-Writer + lib-Frontend-OpenMP + llvm14-lib-IR + llvm14-lib-IRReader + llvm14-lib-Linker + llvm14-lib-Object + llvm14-lib-ProfileData + llvm14-lib-Support + lib-Transforms-AggressiveInstCombine + lib-Transforms-InstCombine + lib-Transforms-Instrumentation + lib-Transforms-Scalar + lib-Transforms-Utils + lib-Transforms-Vectorize +) +target_sources(lib-Transforms-IPO PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/AlwaysInliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/Annotation2Metadata.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ArgumentPromotion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/Attributor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/AttributorAttributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/BarrierNoopPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/BlockExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/CalledValuePropagation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ConstantMerge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/CrossDSOCFI.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/DeadArgumentElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ElimAvailExtern.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ExtractGV.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ForceFunctionAttrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/FunctionAttrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/FunctionImport.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/FunctionSpecialization.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/GlobalDCE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/GlobalOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/GlobalSplit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/HotColdSplitting.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/IPO.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/IROutliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/InferFunctionAttrs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/InlineSimple.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/Inliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/Internalize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/LoopExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/LowerTypeTests.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/MergeFunctions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ModuleInliner.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/OpenMPOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/PartialInlining.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/PassManagerBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/PruneEH.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SCCP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SampleContextTracker.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SampleProfile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SampleProfileProbe.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/StripDeadPrototypes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/StripSymbols.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/SyntheticCountsPropagation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/ThinLTOBitcodeWriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/IPO/WholeProgramDevirt.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..c6dc4864667c --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.darwin-arm64.txt @@ -0,0 +1,42 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-InstCombine) +target_compile_options(lib-Transforms-InstCombine PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-InstCombine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine +) +target_link_libraries(lib-Transforms-InstCombine PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-InstCombine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineAddSub.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineAndOrXor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineAtomicRMW.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineCalls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineCasts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineCompares.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineLoadStoreAlloca.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineMulDivRem.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineNegator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombinePHI.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineSelect.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineShifts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineSimplifyDemanded.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineVectorOps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstructionCombining.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..c6dc4864667c --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,42 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-InstCombine) +target_compile_options(lib-Transforms-InstCombine PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-InstCombine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine +) +target_link_libraries(lib-Transforms-InstCombine PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-InstCombine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineAddSub.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineAndOrXor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineAtomicRMW.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineCalls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineCasts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineCompares.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineLoadStoreAlloca.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineMulDivRem.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineNegator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombinePHI.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineSelect.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineShifts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineSimplifyDemanded.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineVectorOps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstructionCombining.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..0f3e8fe7fd97 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.linux-aarch64.txt @@ -0,0 +1,43 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-InstCombine) +target_compile_options(lib-Transforms-InstCombine PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-InstCombine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine +) +target_link_libraries(lib-Transforms-InstCombine PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-InstCombine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineAddSub.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineAndOrXor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineAtomicRMW.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineCalls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineCasts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineCompares.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineLoadStoreAlloca.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineMulDivRem.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineNegator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombinePHI.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineSelect.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineShifts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineSimplifyDemanded.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineVectorOps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstructionCombining.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..0f3e8fe7fd97 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.linux-x86_64.txt @@ -0,0 +1,43 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-InstCombine) +target_compile_options(lib-Transforms-InstCombine PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-InstCombine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine +) +target_link_libraries(lib-Transforms-InstCombine PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-InstCombine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineAddSub.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineAndOrXor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineAtomicRMW.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineCalls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineCasts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineCompares.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineLoadStoreAlloca.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineMulDivRem.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineNegator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombinePHI.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineSelect.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineShifts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineSimplifyDemanded.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineVectorOps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstructionCombining.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.txt b/contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..c6dc4864667c --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/InstCombine/CMakeLists.windows-x86_64.txt @@ -0,0 +1,42 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-InstCombine) +target_compile_options(lib-Transforms-InstCombine PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-InstCombine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine +) +target_link_libraries(lib-Transforms-InstCombine PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-InstCombine PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineAddSub.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineAndOrXor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineAtomicRMW.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineCalls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineCasts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineCompares.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineLoadStoreAlloca.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineMulDivRem.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineNegator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombinePHI.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineSelect.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineShifts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineSimplifyDemanded.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstCombineVectorOps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/InstCombine/InstructionCombining.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..41d5f49dc299 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.darwin-arm64.txt @@ -0,0 +1,48 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-Instrumentation) +target_compile_options(lib-Transforms-Instrumentation PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-Instrumentation PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation +) +target_link_libraries(lib-Transforms-Instrumentation PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-ProfileData + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-Instrumentation PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/AddressSanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/BoundsChecking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/CGProfile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/ControlHeightReduction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/DataFlowSanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/GCOVProfiling.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/HWAddressSanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/IndirectCallPromotion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/InstrOrderFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/InstrProfiling.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/Instrumentation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/MemProfiler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/MemorySanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/PGOInstrumentation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/PGOMemOPSizeOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/PoisonChecking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/SanitizerCoverage.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/ThreadSanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/ValueProfileCollector.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..41d5f49dc299 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,48 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-Instrumentation) +target_compile_options(lib-Transforms-Instrumentation PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-Instrumentation PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation +) +target_link_libraries(lib-Transforms-Instrumentation PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-ProfileData + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-Instrumentation PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/AddressSanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/BoundsChecking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/CGProfile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/ControlHeightReduction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/DataFlowSanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/GCOVProfiling.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/HWAddressSanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/IndirectCallPromotion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/InstrOrderFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/InstrProfiling.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/Instrumentation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/MemProfiler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/MemorySanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/PGOInstrumentation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/PGOMemOPSizeOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/PoisonChecking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/SanitizerCoverage.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/ThreadSanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/ValueProfileCollector.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..1dbd2a3fa921 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.linux-aarch64.txt @@ -0,0 +1,49 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-Instrumentation) +target_compile_options(lib-Transforms-Instrumentation PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-Instrumentation PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation +) +target_link_libraries(lib-Transforms-Instrumentation PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-ProfileData + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-Instrumentation PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/AddressSanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/BoundsChecking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/CGProfile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/ControlHeightReduction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/DataFlowSanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/GCOVProfiling.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/HWAddressSanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/IndirectCallPromotion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/InstrOrderFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/InstrProfiling.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/Instrumentation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/MemProfiler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/MemorySanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/PGOInstrumentation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/PGOMemOPSizeOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/PoisonChecking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/SanitizerCoverage.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/ThreadSanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/ValueProfileCollector.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..1dbd2a3fa921 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.linux-x86_64.txt @@ -0,0 +1,49 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-Instrumentation) +target_compile_options(lib-Transforms-Instrumentation PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-Instrumentation PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation +) +target_link_libraries(lib-Transforms-Instrumentation PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-ProfileData + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-Instrumentation PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/AddressSanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/BoundsChecking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/CGProfile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/ControlHeightReduction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/DataFlowSanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/GCOVProfiling.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/HWAddressSanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/IndirectCallPromotion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/InstrOrderFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/InstrProfiling.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/Instrumentation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/MemProfiler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/MemorySanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/PGOInstrumentation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/PGOMemOPSizeOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/PoisonChecking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/SanitizerCoverage.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/ThreadSanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/ValueProfileCollector.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.txt b/contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..41d5f49dc299 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Instrumentation/CMakeLists.windows-x86_64.txt @@ -0,0 +1,48 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-Instrumentation) +target_compile_options(lib-Transforms-Instrumentation PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-Instrumentation PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation +) +target_link_libraries(lib-Transforms-Instrumentation PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-MC + llvm14-lib-ProfileData + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-Instrumentation PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/AddressSanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/BoundsChecking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/CGProfile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/ControlHeightReduction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/DataFlowSanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/GCOVProfiling.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/HWAddressSanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/IndirectCallPromotion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/InstrOrderFile.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/InstrProfiling.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/Instrumentation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/MemProfiler.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/MemorySanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/PGOInstrumentation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/PGOMemOPSizeOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/PoisonChecking.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/SanitizerCoverage.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/ThreadSanitizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Instrumentation/ValueProfileCollector.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..48566cf1a606 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.darwin-arm64.txt @@ -0,0 +1,36 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-ObjCARC) +target_compile_options(lib-Transforms-ObjCARC PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-ObjCARC PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC +) +target_link_libraries(lib-Transforms-ObjCARC PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-ObjCARC PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/DependencyAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARC.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARCAPElim.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARCContract.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARCExpand.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARCOpts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ProvenanceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ProvenanceAnalysisEvaluator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/PtrState.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..48566cf1a606 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,36 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-ObjCARC) +target_compile_options(lib-Transforms-ObjCARC PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-ObjCARC PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC +) +target_link_libraries(lib-Transforms-ObjCARC PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-ObjCARC PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/DependencyAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARC.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARCAPElim.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARCContract.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARCExpand.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARCOpts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ProvenanceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ProvenanceAnalysisEvaluator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/PtrState.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..05fc2d977aae --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.linux-aarch64.txt @@ -0,0 +1,37 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-ObjCARC) +target_compile_options(lib-Transforms-ObjCARC PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-ObjCARC PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC +) +target_link_libraries(lib-Transforms-ObjCARC PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-ObjCARC PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/DependencyAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARC.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARCAPElim.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARCContract.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARCExpand.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARCOpts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ProvenanceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ProvenanceAnalysisEvaluator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/PtrState.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..05fc2d977aae --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.linux-x86_64.txt @@ -0,0 +1,37 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-ObjCARC) +target_compile_options(lib-Transforms-ObjCARC PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-ObjCARC PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC +) +target_link_libraries(lib-Transforms-ObjCARC PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-ObjCARC PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/DependencyAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARC.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARCAPElim.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARCContract.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARCExpand.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARCOpts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ProvenanceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ProvenanceAnalysisEvaluator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/PtrState.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.txt b/contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..48566cf1a606 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/ObjCARC/CMakeLists.windows-x86_64.txt @@ -0,0 +1,36 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-ObjCARC) +target_compile_options(lib-Transforms-ObjCARC PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-ObjCARC PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC +) +target_link_libraries(lib-Transforms-ObjCARC PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-ObjCARC PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/DependencyAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARC.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARCAPElim.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARCContract.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARCExpand.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ObjCARCOpts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ProvenanceAnalysis.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/ProvenanceAnalysisEvaluator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/ObjCARC/PtrState.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..9ed80178f3b7 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.darwin-arm64.txt @@ -0,0 +1,108 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-Scalar) +target_compile_options(lib-Transforms-Scalar PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-Scalar PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar +) +target_link_libraries(lib-Transforms-Scalar PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-AggressiveInstCombine + lib-Transforms-InstCombine + lib-Transforms-Utils +) +target_sources(lib-Transforms-Scalar PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/ADCE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/AlignmentFromAssumptions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/AnnotationRemarks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/BDCE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/CallSiteSplitting.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/ConstantHoisting.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/ConstraintElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/CorrelatedValuePropagation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/DCE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/DFAJumpThreading.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/DeadStoreElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/DivRemPairs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/EarlyCSE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/FlattenCFGPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Float2Int.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/GVN.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/GVNHoist.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/GVNSink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/GuardWidening.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/IVUsersPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/IndVarSimplify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/InductiveRangeCheckElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/InferAddressSpaces.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/InstSimplifyPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/JumpThreading.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LICM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopAccessAnalysisPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopBoundSplit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopDataPrefetch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopDeletion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopDistribute.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopFlatten.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopFuse.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopIdiomRecognize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopInstSimplify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopInterchange.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopLoadElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopPassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopPredication.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopRerollPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopRotation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopSimplifyCFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopSink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopStrengthReduce.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopUnrollAndJamPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopUnrollPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopUnswitch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopVersioningLICM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerAtomic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerConstantIntrinsics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerExpectIntrinsic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerGuardIntrinsic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerMatrixIntrinsics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerWidenableCondition.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/MakeGuardsExplicit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/MemCpyOptimizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/MergeICmps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/MergedLoadStoreMotion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/NaryReassociate.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/NewGVN.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/PartiallyInlineLibCalls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/PlaceSafepoints.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Reassociate.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Reg2Mem.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/RewriteStatepointsForGC.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SCCP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SROA.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Scalar.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/ScalarizeMaskedMemIntrin.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Scalarizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SeparateConstOffsetFromGEP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SimpleLoopUnswitch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SimplifyCFGPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Sink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SpeculativeExecution.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/StraightLineStrengthReduce.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/StructurizeCFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/TailRecursionElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/WarnMissedTransforms.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..9ed80178f3b7 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,108 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-Scalar) +target_compile_options(lib-Transforms-Scalar PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-Scalar PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar +) +target_link_libraries(lib-Transforms-Scalar PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-AggressiveInstCombine + lib-Transforms-InstCombine + lib-Transforms-Utils +) +target_sources(lib-Transforms-Scalar PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/ADCE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/AlignmentFromAssumptions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/AnnotationRemarks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/BDCE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/CallSiteSplitting.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/ConstantHoisting.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/ConstraintElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/CorrelatedValuePropagation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/DCE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/DFAJumpThreading.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/DeadStoreElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/DivRemPairs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/EarlyCSE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/FlattenCFGPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Float2Int.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/GVN.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/GVNHoist.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/GVNSink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/GuardWidening.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/IVUsersPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/IndVarSimplify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/InductiveRangeCheckElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/InferAddressSpaces.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/InstSimplifyPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/JumpThreading.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LICM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopAccessAnalysisPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopBoundSplit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopDataPrefetch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopDeletion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopDistribute.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopFlatten.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopFuse.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopIdiomRecognize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopInstSimplify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopInterchange.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopLoadElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopPassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopPredication.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopRerollPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopRotation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopSimplifyCFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopSink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopStrengthReduce.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopUnrollAndJamPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopUnrollPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopUnswitch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopVersioningLICM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerAtomic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerConstantIntrinsics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerExpectIntrinsic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerGuardIntrinsic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerMatrixIntrinsics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerWidenableCondition.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/MakeGuardsExplicit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/MemCpyOptimizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/MergeICmps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/MergedLoadStoreMotion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/NaryReassociate.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/NewGVN.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/PartiallyInlineLibCalls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/PlaceSafepoints.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Reassociate.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Reg2Mem.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/RewriteStatepointsForGC.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SCCP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SROA.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Scalar.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/ScalarizeMaskedMemIntrin.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Scalarizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SeparateConstOffsetFromGEP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SimpleLoopUnswitch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SimplifyCFGPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Sink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SpeculativeExecution.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/StraightLineStrengthReduce.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/StructurizeCFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/TailRecursionElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/WarnMissedTransforms.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..cbc5530fbcb5 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.linux-aarch64.txt @@ -0,0 +1,109 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-Scalar) +target_compile_options(lib-Transforms-Scalar PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-Scalar PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar +) +target_link_libraries(lib-Transforms-Scalar PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-AggressiveInstCombine + lib-Transforms-InstCombine + lib-Transforms-Utils +) +target_sources(lib-Transforms-Scalar PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/ADCE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/AlignmentFromAssumptions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/AnnotationRemarks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/BDCE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/CallSiteSplitting.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/ConstantHoisting.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/ConstraintElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/CorrelatedValuePropagation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/DCE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/DFAJumpThreading.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/DeadStoreElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/DivRemPairs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/EarlyCSE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/FlattenCFGPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Float2Int.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/GVN.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/GVNHoist.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/GVNSink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/GuardWidening.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/IVUsersPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/IndVarSimplify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/InductiveRangeCheckElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/InferAddressSpaces.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/InstSimplifyPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/JumpThreading.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LICM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopAccessAnalysisPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopBoundSplit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopDataPrefetch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopDeletion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopDistribute.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopFlatten.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopFuse.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopIdiomRecognize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopInstSimplify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopInterchange.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopLoadElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopPassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopPredication.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopRerollPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopRotation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopSimplifyCFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopSink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopStrengthReduce.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopUnrollAndJamPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopUnrollPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopUnswitch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopVersioningLICM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerAtomic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerConstantIntrinsics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerExpectIntrinsic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerGuardIntrinsic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerMatrixIntrinsics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerWidenableCondition.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/MakeGuardsExplicit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/MemCpyOptimizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/MergeICmps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/MergedLoadStoreMotion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/NaryReassociate.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/NewGVN.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/PartiallyInlineLibCalls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/PlaceSafepoints.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Reassociate.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Reg2Mem.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/RewriteStatepointsForGC.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SCCP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SROA.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Scalar.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/ScalarizeMaskedMemIntrin.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Scalarizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SeparateConstOffsetFromGEP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SimpleLoopUnswitch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SimplifyCFGPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Sink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SpeculativeExecution.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/StraightLineStrengthReduce.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/StructurizeCFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/TailRecursionElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/WarnMissedTransforms.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..cbc5530fbcb5 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.linux-x86_64.txt @@ -0,0 +1,109 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-Scalar) +target_compile_options(lib-Transforms-Scalar PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-Scalar PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar +) +target_link_libraries(lib-Transforms-Scalar PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-AggressiveInstCombine + lib-Transforms-InstCombine + lib-Transforms-Utils +) +target_sources(lib-Transforms-Scalar PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/ADCE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/AlignmentFromAssumptions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/AnnotationRemarks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/BDCE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/CallSiteSplitting.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/ConstantHoisting.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/ConstraintElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/CorrelatedValuePropagation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/DCE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/DFAJumpThreading.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/DeadStoreElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/DivRemPairs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/EarlyCSE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/FlattenCFGPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Float2Int.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/GVN.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/GVNHoist.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/GVNSink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/GuardWidening.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/IVUsersPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/IndVarSimplify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/InductiveRangeCheckElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/InferAddressSpaces.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/InstSimplifyPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/JumpThreading.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LICM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopAccessAnalysisPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopBoundSplit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopDataPrefetch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopDeletion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopDistribute.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopFlatten.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopFuse.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopIdiomRecognize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopInstSimplify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopInterchange.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopLoadElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopPassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopPredication.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopRerollPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopRotation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopSimplifyCFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopSink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopStrengthReduce.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopUnrollAndJamPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopUnrollPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopUnswitch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopVersioningLICM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerAtomic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerConstantIntrinsics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerExpectIntrinsic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerGuardIntrinsic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerMatrixIntrinsics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerWidenableCondition.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/MakeGuardsExplicit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/MemCpyOptimizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/MergeICmps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/MergedLoadStoreMotion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/NaryReassociate.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/NewGVN.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/PartiallyInlineLibCalls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/PlaceSafepoints.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Reassociate.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Reg2Mem.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/RewriteStatepointsForGC.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SCCP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SROA.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Scalar.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/ScalarizeMaskedMemIntrin.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Scalarizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SeparateConstOffsetFromGEP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SimpleLoopUnswitch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SimplifyCFGPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Sink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SpeculativeExecution.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/StraightLineStrengthReduce.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/StructurizeCFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/TailRecursionElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/WarnMissedTransforms.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.txt b/contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..9ed80178f3b7 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Scalar/CMakeLists.windows-x86_64.txt @@ -0,0 +1,108 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-Scalar) +target_compile_options(lib-Transforms-Scalar PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-Scalar PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar +) +target_link_libraries(lib-Transforms-Scalar PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-AggressiveInstCombine + lib-Transforms-InstCombine + lib-Transforms-Utils +) +target_sources(lib-Transforms-Scalar PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/ADCE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/AlignmentFromAssumptions.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/AnnotationRemarks.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/BDCE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/CallSiteSplitting.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/ConstantHoisting.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/ConstraintElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/CorrelatedValuePropagation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/DCE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/DFAJumpThreading.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/DeadStoreElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/DivRemPairs.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/EarlyCSE.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/FlattenCFGPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Float2Int.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/GVN.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/GVNHoist.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/GVNSink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/GuardWidening.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/IVUsersPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/IndVarSimplify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/InductiveRangeCheckElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/InferAddressSpaces.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/InstSimplifyPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/JumpThreading.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LICM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopAccessAnalysisPrinter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopBoundSplit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopDataPrefetch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopDeletion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopDistribute.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopFlatten.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopFuse.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopIdiomRecognize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopInstSimplify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopInterchange.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopLoadElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopPassManager.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopPredication.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopRerollPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopRotation.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopSimplifyCFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopSink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopStrengthReduce.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopUnrollAndJamPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopUnrollPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopUnswitch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LoopVersioningLICM.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerAtomic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerConstantIntrinsics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerExpectIntrinsic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerGuardIntrinsic.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerMatrixIntrinsics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/LowerWidenableCondition.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/MakeGuardsExplicit.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/MemCpyOptimizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/MergeICmps.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/MergedLoadStoreMotion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/NaryReassociate.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/NewGVN.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/PartiallyInlineLibCalls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/PlaceSafepoints.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Reassociate.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Reg2Mem.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/RewriteStatepointsForGC.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SCCP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SROA.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Scalar.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/ScalarizeMaskedMemIntrin.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Scalarizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SeparateConstOffsetFromGEP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SimpleLoopUnswitch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SimplifyCFGPass.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/Sink.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/SpeculativeExecution.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/StraightLineStrengthReduce.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/StructurizeCFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/TailRecursionElimination.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Scalar/WarnMissedTransforms.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..7546a71a489c --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.darwin-arm64.txt @@ -0,0 +1,103 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-Utils) +target_compile_options(lib-Transforms-Utils PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-Utils PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils +) +target_link_libraries(lib-Transforms-Utils PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(lib-Transforms-Utils PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/AMDGPUEmitPrintf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/ASanStackFrameLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/AddDiscriminators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/AssumeBundleBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/BasicBlockUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/BreakCriticalEdges.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/BuildLibCalls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/BypassSlowDivision.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CallGraphUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CallPromotionUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CanonicalizeAliases.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CanonicalizeFreezeInLoops.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CloneFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CloneModule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CodeExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CodeLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CodeMoverUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CtorUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Debugify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/DemoteRegToStack.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/EntryExitInstrumenter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/EscapeEnumerator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Evaluator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/FixIrreducible.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/FlattenCFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/FunctionComparator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/FunctionImportUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/GlobalStatus.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/GuardUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/HelloWorld.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/InjectTLIMappings.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/InlineFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/InstructionNamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/IntegerDivision.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LCSSA.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LibCallsShrinkWrap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Local.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopPeel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopRotationUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopSimplify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopUnroll.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopUnrollAndJam.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopUnrollRuntime.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopVersioning.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LowerInvoke.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LowerMemIntrinsics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LowerSwitch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/MatrixUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Mem2Reg.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/MemoryOpRemark.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/MetaRenamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/ModuleUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/NameAnonGlobals.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/PredicateInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/PromoteMemoryToRegister.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/RelLookupTableConverter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SCCPSolver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SSAUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SSAUpdaterBulk.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SampleProfileInference.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SampleProfileLoaderBaseUtil.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SanitizerStats.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/ScalarEvolutionExpander.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SimplifyCFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SimplifyIndVar.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SimplifyLibCalls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SizeOpts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SplitModule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/StripGCRelocates.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/StripNonLineTableDebugInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SymbolRewriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/UnifyFunctionExitNodes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/UnifyLoopExits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Utils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/VNCoercion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/ValueMapper.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..7546a71a489c --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,103 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-Utils) +target_compile_options(lib-Transforms-Utils PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-Utils PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils +) +target_link_libraries(lib-Transforms-Utils PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(lib-Transforms-Utils PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/AMDGPUEmitPrintf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/ASanStackFrameLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/AddDiscriminators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/AssumeBundleBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/BasicBlockUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/BreakCriticalEdges.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/BuildLibCalls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/BypassSlowDivision.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CallGraphUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CallPromotionUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CanonicalizeAliases.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CanonicalizeFreezeInLoops.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CloneFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CloneModule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CodeExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CodeLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CodeMoverUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CtorUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Debugify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/DemoteRegToStack.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/EntryExitInstrumenter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/EscapeEnumerator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Evaluator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/FixIrreducible.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/FlattenCFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/FunctionComparator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/FunctionImportUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/GlobalStatus.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/GuardUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/HelloWorld.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/InjectTLIMappings.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/InlineFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/InstructionNamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/IntegerDivision.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LCSSA.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LibCallsShrinkWrap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Local.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopPeel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopRotationUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopSimplify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopUnroll.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopUnrollAndJam.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopUnrollRuntime.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopVersioning.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LowerInvoke.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LowerMemIntrinsics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LowerSwitch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/MatrixUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Mem2Reg.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/MemoryOpRemark.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/MetaRenamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/ModuleUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/NameAnonGlobals.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/PredicateInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/PromoteMemoryToRegister.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/RelLookupTableConverter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SCCPSolver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SSAUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SSAUpdaterBulk.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SampleProfileInference.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SampleProfileLoaderBaseUtil.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SanitizerStats.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/ScalarEvolutionExpander.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SimplifyCFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SimplifyIndVar.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SimplifyLibCalls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SizeOpts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SplitModule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/StripGCRelocates.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/StripNonLineTableDebugInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SymbolRewriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/UnifyFunctionExitNodes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/UnifyLoopExits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Utils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/VNCoercion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/ValueMapper.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..45ca66c4a7f7 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.linux-aarch64.txt @@ -0,0 +1,104 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-Utils) +target_compile_options(lib-Transforms-Utils PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-Utils PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils +) +target_link_libraries(lib-Transforms-Utils PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(lib-Transforms-Utils PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/AMDGPUEmitPrintf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/ASanStackFrameLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/AddDiscriminators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/AssumeBundleBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/BasicBlockUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/BreakCriticalEdges.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/BuildLibCalls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/BypassSlowDivision.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CallGraphUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CallPromotionUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CanonicalizeAliases.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CanonicalizeFreezeInLoops.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CloneFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CloneModule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CodeExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CodeLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CodeMoverUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CtorUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Debugify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/DemoteRegToStack.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/EntryExitInstrumenter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/EscapeEnumerator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Evaluator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/FixIrreducible.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/FlattenCFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/FunctionComparator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/FunctionImportUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/GlobalStatus.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/GuardUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/HelloWorld.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/InjectTLIMappings.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/InlineFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/InstructionNamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/IntegerDivision.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LCSSA.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LibCallsShrinkWrap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Local.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopPeel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopRotationUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopSimplify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopUnroll.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopUnrollAndJam.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopUnrollRuntime.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopVersioning.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LowerInvoke.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LowerMemIntrinsics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LowerSwitch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/MatrixUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Mem2Reg.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/MemoryOpRemark.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/MetaRenamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/ModuleUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/NameAnonGlobals.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/PredicateInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/PromoteMemoryToRegister.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/RelLookupTableConverter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SCCPSolver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SSAUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SSAUpdaterBulk.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SampleProfileInference.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SampleProfileLoaderBaseUtil.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SanitizerStats.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/ScalarEvolutionExpander.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SimplifyCFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SimplifyIndVar.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SimplifyLibCalls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SizeOpts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SplitModule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/StripGCRelocates.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/StripNonLineTableDebugInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SymbolRewriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/UnifyFunctionExitNodes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/UnifyLoopExits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Utils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/VNCoercion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/ValueMapper.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..45ca66c4a7f7 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.linux-x86_64.txt @@ -0,0 +1,104 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-Utils) +target_compile_options(lib-Transforms-Utils PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-Utils PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils +) +target_link_libraries(lib-Transforms-Utils PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(lib-Transforms-Utils PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/AMDGPUEmitPrintf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/ASanStackFrameLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/AddDiscriminators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/AssumeBundleBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/BasicBlockUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/BreakCriticalEdges.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/BuildLibCalls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/BypassSlowDivision.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CallGraphUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CallPromotionUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CanonicalizeAliases.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CanonicalizeFreezeInLoops.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CloneFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CloneModule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CodeExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CodeLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CodeMoverUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CtorUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Debugify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/DemoteRegToStack.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/EntryExitInstrumenter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/EscapeEnumerator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Evaluator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/FixIrreducible.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/FlattenCFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/FunctionComparator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/FunctionImportUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/GlobalStatus.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/GuardUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/HelloWorld.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/InjectTLIMappings.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/InlineFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/InstructionNamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/IntegerDivision.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LCSSA.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LibCallsShrinkWrap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Local.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopPeel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopRotationUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopSimplify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopUnroll.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopUnrollAndJam.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopUnrollRuntime.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopVersioning.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LowerInvoke.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LowerMemIntrinsics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LowerSwitch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/MatrixUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Mem2Reg.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/MemoryOpRemark.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/MetaRenamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/ModuleUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/NameAnonGlobals.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/PredicateInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/PromoteMemoryToRegister.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/RelLookupTableConverter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SCCPSolver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SSAUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SSAUpdaterBulk.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SampleProfileInference.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SampleProfileLoaderBaseUtil.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SanitizerStats.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/ScalarEvolutionExpander.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SimplifyCFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SimplifyIndVar.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SimplifyLibCalls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SizeOpts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SplitModule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/StripGCRelocates.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/StripNonLineTableDebugInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SymbolRewriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/UnifyFunctionExitNodes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/UnifyLoopExits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Utils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/VNCoercion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/ValueMapper.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.txt b/contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..7546a71a489c --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Utils/CMakeLists.windows-x86_64.txt @@ -0,0 +1,103 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-Utils) +target_compile_options(lib-Transforms-Utils PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-Utils PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils +) +target_link_libraries(lib-Transforms-Utils PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support +) +target_sources(lib-Transforms-Utils PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/AMDGPUEmitPrintf.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/ASanStackFrameLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/AddDiscriminators.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/AssumeBundleBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/BasicBlockUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/BreakCriticalEdges.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/BuildLibCalls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/BypassSlowDivision.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CallGraphUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CallPromotionUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CanonicalizeAliases.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CanonicalizeFreezeInLoops.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CloneFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CloneModule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CodeExtractor.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CodeLayout.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CodeMoverUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/CtorUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Debugify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/DemoteRegToStack.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/EntryExitInstrumenter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/EscapeEnumerator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Evaluator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/FixIrreducible.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/FlattenCFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/FunctionComparator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/FunctionImportUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/GlobalStatus.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/GuardUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/HelloWorld.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/InjectTLIMappings.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/InlineFunction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/InstructionNamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/IntegerDivision.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LCSSA.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LibCallsShrinkWrap.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Local.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopPeel.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopRotationUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopSimplify.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopUnroll.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopUnrollAndJam.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopUnrollRuntime.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LoopVersioning.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LowerInvoke.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LowerMemIntrinsics.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/LowerSwitch.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/MatrixUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Mem2Reg.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/MemoryOpRemark.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/MetaRenamer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/ModuleUtils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/NameAnonGlobals.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/PredicateInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/PromoteMemoryToRegister.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/RelLookupTableConverter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SCCPSolver.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SSAUpdater.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SSAUpdaterBulk.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SampleProfileInference.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SampleProfileLoaderBaseUtil.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SanitizerStats.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/ScalarEvolutionExpander.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SimplifyCFG.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SimplifyIndVar.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SimplifyLibCalls.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SizeOpts.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SplitModule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/StripGCRelocates.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/StripNonLineTableDebugInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/SymbolRewriter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/UnifyFunctionExitNodes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/UnifyLoopExits.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/Utils.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/VNCoercion.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Utils/ValueMapper.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..bb9a9d7ea151 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.darwin-arm64.txt @@ -0,0 +1,39 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-Vectorize) +target_compile_options(lib-Transforms-Vectorize PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-Vectorize PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize +) +target_link_libraries(lib-Transforms-Vectorize PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-Vectorize PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/LoadStoreVectorizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/LoopVectorizationLegality.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/LoopVectorize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/SLPVectorizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlan.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanHCFGBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanPredicator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanSLP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanTransforms.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanVerifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VectorCombine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/Vectorize.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..bb9a9d7ea151 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,39 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-Vectorize) +target_compile_options(lib-Transforms-Vectorize PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-Vectorize PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize +) +target_link_libraries(lib-Transforms-Vectorize PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-Vectorize PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/LoadStoreVectorizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/LoopVectorizationLegality.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/LoopVectorize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/SLPVectorizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlan.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanHCFGBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanPredicator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanSLP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanTransforms.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanVerifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VectorCombine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/Vectorize.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..cea55ea004e2 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.linux-aarch64.txt @@ -0,0 +1,40 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-Vectorize) +target_compile_options(lib-Transforms-Vectorize PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-Vectorize PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize +) +target_link_libraries(lib-Transforms-Vectorize PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-Vectorize PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/LoadStoreVectorizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/LoopVectorizationLegality.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/LoopVectorize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/SLPVectorizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlan.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanHCFGBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanPredicator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanSLP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanTransforms.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanVerifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VectorCombine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/Vectorize.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..cea55ea004e2 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.linux-x86_64.txt @@ -0,0 +1,40 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-Vectorize) +target_compile_options(lib-Transforms-Vectorize PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-Vectorize PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize +) +target_link_libraries(lib-Transforms-Vectorize PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-Vectorize PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/LoadStoreVectorizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/LoopVectorizationLegality.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/LoopVectorize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/SLPVectorizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlan.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanHCFGBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanPredicator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanSLP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanTransforms.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanVerifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VectorCombine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/Vectorize.cpp +) diff --git a/contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.txt b/contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..bb9a9d7ea151 --- /dev/null +++ b/contrib/libs/llvm14/lib/Transforms/Vectorize/CMakeLists.windows-x86_64.txt @@ -0,0 +1,39 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(lib-Transforms-Vectorize) +target_compile_options(lib-Transforms-Vectorize PRIVATE + $,,-Wno-everything> +) +target_include_directories(lib-Transforms-Vectorize PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize +) +target_link_libraries(lib-Transforms-Vectorize PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + libs-llvm14-include + llvm14-lib-Analysis + llvm14-lib-IR + llvm14-lib-Support + lib-Transforms-Utils +) +target_sources(lib-Transforms-Vectorize PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/LoadStoreVectorizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/LoopVectorizationLegality.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/LoopVectorize.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/SLPVectorizer.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlan.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanHCFGBuilder.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanPredicator.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanSLP.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanTransforms.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VPlanVerifier.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/VectorCombine.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/lib/Transforms/Vectorize/Vectorize.cpp +) diff --git a/contrib/libs/llvm14/utils/CMakeLists.txt b/contrib/libs/llvm14/utils/CMakeLists.txt new file mode 100644 index 000000000000..b58ec8b78f15 --- /dev/null +++ b/contrib/libs/llvm14/utils/CMakeLists.txt @@ -0,0 +1,9 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(TableGen) diff --git a/contrib/libs/llvm14/utils/TableGen/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/utils/TableGen/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..8acb2dfb32d7 --- /dev/null +++ b/contrib/libs/llvm14/utils/TableGen/CMakeLists.darwin-arm64.txt @@ -0,0 +1,90 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(GlobalISel) + +add_executable(llvm-tblgen) +target_compile_options(llvm-tblgen PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm-tblgen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen +) +target_link_libraries(llvm-tblgen PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Demangle + llvm14-lib-Support + llvm14-lib-TableGen + utils-TableGen-GlobalISel + cpp-sanitizer-include +) +target_link_options(llvm-tblgen PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(llvm-tblgen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/AsmMatcherEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/AsmWriterEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/AsmWriterInst.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/Attributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CTagsEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CallingConvEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeBeadsGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeEmitterGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenDAGPatterns.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenHwModes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenInstruction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenMapTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenRegisters.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenSchedule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenTarget.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CompressInstEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelMatcher.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelMatcherEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelMatcherGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelMatcherOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DFAEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DFAPacketizerEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DirectiveEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DisassemblerEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/ExegesisEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/FastISelEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/FixedLenDecoderEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GICombinerEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISelEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/InfoByHwMode.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/InstrDocsEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/InstrInfoEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/IntrinsicEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/OptEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/OptParserEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/OptRSTEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/PredicateExpander.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/PseudoLoweringEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/RegisterBankEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/RegisterInfoEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/SDNodeProperties.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/SearchableTableEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/SubtargetEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/SubtargetFeatureInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/TableGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/Types.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/WebAssemblyDisassemblerEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86DisassemblerTables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86EVEX2VEXTablesEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86FoldTablesEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86ModRMFilters.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86RecognizableInstr.cpp +) +target_allocator(llvm-tblgen + system_allocator +) +vcs_info(llvm-tblgen) diff --git a/contrib/libs/llvm14/utils/TableGen/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/utils/TableGen/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..8acb2dfb32d7 --- /dev/null +++ b/contrib/libs/llvm14/utils/TableGen/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,90 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(GlobalISel) + +add_executable(llvm-tblgen) +target_compile_options(llvm-tblgen PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm-tblgen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen +) +target_link_libraries(llvm-tblgen PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Demangle + llvm14-lib-Support + llvm14-lib-TableGen + utils-TableGen-GlobalISel + cpp-sanitizer-include +) +target_link_options(llvm-tblgen PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(llvm-tblgen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/AsmMatcherEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/AsmWriterEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/AsmWriterInst.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/Attributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CTagsEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CallingConvEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeBeadsGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeEmitterGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenDAGPatterns.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenHwModes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenInstruction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenMapTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenRegisters.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenSchedule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenTarget.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CompressInstEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelMatcher.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelMatcherEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelMatcherGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelMatcherOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DFAEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DFAPacketizerEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DirectiveEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DisassemblerEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/ExegesisEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/FastISelEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/FixedLenDecoderEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GICombinerEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISelEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/InfoByHwMode.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/InstrDocsEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/InstrInfoEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/IntrinsicEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/OptEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/OptParserEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/OptRSTEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/PredicateExpander.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/PseudoLoweringEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/RegisterBankEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/RegisterInfoEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/SDNodeProperties.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/SearchableTableEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/SubtargetEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/SubtargetFeatureInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/TableGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/Types.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/WebAssemblyDisassemblerEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86DisassemblerTables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86EVEX2VEXTablesEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86FoldTablesEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86ModRMFilters.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86RecognizableInstr.cpp +) +target_allocator(llvm-tblgen + system_allocator +) +vcs_info(llvm-tblgen) diff --git a/contrib/libs/llvm14/utils/TableGen/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/utils/TableGen/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..25b0fa9b7cc1 --- /dev/null +++ b/contrib/libs/llvm14/utils/TableGen/CMakeLists.linux-aarch64.txt @@ -0,0 +1,93 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(GlobalISel) + +add_executable(llvm-tblgen) +target_compile_options(llvm-tblgen PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm-tblgen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen +) +target_link_libraries(llvm-tblgen PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Demangle + llvm14-lib-Support + llvm14-lib-TableGen + utils-TableGen-GlobalISel + cpp-sanitizer-include +) +target_link_options(llvm-tblgen PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(llvm-tblgen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/AsmMatcherEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/AsmWriterEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/AsmWriterInst.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/Attributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CTagsEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CallingConvEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeBeadsGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeEmitterGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenDAGPatterns.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenHwModes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenInstruction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenMapTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenRegisters.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenSchedule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenTarget.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CompressInstEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelMatcher.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelMatcherEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelMatcherGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelMatcherOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DFAEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DFAPacketizerEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DirectiveEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DisassemblerEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/ExegesisEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/FastISelEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/FixedLenDecoderEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GICombinerEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISelEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/InfoByHwMode.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/InstrDocsEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/InstrInfoEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/IntrinsicEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/OptEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/OptParserEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/OptRSTEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/PredicateExpander.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/PseudoLoweringEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/RegisterBankEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/RegisterInfoEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/SDNodeProperties.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/SearchableTableEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/SubtargetEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/SubtargetFeatureInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/TableGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/Types.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/WebAssemblyDisassemblerEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86DisassemblerTables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86EVEX2VEXTablesEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86FoldTablesEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86ModRMFilters.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86RecognizableInstr.cpp +) +target_allocator(llvm-tblgen + cpp-malloc-jemalloc +) +vcs_info(llvm-tblgen) diff --git a/contrib/libs/llvm14/utils/TableGen/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/utils/TableGen/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..fe9dbdcf1b8b --- /dev/null +++ b/contrib/libs/llvm14/utils/TableGen/CMakeLists.linux-x86_64.txt @@ -0,0 +1,94 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(GlobalISel) + +add_executable(llvm-tblgen) +target_compile_options(llvm-tblgen PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm-tblgen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen +) +target_link_libraries(llvm-tblgen PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Demangle + llvm14-lib-Support + llvm14-lib-TableGen + utils-TableGen-GlobalISel + cpp-sanitizer-include +) +target_link_options(llvm-tblgen PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(llvm-tblgen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/AsmMatcherEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/AsmWriterEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/AsmWriterInst.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/Attributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CTagsEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CallingConvEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeBeadsGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeEmitterGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenDAGPatterns.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenHwModes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenInstruction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenMapTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenRegisters.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenSchedule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenTarget.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CompressInstEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelMatcher.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelMatcherEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelMatcherGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelMatcherOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DFAEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DFAPacketizerEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DirectiveEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DisassemblerEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/ExegesisEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/FastISelEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/FixedLenDecoderEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GICombinerEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISelEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/InfoByHwMode.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/InstrDocsEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/InstrInfoEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/IntrinsicEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/OptEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/OptParserEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/OptRSTEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/PredicateExpander.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/PseudoLoweringEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/RegisterBankEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/RegisterInfoEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/SDNodeProperties.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/SearchableTableEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/SubtargetEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/SubtargetFeatureInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/TableGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/Types.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/WebAssemblyDisassemblerEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86DisassemblerTables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86EVEX2VEXTablesEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86FoldTablesEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86ModRMFilters.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86RecognizableInstr.cpp +) +target_allocator(llvm-tblgen + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(llvm-tblgen) diff --git a/contrib/libs/llvm14/utils/TableGen/CMakeLists.txt b/contrib/libs/llvm14/utils/TableGen/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/utils/TableGen/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/utils/TableGen/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/utils/TableGen/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..25ae00a6c731 --- /dev/null +++ b/contrib/libs/llvm14/utils/TableGen/CMakeLists.windows-x86_64.txt @@ -0,0 +1,85 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(GlobalISel) + +add_executable(llvm-tblgen) +target_compile_options(llvm-tblgen PRIVATE + $,,-Wno-everything> +) +target_include_directories(llvm-tblgen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen +) +target_link_libraries(llvm-tblgen PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Demangle + llvm14-lib-Support + llvm14-lib-TableGen + utils-TableGen-GlobalISel + cpp-sanitizer-include +) +target_sources(llvm-tblgen PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/AsmMatcherEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/AsmWriterEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/AsmWriterInst.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/Attributes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CTagsEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CallingConvEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeBeadsGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeEmitterGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenDAGPatterns.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenHwModes.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenInstruction.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenMapTable.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenRegisters.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenSchedule.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CodeGenTarget.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/CompressInstEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelMatcher.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelMatcherEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelMatcherGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DAGISelMatcherOpt.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DFAEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DFAPacketizerEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DirectiveEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/DisassemblerEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/ExegesisEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/FastISelEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/FixedLenDecoderEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GICombinerEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISelEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/InfoByHwMode.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/InstrDocsEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/InstrInfoEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/IntrinsicEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/OptEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/OptParserEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/OptRSTEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/PredicateExpander.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/PseudoLoweringEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/RegisterBankEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/RegisterInfoEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/SDNodeProperties.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/SearchableTableEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/SubtargetEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/SubtargetFeatureInfo.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/TableGen.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/Types.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/WebAssemblyDisassemblerEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86DisassemblerTables.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86EVEX2VEXTablesEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86FoldTablesEmitter.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86ModRMFilters.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/X86RecognizableInstr.cpp +) +target_allocator(llvm-tblgen + system_allocator +) +vcs_info(llvm-tblgen) diff --git a/contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.darwin-arm64.txt b/contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..43275d7d1f8a --- /dev/null +++ b/contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.darwin-arm64.txt @@ -0,0 +1,32 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(utils-TableGen-GlobalISel) +target_compile_options(utils-TableGen-GlobalISel PRIVATE + $,,-Wno-everything> +) +target_include_directories(utils-TableGen-GlobalISel PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel +) +target_link_libraries(utils-TableGen-GlobalISel PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support + llvm14-lib-TableGen +) +target_sources(utils-TableGen-GlobalISel PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/CodeExpander.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDag.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagEdge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagInstr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagOperands.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagPredicate.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagPredicateDependencyEdge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchTree.cpp +) diff --git a/contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.darwin-x86_64.txt b/contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..43275d7d1f8a --- /dev/null +++ b/contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,32 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(utils-TableGen-GlobalISel) +target_compile_options(utils-TableGen-GlobalISel PRIVATE + $,,-Wno-everything> +) +target_include_directories(utils-TableGen-GlobalISel PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel +) +target_link_libraries(utils-TableGen-GlobalISel PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support + llvm14-lib-TableGen +) +target_sources(utils-TableGen-GlobalISel PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/CodeExpander.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDag.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagEdge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagInstr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagOperands.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagPredicate.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagPredicateDependencyEdge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchTree.cpp +) diff --git a/contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.linux-aarch64.txt b/contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..b312adf510e1 --- /dev/null +++ b/contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.linux-aarch64.txt @@ -0,0 +1,33 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(utils-TableGen-GlobalISel) +target_compile_options(utils-TableGen-GlobalISel PRIVATE + $,,-Wno-everything> +) +target_include_directories(utils-TableGen-GlobalISel PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel +) +target_link_libraries(utils-TableGen-GlobalISel PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support + llvm14-lib-TableGen +) +target_sources(utils-TableGen-GlobalISel PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/CodeExpander.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDag.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagEdge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagInstr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagOperands.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagPredicate.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagPredicateDependencyEdge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchTree.cpp +) diff --git a/contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.linux-x86_64.txt b/contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..b312adf510e1 --- /dev/null +++ b/contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.linux-x86_64.txt @@ -0,0 +1,33 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(utils-TableGen-GlobalISel) +target_compile_options(utils-TableGen-GlobalISel PRIVATE + $,,-Wno-everything> +) +target_include_directories(utils-TableGen-GlobalISel PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel +) +target_link_libraries(utils-TableGen-GlobalISel PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support + llvm14-lib-TableGen +) +target_sources(utils-TableGen-GlobalISel PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/CodeExpander.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDag.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagEdge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagInstr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagOperands.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagPredicate.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagPredicateDependencyEdge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchTree.cpp +) diff --git a/contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.txt b/contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.windows-x86_64.txt b/contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..43275d7d1f8a --- /dev/null +++ b/contrib/libs/llvm14/utils/TableGen/GlobalISel/CMakeLists.windows-x86_64.txt @@ -0,0 +1,32 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(utils-TableGen-GlobalISel) +target_compile_options(utils-TableGen-GlobalISel PRIVATE + $,,-Wno-everything> +) +target_include_directories(utils-TableGen-GlobalISel PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel +) +target_link_libraries(utils-TableGen-GlobalISel PUBLIC + contrib-libs-cxxsupp + contrib-libs-llvm14 + llvm14-lib-Support + llvm14-lib-TableGen +) +target_sources(utils-TableGen-GlobalISel PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/CodeExpander.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDag.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagEdge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagInstr.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagOperands.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagPredicate.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchDagPredicateDependencyEdge.cpp + ${CMAKE_SOURCE_DIR}/contrib/libs/llvm14/utils/TableGen/GlobalISel/GIMatchTree.cpp +) diff --git a/contrib/libs/lua/CMakeLists.darwin-arm64.txt b/contrib/libs/lua/CMakeLists.darwin-arm64.txt index b8bb770b445b..bd2e5d4bc8f8 100644 --- a/contrib/libs/lua/CMakeLists.darwin-arm64.txt +++ b/contrib/libs/lua/CMakeLists.darwin-arm64.txt @@ -30,6 +30,7 @@ target_link_libraries(contrib-libs-lua PUBLIC library-cpp-archive ) target_sources(contrib-libs-lua PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/lua/common.inc ${CMAKE_SOURCE_DIR}/contrib/libs/lua/lib.cpp ${CMAKE_BINARY_DIR}/contrib/libs/lua/common.inc ) diff --git a/contrib/libs/lua/CMakeLists.darwin-x86_64.txt b/contrib/libs/lua/CMakeLists.darwin-x86_64.txt index b8bb770b445b..bd2e5d4bc8f8 100644 --- a/contrib/libs/lua/CMakeLists.darwin-x86_64.txt +++ b/contrib/libs/lua/CMakeLists.darwin-x86_64.txt @@ -30,6 +30,7 @@ target_link_libraries(contrib-libs-lua PUBLIC library-cpp-archive ) target_sources(contrib-libs-lua PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/lua/common.inc ${CMAKE_SOURCE_DIR}/contrib/libs/lua/lib.cpp ${CMAKE_BINARY_DIR}/contrib/libs/lua/common.inc ) diff --git a/contrib/libs/lua/CMakeLists.linux-aarch64.txt b/contrib/libs/lua/CMakeLists.linux-aarch64.txt index c9c201999bbf..ebedc945e244 100644 --- a/contrib/libs/lua/CMakeLists.linux-aarch64.txt +++ b/contrib/libs/lua/CMakeLists.linux-aarch64.txt @@ -31,6 +31,7 @@ target_link_libraries(contrib-libs-lua PUBLIC library-cpp-archive ) target_sources(contrib-libs-lua PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/lua/common.inc ${CMAKE_SOURCE_DIR}/contrib/libs/lua/lib.cpp ${CMAKE_BINARY_DIR}/contrib/libs/lua/common.inc ) diff --git a/contrib/libs/lua/CMakeLists.linux-x86_64.txt b/contrib/libs/lua/CMakeLists.linux-x86_64.txt index c9c201999bbf..ebedc945e244 100644 --- a/contrib/libs/lua/CMakeLists.linux-x86_64.txt +++ b/contrib/libs/lua/CMakeLists.linux-x86_64.txt @@ -31,6 +31,7 @@ target_link_libraries(contrib-libs-lua PUBLIC library-cpp-archive ) target_sources(contrib-libs-lua PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/lua/common.inc ${CMAKE_SOURCE_DIR}/contrib/libs/lua/lib.cpp ${CMAKE_BINARY_DIR}/contrib/libs/lua/common.inc ) diff --git a/contrib/libs/lua/CMakeLists.windows-x86_64.txt b/contrib/libs/lua/CMakeLists.windows-x86_64.txt index eae8e899a2da..6a25dc93dea5 100644 --- a/contrib/libs/lua/CMakeLists.windows-x86_64.txt +++ b/contrib/libs/lua/CMakeLists.windows-x86_64.txt @@ -30,6 +30,7 @@ target_link_libraries(contrib-libs-lua PUBLIC library-cpp-archive ) target_sources(contrib-libs-lua PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/lua/common.inc ${CMAKE_SOURCE_DIR}/contrib/libs/lua/lib.cpp ${CMAKE_BINARY_DIR}/contrib/libs/lua/common.inc ) diff --git a/contrib/libs/opentelemetry-proto/CMakeLists.darwin-arm64.txt b/contrib/libs/opentelemetry-proto/CMakeLists.darwin-arm64.txt index c26ac9dfec60..09bd686ee0a2 100644 --- a/contrib/libs/opentelemetry-proto/CMakeLists.darwin-arm64.txt +++ b/contrib/libs/opentelemetry-proto/CMakeLists.darwin-arm64.txt @@ -135,6 +135,24 @@ target_proto_messages(contrib-libs-opentelemetry-proto PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/resource/v1/resource.proto ${CMAKE_SOURCE_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/trace/v1/trace.proto ) +target_sources(contrib-libs-opentelemetry-proto PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/logs/v1/logs_service.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/logs/v1/logs_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/metrics/v1/metrics_service.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/metrics/v1/metrics_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/trace/v1/trace_service.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/trace/v1/trace_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/common/v1/common.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/common/v1/common.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/logs/v1/logs.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/logs/v1/logs.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/metrics/v1/metrics.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/metrics/v1/metrics.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/resource/v1/resource.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/resource/v1/resource.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/trace/v1/trace.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/trace/v1/trace.grpc.pb.h +) target_proto_addincls(contrib-libs-opentelemetry-proto ./contrib/libs/opentelemetry-proto ${CMAKE_SOURCE_DIR}/contrib/libs/opentelemetry-proto diff --git a/contrib/libs/opentelemetry-proto/CMakeLists.darwin-x86_64.txt b/contrib/libs/opentelemetry-proto/CMakeLists.darwin-x86_64.txt index c26ac9dfec60..09bd686ee0a2 100644 --- a/contrib/libs/opentelemetry-proto/CMakeLists.darwin-x86_64.txt +++ b/contrib/libs/opentelemetry-proto/CMakeLists.darwin-x86_64.txt @@ -135,6 +135,24 @@ target_proto_messages(contrib-libs-opentelemetry-proto PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/resource/v1/resource.proto ${CMAKE_SOURCE_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/trace/v1/trace.proto ) +target_sources(contrib-libs-opentelemetry-proto PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/logs/v1/logs_service.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/logs/v1/logs_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/metrics/v1/metrics_service.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/metrics/v1/metrics_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/trace/v1/trace_service.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/trace/v1/trace_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/common/v1/common.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/common/v1/common.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/logs/v1/logs.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/logs/v1/logs.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/metrics/v1/metrics.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/metrics/v1/metrics.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/resource/v1/resource.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/resource/v1/resource.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/trace/v1/trace.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/trace/v1/trace.grpc.pb.h +) target_proto_addincls(contrib-libs-opentelemetry-proto ./contrib/libs/opentelemetry-proto ${CMAKE_SOURCE_DIR}/contrib/libs/opentelemetry-proto diff --git a/contrib/libs/opentelemetry-proto/CMakeLists.linux-aarch64.txt b/contrib/libs/opentelemetry-proto/CMakeLists.linux-aarch64.txt index 3379498d0ebf..03d9f9516583 100644 --- a/contrib/libs/opentelemetry-proto/CMakeLists.linux-aarch64.txt +++ b/contrib/libs/opentelemetry-proto/CMakeLists.linux-aarch64.txt @@ -136,6 +136,24 @@ target_proto_messages(contrib-libs-opentelemetry-proto PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/resource/v1/resource.proto ${CMAKE_SOURCE_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/trace/v1/trace.proto ) +target_sources(contrib-libs-opentelemetry-proto PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/logs/v1/logs_service.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/logs/v1/logs_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/metrics/v1/metrics_service.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/metrics/v1/metrics_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/trace/v1/trace_service.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/trace/v1/trace_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/common/v1/common.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/common/v1/common.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/logs/v1/logs.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/logs/v1/logs.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/metrics/v1/metrics.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/metrics/v1/metrics.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/resource/v1/resource.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/resource/v1/resource.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/trace/v1/trace.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/trace/v1/trace.grpc.pb.h +) target_proto_addincls(contrib-libs-opentelemetry-proto ./contrib/libs/opentelemetry-proto ${CMAKE_SOURCE_DIR}/contrib/libs/opentelemetry-proto diff --git a/contrib/libs/opentelemetry-proto/CMakeLists.linux-x86_64.txt b/contrib/libs/opentelemetry-proto/CMakeLists.linux-x86_64.txt index 3379498d0ebf..03d9f9516583 100644 --- a/contrib/libs/opentelemetry-proto/CMakeLists.linux-x86_64.txt +++ b/contrib/libs/opentelemetry-proto/CMakeLists.linux-x86_64.txt @@ -136,6 +136,24 @@ target_proto_messages(contrib-libs-opentelemetry-proto PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/resource/v1/resource.proto ${CMAKE_SOURCE_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/trace/v1/trace.proto ) +target_sources(contrib-libs-opentelemetry-proto PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/logs/v1/logs_service.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/logs/v1/logs_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/metrics/v1/metrics_service.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/metrics/v1/metrics_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/trace/v1/trace_service.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/trace/v1/trace_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/common/v1/common.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/common/v1/common.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/logs/v1/logs.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/logs/v1/logs.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/metrics/v1/metrics.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/metrics/v1/metrics.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/resource/v1/resource.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/resource/v1/resource.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/trace/v1/trace.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/trace/v1/trace.grpc.pb.h +) target_proto_addincls(contrib-libs-opentelemetry-proto ./contrib/libs/opentelemetry-proto ${CMAKE_SOURCE_DIR}/contrib/libs/opentelemetry-proto diff --git a/contrib/libs/opentelemetry-proto/CMakeLists.windows-x86_64.txt b/contrib/libs/opentelemetry-proto/CMakeLists.windows-x86_64.txt index c26ac9dfec60..09bd686ee0a2 100644 --- a/contrib/libs/opentelemetry-proto/CMakeLists.windows-x86_64.txt +++ b/contrib/libs/opentelemetry-proto/CMakeLists.windows-x86_64.txt @@ -135,6 +135,24 @@ target_proto_messages(contrib-libs-opentelemetry-proto PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/resource/v1/resource.proto ${CMAKE_SOURCE_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/trace/v1/trace.proto ) +target_sources(contrib-libs-opentelemetry-proto PRIVATE + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/logs/v1/logs_service.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/logs/v1/logs_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/metrics/v1/metrics_service.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/metrics/v1/metrics_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/trace/v1/trace_service.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/collector/trace/v1/trace_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/common/v1/common.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/common/v1/common.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/logs/v1/logs.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/logs/v1/logs.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/metrics/v1/metrics.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/metrics/v1/metrics.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/resource/v1/resource.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/resource/v1/resource.grpc.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/trace/v1/trace.pb.h + ${CMAKE_BINARY_DIR}/contrib/libs/opentelemetry-proto/opentelemetry/proto/trace/v1/trace.grpc.pb.h +) target_proto_addincls(contrib-libs-opentelemetry-proto ./contrib/libs/opentelemetry-proto ${CMAKE_SOURCE_DIR}/contrib/libs/opentelemetry-proto diff --git a/contrib/libs/protobuf/CMakeLists.darwin-arm64.txt b/contrib/libs/protobuf/CMakeLists.darwin-arm64.txt index 7bb6b1fa02a5..8c7d5f73f1ce 100644 --- a/contrib/libs/protobuf/CMakeLists.darwin-arm64.txt +++ b/contrib/libs/protobuf/CMakeLists.darwin-arm64.txt @@ -109,50 +109,6 @@ target_sources(contrib-libs-protobuf PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/wire_format_lite.cc ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/wrappers.pb.cc ) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/any.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/any.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/api.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/api.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/descriptor.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/descriptor.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/duration.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/duration.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/empty.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/empty.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/field_mask.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/field_mask.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/source_context.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/source_context.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/struct.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/struct.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/timestamp.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/timestamp.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/type.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/type.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/wrappers.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/wrappers.proto -) add_global_library_for(contrib-libs-protobuf.global contrib-libs-protobuf) target_compile_options(contrib-libs-protobuf.global PRIVATE diff --git a/contrib/libs/protobuf/CMakeLists.darwin-x86_64.txt b/contrib/libs/protobuf/CMakeLists.darwin-x86_64.txt index 7bb6b1fa02a5..8c7d5f73f1ce 100644 --- a/contrib/libs/protobuf/CMakeLists.darwin-x86_64.txt +++ b/contrib/libs/protobuf/CMakeLists.darwin-x86_64.txt @@ -109,50 +109,6 @@ target_sources(contrib-libs-protobuf PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/wire_format_lite.cc ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/wrappers.pb.cc ) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/any.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/any.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/api.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/api.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/descriptor.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/descriptor.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/duration.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/duration.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/empty.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/empty.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/field_mask.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/field_mask.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/source_context.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/source_context.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/struct.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/struct.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/timestamp.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/timestamp.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/type.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/type.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/wrappers.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/wrappers.proto -) add_global_library_for(contrib-libs-protobuf.global contrib-libs-protobuf) target_compile_options(contrib-libs-protobuf.global PRIVATE diff --git a/contrib/libs/protobuf/CMakeLists.linux-aarch64.txt b/contrib/libs/protobuf/CMakeLists.linux-aarch64.txt index 5357276de1a1..6cd6c00aa9db 100644 --- a/contrib/libs/protobuf/CMakeLists.linux-aarch64.txt +++ b/contrib/libs/protobuf/CMakeLists.linux-aarch64.txt @@ -110,50 +110,6 @@ target_sources(contrib-libs-protobuf PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/wire_format_lite.cc ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/wrappers.pb.cc ) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/any.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/any.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/api.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/api.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/descriptor.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/descriptor.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/duration.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/duration.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/empty.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/empty.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/field_mask.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/field_mask.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/source_context.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/source_context.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/struct.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/struct.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/timestamp.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/timestamp.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/type.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/type.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/wrappers.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/wrappers.proto -) add_global_library_for(contrib-libs-protobuf.global contrib-libs-protobuf) target_compile_options(contrib-libs-protobuf.global PRIVATE diff --git a/contrib/libs/protobuf/CMakeLists.linux-x86_64.txt b/contrib/libs/protobuf/CMakeLists.linux-x86_64.txt index 5357276de1a1..6cd6c00aa9db 100644 --- a/contrib/libs/protobuf/CMakeLists.linux-x86_64.txt +++ b/contrib/libs/protobuf/CMakeLists.linux-x86_64.txt @@ -110,50 +110,6 @@ target_sources(contrib-libs-protobuf PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/wire_format_lite.cc ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/wrappers.pb.cc ) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/any.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/any.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/api.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/api.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/descriptor.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/descriptor.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/duration.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/duration.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/empty.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/empty.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/field_mask.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/field_mask.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/source_context.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/source_context.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/struct.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/struct.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/timestamp.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/timestamp.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/type.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/type.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/wrappers.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/wrappers.proto -) add_global_library_for(contrib-libs-protobuf.global contrib-libs-protobuf) target_compile_options(contrib-libs-protobuf.global PRIVATE diff --git a/contrib/libs/protobuf/CMakeLists.windows-x86_64.txt b/contrib/libs/protobuf/CMakeLists.windows-x86_64.txt index 7bb6b1fa02a5..8c7d5f73f1ce 100644 --- a/contrib/libs/protobuf/CMakeLists.windows-x86_64.txt +++ b/contrib/libs/protobuf/CMakeLists.windows-x86_64.txt @@ -109,50 +109,6 @@ target_sources(contrib-libs-protobuf PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/wire_format_lite.cc ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/wrappers.pb.cc ) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/any.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/any.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/api.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/api.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/descriptor.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/descriptor.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/duration.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/duration.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/empty.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/empty.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/field_mask.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/field_mask.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/source_context.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/source_context.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/struct.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/struct.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/timestamp.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/timestamp.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/type.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/type.proto -) -copy_file( - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src/google/protobuf/wrappers.proto - ${CMAKE_BINARY_DIR}/contrib/libs/protobuf/src/google/protobuf/wrappers.proto -) add_global_library_for(contrib-libs-protobuf.global contrib-libs-protobuf) target_compile_options(contrib-libs-protobuf.global PRIVATE diff --git a/contrib/libs/tbb/CMakeLists.windows-x86_64.txt b/contrib/libs/tbb/CMakeLists.windows-x86_64.txt index b87f54ab2747..159456e1593c 100644 --- a/contrib/libs/tbb/CMakeLists.windows-x86_64.txt +++ b/contrib/libs/tbb/CMakeLists.windows-x86_64.txt @@ -10,8 +10,6 @@ add_library(contrib-libs-tbb) target_compile_options(contrib-libs-tbb PRIVATE -D__TBB_BUILD - -mrtm - -mwaitpkg -DUSE_WINTHREAD -D__TBB_USE_ITT_NOTIFY -DDO_ITT_NOTIFY diff --git a/contrib/restricted/abseil-cpp/absl/flags/CMakeLists.darwin-arm64.txt b/contrib/restricted/abseil-cpp/absl/flags/CMakeLists.darwin-arm64.txt index 51a0971139aa..66c0af350577 100644 --- a/contrib/restricted/abseil-cpp/absl/flags/CMakeLists.darwin-arm64.txt +++ b/contrib/restricted/abseil-cpp/absl/flags/CMakeLists.darwin-arm64.txt @@ -30,7 +30,6 @@ target_link_libraries(abseil-cpp-absl-flags PUBLIC ) target_sources(abseil-cpp-absl-flags PRIVATE ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/commandlineflag.cc - ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/flag.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/internal/commandlineflag.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/internal/flag.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/internal/private_handle_accessor.cc diff --git a/contrib/restricted/abseil-cpp/absl/flags/CMakeLists.darwin-x86_64.txt b/contrib/restricted/abseil-cpp/absl/flags/CMakeLists.darwin-x86_64.txt index 51a0971139aa..66c0af350577 100644 --- a/contrib/restricted/abseil-cpp/absl/flags/CMakeLists.darwin-x86_64.txt +++ b/contrib/restricted/abseil-cpp/absl/flags/CMakeLists.darwin-x86_64.txt @@ -30,7 +30,6 @@ target_link_libraries(abseil-cpp-absl-flags PUBLIC ) target_sources(abseil-cpp-absl-flags PRIVATE ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/commandlineflag.cc - ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/flag.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/internal/commandlineflag.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/internal/flag.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/internal/private_handle_accessor.cc diff --git a/contrib/restricted/abseil-cpp/absl/flags/CMakeLists.linux-aarch64.txt b/contrib/restricted/abseil-cpp/absl/flags/CMakeLists.linux-aarch64.txt index a61094881a3b..00550a57091d 100644 --- a/contrib/restricted/abseil-cpp/absl/flags/CMakeLists.linux-aarch64.txt +++ b/contrib/restricted/abseil-cpp/absl/flags/CMakeLists.linux-aarch64.txt @@ -31,7 +31,6 @@ target_link_libraries(abseil-cpp-absl-flags PUBLIC ) target_sources(abseil-cpp-absl-flags PRIVATE ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/commandlineflag.cc - ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/flag.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/internal/commandlineflag.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/internal/flag.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/internal/private_handle_accessor.cc diff --git a/contrib/restricted/abseil-cpp/absl/flags/CMakeLists.linux-x86_64.txt b/contrib/restricted/abseil-cpp/absl/flags/CMakeLists.linux-x86_64.txt index a61094881a3b..00550a57091d 100644 --- a/contrib/restricted/abseil-cpp/absl/flags/CMakeLists.linux-x86_64.txt +++ b/contrib/restricted/abseil-cpp/absl/flags/CMakeLists.linux-x86_64.txt @@ -31,7 +31,6 @@ target_link_libraries(abseil-cpp-absl-flags PUBLIC ) target_sources(abseil-cpp-absl-flags PRIVATE ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/commandlineflag.cc - ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/flag.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/internal/commandlineflag.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/internal/flag.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/internal/private_handle_accessor.cc diff --git a/contrib/restricted/abseil-cpp/absl/flags/CMakeLists.windows-x86_64.txt b/contrib/restricted/abseil-cpp/absl/flags/CMakeLists.windows-x86_64.txt index 51a0971139aa..66c0af350577 100644 --- a/contrib/restricted/abseil-cpp/absl/flags/CMakeLists.windows-x86_64.txt +++ b/contrib/restricted/abseil-cpp/absl/flags/CMakeLists.windows-x86_64.txt @@ -30,7 +30,6 @@ target_link_libraries(abseil-cpp-absl-flags PUBLIC ) target_sources(abseil-cpp-absl-flags PRIVATE ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/commandlineflag.cc - ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/flag.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/internal/commandlineflag.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/internal/flag.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/flags/internal/private_handle_accessor.cc diff --git a/contrib/restricted/abseil-cpp/absl/log/CMakeLists.darwin-arm64.txt b/contrib/restricted/abseil-cpp/absl/log/CMakeLists.darwin-arm64.txt index c2793a97eaa1..45409ec603cd 100644 --- a/contrib/restricted/abseil-cpp/absl/log/CMakeLists.darwin-arm64.txt +++ b/contrib/restricted/abseil-cpp/absl/log/CMakeLists.darwin-arm64.txt @@ -35,12 +35,14 @@ target_sources(abseil-cpp-absl-log PRIVATE ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/initialize.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/check_op.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/conditions.cc + ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/fnmatch.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/globals.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/log_format.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/log_message.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/log_sink_set.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/nullguard.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/proto.cc + ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/vlog_config.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/log_entry.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/log_sink.cc ) diff --git a/contrib/restricted/abseil-cpp/absl/log/CMakeLists.darwin-x86_64.txt b/contrib/restricted/abseil-cpp/absl/log/CMakeLists.darwin-x86_64.txt index c2793a97eaa1..45409ec603cd 100644 --- a/contrib/restricted/abseil-cpp/absl/log/CMakeLists.darwin-x86_64.txt +++ b/contrib/restricted/abseil-cpp/absl/log/CMakeLists.darwin-x86_64.txt @@ -35,12 +35,14 @@ target_sources(abseil-cpp-absl-log PRIVATE ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/initialize.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/check_op.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/conditions.cc + ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/fnmatch.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/globals.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/log_format.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/log_message.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/log_sink_set.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/nullguard.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/proto.cc + ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/vlog_config.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/log_entry.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/log_sink.cc ) diff --git a/contrib/restricted/abseil-cpp/absl/log/CMakeLists.linux-aarch64.txt b/contrib/restricted/abseil-cpp/absl/log/CMakeLists.linux-aarch64.txt index a7743e41a055..d3d4f2c40ec4 100644 --- a/contrib/restricted/abseil-cpp/absl/log/CMakeLists.linux-aarch64.txt +++ b/contrib/restricted/abseil-cpp/absl/log/CMakeLists.linux-aarch64.txt @@ -36,12 +36,14 @@ target_sources(abseil-cpp-absl-log PRIVATE ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/initialize.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/check_op.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/conditions.cc + ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/fnmatch.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/globals.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/log_format.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/log_message.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/log_sink_set.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/nullguard.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/proto.cc + ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/vlog_config.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/log_entry.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/log_sink.cc ) diff --git a/contrib/restricted/abseil-cpp/absl/log/CMakeLists.linux-x86_64.txt b/contrib/restricted/abseil-cpp/absl/log/CMakeLists.linux-x86_64.txt index a7743e41a055..d3d4f2c40ec4 100644 --- a/contrib/restricted/abseil-cpp/absl/log/CMakeLists.linux-x86_64.txt +++ b/contrib/restricted/abseil-cpp/absl/log/CMakeLists.linux-x86_64.txt @@ -36,12 +36,14 @@ target_sources(abseil-cpp-absl-log PRIVATE ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/initialize.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/check_op.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/conditions.cc + ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/fnmatch.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/globals.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/log_format.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/log_message.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/log_sink_set.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/nullguard.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/proto.cc + ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/vlog_config.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/log_entry.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/log_sink.cc ) diff --git a/contrib/restricted/abseil-cpp/absl/log/CMakeLists.windows-x86_64.txt b/contrib/restricted/abseil-cpp/absl/log/CMakeLists.windows-x86_64.txt index c2793a97eaa1..45409ec603cd 100644 --- a/contrib/restricted/abseil-cpp/absl/log/CMakeLists.windows-x86_64.txt +++ b/contrib/restricted/abseil-cpp/absl/log/CMakeLists.windows-x86_64.txt @@ -35,12 +35,14 @@ target_sources(abseil-cpp-absl-log PRIVATE ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/initialize.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/check_op.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/conditions.cc + ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/fnmatch.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/globals.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/log_format.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/log_message.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/log_sink_set.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/nullguard.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/proto.cc + ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/internal/vlog_config.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/log_entry.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/log/log_sink.cc ) diff --git a/contrib/restricted/abseil-cpp/absl/status/CMakeLists.darwin-arm64.txt b/contrib/restricted/abseil-cpp/absl/status/CMakeLists.darwin-arm64.txt index 82c6e43c9117..0f12fbafd79c 100644 --- a/contrib/restricted/abseil-cpp/absl/status/CMakeLists.darwin-arm64.txt +++ b/contrib/restricted/abseil-cpp/absl/status/CMakeLists.darwin-arm64.txt @@ -26,6 +26,7 @@ target_link_libraries(abseil-cpp-absl-status PUBLIC abseil-cpp-absl-types ) target_sources(abseil-cpp-absl-status PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/status/internal/status_internal.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/status/status.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/status/status_payload_printer.cc ) diff --git a/contrib/restricted/abseil-cpp/absl/status/CMakeLists.darwin-x86_64.txt b/contrib/restricted/abseil-cpp/absl/status/CMakeLists.darwin-x86_64.txt index 82c6e43c9117..0f12fbafd79c 100644 --- a/contrib/restricted/abseil-cpp/absl/status/CMakeLists.darwin-x86_64.txt +++ b/contrib/restricted/abseil-cpp/absl/status/CMakeLists.darwin-x86_64.txt @@ -26,6 +26,7 @@ target_link_libraries(abseil-cpp-absl-status PUBLIC abseil-cpp-absl-types ) target_sources(abseil-cpp-absl-status PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/status/internal/status_internal.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/status/status.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/status/status_payload_printer.cc ) diff --git a/contrib/restricted/abseil-cpp/absl/status/CMakeLists.linux-aarch64.txt b/contrib/restricted/abseil-cpp/absl/status/CMakeLists.linux-aarch64.txt index ef805d8dde2a..76efbb8a76d3 100644 --- a/contrib/restricted/abseil-cpp/absl/status/CMakeLists.linux-aarch64.txt +++ b/contrib/restricted/abseil-cpp/absl/status/CMakeLists.linux-aarch64.txt @@ -27,6 +27,7 @@ target_link_libraries(abseil-cpp-absl-status PUBLIC abseil-cpp-absl-types ) target_sources(abseil-cpp-absl-status PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/status/internal/status_internal.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/status/status.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/status/status_payload_printer.cc ) diff --git a/contrib/restricted/abseil-cpp/absl/status/CMakeLists.linux-x86_64.txt b/contrib/restricted/abseil-cpp/absl/status/CMakeLists.linux-x86_64.txt index ef805d8dde2a..76efbb8a76d3 100644 --- a/contrib/restricted/abseil-cpp/absl/status/CMakeLists.linux-x86_64.txt +++ b/contrib/restricted/abseil-cpp/absl/status/CMakeLists.linux-x86_64.txt @@ -27,6 +27,7 @@ target_link_libraries(abseil-cpp-absl-status PUBLIC abseil-cpp-absl-types ) target_sources(abseil-cpp-absl-status PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/status/internal/status_internal.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/status/status.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/status/status_payload_printer.cc ) diff --git a/contrib/restricted/abseil-cpp/absl/status/CMakeLists.windows-x86_64.txt b/contrib/restricted/abseil-cpp/absl/status/CMakeLists.windows-x86_64.txt index 82c6e43c9117..0f12fbafd79c 100644 --- a/contrib/restricted/abseil-cpp/absl/status/CMakeLists.windows-x86_64.txt +++ b/contrib/restricted/abseil-cpp/absl/status/CMakeLists.windows-x86_64.txt @@ -26,6 +26,7 @@ target_link_libraries(abseil-cpp-absl-status PUBLIC abseil-cpp-absl-types ) target_sources(abseil-cpp-absl-status PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/status/internal/status_internal.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/status/status.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/status/status_payload_printer.cc ) diff --git a/contrib/restricted/abseil-cpp/absl/strings/CMakeLists.darwin-arm64.txt b/contrib/restricted/abseil-cpp/absl/strings/CMakeLists.darwin-arm64.txt index e3aa400b959a..a9e4eff8889c 100644 --- a/contrib/restricted/abseil-cpp/absl/strings/CMakeLists.darwin-arm64.txt +++ b/contrib/restricted/abseil-cpp/absl/strings/CMakeLists.darwin-arm64.txt @@ -25,7 +25,7 @@ target_sources(abseil-cpp-absl-strings PRIVATE ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_cord_state.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_memcpy_fallback.cc - ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_memcpy_x86_64.cc + ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_memcpy_x86_arm_combined.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_non_temporal_memcpy.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_x86_arm_combined.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/status/statusor.cc @@ -43,7 +43,6 @@ target_sources(abseil-cpp-absl-strings PRIVATE ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cord_rep_btree_reader.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cord_rep_consume.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cord_rep_crc.cc - ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cord_rep_ring.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cordz_functions.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cordz_handle.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cordz_info.cc diff --git a/contrib/restricted/abseil-cpp/absl/strings/CMakeLists.darwin-x86_64.txt b/contrib/restricted/abseil-cpp/absl/strings/CMakeLists.darwin-x86_64.txt index e3aa400b959a..a9e4eff8889c 100644 --- a/contrib/restricted/abseil-cpp/absl/strings/CMakeLists.darwin-x86_64.txt +++ b/contrib/restricted/abseil-cpp/absl/strings/CMakeLists.darwin-x86_64.txt @@ -25,7 +25,7 @@ target_sources(abseil-cpp-absl-strings PRIVATE ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_cord_state.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_memcpy_fallback.cc - ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_memcpy_x86_64.cc + ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_memcpy_x86_arm_combined.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_non_temporal_memcpy.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_x86_arm_combined.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/status/statusor.cc @@ -43,7 +43,6 @@ target_sources(abseil-cpp-absl-strings PRIVATE ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cord_rep_btree_reader.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cord_rep_consume.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cord_rep_crc.cc - ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cord_rep_ring.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cordz_functions.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cordz_handle.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cordz_info.cc diff --git a/contrib/restricted/abseil-cpp/absl/strings/CMakeLists.linux-aarch64.txt b/contrib/restricted/abseil-cpp/absl/strings/CMakeLists.linux-aarch64.txt index 2da01ab774e3..83a8fa70e66d 100644 --- a/contrib/restricted/abseil-cpp/absl/strings/CMakeLists.linux-aarch64.txt +++ b/contrib/restricted/abseil-cpp/absl/strings/CMakeLists.linux-aarch64.txt @@ -26,7 +26,7 @@ target_sources(abseil-cpp-absl-strings PRIVATE ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_cord_state.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_memcpy_fallback.cc - ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_memcpy_x86_64.cc + ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_memcpy_x86_arm_combined.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_non_temporal_memcpy.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_x86_arm_combined.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/status/statusor.cc @@ -44,7 +44,6 @@ target_sources(abseil-cpp-absl-strings PRIVATE ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cord_rep_btree_reader.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cord_rep_consume.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cord_rep_crc.cc - ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cord_rep_ring.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cordz_functions.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cordz_handle.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cordz_info.cc diff --git a/contrib/restricted/abseil-cpp/absl/strings/CMakeLists.linux-x86_64.txt b/contrib/restricted/abseil-cpp/absl/strings/CMakeLists.linux-x86_64.txt index 2da01ab774e3..83a8fa70e66d 100644 --- a/contrib/restricted/abseil-cpp/absl/strings/CMakeLists.linux-x86_64.txt +++ b/contrib/restricted/abseil-cpp/absl/strings/CMakeLists.linux-x86_64.txt @@ -26,7 +26,7 @@ target_sources(abseil-cpp-absl-strings PRIVATE ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_cord_state.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_memcpy_fallback.cc - ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_memcpy_x86_64.cc + ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_memcpy_x86_arm_combined.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_non_temporal_memcpy.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_x86_arm_combined.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/status/statusor.cc @@ -44,7 +44,6 @@ target_sources(abseil-cpp-absl-strings PRIVATE ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cord_rep_btree_reader.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cord_rep_consume.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cord_rep_crc.cc - ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cord_rep_ring.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cordz_functions.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cordz_handle.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cordz_info.cc diff --git a/contrib/restricted/abseil-cpp/absl/strings/CMakeLists.windows-x86_64.txt b/contrib/restricted/abseil-cpp/absl/strings/CMakeLists.windows-x86_64.txt index e3aa400b959a..a9e4eff8889c 100644 --- a/contrib/restricted/abseil-cpp/absl/strings/CMakeLists.windows-x86_64.txt +++ b/contrib/restricted/abseil-cpp/absl/strings/CMakeLists.windows-x86_64.txt @@ -25,7 +25,7 @@ target_sources(abseil-cpp-absl-strings PRIVATE ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_cord_state.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_memcpy_fallback.cc - ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_memcpy_x86_64.cc + ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_memcpy_x86_arm_combined.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_non_temporal_memcpy.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/crc/internal/crc_x86_arm_combined.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/status/statusor.cc @@ -43,7 +43,6 @@ target_sources(abseil-cpp-absl-strings PRIVATE ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cord_rep_btree_reader.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cord_rep_consume.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cord_rep_crc.cc - ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cord_rep_ring.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cordz_functions.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cordz_handle.cc ${CMAKE_SOURCE_DIR}/contrib/restricted/abseil-cpp/absl/strings/internal/cordz_info.cc diff --git a/contrib/restricted/aws/aws-c-cal/CMakeLists.darwin-arm64.txt b/contrib/restricted/aws/aws-c-cal/CMakeLists.darwin-arm64.txt index 6206412f6471..fca049829106 100644 --- a/contrib/restricted/aws/aws-c-cal/CMakeLists.darwin-arm64.txt +++ b/contrib/restricted/aws/aws-c-cal/CMakeLists.darwin-arm64.txt @@ -26,6 +26,7 @@ target_link_options(restricted-aws-aws-c-cal INTERFACE Security ) target_sources(restricted-aws-aws-c-cal PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/restricted/aws/aws-c-cal/source/darwin/common_cryptor_spi.h ${CMAKE_SOURCE_DIR}/contrib/restricted/aws/aws-c-cal/source/cal.c ${CMAKE_SOURCE_DIR}/contrib/restricted/aws/aws-c-cal/source/der.c ${CMAKE_SOURCE_DIR}/contrib/restricted/aws/aws-c-cal/source/ecc.c diff --git a/contrib/restricted/aws/aws-c-cal/CMakeLists.darwin-x86_64.txt b/contrib/restricted/aws/aws-c-cal/CMakeLists.darwin-x86_64.txt index 6206412f6471..fca049829106 100644 --- a/contrib/restricted/aws/aws-c-cal/CMakeLists.darwin-x86_64.txt +++ b/contrib/restricted/aws/aws-c-cal/CMakeLists.darwin-x86_64.txt @@ -26,6 +26,7 @@ target_link_options(restricted-aws-aws-c-cal INTERFACE Security ) target_sources(restricted-aws-aws-c-cal PRIVATE + ${CMAKE_SOURCE_DIR}/contrib/restricted/aws/aws-c-cal/source/darwin/common_cryptor_spi.h ${CMAKE_SOURCE_DIR}/contrib/restricted/aws/aws-c-cal/source/cal.c ${CMAKE_SOURCE_DIR}/contrib/restricted/aws/aws-c-cal/source/der.c ${CMAKE_SOURCE_DIR}/contrib/restricted/aws/aws-c-cal/source/ecc.c diff --git a/contrib/restricted/aws/aws-c-common/CMakeLists.windows-x86_64.txt b/contrib/restricted/aws/aws-c-common/CMakeLists.windows-x86_64.txt index fb7823f7c5d9..5403dfef9ed4 100644 --- a/contrib/restricted/aws/aws-c-common/CMakeLists.windows-x86_64.txt +++ b/contrib/restricted/aws/aws-c-common/CMakeLists.windows-x86_64.txt @@ -74,8 +74,6 @@ target_sources_custom(restricted-aws-aws-c-common SRCS ${CMAKE_SOURCE_DIR}/contrib/restricted/aws/aws-c-common/source/arch/intel/encoding_avx2.c CUSTOM_FLAGS - -mavx2 - -mfma - -mbmi - -mbmi2 + /arch:AVX2 + /DAVX2_ENABLED=1 ) diff --git a/contrib/restricted/aws/aws-c-http/CMakeLists.windows-x86_64.txt b/contrib/restricted/aws/aws-c-http/CMakeLists.windows-x86_64.txt index 8d1599b73092..904c60d055a7 100644 --- a/contrib/restricted/aws/aws-c-http/CMakeLists.windows-x86_64.txt +++ b/contrib/restricted/aws/aws-c-http/CMakeLists.windows-x86_64.txt @@ -29,7 +29,6 @@ target_compile_options(restricted-aws-aws-c-http PRIVATE -DS2N_STACKTRACE -DS2N___RESTRICT__SUPPORTED -DAWS_HTTP_EXPORTS - -std=c99 $,,-Wno-everything> ) target_include_directories(restricted-aws-aws-c-http PUBLIC diff --git a/contrib/restricted/aws/aws-c-io/CMakeLists.windows-x86_64.txt b/contrib/restricted/aws/aws-c-io/CMakeLists.windows-x86_64.txt index f353ab49e0f0..11d506e7fcbb 100644 --- a/contrib/restricted/aws/aws-c-io/CMakeLists.windows-x86_64.txt +++ b/contrib/restricted/aws/aws-c-io/CMakeLists.windows-x86_64.txt @@ -27,7 +27,6 @@ target_compile_options(restricted-aws-aws-c-io PRIVATE -DS2N___RESTRICT__SUPPORTED -DAWS_IO_EXPORTS -DAWS_USE_IO_COMPLETION_PORTS - -std=c99 $,,-Wno-everything> ) target_include_directories(restricted-aws-aws-c-io PUBLIC diff --git a/contrib/restricted/boost/CMakeLists.windows-x86_64.txt b/contrib/restricted/boost/CMakeLists.windows-x86_64.txt index 79eb1eb674dd..b02cf0ea8a6d 100644 --- a/contrib/restricted/boost/CMakeLists.windows-x86_64.txt +++ b/contrib/restricted/boost/CMakeLists.windows-x86_64.txt @@ -28,7 +28,6 @@ add_subdirectory(dynamic_bitset) add_subdirectory(endian) add_subdirectory(exception) add_subdirectory(foreach) -add_subdirectory(format) add_subdirectory(function) add_subdirectory(function_types) add_subdirectory(functional) diff --git a/contrib/restricted/boost/container_hash/CMakeLists.darwin-arm64.txt b/contrib/restricted/boost/container_hash/CMakeLists.darwin-arm64.txt index f6ba33a6e963..be93cb43a71a 100644 --- a/contrib/restricted/boost/container_hash/CMakeLists.darwin-arm64.txt +++ b/contrib/restricted/boost/container_hash/CMakeLists.darwin-arm64.txt @@ -16,5 +16,4 @@ target_link_libraries(restricted-boost-container_hash INTERFACE restricted-boost-config restricted-boost-describe restricted-boost-mp11 - restricted-boost-type_traits ) diff --git a/contrib/restricted/boost/container_hash/CMakeLists.darwin-x86_64.txt b/contrib/restricted/boost/container_hash/CMakeLists.darwin-x86_64.txt index f6ba33a6e963..be93cb43a71a 100644 --- a/contrib/restricted/boost/container_hash/CMakeLists.darwin-x86_64.txt +++ b/contrib/restricted/boost/container_hash/CMakeLists.darwin-x86_64.txt @@ -16,5 +16,4 @@ target_link_libraries(restricted-boost-container_hash INTERFACE restricted-boost-config restricted-boost-describe restricted-boost-mp11 - restricted-boost-type_traits ) diff --git a/contrib/restricted/boost/container_hash/CMakeLists.linux-aarch64.txt b/contrib/restricted/boost/container_hash/CMakeLists.linux-aarch64.txt index 0e9a7fc39015..469e2aca8042 100644 --- a/contrib/restricted/boost/container_hash/CMakeLists.linux-aarch64.txt +++ b/contrib/restricted/boost/container_hash/CMakeLists.linux-aarch64.txt @@ -17,5 +17,4 @@ target_link_libraries(restricted-boost-container_hash INTERFACE restricted-boost-config restricted-boost-describe restricted-boost-mp11 - restricted-boost-type_traits ) diff --git a/contrib/restricted/boost/container_hash/CMakeLists.linux-x86_64.txt b/contrib/restricted/boost/container_hash/CMakeLists.linux-x86_64.txt index 0e9a7fc39015..469e2aca8042 100644 --- a/contrib/restricted/boost/container_hash/CMakeLists.linux-x86_64.txt +++ b/contrib/restricted/boost/container_hash/CMakeLists.linux-x86_64.txt @@ -17,5 +17,4 @@ target_link_libraries(restricted-boost-container_hash INTERFACE restricted-boost-config restricted-boost-describe restricted-boost-mp11 - restricted-boost-type_traits ) diff --git a/contrib/restricted/boost/container_hash/CMakeLists.windows-x86_64.txt b/contrib/restricted/boost/container_hash/CMakeLists.windows-x86_64.txt index f6ba33a6e963..be93cb43a71a 100644 --- a/contrib/restricted/boost/container_hash/CMakeLists.windows-x86_64.txt +++ b/contrib/restricted/boost/container_hash/CMakeLists.windows-x86_64.txt @@ -16,5 +16,4 @@ target_link_libraries(restricted-boost-container_hash INTERFACE restricted-boost-config restricted-boost-describe restricted-boost-mp11 - restricted-boost-type_traits ) diff --git a/contrib/restricted/boost/format/CMakeLists.txt b/contrib/restricted/boost/format/CMakeLists.txt index d863ebd18067..380079ac7b4a 100644 --- a/contrib/restricted/boost/format/CMakeLists.txt +++ b/contrib/restricted/boost/format/CMakeLists.txt @@ -14,6 +14,4 @@ elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL include(CMakeLists.darwin-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) endif() diff --git a/contrib/restricted/boost/iterator/CMakeLists.darwin-arm64.txt b/contrib/restricted/boost/iterator/CMakeLists.darwin-arm64.txt index df59b473b284..a997178c2c48 100644 --- a/contrib/restricted/boost/iterator/CMakeLists.darwin-arm64.txt +++ b/contrib/restricted/boost/iterator/CMakeLists.darwin-arm64.txt @@ -16,7 +16,6 @@ target_link_libraries(restricted-boost-iterator INTERFACE restricted-boost-assert restricted-boost-concept_check restricted-boost-config - restricted-boost-conversion restricted-boost-core restricted-boost-detail restricted-boost-function_types diff --git a/contrib/restricted/boost/iterator/CMakeLists.darwin-x86_64.txt b/contrib/restricted/boost/iterator/CMakeLists.darwin-x86_64.txt index df59b473b284..a997178c2c48 100644 --- a/contrib/restricted/boost/iterator/CMakeLists.darwin-x86_64.txt +++ b/contrib/restricted/boost/iterator/CMakeLists.darwin-x86_64.txt @@ -16,7 +16,6 @@ target_link_libraries(restricted-boost-iterator INTERFACE restricted-boost-assert restricted-boost-concept_check restricted-boost-config - restricted-boost-conversion restricted-boost-core restricted-boost-detail restricted-boost-function_types diff --git a/contrib/restricted/boost/iterator/CMakeLists.linux-aarch64.txt b/contrib/restricted/boost/iterator/CMakeLists.linux-aarch64.txt index a1ebd81a38f7..6bccab05c831 100644 --- a/contrib/restricted/boost/iterator/CMakeLists.linux-aarch64.txt +++ b/contrib/restricted/boost/iterator/CMakeLists.linux-aarch64.txt @@ -17,7 +17,6 @@ target_link_libraries(restricted-boost-iterator INTERFACE restricted-boost-assert restricted-boost-concept_check restricted-boost-config - restricted-boost-conversion restricted-boost-core restricted-boost-detail restricted-boost-function_types diff --git a/contrib/restricted/boost/iterator/CMakeLists.linux-x86_64.txt b/contrib/restricted/boost/iterator/CMakeLists.linux-x86_64.txt index a1ebd81a38f7..6bccab05c831 100644 --- a/contrib/restricted/boost/iterator/CMakeLists.linux-x86_64.txt +++ b/contrib/restricted/boost/iterator/CMakeLists.linux-x86_64.txt @@ -17,7 +17,6 @@ target_link_libraries(restricted-boost-iterator INTERFACE restricted-boost-assert restricted-boost-concept_check restricted-boost-config - restricted-boost-conversion restricted-boost-core restricted-boost-detail restricted-boost-function_types diff --git a/contrib/restricted/boost/iterator/CMakeLists.windows-x86_64.txt b/contrib/restricted/boost/iterator/CMakeLists.windows-x86_64.txt index df59b473b284..a997178c2c48 100644 --- a/contrib/restricted/boost/iterator/CMakeLists.windows-x86_64.txt +++ b/contrib/restricted/boost/iterator/CMakeLists.windows-x86_64.txt @@ -16,7 +16,6 @@ target_link_libraries(restricted-boost-iterator INTERFACE restricted-boost-assert restricted-boost-concept_check restricted-boost-config - restricted-boost-conversion restricted-boost-core restricted-boost-detail restricted-boost-function_types diff --git a/contrib/restricted/boost/lexical_cast/CMakeLists.darwin-arm64.txt b/contrib/restricted/boost/lexical_cast/CMakeLists.darwin-arm64.txt index c4aff4db0d5e..6ca4efe3360e 100644 --- a/contrib/restricted/boost/lexical_cast/CMakeLists.darwin-arm64.txt +++ b/contrib/restricted/boost/lexical_cast/CMakeLists.darwin-arm64.txt @@ -13,15 +13,11 @@ target_include_directories(restricted-boost-lexical_cast INTERFACE ) target_link_libraries(restricted-boost-lexical_cast INTERFACE contrib-libs-cxxsupp - restricted-boost-array - restricted-boost-assert restricted-boost-config restricted-boost-container restricted-boost-core restricted-boost-integer restricted-boost-numeric_conversion - restricted-boost-range - restricted-boost-static_assert restricted-boost-throw_exception restricted-boost-type_traits ) diff --git a/contrib/restricted/boost/lexical_cast/CMakeLists.darwin-x86_64.txt b/contrib/restricted/boost/lexical_cast/CMakeLists.darwin-x86_64.txt index c4aff4db0d5e..6ca4efe3360e 100644 --- a/contrib/restricted/boost/lexical_cast/CMakeLists.darwin-x86_64.txt +++ b/contrib/restricted/boost/lexical_cast/CMakeLists.darwin-x86_64.txt @@ -13,15 +13,11 @@ target_include_directories(restricted-boost-lexical_cast INTERFACE ) target_link_libraries(restricted-boost-lexical_cast INTERFACE contrib-libs-cxxsupp - restricted-boost-array - restricted-boost-assert restricted-boost-config restricted-boost-container restricted-boost-core restricted-boost-integer restricted-boost-numeric_conversion - restricted-boost-range - restricted-boost-static_assert restricted-boost-throw_exception restricted-boost-type_traits ) diff --git a/contrib/restricted/boost/lexical_cast/CMakeLists.linux-aarch64.txt b/contrib/restricted/boost/lexical_cast/CMakeLists.linux-aarch64.txt index d746f22befeb..b8c101adf91d 100644 --- a/contrib/restricted/boost/lexical_cast/CMakeLists.linux-aarch64.txt +++ b/contrib/restricted/boost/lexical_cast/CMakeLists.linux-aarch64.txt @@ -14,15 +14,11 @@ target_include_directories(restricted-boost-lexical_cast INTERFACE target_link_libraries(restricted-boost-lexical_cast INTERFACE contrib-libs-linux-headers contrib-libs-cxxsupp - restricted-boost-array - restricted-boost-assert restricted-boost-config restricted-boost-container restricted-boost-core restricted-boost-integer restricted-boost-numeric_conversion - restricted-boost-range - restricted-boost-static_assert restricted-boost-throw_exception restricted-boost-type_traits ) diff --git a/contrib/restricted/boost/lexical_cast/CMakeLists.linux-x86_64.txt b/contrib/restricted/boost/lexical_cast/CMakeLists.linux-x86_64.txt index d746f22befeb..b8c101adf91d 100644 --- a/contrib/restricted/boost/lexical_cast/CMakeLists.linux-x86_64.txt +++ b/contrib/restricted/boost/lexical_cast/CMakeLists.linux-x86_64.txt @@ -14,15 +14,11 @@ target_include_directories(restricted-boost-lexical_cast INTERFACE target_link_libraries(restricted-boost-lexical_cast INTERFACE contrib-libs-linux-headers contrib-libs-cxxsupp - restricted-boost-array - restricted-boost-assert restricted-boost-config restricted-boost-container restricted-boost-core restricted-boost-integer restricted-boost-numeric_conversion - restricted-boost-range - restricted-boost-static_assert restricted-boost-throw_exception restricted-boost-type_traits ) diff --git a/contrib/restricted/boost/lexical_cast/CMakeLists.windows-x86_64.txt b/contrib/restricted/boost/lexical_cast/CMakeLists.windows-x86_64.txt index c4aff4db0d5e..6ca4efe3360e 100644 --- a/contrib/restricted/boost/lexical_cast/CMakeLists.windows-x86_64.txt +++ b/contrib/restricted/boost/lexical_cast/CMakeLists.windows-x86_64.txt @@ -13,15 +13,11 @@ target_include_directories(restricted-boost-lexical_cast INTERFACE ) target_link_libraries(restricted-boost-lexical_cast INTERFACE contrib-libs-cxxsupp - restricted-boost-array - restricted-boost-assert restricted-boost-config restricted-boost-container restricted-boost-core restricted-boost-integer restricted-boost-numeric_conversion - restricted-boost-range - restricted-boost-static_assert restricted-boost-throw_exception restricted-boost-type_traits ) diff --git a/contrib/restricted/boost/property_tree/CMakeLists.darwin-x86_64.txt b/contrib/restricted/boost/property_tree/CMakeLists.darwin-x86_64.txt index 57f107d22d6d..664325c48ded 100644 --- a/contrib/restricted/boost/property_tree/CMakeLists.darwin-x86_64.txt +++ b/contrib/restricted/boost/property_tree/CMakeLists.darwin-x86_64.txt @@ -18,7 +18,6 @@ target_link_libraries(restricted-boost-property_tree INTERFACE restricted-boost-bind restricted-boost-config restricted-boost-core - restricted-boost-format restricted-boost-iterator restricted-boost-mpl restricted-boost-multi_index diff --git a/contrib/restricted/boost/property_tree/CMakeLists.linux-x86_64.txt b/contrib/restricted/boost/property_tree/CMakeLists.linux-x86_64.txt index b64b977a6456..5cc82a47607e 100644 --- a/contrib/restricted/boost/property_tree/CMakeLists.linux-x86_64.txt +++ b/contrib/restricted/boost/property_tree/CMakeLists.linux-x86_64.txt @@ -19,7 +19,6 @@ target_link_libraries(restricted-boost-property_tree INTERFACE restricted-boost-bind restricted-boost-config restricted-boost-core - restricted-boost-format restricted-boost-iterator restricted-boost-mpl restricted-boost-multi_index diff --git a/contrib/restricted/boost/property_tree/CMakeLists.windows-x86_64.txt b/contrib/restricted/boost/property_tree/CMakeLists.windows-x86_64.txt index 57f107d22d6d..664325c48ded 100644 --- a/contrib/restricted/boost/property_tree/CMakeLists.windows-x86_64.txt +++ b/contrib/restricted/boost/property_tree/CMakeLists.windows-x86_64.txt @@ -18,7 +18,6 @@ target_link_libraries(restricted-boost-property_tree INTERFACE restricted-boost-bind restricted-boost-config restricted-boost-core - restricted-boost-format restricted-boost-iterator restricted-boost-mpl restricted-boost-multi_index diff --git a/contrib/restricted/boost/rational/CMakeLists.darwin-x86_64.txt b/contrib/restricted/boost/rational/CMakeLists.darwin-x86_64.txt index c4d92a21a6e3..f0cb6d48aa6e 100644 --- a/contrib/restricted/boost/rational/CMakeLists.darwin-x86_64.txt +++ b/contrib/restricted/boost/rational/CMakeLists.darwin-x86_64.txt @@ -8,9 +8,6 @@ add_library(restricted-boost-rational INTERFACE) -target_include_directories(restricted-boost-rational INTERFACE - ${CMAKE_SOURCE_DIR}/contrib/restricted/boost/rational/include -) target_link_libraries(restricted-boost-rational INTERFACE contrib-libs-cxxsupp restricted-boost-assert diff --git a/contrib/restricted/boost/rational/CMakeLists.linux-x86_64.txt b/contrib/restricted/boost/rational/CMakeLists.linux-x86_64.txt index 61fd5149ab30..58b190a47a07 100644 --- a/contrib/restricted/boost/rational/CMakeLists.linux-x86_64.txt +++ b/contrib/restricted/boost/rational/CMakeLists.linux-x86_64.txt @@ -8,9 +8,6 @@ add_library(restricted-boost-rational INTERFACE) -target_include_directories(restricted-boost-rational INTERFACE - ${CMAKE_SOURCE_DIR}/contrib/restricted/boost/rational/include -) target_link_libraries(restricted-boost-rational INTERFACE contrib-libs-linux-headers contrib-libs-cxxsupp diff --git a/contrib/restricted/boost/rational/CMakeLists.windows-x86_64.txt b/contrib/restricted/boost/rational/CMakeLists.windows-x86_64.txt index c4d92a21a6e3..f0cb6d48aa6e 100644 --- a/contrib/restricted/boost/rational/CMakeLists.windows-x86_64.txt +++ b/contrib/restricted/boost/rational/CMakeLists.windows-x86_64.txt @@ -8,9 +8,6 @@ add_library(restricted-boost-rational INTERFACE) -target_include_directories(restricted-boost-rational INTERFACE - ${CMAKE_SOURCE_DIR}/contrib/restricted/boost/rational/include -) target_link_libraries(restricted-boost-rational INTERFACE contrib-libs-cxxsupp restricted-boost-assert diff --git a/contrib/restricted/boost/type_index/CMakeLists.darwin-arm64.txt b/contrib/restricted/boost/type_index/CMakeLists.darwin-arm64.txt index 701e4811957c..b167e31a32ce 100644 --- a/contrib/restricted/boost/type_index/CMakeLists.darwin-arm64.txt +++ b/contrib/restricted/boost/type_index/CMakeLists.darwin-arm64.txt @@ -16,8 +16,5 @@ target_link_libraries(restricted-boost-type_index INTERFACE restricted-boost-config restricted-boost-container_hash restricted-boost-core - restricted-boost-preprocessor - restricted-boost-static_assert restricted-boost-throw_exception - restricted-boost-type_traits ) diff --git a/contrib/restricted/boost/type_index/CMakeLists.darwin-x86_64.txt b/contrib/restricted/boost/type_index/CMakeLists.darwin-x86_64.txt index 701e4811957c..b167e31a32ce 100644 --- a/contrib/restricted/boost/type_index/CMakeLists.darwin-x86_64.txt +++ b/contrib/restricted/boost/type_index/CMakeLists.darwin-x86_64.txt @@ -16,8 +16,5 @@ target_link_libraries(restricted-boost-type_index INTERFACE restricted-boost-config restricted-boost-container_hash restricted-boost-core - restricted-boost-preprocessor - restricted-boost-static_assert restricted-boost-throw_exception - restricted-boost-type_traits ) diff --git a/contrib/restricted/boost/type_index/CMakeLists.linux-aarch64.txt b/contrib/restricted/boost/type_index/CMakeLists.linux-aarch64.txt index 5d9a71e2cc4a..150623a9c31d 100644 --- a/contrib/restricted/boost/type_index/CMakeLists.linux-aarch64.txt +++ b/contrib/restricted/boost/type_index/CMakeLists.linux-aarch64.txt @@ -17,8 +17,5 @@ target_link_libraries(restricted-boost-type_index INTERFACE restricted-boost-config restricted-boost-container_hash restricted-boost-core - restricted-boost-preprocessor - restricted-boost-static_assert restricted-boost-throw_exception - restricted-boost-type_traits ) diff --git a/contrib/restricted/boost/type_index/CMakeLists.linux-x86_64.txt b/contrib/restricted/boost/type_index/CMakeLists.linux-x86_64.txt index 5d9a71e2cc4a..150623a9c31d 100644 --- a/contrib/restricted/boost/type_index/CMakeLists.linux-x86_64.txt +++ b/contrib/restricted/boost/type_index/CMakeLists.linux-x86_64.txt @@ -17,8 +17,5 @@ target_link_libraries(restricted-boost-type_index INTERFACE restricted-boost-config restricted-boost-container_hash restricted-boost-core - restricted-boost-preprocessor - restricted-boost-static_assert restricted-boost-throw_exception - restricted-boost-type_traits ) diff --git a/contrib/restricted/boost/type_index/CMakeLists.windows-x86_64.txt b/contrib/restricted/boost/type_index/CMakeLists.windows-x86_64.txt index 701e4811957c..b167e31a32ce 100644 --- a/contrib/restricted/boost/type_index/CMakeLists.windows-x86_64.txt +++ b/contrib/restricted/boost/type_index/CMakeLists.windows-x86_64.txt @@ -16,8 +16,5 @@ target_link_libraries(restricted-boost-type_index INTERFACE restricted-boost-config restricted-boost-container_hash restricted-boost-core - restricted-boost-preprocessor - restricted-boost-static_assert restricted-boost-throw_exception - restricted-boost-type_traits ) diff --git a/contrib/restricted/boost/typeof/CMakeLists.darwin-arm64.txt b/contrib/restricted/boost/typeof/CMakeLists.darwin-arm64.txt index 04fff27108b1..87586deb2833 100644 --- a/contrib/restricted/boost/typeof/CMakeLists.darwin-arm64.txt +++ b/contrib/restricted/boost/typeof/CMakeLists.darwin-arm64.txt @@ -14,6 +14,4 @@ target_include_directories(restricted-boost-typeof INTERFACE target_link_libraries(restricted-boost-typeof INTERFACE contrib-libs-cxxsupp restricted-boost-config - restricted-boost-preprocessor - restricted-boost-type_traits ) diff --git a/contrib/restricted/boost/typeof/CMakeLists.darwin-x86_64.txt b/contrib/restricted/boost/typeof/CMakeLists.darwin-x86_64.txt index 04fff27108b1..87586deb2833 100644 --- a/contrib/restricted/boost/typeof/CMakeLists.darwin-x86_64.txt +++ b/contrib/restricted/boost/typeof/CMakeLists.darwin-x86_64.txt @@ -14,6 +14,4 @@ target_include_directories(restricted-boost-typeof INTERFACE target_link_libraries(restricted-boost-typeof INTERFACE contrib-libs-cxxsupp restricted-boost-config - restricted-boost-preprocessor - restricted-boost-type_traits ) diff --git a/contrib/restricted/boost/typeof/CMakeLists.linux-aarch64.txt b/contrib/restricted/boost/typeof/CMakeLists.linux-aarch64.txt index ff3ee3a26605..9bee1c60fe8b 100644 --- a/contrib/restricted/boost/typeof/CMakeLists.linux-aarch64.txt +++ b/contrib/restricted/boost/typeof/CMakeLists.linux-aarch64.txt @@ -15,6 +15,4 @@ target_link_libraries(restricted-boost-typeof INTERFACE contrib-libs-linux-headers contrib-libs-cxxsupp restricted-boost-config - restricted-boost-preprocessor - restricted-boost-type_traits ) diff --git a/contrib/restricted/boost/typeof/CMakeLists.linux-x86_64.txt b/contrib/restricted/boost/typeof/CMakeLists.linux-x86_64.txt index ff3ee3a26605..9bee1c60fe8b 100644 --- a/contrib/restricted/boost/typeof/CMakeLists.linux-x86_64.txt +++ b/contrib/restricted/boost/typeof/CMakeLists.linux-x86_64.txt @@ -15,6 +15,4 @@ target_link_libraries(restricted-boost-typeof INTERFACE contrib-libs-linux-headers contrib-libs-cxxsupp restricted-boost-config - restricted-boost-preprocessor - restricted-boost-type_traits ) diff --git a/contrib/restricted/boost/typeof/CMakeLists.windows-x86_64.txt b/contrib/restricted/boost/typeof/CMakeLists.windows-x86_64.txt index 04fff27108b1..87586deb2833 100644 --- a/contrib/restricted/boost/typeof/CMakeLists.windows-x86_64.txt +++ b/contrib/restricted/boost/typeof/CMakeLists.windows-x86_64.txt @@ -14,6 +14,4 @@ target_include_directories(restricted-boost-typeof INTERFACE target_link_libraries(restricted-boost-typeof INTERFACE contrib-libs-cxxsupp restricted-boost-config - restricted-boost-preprocessor - restricted-boost-type_traits ) diff --git a/contrib/tools/flatc/bin/CMakeLists.linux-aarch64.txt b/contrib/tools/flatc/bin/CMakeLists.linux-aarch64.txt index 83ac0382b9a4..55533e40e92e 100644 --- a/contrib/tools/flatc/bin/CMakeLists.linux-aarch64.txt +++ b/contrib/tools/flatc/bin/CMakeLists.linux-aarch64.txt @@ -22,7 +22,6 @@ target_link_options(flatc PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread ) target_sources(flatc PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/flatbuffers/src/flatc_main.cpp diff --git a/contrib/tools/flatc/bin/CMakeLists.linux-x86_64.txt b/contrib/tools/flatc/bin/CMakeLists.linux-x86_64.txt index bf662e0f7910..7a29fdea9969 100644 --- a/contrib/tools/flatc/bin/CMakeLists.linux-x86_64.txt +++ b/contrib/tools/flatc/bin/CMakeLists.linux-x86_64.txt @@ -22,7 +22,6 @@ target_link_options(flatc PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread ) target_sources(flatc PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/flatbuffers/src/flatc_main.cpp diff --git a/contrib/tools/protoc/bin/CMakeLists.linux-aarch64.txt b/contrib/tools/protoc/bin/CMakeLists.linux-aarch64.txt index 7aa65033fd02..b6dc2b747ebc 100644 --- a/contrib/tools/protoc/bin/CMakeLists.linux-aarch64.txt +++ b/contrib/tools/protoc/bin/CMakeLists.linux-aarch64.txt @@ -23,9 +23,6 @@ target_link_options(protoc PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(protoc PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/protoc/src/google/protobuf/compiler/main.cc diff --git a/contrib/tools/protoc/bin/CMakeLists.linux-x86_64.txt b/contrib/tools/protoc/bin/CMakeLists.linux-x86_64.txt index 37364dc61aac..7a233fd38d5c 100644 --- a/contrib/tools/protoc/bin/CMakeLists.linux-x86_64.txt +++ b/contrib/tools/protoc/bin/CMakeLists.linux-x86_64.txt @@ -24,9 +24,6 @@ target_link_options(protoc PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(protoc PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/protoc/src/google/protobuf/compiler/main.cc diff --git a/contrib/tools/protoc/plugins/cpp_styleguide/CMakeLists.linux-aarch64.txt b/contrib/tools/protoc/plugins/cpp_styleguide/CMakeLists.linux-aarch64.txt index 744e24124bff..42da49f53694 100644 --- a/contrib/tools/protoc/plugins/cpp_styleguide/CMakeLists.linux-aarch64.txt +++ b/contrib/tools/protoc/plugins/cpp_styleguide/CMakeLists.linux-aarch64.txt @@ -23,9 +23,6 @@ target_link_options(cpp_styleguide PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(cpp_styleguide PRIVATE ${CMAKE_SOURCE_DIR}/contrib/tools/protoc/plugins/cpp_styleguide/cpp_styleguide.cpp diff --git a/contrib/tools/protoc/plugins/cpp_styleguide/CMakeLists.linux-x86_64.txt b/contrib/tools/protoc/plugins/cpp_styleguide/CMakeLists.linux-x86_64.txt index d39ea8b10b1b..8cbd55c43671 100644 --- a/contrib/tools/protoc/plugins/cpp_styleguide/CMakeLists.linux-x86_64.txt +++ b/contrib/tools/protoc/plugins/cpp_styleguide/CMakeLists.linux-x86_64.txt @@ -24,9 +24,6 @@ target_link_options(cpp_styleguide PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(cpp_styleguide PRIVATE ${CMAKE_SOURCE_DIR}/contrib/tools/protoc/plugins/cpp_styleguide/cpp_styleguide.cpp diff --git a/contrib/tools/protoc/plugins/grpc_cpp/CMakeLists.linux-aarch64.txt b/contrib/tools/protoc/plugins/grpc_cpp/CMakeLists.linux-aarch64.txt index 860ce479935e..d2a3c99c3bc9 100644 --- a/contrib/tools/protoc/plugins/grpc_cpp/CMakeLists.linux-aarch64.txt +++ b/contrib/tools/protoc/plugins/grpc_cpp/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(grpc_cpp PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(grpc_cpp PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/grpc/src/compiler/cpp_plugin.cc diff --git a/contrib/tools/protoc/plugins/grpc_cpp/CMakeLists.linux-x86_64.txt b/contrib/tools/protoc/plugins/grpc_cpp/CMakeLists.linux-x86_64.txt index 38f77750e6b6..bd6bc76ba1d5 100644 --- a/contrib/tools/protoc/plugins/grpc_cpp/CMakeLists.linux-x86_64.txt +++ b/contrib/tools/protoc/plugins/grpc_cpp/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(grpc_cpp PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(grpc_cpp PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/grpc/src/compiler/cpp_plugin.cc diff --git a/library/cpp/CMakeLists.windows-x86_64.txt b/library/cpp/CMakeLists.windows-x86_64.txt index 7867eb10618e..1fc99ac7c865 100644 --- a/library/cpp/CMakeLists.windows-x86_64.txt +++ b/library/cpp/CMakeLists.windows-x86_64.txt @@ -18,6 +18,7 @@ add_subdirectory(cache) add_subdirectory(case_insensitive_string) add_subdirectory(cgiparam) add_subdirectory(charset) +add_subdirectory(clickhouse) add_subdirectory(codecs) add_subdirectory(colorizer) add_subdirectory(compproto) diff --git a/library/cpp/accurate_accumulate/CMakeLists.darwin-arm64.txt b/library/cpp/accurate_accumulate/CMakeLists.darwin-arm64.txt index 6d68faefed96..62f15debba1d 100644 --- a/library/cpp/accurate_accumulate/CMakeLists.darwin-arm64.txt +++ b/library/cpp/accurate_accumulate/CMakeLists.darwin-arm64.txt @@ -13,5 +13,6 @@ target_link_libraries(library-cpp-accurate_accumulate PUBLIC yutil ) target_sources(library-cpp-accurate_accumulate PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/accurate_accumulate/accurate_accumulate.h ${CMAKE_SOURCE_DIR}/library/cpp/accurate_accumulate/accurate_accumulate.cpp ) diff --git a/library/cpp/accurate_accumulate/CMakeLists.darwin-x86_64.txt b/library/cpp/accurate_accumulate/CMakeLists.darwin-x86_64.txt index 6d68faefed96..62f15debba1d 100644 --- a/library/cpp/accurate_accumulate/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/accurate_accumulate/CMakeLists.darwin-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(library-cpp-accurate_accumulate PUBLIC yutil ) target_sources(library-cpp-accurate_accumulate PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/accurate_accumulate/accurate_accumulate.h ${CMAKE_SOURCE_DIR}/library/cpp/accurate_accumulate/accurate_accumulate.cpp ) diff --git a/library/cpp/accurate_accumulate/CMakeLists.linux-aarch64.txt b/library/cpp/accurate_accumulate/CMakeLists.linux-aarch64.txt index d168ea5295a7..d8a5028e256d 100644 --- a/library/cpp/accurate_accumulate/CMakeLists.linux-aarch64.txt +++ b/library/cpp/accurate_accumulate/CMakeLists.linux-aarch64.txt @@ -14,5 +14,6 @@ target_link_libraries(library-cpp-accurate_accumulate PUBLIC yutil ) target_sources(library-cpp-accurate_accumulate PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/accurate_accumulate/accurate_accumulate.h ${CMAKE_SOURCE_DIR}/library/cpp/accurate_accumulate/accurate_accumulate.cpp ) diff --git a/library/cpp/accurate_accumulate/CMakeLists.linux-x86_64.txt b/library/cpp/accurate_accumulate/CMakeLists.linux-x86_64.txt index d168ea5295a7..d8a5028e256d 100644 --- a/library/cpp/accurate_accumulate/CMakeLists.linux-x86_64.txt +++ b/library/cpp/accurate_accumulate/CMakeLists.linux-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(library-cpp-accurate_accumulate PUBLIC yutil ) target_sources(library-cpp-accurate_accumulate PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/accurate_accumulate/accurate_accumulate.h ${CMAKE_SOURCE_DIR}/library/cpp/accurate_accumulate/accurate_accumulate.cpp ) diff --git a/library/cpp/accurate_accumulate/CMakeLists.windows-x86_64.txt b/library/cpp/accurate_accumulate/CMakeLists.windows-x86_64.txt index 6d68faefed96..62f15debba1d 100644 --- a/library/cpp/accurate_accumulate/CMakeLists.windows-x86_64.txt +++ b/library/cpp/accurate_accumulate/CMakeLists.windows-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(library-cpp-accurate_accumulate PUBLIC yutil ) target_sources(library-cpp-accurate_accumulate PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/accurate_accumulate/accurate_accumulate.h ${CMAKE_SOURCE_DIR}/library/cpp/accurate_accumulate/accurate_accumulate.cpp ) diff --git a/library/cpp/archive/CMakeLists.darwin-arm64.txt b/library/cpp/archive/CMakeLists.darwin-arm64.txt index 37c28ba02a3c..680cd10706bf 100644 --- a/library/cpp/archive/CMakeLists.darwin-arm64.txt +++ b/library/cpp/archive/CMakeLists.darwin-arm64.txt @@ -13,6 +13,8 @@ target_link_libraries(library-cpp-archive PUBLIC yutil ) target_sources(library-cpp-archive PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/archive/yarchive.h + ${CMAKE_SOURCE_DIR}/library/cpp/archive/directory_models_archive_reader.h ${CMAKE_SOURCE_DIR}/library/cpp/archive/yarchive.cpp ${CMAKE_SOURCE_DIR}/library/cpp/archive/directory_models_archive_reader.cpp ) diff --git a/library/cpp/archive/CMakeLists.darwin-x86_64.txt b/library/cpp/archive/CMakeLists.darwin-x86_64.txt index 37c28ba02a3c..680cd10706bf 100644 --- a/library/cpp/archive/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/archive/CMakeLists.darwin-x86_64.txt @@ -13,6 +13,8 @@ target_link_libraries(library-cpp-archive PUBLIC yutil ) target_sources(library-cpp-archive PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/archive/yarchive.h + ${CMAKE_SOURCE_DIR}/library/cpp/archive/directory_models_archive_reader.h ${CMAKE_SOURCE_DIR}/library/cpp/archive/yarchive.cpp ${CMAKE_SOURCE_DIR}/library/cpp/archive/directory_models_archive_reader.cpp ) diff --git a/library/cpp/archive/CMakeLists.linux-aarch64.txt b/library/cpp/archive/CMakeLists.linux-aarch64.txt index 03631029ddfe..c6ba0eeceedd 100644 --- a/library/cpp/archive/CMakeLists.linux-aarch64.txt +++ b/library/cpp/archive/CMakeLists.linux-aarch64.txt @@ -14,6 +14,8 @@ target_link_libraries(library-cpp-archive PUBLIC yutil ) target_sources(library-cpp-archive PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/archive/yarchive.h + ${CMAKE_SOURCE_DIR}/library/cpp/archive/directory_models_archive_reader.h ${CMAKE_SOURCE_DIR}/library/cpp/archive/yarchive.cpp ${CMAKE_SOURCE_DIR}/library/cpp/archive/directory_models_archive_reader.cpp ) diff --git a/library/cpp/archive/CMakeLists.linux-x86_64.txt b/library/cpp/archive/CMakeLists.linux-x86_64.txt index 03631029ddfe..c6ba0eeceedd 100644 --- a/library/cpp/archive/CMakeLists.linux-x86_64.txt +++ b/library/cpp/archive/CMakeLists.linux-x86_64.txt @@ -14,6 +14,8 @@ target_link_libraries(library-cpp-archive PUBLIC yutil ) target_sources(library-cpp-archive PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/archive/yarchive.h + ${CMAKE_SOURCE_DIR}/library/cpp/archive/directory_models_archive_reader.h ${CMAKE_SOURCE_DIR}/library/cpp/archive/yarchive.cpp ${CMAKE_SOURCE_DIR}/library/cpp/archive/directory_models_archive_reader.cpp ) diff --git a/library/cpp/archive/CMakeLists.windows-x86_64.txt b/library/cpp/archive/CMakeLists.windows-x86_64.txt index 37c28ba02a3c..680cd10706bf 100644 --- a/library/cpp/archive/CMakeLists.windows-x86_64.txt +++ b/library/cpp/archive/CMakeLists.windows-x86_64.txt @@ -13,6 +13,8 @@ target_link_libraries(library-cpp-archive PUBLIC yutil ) target_sources(library-cpp-archive PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/archive/yarchive.h + ${CMAKE_SOURCE_DIR}/library/cpp/archive/directory_models_archive_reader.h ${CMAKE_SOURCE_DIR}/library/cpp/archive/yarchive.cpp ${CMAKE_SOURCE_DIR}/library/cpp/archive/directory_models_archive_reader.cpp ) diff --git a/library/cpp/balloc/lib/CMakeLists.darwin-arm64.txt b/library/cpp/balloc/lib/CMakeLists.darwin-arm64.txt index 044487668190..fe7191923f05 100644 --- a/library/cpp/balloc/lib/CMakeLists.darwin-arm64.txt +++ b/library/cpp/balloc/lib/CMakeLists.darwin-arm64.txt @@ -17,5 +17,6 @@ target_link_libraries(cpp-balloc-lib PUBLIC cpp-malloc-api ) target_sources(cpp-balloc-lib PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/balloc/lib/alloc_stats.h ${CMAKE_SOURCE_DIR}/library/cpp/balloc/lib/alloc_stats.cpp ) diff --git a/library/cpp/balloc/lib/CMakeLists.darwin-x86_64.txt b/library/cpp/balloc/lib/CMakeLists.darwin-x86_64.txt index 044487668190..fe7191923f05 100644 --- a/library/cpp/balloc/lib/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/balloc/lib/CMakeLists.darwin-x86_64.txt @@ -17,5 +17,6 @@ target_link_libraries(cpp-balloc-lib PUBLIC cpp-malloc-api ) target_sources(cpp-balloc-lib PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/balloc/lib/alloc_stats.h ${CMAKE_SOURCE_DIR}/library/cpp/balloc/lib/alloc_stats.cpp ) diff --git a/library/cpp/balloc/lib/CMakeLists.linux-aarch64.txt b/library/cpp/balloc/lib/CMakeLists.linux-aarch64.txt index 78dd3d4b903a..37a61dfda991 100644 --- a/library/cpp/balloc/lib/CMakeLists.linux-aarch64.txt +++ b/library/cpp/balloc/lib/CMakeLists.linux-aarch64.txt @@ -19,5 +19,6 @@ target_link_libraries(cpp-balloc-lib PUBLIC cpp-malloc-api ) target_sources(cpp-balloc-lib PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/balloc/lib/alloc_stats.h ${CMAKE_SOURCE_DIR}/library/cpp/balloc/lib/alloc_stats.cpp ) diff --git a/library/cpp/balloc/lib/CMakeLists.linux-x86_64.txt b/library/cpp/balloc/lib/CMakeLists.linux-x86_64.txt index 78dd3d4b903a..37a61dfda991 100644 --- a/library/cpp/balloc/lib/CMakeLists.linux-x86_64.txt +++ b/library/cpp/balloc/lib/CMakeLists.linux-x86_64.txt @@ -19,5 +19,6 @@ target_link_libraries(cpp-balloc-lib PUBLIC cpp-malloc-api ) target_sources(cpp-balloc-lib PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/balloc/lib/alloc_stats.h ${CMAKE_SOURCE_DIR}/library/cpp/balloc/lib/alloc_stats.cpp ) diff --git a/library/cpp/binsaver/CMakeLists.darwin-arm64.txt b/library/cpp/binsaver/CMakeLists.darwin-arm64.txt index 3430226be1f9..a48ef9811266 100644 --- a/library/cpp/binsaver/CMakeLists.darwin-arm64.txt +++ b/library/cpp/binsaver/CMakeLists.darwin-arm64.txt @@ -14,6 +14,7 @@ target_link_libraries(library-cpp-binsaver PUBLIC cpp-containers-2d_array ) target_sources(library-cpp-binsaver PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/binsaver/class_factory.h ${CMAKE_SOURCE_DIR}/library/cpp/binsaver/bin_saver.cpp ${CMAKE_SOURCE_DIR}/library/cpp/binsaver/blob_io.cpp ${CMAKE_SOURCE_DIR}/library/cpp/binsaver/buffered_io.cpp diff --git a/library/cpp/binsaver/CMakeLists.darwin-x86_64.txt b/library/cpp/binsaver/CMakeLists.darwin-x86_64.txt index 3430226be1f9..a48ef9811266 100644 --- a/library/cpp/binsaver/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/binsaver/CMakeLists.darwin-x86_64.txt @@ -14,6 +14,7 @@ target_link_libraries(library-cpp-binsaver PUBLIC cpp-containers-2d_array ) target_sources(library-cpp-binsaver PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/binsaver/class_factory.h ${CMAKE_SOURCE_DIR}/library/cpp/binsaver/bin_saver.cpp ${CMAKE_SOURCE_DIR}/library/cpp/binsaver/blob_io.cpp ${CMAKE_SOURCE_DIR}/library/cpp/binsaver/buffered_io.cpp diff --git a/library/cpp/binsaver/CMakeLists.linux-aarch64.txt b/library/cpp/binsaver/CMakeLists.linux-aarch64.txt index 1a5048d32f57..1b24d0daeab4 100644 --- a/library/cpp/binsaver/CMakeLists.linux-aarch64.txt +++ b/library/cpp/binsaver/CMakeLists.linux-aarch64.txt @@ -15,6 +15,7 @@ target_link_libraries(library-cpp-binsaver PUBLIC cpp-containers-2d_array ) target_sources(library-cpp-binsaver PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/binsaver/class_factory.h ${CMAKE_SOURCE_DIR}/library/cpp/binsaver/bin_saver.cpp ${CMAKE_SOURCE_DIR}/library/cpp/binsaver/blob_io.cpp ${CMAKE_SOURCE_DIR}/library/cpp/binsaver/buffered_io.cpp diff --git a/library/cpp/binsaver/CMakeLists.linux-x86_64.txt b/library/cpp/binsaver/CMakeLists.linux-x86_64.txt index 1a5048d32f57..1b24d0daeab4 100644 --- a/library/cpp/binsaver/CMakeLists.linux-x86_64.txt +++ b/library/cpp/binsaver/CMakeLists.linux-x86_64.txt @@ -15,6 +15,7 @@ target_link_libraries(library-cpp-binsaver PUBLIC cpp-containers-2d_array ) target_sources(library-cpp-binsaver PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/binsaver/class_factory.h ${CMAKE_SOURCE_DIR}/library/cpp/binsaver/bin_saver.cpp ${CMAKE_SOURCE_DIR}/library/cpp/binsaver/blob_io.cpp ${CMAKE_SOURCE_DIR}/library/cpp/binsaver/buffered_io.cpp diff --git a/library/cpp/binsaver/CMakeLists.windows-x86_64.txt b/library/cpp/binsaver/CMakeLists.windows-x86_64.txt index 3430226be1f9..a48ef9811266 100644 --- a/library/cpp/binsaver/CMakeLists.windows-x86_64.txt +++ b/library/cpp/binsaver/CMakeLists.windows-x86_64.txt @@ -14,6 +14,7 @@ target_link_libraries(library-cpp-binsaver PUBLIC cpp-containers-2d_array ) target_sources(library-cpp-binsaver PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/binsaver/class_factory.h ${CMAKE_SOURCE_DIR}/library/cpp/binsaver/bin_saver.cpp ${CMAKE_SOURCE_DIR}/library/cpp/binsaver/blob_io.cpp ${CMAKE_SOURCE_DIR}/library/cpp/binsaver/buffered_io.cpp diff --git a/library/cpp/build_info/CMakeLists.darwin-arm64.txt b/library/cpp/build_info/CMakeLists.darwin-arm64.txt index a749cac8a038..2f6c940a39ff 100644 --- a/library/cpp/build_info/CMakeLists.darwin-arm64.txt +++ b/library/cpp/build_info/CMakeLists.darwin-arm64.txt @@ -30,6 +30,7 @@ target_link_libraries(library-cpp-build_info PUBLIC cpp-string_utils-base64 ) target_sources(library-cpp-build_info PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/build_info/buildinfo_data.h ${CMAKE_SOURCE_DIR}/library/cpp/build_info/build_info_static.cpp ${CMAKE_BINARY_DIR}/library/cpp/build_info/buildinfo_data.h ${CMAKE_BINARY_DIR}/library/cpp/build_info/sandbox.cpp diff --git a/library/cpp/build_info/CMakeLists.darwin-x86_64.txt b/library/cpp/build_info/CMakeLists.darwin-x86_64.txt index a749cac8a038..2f6c940a39ff 100644 --- a/library/cpp/build_info/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/build_info/CMakeLists.darwin-x86_64.txt @@ -30,6 +30,7 @@ target_link_libraries(library-cpp-build_info PUBLIC cpp-string_utils-base64 ) target_sources(library-cpp-build_info PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/build_info/buildinfo_data.h ${CMAKE_SOURCE_DIR}/library/cpp/build_info/build_info_static.cpp ${CMAKE_BINARY_DIR}/library/cpp/build_info/buildinfo_data.h ${CMAKE_BINARY_DIR}/library/cpp/build_info/sandbox.cpp diff --git a/library/cpp/build_info/CMakeLists.linux-aarch64.txt b/library/cpp/build_info/CMakeLists.linux-aarch64.txt index 7067bdf107c2..f515b52d6a01 100644 --- a/library/cpp/build_info/CMakeLists.linux-aarch64.txt +++ b/library/cpp/build_info/CMakeLists.linux-aarch64.txt @@ -31,6 +31,7 @@ target_link_libraries(library-cpp-build_info PUBLIC cpp-string_utils-base64 ) target_sources(library-cpp-build_info PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/build_info/buildinfo_data.h ${CMAKE_SOURCE_DIR}/library/cpp/build_info/build_info_static.cpp ${CMAKE_BINARY_DIR}/library/cpp/build_info/buildinfo_data.h ${CMAKE_BINARY_DIR}/library/cpp/build_info/sandbox.cpp diff --git a/library/cpp/build_info/CMakeLists.linux-x86_64.txt b/library/cpp/build_info/CMakeLists.linux-x86_64.txt index 7067bdf107c2..f515b52d6a01 100644 --- a/library/cpp/build_info/CMakeLists.linux-x86_64.txt +++ b/library/cpp/build_info/CMakeLists.linux-x86_64.txt @@ -31,6 +31,7 @@ target_link_libraries(library-cpp-build_info PUBLIC cpp-string_utils-base64 ) target_sources(library-cpp-build_info PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/build_info/buildinfo_data.h ${CMAKE_SOURCE_DIR}/library/cpp/build_info/build_info_static.cpp ${CMAKE_BINARY_DIR}/library/cpp/build_info/buildinfo_data.h ${CMAKE_BINARY_DIR}/library/cpp/build_info/sandbox.cpp diff --git a/library/cpp/build_info/CMakeLists.windows-x86_64.txt b/library/cpp/build_info/CMakeLists.windows-x86_64.txt index a749cac8a038..2f6c940a39ff 100644 --- a/library/cpp/build_info/CMakeLists.windows-x86_64.txt +++ b/library/cpp/build_info/CMakeLists.windows-x86_64.txt @@ -30,6 +30,7 @@ target_link_libraries(library-cpp-build_info PUBLIC cpp-string_utils-base64 ) target_sources(library-cpp-build_info PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/build_info/buildinfo_data.h ${CMAKE_SOURCE_DIR}/library/cpp/build_info/build_info_static.cpp ${CMAKE_BINARY_DIR}/library/cpp/build_info/buildinfo_data.h ${CMAKE_BINARY_DIR}/library/cpp/build_info/sandbox.cpp diff --git a/library/cpp/cgiparam/CMakeLists.darwin-arm64.txt b/library/cpp/cgiparam/CMakeLists.darwin-arm64.txt index 186d00a9389b..a3bb2ba5a2bc 100644 --- a/library/cpp/cgiparam/CMakeLists.darwin-arm64.txt +++ b/library/cpp/cgiparam/CMakeLists.darwin-arm64.txt @@ -16,5 +16,6 @@ target_link_libraries(library-cpp-cgiparam PUBLIC cpp-string_utils-scan ) target_sources(library-cpp-cgiparam PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/cgiparam/cgiparam.h ${CMAKE_SOURCE_DIR}/library/cpp/cgiparam/cgiparam.cpp ) diff --git a/library/cpp/cgiparam/CMakeLists.darwin-x86_64.txt b/library/cpp/cgiparam/CMakeLists.darwin-x86_64.txt index 186d00a9389b..a3bb2ba5a2bc 100644 --- a/library/cpp/cgiparam/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/cgiparam/CMakeLists.darwin-x86_64.txt @@ -16,5 +16,6 @@ target_link_libraries(library-cpp-cgiparam PUBLIC cpp-string_utils-scan ) target_sources(library-cpp-cgiparam PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/cgiparam/cgiparam.h ${CMAKE_SOURCE_DIR}/library/cpp/cgiparam/cgiparam.cpp ) diff --git a/library/cpp/cgiparam/CMakeLists.linux-aarch64.txt b/library/cpp/cgiparam/CMakeLists.linux-aarch64.txt index eec57f881a2e..0edbc3928af0 100644 --- a/library/cpp/cgiparam/CMakeLists.linux-aarch64.txt +++ b/library/cpp/cgiparam/CMakeLists.linux-aarch64.txt @@ -17,5 +17,6 @@ target_link_libraries(library-cpp-cgiparam PUBLIC cpp-string_utils-scan ) target_sources(library-cpp-cgiparam PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/cgiparam/cgiparam.h ${CMAKE_SOURCE_DIR}/library/cpp/cgiparam/cgiparam.cpp ) diff --git a/library/cpp/cgiparam/CMakeLists.linux-x86_64.txt b/library/cpp/cgiparam/CMakeLists.linux-x86_64.txt index eec57f881a2e..0edbc3928af0 100644 --- a/library/cpp/cgiparam/CMakeLists.linux-x86_64.txt +++ b/library/cpp/cgiparam/CMakeLists.linux-x86_64.txt @@ -17,5 +17,6 @@ target_link_libraries(library-cpp-cgiparam PUBLIC cpp-string_utils-scan ) target_sources(library-cpp-cgiparam PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/cgiparam/cgiparam.h ${CMAKE_SOURCE_DIR}/library/cpp/cgiparam/cgiparam.cpp ) diff --git a/library/cpp/cgiparam/CMakeLists.windows-x86_64.txt b/library/cpp/cgiparam/CMakeLists.windows-x86_64.txt index 186d00a9389b..a3bb2ba5a2bc 100644 --- a/library/cpp/cgiparam/CMakeLists.windows-x86_64.txt +++ b/library/cpp/cgiparam/CMakeLists.windows-x86_64.txt @@ -16,5 +16,6 @@ target_link_libraries(library-cpp-cgiparam PUBLIC cpp-string_utils-scan ) target_sources(library-cpp-cgiparam PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/cgiparam/cgiparam.h ${CMAKE_SOURCE_DIR}/library/cpp/cgiparam/cgiparam.cpp ) diff --git a/library/cpp/charset/CMakeLists.darwin-arm64.txt b/library/cpp/charset/CMakeLists.darwin-arm64.txt index cade4ef3cd98..75e8c65c99c5 100644 --- a/library/cpp/charset/CMakeLists.darwin-arm64.txt +++ b/library/cpp/charset/CMakeLists.darwin-arm64.txt @@ -15,6 +15,8 @@ target_link_libraries(library-cpp-charset PUBLIC cpp-charset-lite ) target_sources(library-cpp-charset PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/charset/recyr.hh + ${CMAKE_SOURCE_DIR}/library/cpp/charset/recyr_int.hh ${CMAKE_SOURCE_DIR}/library/cpp/charset/decodeunknownplane.cpp ${CMAKE_SOURCE_DIR}/library/cpp/charset/wide.cpp ${CMAKE_SOURCE_DIR}/library/cpp/charset/iconv.cpp diff --git a/library/cpp/charset/CMakeLists.darwin-x86_64.txt b/library/cpp/charset/CMakeLists.darwin-x86_64.txt index cade4ef3cd98..75e8c65c99c5 100644 --- a/library/cpp/charset/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/charset/CMakeLists.darwin-x86_64.txt @@ -15,6 +15,8 @@ target_link_libraries(library-cpp-charset PUBLIC cpp-charset-lite ) target_sources(library-cpp-charset PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/charset/recyr.hh + ${CMAKE_SOURCE_DIR}/library/cpp/charset/recyr_int.hh ${CMAKE_SOURCE_DIR}/library/cpp/charset/decodeunknownplane.cpp ${CMAKE_SOURCE_DIR}/library/cpp/charset/wide.cpp ${CMAKE_SOURCE_DIR}/library/cpp/charset/iconv.cpp diff --git a/library/cpp/charset/CMakeLists.linux-aarch64.txt b/library/cpp/charset/CMakeLists.linux-aarch64.txt index 63f8766de9b3..5bb17b13bd77 100644 --- a/library/cpp/charset/CMakeLists.linux-aarch64.txt +++ b/library/cpp/charset/CMakeLists.linux-aarch64.txt @@ -16,6 +16,8 @@ target_link_libraries(library-cpp-charset PUBLIC cpp-charset-lite ) target_sources(library-cpp-charset PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/charset/recyr.hh + ${CMAKE_SOURCE_DIR}/library/cpp/charset/recyr_int.hh ${CMAKE_SOURCE_DIR}/library/cpp/charset/decodeunknownplane.cpp ${CMAKE_SOURCE_DIR}/library/cpp/charset/wide.cpp ${CMAKE_SOURCE_DIR}/library/cpp/charset/iconv.cpp diff --git a/library/cpp/charset/CMakeLists.linux-x86_64.txt b/library/cpp/charset/CMakeLists.linux-x86_64.txt index 63f8766de9b3..5bb17b13bd77 100644 --- a/library/cpp/charset/CMakeLists.linux-x86_64.txt +++ b/library/cpp/charset/CMakeLists.linux-x86_64.txt @@ -16,6 +16,8 @@ target_link_libraries(library-cpp-charset PUBLIC cpp-charset-lite ) target_sources(library-cpp-charset PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/charset/recyr.hh + ${CMAKE_SOURCE_DIR}/library/cpp/charset/recyr_int.hh ${CMAKE_SOURCE_DIR}/library/cpp/charset/decodeunknownplane.cpp ${CMAKE_SOURCE_DIR}/library/cpp/charset/wide.cpp ${CMAKE_SOURCE_DIR}/library/cpp/charset/iconv.cpp diff --git a/library/cpp/charset/CMakeLists.windows-x86_64.txt b/library/cpp/charset/CMakeLists.windows-x86_64.txt index 951a43b8122c..41443ad9b0d9 100644 --- a/library/cpp/charset/CMakeLists.windows-x86_64.txt +++ b/library/cpp/charset/CMakeLists.windows-x86_64.txt @@ -17,6 +17,8 @@ target_link_libraries(library-cpp-charset PUBLIC Iconv::Iconv ) target_sources(library-cpp-charset PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/charset/recyr.hh + ${CMAKE_SOURCE_DIR}/library/cpp/charset/recyr_int.hh ${CMAKE_SOURCE_DIR}/library/cpp/charset/decodeunknownplane.cpp ${CMAKE_SOURCE_DIR}/library/cpp/charset/wide.cpp ${CMAKE_SOURCE_DIR}/library/cpp/charset/iconv.cpp diff --git a/library/cpp/clickhouse/CMakeLists.txt b/library/cpp/clickhouse/CMakeLists.txt index 380079ac7b4a..7f79107ebc79 100644 --- a/library/cpp/clickhouse/CMakeLists.txt +++ b/library/cpp/clickhouse/CMakeLists.txt @@ -6,12 +6,4 @@ # original buildsystem will not be accepted. -if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) - include(CMakeLists.linux-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) - include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -endif() +add_subdirectory(client) diff --git a/library/cpp/clickhouse/client/CMakeLists.txt b/library/cpp/clickhouse/client/CMakeLists.txt index 380079ac7b4a..d863ebd18067 100644 --- a/library/cpp/clickhouse/client/CMakeLists.txt +++ b/library/cpp/clickhouse/client/CMakeLists.txt @@ -14,4 +14,6 @@ elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL include(CMakeLists.darwin-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) endif() diff --git a/library/cpp/clickhouse/client/CMakeLists.windows-x86_64.txt b/library/cpp/clickhouse/client/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..d31f838946c2 --- /dev/null +++ b/library/cpp/clickhouse/client/CMakeLists.windows-x86_64.txt @@ -0,0 +1,28 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(base) +add_subdirectory(columns) +add_subdirectory(types) + +add_library(cpp-clickhouse-client) +target_link_libraries(cpp-clickhouse-client PUBLIC + contrib-libs-cxxsupp + yutil + contrib-libs-lz4 + contrib-restricted-cityhash-1.0.2 + clickhouse-client-base + clickhouse-client-columns + clickhouse-client-types + cpp-openssl-io +) +target_sources(cpp-clickhouse-client PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/block.cpp + ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/client.cpp + ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/query.cpp +) diff --git a/library/cpp/clickhouse/client/base/CMakeLists.darwin-arm64.txt b/library/cpp/clickhouse/client/base/CMakeLists.darwin-arm64.txt index a76303537c6e..4bb9a0bad779 100644 --- a/library/cpp/clickhouse/client/base/CMakeLists.darwin-arm64.txt +++ b/library/cpp/clickhouse/client/base/CMakeLists.darwin-arm64.txt @@ -13,6 +13,7 @@ target_link_libraries(clickhouse-client-base PUBLIC yutil ) target_sources(clickhouse-client-base PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/base/wire_format.h ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/base/coded.cpp ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/base/compressed.cpp ) diff --git a/library/cpp/clickhouse/client/base/CMakeLists.darwin-x86_64.txt b/library/cpp/clickhouse/client/base/CMakeLists.darwin-x86_64.txt index a76303537c6e..4bb9a0bad779 100644 --- a/library/cpp/clickhouse/client/base/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/clickhouse/client/base/CMakeLists.darwin-x86_64.txt @@ -13,6 +13,7 @@ target_link_libraries(clickhouse-client-base PUBLIC yutil ) target_sources(clickhouse-client-base PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/base/wire_format.h ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/base/coded.cpp ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/base/compressed.cpp ) diff --git a/library/cpp/clickhouse/client/base/CMakeLists.linux-aarch64.txt b/library/cpp/clickhouse/client/base/CMakeLists.linux-aarch64.txt index 98015a9e92da..4cd03128b8b5 100644 --- a/library/cpp/clickhouse/client/base/CMakeLists.linux-aarch64.txt +++ b/library/cpp/clickhouse/client/base/CMakeLists.linux-aarch64.txt @@ -14,6 +14,7 @@ target_link_libraries(clickhouse-client-base PUBLIC yutil ) target_sources(clickhouse-client-base PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/base/wire_format.h ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/base/coded.cpp ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/base/compressed.cpp ) diff --git a/library/cpp/clickhouse/client/base/CMakeLists.linux-x86_64.txt b/library/cpp/clickhouse/client/base/CMakeLists.linux-x86_64.txt index 98015a9e92da..4cd03128b8b5 100644 --- a/library/cpp/clickhouse/client/base/CMakeLists.linux-x86_64.txt +++ b/library/cpp/clickhouse/client/base/CMakeLists.linux-x86_64.txt @@ -14,6 +14,7 @@ target_link_libraries(clickhouse-client-base PUBLIC yutil ) target_sources(clickhouse-client-base PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/base/wire_format.h ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/base/coded.cpp ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/base/compressed.cpp ) diff --git a/library/cpp/clickhouse/client/base/CMakeLists.txt b/library/cpp/clickhouse/client/base/CMakeLists.txt index 380079ac7b4a..d863ebd18067 100644 --- a/library/cpp/clickhouse/client/base/CMakeLists.txt +++ b/library/cpp/clickhouse/client/base/CMakeLists.txt @@ -14,4 +14,6 @@ elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL include(CMakeLists.darwin-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) endif() diff --git a/library/cpp/clickhouse/client/base/CMakeLists.windows-x86_64.txt b/library/cpp/clickhouse/client/base/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..4bb9a0bad779 --- /dev/null +++ b/library/cpp/clickhouse/client/base/CMakeLists.windows-x86_64.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(clickhouse-client-base) +target_link_libraries(clickhouse-client-base PUBLIC + contrib-libs-cxxsupp + yutil +) +target_sources(clickhouse-client-base PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/base/wire_format.h + ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/base/coded.cpp + ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/base/compressed.cpp +) diff --git a/library/cpp/clickhouse/client/columns/CMakeLists.txt b/library/cpp/clickhouse/client/columns/CMakeLists.txt index 380079ac7b4a..d863ebd18067 100644 --- a/library/cpp/clickhouse/client/columns/CMakeLists.txt +++ b/library/cpp/clickhouse/client/columns/CMakeLists.txt @@ -14,4 +14,6 @@ elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL include(CMakeLists.darwin-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) endif() diff --git a/library/cpp/clickhouse/client/columns/CMakeLists.windows-x86_64.txt b/library/cpp/clickhouse/client/columns/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..306332e5fa77 --- /dev/null +++ b/library/cpp/clickhouse/client/columns/CMakeLists.windows-x86_64.txt @@ -0,0 +1,26 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(clickhouse-client-columns) +target_link_libraries(clickhouse-client-columns PUBLIC + contrib-libs-cxxsupp + yutil + clickhouse-client-base + clickhouse-client-types +) +target_sources(clickhouse-client-columns PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/columns/array.cpp + ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/columns/date.cpp + ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/columns/enum.cpp + ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/columns/factory.cpp + ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/columns/nullable.cpp + ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/columns/numeric.cpp + ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/columns/string.cpp + ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/columns/tuple.cpp +) diff --git a/library/cpp/clickhouse/client/types/CMakeLists.txt b/library/cpp/clickhouse/client/types/CMakeLists.txt index 380079ac7b4a..d863ebd18067 100644 --- a/library/cpp/clickhouse/client/types/CMakeLists.txt +++ b/library/cpp/clickhouse/client/types/CMakeLists.txt @@ -14,4 +14,6 @@ elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL include(CMakeLists.darwin-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) endif() diff --git a/library/cpp/clickhouse/client/types/CMakeLists.windows-x86_64.txt b/library/cpp/clickhouse/client/types/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..abd32a87511e --- /dev/null +++ b/library/cpp/clickhouse/client/types/CMakeLists.windows-x86_64.txt @@ -0,0 +1,18 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(clickhouse-client-types) +target_link_libraries(clickhouse-client-types PUBLIC + contrib-libs-cxxsupp + yutil +) +target_sources(clickhouse-client-types PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/types/type_parser.cpp + ${CMAKE_SOURCE_DIR}/library/cpp/clickhouse/client/types/types.cpp +) diff --git a/library/cpp/compproto/CMakeLists.darwin-arm64.txt b/library/cpp/compproto/CMakeLists.darwin-arm64.txt index abcc95d486fe..ca226d4a15b7 100644 --- a/library/cpp/compproto/CMakeLists.darwin-arm64.txt +++ b/library/cpp/compproto/CMakeLists.darwin-arm64.txt @@ -13,5 +13,9 @@ target_link_libraries(library-cpp-compproto PUBLIC yutil ) target_sources(library-cpp-compproto PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/compproto/bit.h + ${CMAKE_SOURCE_DIR}/library/cpp/compproto/compressor.h + ${CMAKE_SOURCE_DIR}/library/cpp/compproto/huff.h + ${CMAKE_SOURCE_DIR}/library/cpp/compproto/metainfo.h ${CMAKE_SOURCE_DIR}/library/cpp/compproto/lib.cpp ) diff --git a/library/cpp/compproto/CMakeLists.darwin-x86_64.txt b/library/cpp/compproto/CMakeLists.darwin-x86_64.txt index abcc95d486fe..ca226d4a15b7 100644 --- a/library/cpp/compproto/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/compproto/CMakeLists.darwin-x86_64.txt @@ -13,5 +13,9 @@ target_link_libraries(library-cpp-compproto PUBLIC yutil ) target_sources(library-cpp-compproto PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/compproto/bit.h + ${CMAKE_SOURCE_DIR}/library/cpp/compproto/compressor.h + ${CMAKE_SOURCE_DIR}/library/cpp/compproto/huff.h + ${CMAKE_SOURCE_DIR}/library/cpp/compproto/metainfo.h ${CMAKE_SOURCE_DIR}/library/cpp/compproto/lib.cpp ) diff --git a/library/cpp/compproto/CMakeLists.linux-aarch64.txt b/library/cpp/compproto/CMakeLists.linux-aarch64.txt index f7c1ee7be784..387fd6309adb 100644 --- a/library/cpp/compproto/CMakeLists.linux-aarch64.txt +++ b/library/cpp/compproto/CMakeLists.linux-aarch64.txt @@ -14,5 +14,9 @@ target_link_libraries(library-cpp-compproto PUBLIC yutil ) target_sources(library-cpp-compproto PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/compproto/bit.h + ${CMAKE_SOURCE_DIR}/library/cpp/compproto/compressor.h + ${CMAKE_SOURCE_DIR}/library/cpp/compproto/huff.h + ${CMAKE_SOURCE_DIR}/library/cpp/compproto/metainfo.h ${CMAKE_SOURCE_DIR}/library/cpp/compproto/lib.cpp ) diff --git a/library/cpp/compproto/CMakeLists.linux-x86_64.txt b/library/cpp/compproto/CMakeLists.linux-x86_64.txt index f7c1ee7be784..387fd6309adb 100644 --- a/library/cpp/compproto/CMakeLists.linux-x86_64.txt +++ b/library/cpp/compproto/CMakeLists.linux-x86_64.txt @@ -14,5 +14,9 @@ target_link_libraries(library-cpp-compproto PUBLIC yutil ) target_sources(library-cpp-compproto PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/compproto/bit.h + ${CMAKE_SOURCE_DIR}/library/cpp/compproto/compressor.h + ${CMAKE_SOURCE_DIR}/library/cpp/compproto/huff.h + ${CMAKE_SOURCE_DIR}/library/cpp/compproto/metainfo.h ${CMAKE_SOURCE_DIR}/library/cpp/compproto/lib.cpp ) diff --git a/library/cpp/compproto/CMakeLists.windows-x86_64.txt b/library/cpp/compproto/CMakeLists.windows-x86_64.txt index abcc95d486fe..ca226d4a15b7 100644 --- a/library/cpp/compproto/CMakeLists.windows-x86_64.txt +++ b/library/cpp/compproto/CMakeLists.windows-x86_64.txt @@ -13,5 +13,9 @@ target_link_libraries(library-cpp-compproto PUBLIC yutil ) target_sources(library-cpp-compproto PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/compproto/bit.h + ${CMAKE_SOURCE_DIR}/library/cpp/compproto/compressor.h + ${CMAKE_SOURCE_DIR}/library/cpp/compproto/huff.h + ${CMAKE_SOURCE_DIR}/library/cpp/compproto/metainfo.h ${CMAKE_SOURCE_DIR}/library/cpp/compproto/lib.cpp ) diff --git a/library/cpp/config/CMakeLists.darwin-arm64.txt b/library/cpp/config/CMakeLists.darwin-arm64.txt index 23c772e4fc25..fd836e3f61bb 100644 --- a/library/cpp/config/CMakeLists.darwin-arm64.txt +++ b/library/cpp/config/CMakeLists.darwin-arm64.txt @@ -26,6 +26,7 @@ target_link_libraries(library-cpp-config PUBLIC cpp-string_utils-relaxed_escaper ) target_sources(library-cpp-config PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/config/code.inc ${CMAKE_SOURCE_DIR}/library/cpp/config/config.cpp ${CMAKE_SOURCE_DIR}/library/cpp/config/sax.cpp ${CMAKE_SOURCE_DIR}/library/cpp/config/value.cpp diff --git a/library/cpp/config/CMakeLists.darwin-x86_64.txt b/library/cpp/config/CMakeLists.darwin-x86_64.txt index 23c772e4fc25..fd836e3f61bb 100644 --- a/library/cpp/config/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/config/CMakeLists.darwin-x86_64.txt @@ -26,6 +26,7 @@ target_link_libraries(library-cpp-config PUBLIC cpp-string_utils-relaxed_escaper ) target_sources(library-cpp-config PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/config/code.inc ${CMAKE_SOURCE_DIR}/library/cpp/config/config.cpp ${CMAKE_SOURCE_DIR}/library/cpp/config/sax.cpp ${CMAKE_SOURCE_DIR}/library/cpp/config/value.cpp diff --git a/library/cpp/config/CMakeLists.linux-aarch64.txt b/library/cpp/config/CMakeLists.linux-aarch64.txt index 3e91ece220b4..d03a43c75608 100644 --- a/library/cpp/config/CMakeLists.linux-aarch64.txt +++ b/library/cpp/config/CMakeLists.linux-aarch64.txt @@ -27,6 +27,7 @@ target_link_libraries(library-cpp-config PUBLIC cpp-string_utils-relaxed_escaper ) target_sources(library-cpp-config PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/config/code.inc ${CMAKE_SOURCE_DIR}/library/cpp/config/config.cpp ${CMAKE_SOURCE_DIR}/library/cpp/config/sax.cpp ${CMAKE_SOURCE_DIR}/library/cpp/config/value.cpp diff --git a/library/cpp/config/CMakeLists.linux-x86_64.txt b/library/cpp/config/CMakeLists.linux-x86_64.txt index 3e91ece220b4..d03a43c75608 100644 --- a/library/cpp/config/CMakeLists.linux-x86_64.txt +++ b/library/cpp/config/CMakeLists.linux-x86_64.txt @@ -27,6 +27,7 @@ target_link_libraries(library-cpp-config PUBLIC cpp-string_utils-relaxed_escaper ) target_sources(library-cpp-config PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/config/code.inc ${CMAKE_SOURCE_DIR}/library/cpp/config/config.cpp ${CMAKE_SOURCE_DIR}/library/cpp/config/sax.cpp ${CMAKE_SOURCE_DIR}/library/cpp/config/value.cpp diff --git a/library/cpp/config/CMakeLists.windows-x86_64.txt b/library/cpp/config/CMakeLists.windows-x86_64.txt index a3573c913a04..e4b4e279c9da 100644 --- a/library/cpp/config/CMakeLists.windows-x86_64.txt +++ b/library/cpp/config/CMakeLists.windows-x86_64.txt @@ -26,6 +26,7 @@ target_link_libraries(library-cpp-config PUBLIC cpp-string_utils-relaxed_escaper ) target_sources(library-cpp-config PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/config/code.inc ${CMAKE_SOURCE_DIR}/library/cpp/config/config.cpp ${CMAKE_SOURCE_DIR}/library/cpp/config/sax.cpp ${CMAKE_SOURCE_DIR}/library/cpp/config/value.cpp diff --git a/library/cpp/containers/comptrie/CMakeLists.darwin-arm64.txt b/library/cpp/containers/comptrie/CMakeLists.darwin-arm64.txt index 3a3d86aed707..14a8206214d6 100644 --- a/library/cpp/containers/comptrie/CMakeLists.darwin-arm64.txt +++ b/library/cpp/containers/comptrie/CMakeLists.darwin-arm64.txt @@ -17,6 +17,15 @@ target_link_libraries(cpp-containers-comptrie PUBLIC util-draft ) target_sources(cpp-containers-comptrie PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/array_with_size.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/chunked_helpers_trie.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie_packer.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie_trie.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/first_symbol_iterator.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/key_selector.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/leaf_skipper.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/set.h ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie.cpp ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie_builder.cpp ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie_impl.cpp diff --git a/library/cpp/containers/comptrie/CMakeLists.darwin-x86_64.txt b/library/cpp/containers/comptrie/CMakeLists.darwin-x86_64.txt index 3a3d86aed707..14a8206214d6 100644 --- a/library/cpp/containers/comptrie/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/containers/comptrie/CMakeLists.darwin-x86_64.txt @@ -17,6 +17,15 @@ target_link_libraries(cpp-containers-comptrie PUBLIC util-draft ) target_sources(cpp-containers-comptrie PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/array_with_size.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/chunked_helpers_trie.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie_packer.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie_trie.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/first_symbol_iterator.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/key_selector.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/leaf_skipper.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/set.h ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie.cpp ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie_builder.cpp ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie_impl.cpp diff --git a/library/cpp/containers/comptrie/CMakeLists.linux-aarch64.txt b/library/cpp/containers/comptrie/CMakeLists.linux-aarch64.txt index 599cc37088e1..1173812687ea 100644 --- a/library/cpp/containers/comptrie/CMakeLists.linux-aarch64.txt +++ b/library/cpp/containers/comptrie/CMakeLists.linux-aarch64.txt @@ -18,6 +18,15 @@ target_link_libraries(cpp-containers-comptrie PUBLIC util-draft ) target_sources(cpp-containers-comptrie PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/array_with_size.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/chunked_helpers_trie.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie_packer.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie_trie.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/first_symbol_iterator.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/key_selector.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/leaf_skipper.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/set.h ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie.cpp ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie_builder.cpp ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie_impl.cpp diff --git a/library/cpp/containers/comptrie/CMakeLists.linux-x86_64.txt b/library/cpp/containers/comptrie/CMakeLists.linux-x86_64.txt index 599cc37088e1..1173812687ea 100644 --- a/library/cpp/containers/comptrie/CMakeLists.linux-x86_64.txt +++ b/library/cpp/containers/comptrie/CMakeLists.linux-x86_64.txt @@ -18,6 +18,15 @@ target_link_libraries(cpp-containers-comptrie PUBLIC util-draft ) target_sources(cpp-containers-comptrie PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/array_with_size.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/chunked_helpers_trie.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie_packer.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie_trie.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/first_symbol_iterator.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/key_selector.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/leaf_skipper.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/set.h ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie.cpp ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie_builder.cpp ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie_impl.cpp diff --git a/library/cpp/containers/comptrie/CMakeLists.windows-x86_64.txt b/library/cpp/containers/comptrie/CMakeLists.windows-x86_64.txt index 3a3d86aed707..14a8206214d6 100644 --- a/library/cpp/containers/comptrie/CMakeLists.windows-x86_64.txt +++ b/library/cpp/containers/comptrie/CMakeLists.windows-x86_64.txt @@ -17,6 +17,15 @@ target_link_libraries(cpp-containers-comptrie PUBLIC util-draft ) target_sources(cpp-containers-comptrie PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/array_with_size.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/chunked_helpers_trie.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie_packer.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie_trie.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/first_symbol_iterator.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/key_selector.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/leaf_skipper.h + ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/set.h ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie.cpp ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie_builder.cpp ${CMAKE_SOURCE_DIR}/library/cpp/containers/comptrie/comptrie_impl.cpp diff --git a/library/cpp/deprecated/kmp/CMakeLists.darwin-arm64.txt b/library/cpp/deprecated/kmp/CMakeLists.darwin-arm64.txt index 1a8b825dad6c..fbfdcadb62e0 100644 --- a/library/cpp/deprecated/kmp/CMakeLists.darwin-arm64.txt +++ b/library/cpp/deprecated/kmp/CMakeLists.darwin-arm64.txt @@ -13,5 +13,6 @@ target_link_libraries(cpp-deprecated-kmp PUBLIC yutil ) target_sources(cpp-deprecated-kmp PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/deprecated/kmp/kmp.h ${CMAKE_SOURCE_DIR}/library/cpp/deprecated/kmp/kmp.cpp ) diff --git a/library/cpp/deprecated/kmp/CMakeLists.darwin-x86_64.txt b/library/cpp/deprecated/kmp/CMakeLists.darwin-x86_64.txt index 1a8b825dad6c..fbfdcadb62e0 100644 --- a/library/cpp/deprecated/kmp/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/deprecated/kmp/CMakeLists.darwin-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(cpp-deprecated-kmp PUBLIC yutil ) target_sources(cpp-deprecated-kmp PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/deprecated/kmp/kmp.h ${CMAKE_SOURCE_DIR}/library/cpp/deprecated/kmp/kmp.cpp ) diff --git a/library/cpp/deprecated/kmp/CMakeLists.linux-aarch64.txt b/library/cpp/deprecated/kmp/CMakeLists.linux-aarch64.txt index ed7a436e3c9f..9c7c481d1f79 100644 --- a/library/cpp/deprecated/kmp/CMakeLists.linux-aarch64.txt +++ b/library/cpp/deprecated/kmp/CMakeLists.linux-aarch64.txt @@ -14,5 +14,6 @@ target_link_libraries(cpp-deprecated-kmp PUBLIC yutil ) target_sources(cpp-deprecated-kmp PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/deprecated/kmp/kmp.h ${CMAKE_SOURCE_DIR}/library/cpp/deprecated/kmp/kmp.cpp ) diff --git a/library/cpp/deprecated/kmp/CMakeLists.linux-x86_64.txt b/library/cpp/deprecated/kmp/CMakeLists.linux-x86_64.txt index ed7a436e3c9f..9c7c481d1f79 100644 --- a/library/cpp/deprecated/kmp/CMakeLists.linux-x86_64.txt +++ b/library/cpp/deprecated/kmp/CMakeLists.linux-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(cpp-deprecated-kmp PUBLIC yutil ) target_sources(cpp-deprecated-kmp PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/deprecated/kmp/kmp.h ${CMAKE_SOURCE_DIR}/library/cpp/deprecated/kmp/kmp.cpp ) diff --git a/library/cpp/deprecated/kmp/CMakeLists.windows-x86_64.txt b/library/cpp/deprecated/kmp/CMakeLists.windows-x86_64.txt index 1a8b825dad6c..fbfdcadb62e0 100644 --- a/library/cpp/deprecated/kmp/CMakeLists.windows-x86_64.txt +++ b/library/cpp/deprecated/kmp/CMakeLists.windows-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(cpp-deprecated-kmp PUBLIC yutil ) target_sources(cpp-deprecated-kmp PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/deprecated/kmp/kmp.h ${CMAKE_SOURCE_DIR}/library/cpp/deprecated/kmp/kmp.cpp ) diff --git a/library/cpp/digest/argonish/internal/proxies/avx2/CMakeLists.windows-x86_64.txt b/library/cpp/digest/argonish/internal/proxies/avx2/CMakeLists.windows-x86_64.txt index 6242e299b8f6..665a06a7b6f6 100644 --- a/library/cpp/digest/argonish/internal/proxies/avx2/CMakeLists.windows-x86_64.txt +++ b/library/cpp/digest/argonish/internal/proxies/avx2/CMakeLists.windows-x86_64.txt @@ -19,8 +19,6 @@ target_sources_custom(internal-proxies-avx2 SRCS ${CMAKE_SOURCE_DIR}/library/cpp/digest/argonish/internal/proxies/avx2/proxy_avx2.cpp CUSTOM_FLAGS - -mavx2 - -mfma - -mbmi - -mbmi2 + /arch:AVX2 + /DAVX2_ENABLED=1 ) diff --git a/library/cpp/digest/argonish/internal/proxies/sse2/CMakeLists.windows-x86_64.txt b/library/cpp/digest/argonish/internal/proxies/sse2/CMakeLists.windows-x86_64.txt index 7b57a5e09b2f..e929684c1e52 100644 --- a/library/cpp/digest/argonish/internal/proxies/sse2/CMakeLists.windows-x86_64.txt +++ b/library/cpp/digest/argonish/internal/proxies/sse2/CMakeLists.windows-x86_64.txt @@ -19,5 +19,5 @@ target_sources_custom(internal-proxies-sse2 SRCS ${CMAKE_SOURCE_DIR}/library/cpp/digest/argonish/internal/proxies/sse2/proxy_sse2.cpp CUSTOM_FLAGS - -msse2 + /D__SSE2__=1 ) diff --git a/library/cpp/digest/argonish/internal/proxies/sse41/CMakeLists.windows-x86_64.txt b/library/cpp/digest/argonish/internal/proxies/sse41/CMakeLists.windows-x86_64.txt index 48f772826d37..68503d8c632c 100644 --- a/library/cpp/digest/argonish/internal/proxies/sse41/CMakeLists.windows-x86_64.txt +++ b/library/cpp/digest/argonish/internal/proxies/sse41/CMakeLists.windows-x86_64.txt @@ -19,5 +19,5 @@ target_sources_custom(internal-proxies-sse41 SRCS ${CMAKE_SOURCE_DIR}/library/cpp/digest/argonish/internal/proxies/sse41/proxy_sse41.cpp CUSTOM_FLAGS - -msse4.1 + /D__SSE4_1__=1 ) diff --git a/library/cpp/digest/argonish/internal/proxies/ssse3/CMakeLists.windows-x86_64.txt b/library/cpp/digest/argonish/internal/proxies/ssse3/CMakeLists.windows-x86_64.txt index 8c1d2591ed7d..71c2df1d19f8 100644 --- a/library/cpp/digest/argonish/internal/proxies/ssse3/CMakeLists.windows-x86_64.txt +++ b/library/cpp/digest/argonish/internal/proxies/ssse3/CMakeLists.windows-x86_64.txt @@ -19,5 +19,5 @@ target_sources_custom(internal-proxies-ssse3 SRCS ${CMAKE_SOURCE_DIR}/library/cpp/digest/argonish/internal/proxies/ssse3/proxy_ssse3.cpp CUSTOM_FLAGS - -mssse3 + /D__SSSE3__=1 ) diff --git a/library/cpp/digest/old_crc/CMakeLists.darwin-arm64.txt b/library/cpp/digest/old_crc/CMakeLists.darwin-arm64.txt index a4caa8c7569f..136c4353647f 100644 --- a/library/cpp/digest/old_crc/CMakeLists.darwin-arm64.txt +++ b/library/cpp/digest/old_crc/CMakeLists.darwin-arm64.txt @@ -20,6 +20,7 @@ target_link_libraries(cpp-digest-old_crc PUBLIC yutil ) target_sources(cpp-digest-old_crc PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/digest/old_crc/crc.inc ${CMAKE_SOURCE_DIR}/library/cpp/digest/old_crc/crc.cpp ${CMAKE_BINARY_DIR}/library/cpp/digest/old_crc/crc.inc ) diff --git a/library/cpp/digest/old_crc/CMakeLists.darwin-x86_64.txt b/library/cpp/digest/old_crc/CMakeLists.darwin-x86_64.txt index a4caa8c7569f..136c4353647f 100644 --- a/library/cpp/digest/old_crc/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/digest/old_crc/CMakeLists.darwin-x86_64.txt @@ -20,6 +20,7 @@ target_link_libraries(cpp-digest-old_crc PUBLIC yutil ) target_sources(cpp-digest-old_crc PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/digest/old_crc/crc.inc ${CMAKE_SOURCE_DIR}/library/cpp/digest/old_crc/crc.cpp ${CMAKE_BINARY_DIR}/library/cpp/digest/old_crc/crc.inc ) diff --git a/library/cpp/digest/old_crc/CMakeLists.linux-aarch64.txt b/library/cpp/digest/old_crc/CMakeLists.linux-aarch64.txt index a0883b65f5e4..c7abb5dc5daf 100644 --- a/library/cpp/digest/old_crc/CMakeLists.linux-aarch64.txt +++ b/library/cpp/digest/old_crc/CMakeLists.linux-aarch64.txt @@ -21,6 +21,7 @@ target_link_libraries(cpp-digest-old_crc PUBLIC yutil ) target_sources(cpp-digest-old_crc PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/digest/old_crc/crc.inc ${CMAKE_SOURCE_DIR}/library/cpp/digest/old_crc/crc.cpp ${CMAKE_BINARY_DIR}/library/cpp/digest/old_crc/crc.inc ) diff --git a/library/cpp/digest/old_crc/CMakeLists.linux-x86_64.txt b/library/cpp/digest/old_crc/CMakeLists.linux-x86_64.txt index a0883b65f5e4..c7abb5dc5daf 100644 --- a/library/cpp/digest/old_crc/CMakeLists.linux-x86_64.txt +++ b/library/cpp/digest/old_crc/CMakeLists.linux-x86_64.txt @@ -21,6 +21,7 @@ target_link_libraries(cpp-digest-old_crc PUBLIC yutil ) target_sources(cpp-digest-old_crc PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/digest/old_crc/crc.inc ${CMAKE_SOURCE_DIR}/library/cpp/digest/old_crc/crc.cpp ${CMAKE_BINARY_DIR}/library/cpp/digest/old_crc/crc.inc ) diff --git a/library/cpp/digest/old_crc/CMakeLists.windows-x86_64.txt b/library/cpp/digest/old_crc/CMakeLists.windows-x86_64.txt index a4caa8c7569f..136c4353647f 100644 --- a/library/cpp/digest/old_crc/CMakeLists.windows-x86_64.txt +++ b/library/cpp/digest/old_crc/CMakeLists.windows-x86_64.txt @@ -20,6 +20,7 @@ target_link_libraries(cpp-digest-old_crc PUBLIC yutil ) target_sources(cpp-digest-old_crc PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/digest/old_crc/crc.inc ${CMAKE_SOURCE_DIR}/library/cpp/digest/old_crc/crc.cpp ${CMAKE_BINARY_DIR}/library/cpp/digest/old_crc/crc.inc ) diff --git a/library/cpp/digest/old_crc/gencrc/CMakeLists.linux-aarch64.txt b/library/cpp/digest/old_crc/gencrc/CMakeLists.linux-aarch64.txt index f4a3176047ed..9f0f0c044fce 100644 --- a/library/cpp/digest/old_crc/gencrc/CMakeLists.linux-aarch64.txt +++ b/library/cpp/digest/old_crc/gencrc/CMakeLists.linux-aarch64.txt @@ -19,9 +19,6 @@ target_link_options(gencrc PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(gencrc PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/digest/old_crc/gencrc/main.cpp diff --git a/library/cpp/digest/old_crc/gencrc/CMakeLists.linux-x86_64.txt b/library/cpp/digest/old_crc/gencrc/CMakeLists.linux-x86_64.txt index 33bcd9c559fd..9a392ff54a73 100644 --- a/library/cpp/digest/old_crc/gencrc/CMakeLists.linux-x86_64.txt +++ b/library/cpp/digest/old_crc/gencrc/CMakeLists.linux-x86_64.txt @@ -20,9 +20,6 @@ target_link_options(gencrc PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(gencrc PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/digest/old_crc/gencrc/main.cpp diff --git a/library/cpp/histogram/adaptive/protos/CMakeLists.darwin-arm64.txt b/library/cpp/histogram/adaptive/protos/CMakeLists.darwin-arm64.txt index ff0b6ce0f9bd..ff50f811b05a 100644 --- a/library/cpp/histogram/adaptive/protos/CMakeLists.darwin-arm64.txt +++ b/library/cpp/histogram/adaptive/protos/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(histogram-adaptive-protos PUBLIC target_proto_messages(histogram-adaptive-protos PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/histogram/adaptive/protos/histo.proto ) +target_sources(histogram-adaptive-protos PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/histogram/adaptive/protos/histo.pb.h +) target_proto_addincls(histogram-adaptive-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/histogram/adaptive/protos/CMakeLists.darwin-x86_64.txt b/library/cpp/histogram/adaptive/protos/CMakeLists.darwin-x86_64.txt index ff0b6ce0f9bd..ff50f811b05a 100644 --- a/library/cpp/histogram/adaptive/protos/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/histogram/adaptive/protos/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(histogram-adaptive-protos PUBLIC target_proto_messages(histogram-adaptive-protos PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/histogram/adaptive/protos/histo.proto ) +target_sources(histogram-adaptive-protos PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/histogram/adaptive/protos/histo.pb.h +) target_proto_addincls(histogram-adaptive-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/histogram/adaptive/protos/CMakeLists.linux-aarch64.txt b/library/cpp/histogram/adaptive/protos/CMakeLists.linux-aarch64.txt index c2746fae7777..f40e1f1a5d54 100644 --- a/library/cpp/histogram/adaptive/protos/CMakeLists.linux-aarch64.txt +++ b/library/cpp/histogram/adaptive/protos/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(histogram-adaptive-protos PUBLIC target_proto_messages(histogram-adaptive-protos PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/histogram/adaptive/protos/histo.proto ) +target_sources(histogram-adaptive-protos PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/histogram/adaptive/protos/histo.pb.h +) target_proto_addincls(histogram-adaptive-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/histogram/adaptive/protos/CMakeLists.linux-x86_64.txt b/library/cpp/histogram/adaptive/protos/CMakeLists.linux-x86_64.txt index c2746fae7777..f40e1f1a5d54 100644 --- a/library/cpp/histogram/adaptive/protos/CMakeLists.linux-x86_64.txt +++ b/library/cpp/histogram/adaptive/protos/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(histogram-adaptive-protos PUBLIC target_proto_messages(histogram-adaptive-protos PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/histogram/adaptive/protos/histo.proto ) +target_sources(histogram-adaptive-protos PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/histogram/adaptive/protos/histo.pb.h +) target_proto_addincls(histogram-adaptive-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/histogram/adaptive/protos/CMakeLists.windows-x86_64.txt b/library/cpp/histogram/adaptive/protos/CMakeLists.windows-x86_64.txt index ff0b6ce0f9bd..ff50f811b05a 100644 --- a/library/cpp/histogram/adaptive/protos/CMakeLists.windows-x86_64.txt +++ b/library/cpp/histogram/adaptive/protos/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(histogram-adaptive-protos PUBLIC target_proto_messages(histogram-adaptive-protos PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/histogram/adaptive/protos/histo.proto ) +target_sources(histogram-adaptive-protos PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/histogram/adaptive/protos/histo.pb.h +) target_proto_addincls(histogram-adaptive-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/html/pcdata/CMakeLists.darwin-arm64.txt b/library/cpp/html/pcdata/CMakeLists.darwin-arm64.txt index 0efffd69e04e..a013c5f23972 100644 --- a/library/cpp/html/pcdata/CMakeLists.darwin-arm64.txt +++ b/library/cpp/html/pcdata/CMakeLists.darwin-arm64.txt @@ -13,5 +13,6 @@ target_link_libraries(cpp-html-pcdata PUBLIC yutil ) target_sources(cpp-html-pcdata PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/html/pcdata/pcdata.h ${CMAKE_SOURCE_DIR}/library/cpp/html/pcdata/pcdata.cpp ) diff --git a/library/cpp/html/pcdata/CMakeLists.darwin-x86_64.txt b/library/cpp/html/pcdata/CMakeLists.darwin-x86_64.txt index 0efffd69e04e..a013c5f23972 100644 --- a/library/cpp/html/pcdata/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/html/pcdata/CMakeLists.darwin-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(cpp-html-pcdata PUBLIC yutil ) target_sources(cpp-html-pcdata PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/html/pcdata/pcdata.h ${CMAKE_SOURCE_DIR}/library/cpp/html/pcdata/pcdata.cpp ) diff --git a/library/cpp/html/pcdata/CMakeLists.linux-aarch64.txt b/library/cpp/html/pcdata/CMakeLists.linux-aarch64.txt index c6a073acafcc..0722abf6fffc 100644 --- a/library/cpp/html/pcdata/CMakeLists.linux-aarch64.txt +++ b/library/cpp/html/pcdata/CMakeLists.linux-aarch64.txt @@ -14,5 +14,6 @@ target_link_libraries(cpp-html-pcdata PUBLIC yutil ) target_sources(cpp-html-pcdata PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/html/pcdata/pcdata.h ${CMAKE_SOURCE_DIR}/library/cpp/html/pcdata/pcdata.cpp ) diff --git a/library/cpp/html/pcdata/CMakeLists.linux-x86_64.txt b/library/cpp/html/pcdata/CMakeLists.linux-x86_64.txt index c6a073acafcc..0722abf6fffc 100644 --- a/library/cpp/html/pcdata/CMakeLists.linux-x86_64.txt +++ b/library/cpp/html/pcdata/CMakeLists.linux-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(cpp-html-pcdata PUBLIC yutil ) target_sources(cpp-html-pcdata PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/html/pcdata/pcdata.h ${CMAKE_SOURCE_DIR}/library/cpp/html/pcdata/pcdata.cpp ) diff --git a/library/cpp/html/pcdata/CMakeLists.windows-x86_64.txt b/library/cpp/html/pcdata/CMakeLists.windows-x86_64.txt index 0efffd69e04e..a013c5f23972 100644 --- a/library/cpp/html/pcdata/CMakeLists.windows-x86_64.txt +++ b/library/cpp/html/pcdata/CMakeLists.windows-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(cpp-html-pcdata PUBLIC yutil ) target_sources(cpp-html-pcdata PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/html/pcdata/pcdata.h ${CMAKE_SOURCE_DIR}/library/cpp/html/pcdata/pcdata.cpp ) diff --git a/library/cpp/http/fetch/CMakeLists.darwin-arm64.txt b/library/cpp/http/fetch/CMakeLists.darwin-arm64.txt index 553e7fc0354f..4b9df6d266e2 100644 --- a/library/cpp/http/fetch/CMakeLists.darwin-arm64.txt +++ b/library/cpp/http/fetch/CMakeLists.darwin-arm64.txt @@ -27,6 +27,12 @@ target_link_libraries(cpp-http-fetch PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(cpp-http-fetch PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpagent.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpfetcher.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpheader.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpparser.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpzreader.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/sockhandler.h ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/http_digest.cpp ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/http_socket.cpp ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpheader.cpp diff --git a/library/cpp/http/fetch/CMakeLists.darwin-x86_64.txt b/library/cpp/http/fetch/CMakeLists.darwin-x86_64.txt index 553e7fc0354f..4b9df6d266e2 100644 --- a/library/cpp/http/fetch/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/http/fetch/CMakeLists.darwin-x86_64.txt @@ -27,6 +27,12 @@ target_link_libraries(cpp-http-fetch PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(cpp-http-fetch PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpagent.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpfetcher.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpheader.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpparser.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpzreader.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/sockhandler.h ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/http_digest.cpp ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/http_socket.cpp ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpheader.cpp diff --git a/library/cpp/http/fetch/CMakeLists.linux-aarch64.txt b/library/cpp/http/fetch/CMakeLists.linux-aarch64.txt index 4de49d554dec..dc89cb422d64 100644 --- a/library/cpp/http/fetch/CMakeLists.linux-aarch64.txt +++ b/library/cpp/http/fetch/CMakeLists.linux-aarch64.txt @@ -28,6 +28,12 @@ target_link_libraries(cpp-http-fetch PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(cpp-http-fetch PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpagent.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpfetcher.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpheader.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpparser.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpzreader.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/sockhandler.h ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/http_digest.cpp ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/http_socket.cpp ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpheader.cpp diff --git a/library/cpp/http/fetch/CMakeLists.linux-x86_64.txt b/library/cpp/http/fetch/CMakeLists.linux-x86_64.txt index 4de49d554dec..dc89cb422d64 100644 --- a/library/cpp/http/fetch/CMakeLists.linux-x86_64.txt +++ b/library/cpp/http/fetch/CMakeLists.linux-x86_64.txt @@ -28,6 +28,12 @@ target_link_libraries(cpp-http-fetch PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(cpp-http-fetch PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpagent.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpfetcher.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpheader.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpparser.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpzreader.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/sockhandler.h ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/http_digest.cpp ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/http_socket.cpp ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpheader.cpp diff --git a/library/cpp/http/fetch/CMakeLists.windows-x86_64.txt b/library/cpp/http/fetch/CMakeLists.windows-x86_64.txt index 553e7fc0354f..4b9df6d266e2 100644 --- a/library/cpp/http/fetch/CMakeLists.windows-x86_64.txt +++ b/library/cpp/http/fetch/CMakeLists.windows-x86_64.txt @@ -27,6 +27,12 @@ target_link_libraries(cpp-http-fetch PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(cpp-http-fetch PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpagent.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpfetcher.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpheader.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpparser.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpzreader.h + ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/sockhandler.h ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/http_digest.cpp ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/http_socket.cpp ${CMAKE_SOURCE_DIR}/library/cpp/http/fetch/httpheader.cpp diff --git a/library/cpp/hyperloglog/CMakeLists.darwin-arm64.txt b/library/cpp/hyperloglog/CMakeLists.darwin-arm64.txt index 5a180602bc5c..bb90c998a070 100644 --- a/library/cpp/hyperloglog/CMakeLists.darwin-arm64.txt +++ b/library/cpp/hyperloglog/CMakeLists.darwin-arm64.txt @@ -13,5 +13,6 @@ target_link_libraries(library-cpp-hyperloglog PUBLIC yutil ) target_sources(library-cpp-hyperloglog PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/hyperloglog/hyperloglog.h ${CMAKE_SOURCE_DIR}/library/cpp/hyperloglog/hyperloglog.cpp ) diff --git a/library/cpp/hyperloglog/CMakeLists.darwin-x86_64.txt b/library/cpp/hyperloglog/CMakeLists.darwin-x86_64.txt index 5a180602bc5c..bb90c998a070 100644 --- a/library/cpp/hyperloglog/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/hyperloglog/CMakeLists.darwin-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(library-cpp-hyperloglog PUBLIC yutil ) target_sources(library-cpp-hyperloglog PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/hyperloglog/hyperloglog.h ${CMAKE_SOURCE_DIR}/library/cpp/hyperloglog/hyperloglog.cpp ) diff --git a/library/cpp/hyperloglog/CMakeLists.linux-aarch64.txt b/library/cpp/hyperloglog/CMakeLists.linux-aarch64.txt index bbbb9103f6d4..4e031406829f 100644 --- a/library/cpp/hyperloglog/CMakeLists.linux-aarch64.txt +++ b/library/cpp/hyperloglog/CMakeLists.linux-aarch64.txt @@ -14,5 +14,6 @@ target_link_libraries(library-cpp-hyperloglog PUBLIC yutil ) target_sources(library-cpp-hyperloglog PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/hyperloglog/hyperloglog.h ${CMAKE_SOURCE_DIR}/library/cpp/hyperloglog/hyperloglog.cpp ) diff --git a/library/cpp/hyperloglog/CMakeLists.linux-x86_64.txt b/library/cpp/hyperloglog/CMakeLists.linux-x86_64.txt index bbbb9103f6d4..4e031406829f 100644 --- a/library/cpp/hyperloglog/CMakeLists.linux-x86_64.txt +++ b/library/cpp/hyperloglog/CMakeLists.linux-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(library-cpp-hyperloglog PUBLIC yutil ) target_sources(library-cpp-hyperloglog PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/hyperloglog/hyperloglog.h ${CMAKE_SOURCE_DIR}/library/cpp/hyperloglog/hyperloglog.cpp ) diff --git a/library/cpp/hyperloglog/CMakeLists.windows-x86_64.txt b/library/cpp/hyperloglog/CMakeLists.windows-x86_64.txt index 5a180602bc5c..bb90c998a070 100644 --- a/library/cpp/hyperloglog/CMakeLists.windows-x86_64.txt +++ b/library/cpp/hyperloglog/CMakeLists.windows-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(library-cpp-hyperloglog PUBLIC yutil ) target_sources(library-cpp-hyperloglog PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/hyperloglog/hyperloglog.h ${CMAKE_SOURCE_DIR}/library/cpp/hyperloglog/hyperloglog.cpp ) diff --git a/library/cpp/int128/CMakeLists.darwin-arm64.txt b/library/cpp/int128/CMakeLists.darwin-arm64.txt index cdc5d289eec8..556b89637334 100644 --- a/library/cpp/int128/CMakeLists.darwin-arm64.txt +++ b/library/cpp/int128/CMakeLists.darwin-arm64.txt @@ -13,5 +13,6 @@ target_link_libraries(library-cpp-int128 PUBLIC yutil ) target_sources(library-cpp-int128 PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/int128/int128.h ${CMAKE_SOURCE_DIR}/library/cpp/int128/int128.cpp ) diff --git a/library/cpp/int128/CMakeLists.darwin-x86_64.txt b/library/cpp/int128/CMakeLists.darwin-x86_64.txt index cdc5d289eec8..556b89637334 100644 --- a/library/cpp/int128/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/int128/CMakeLists.darwin-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(library-cpp-int128 PUBLIC yutil ) target_sources(library-cpp-int128 PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/int128/int128.h ${CMAKE_SOURCE_DIR}/library/cpp/int128/int128.cpp ) diff --git a/library/cpp/int128/CMakeLists.linux-aarch64.txt b/library/cpp/int128/CMakeLists.linux-aarch64.txt index 504a4558f752..ca19b9966f7b 100644 --- a/library/cpp/int128/CMakeLists.linux-aarch64.txt +++ b/library/cpp/int128/CMakeLists.linux-aarch64.txt @@ -14,5 +14,6 @@ target_link_libraries(library-cpp-int128 PUBLIC yutil ) target_sources(library-cpp-int128 PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/int128/int128.h ${CMAKE_SOURCE_DIR}/library/cpp/int128/int128.cpp ) diff --git a/library/cpp/int128/CMakeLists.linux-x86_64.txt b/library/cpp/int128/CMakeLists.linux-x86_64.txt index 504a4558f752..ca19b9966f7b 100644 --- a/library/cpp/int128/CMakeLists.linux-x86_64.txt +++ b/library/cpp/int128/CMakeLists.linux-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(library-cpp-int128 PUBLIC yutil ) target_sources(library-cpp-int128 PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/int128/int128.h ${CMAKE_SOURCE_DIR}/library/cpp/int128/int128.cpp ) diff --git a/library/cpp/int128/CMakeLists.windows-x86_64.txt b/library/cpp/int128/CMakeLists.windows-x86_64.txt index cdc5d289eec8..556b89637334 100644 --- a/library/cpp/int128/CMakeLists.windows-x86_64.txt +++ b/library/cpp/int128/CMakeLists.windows-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(library-cpp-int128 PUBLIC yutil ) target_sources(library-cpp-int128 PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/int128/int128.h ${CMAKE_SOURCE_DIR}/library/cpp/int128/int128.cpp ) diff --git a/library/cpp/ipv6_address/CMakeLists.darwin-arm64.txt b/library/cpp/ipv6_address/CMakeLists.darwin-arm64.txt index 6156f5cbe2b1..50df9c54eea5 100644 --- a/library/cpp/ipv6_address/CMakeLists.darwin-arm64.txt +++ b/library/cpp/ipv6_address/CMakeLists.darwin-arm64.txt @@ -14,5 +14,7 @@ target_link_libraries(library-cpp-ipv6_address PUBLIC library-cpp-int128 ) target_sources(library-cpp-ipv6_address PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/ipv6_address/ipv6_address.h + ${CMAKE_SOURCE_DIR}/library/cpp/ipv6_address/ipv6_address_p.h ${CMAKE_SOURCE_DIR}/library/cpp/ipv6_address/ipv6_address.cpp ) diff --git a/library/cpp/ipv6_address/CMakeLists.darwin-x86_64.txt b/library/cpp/ipv6_address/CMakeLists.darwin-x86_64.txt index 6156f5cbe2b1..50df9c54eea5 100644 --- a/library/cpp/ipv6_address/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/ipv6_address/CMakeLists.darwin-x86_64.txt @@ -14,5 +14,7 @@ target_link_libraries(library-cpp-ipv6_address PUBLIC library-cpp-int128 ) target_sources(library-cpp-ipv6_address PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/ipv6_address/ipv6_address.h + ${CMAKE_SOURCE_DIR}/library/cpp/ipv6_address/ipv6_address_p.h ${CMAKE_SOURCE_DIR}/library/cpp/ipv6_address/ipv6_address.cpp ) diff --git a/library/cpp/ipv6_address/CMakeLists.linux-aarch64.txt b/library/cpp/ipv6_address/CMakeLists.linux-aarch64.txt index 478d0655cf0f..6b120b0cf4db 100644 --- a/library/cpp/ipv6_address/CMakeLists.linux-aarch64.txt +++ b/library/cpp/ipv6_address/CMakeLists.linux-aarch64.txt @@ -15,5 +15,7 @@ target_link_libraries(library-cpp-ipv6_address PUBLIC library-cpp-int128 ) target_sources(library-cpp-ipv6_address PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/ipv6_address/ipv6_address.h + ${CMAKE_SOURCE_DIR}/library/cpp/ipv6_address/ipv6_address_p.h ${CMAKE_SOURCE_DIR}/library/cpp/ipv6_address/ipv6_address.cpp ) diff --git a/library/cpp/ipv6_address/CMakeLists.linux-x86_64.txt b/library/cpp/ipv6_address/CMakeLists.linux-x86_64.txt index 478d0655cf0f..6b120b0cf4db 100644 --- a/library/cpp/ipv6_address/CMakeLists.linux-x86_64.txt +++ b/library/cpp/ipv6_address/CMakeLists.linux-x86_64.txt @@ -15,5 +15,7 @@ target_link_libraries(library-cpp-ipv6_address PUBLIC library-cpp-int128 ) target_sources(library-cpp-ipv6_address PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/ipv6_address/ipv6_address.h + ${CMAKE_SOURCE_DIR}/library/cpp/ipv6_address/ipv6_address_p.h ${CMAKE_SOURCE_DIR}/library/cpp/ipv6_address/ipv6_address.cpp ) diff --git a/library/cpp/ipv6_address/CMakeLists.windows-x86_64.txt b/library/cpp/ipv6_address/CMakeLists.windows-x86_64.txt index 6156f5cbe2b1..50df9c54eea5 100644 --- a/library/cpp/ipv6_address/CMakeLists.windows-x86_64.txt +++ b/library/cpp/ipv6_address/CMakeLists.windows-x86_64.txt @@ -14,5 +14,7 @@ target_link_libraries(library-cpp-ipv6_address PUBLIC library-cpp-int128 ) target_sources(library-cpp-ipv6_address PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/ipv6_address/ipv6_address.h + ${CMAKE_SOURCE_DIR}/library/cpp/ipv6_address/ipv6_address_p.h ${CMAKE_SOURCE_DIR}/library/cpp/ipv6_address/ipv6_address.cpp ) diff --git a/library/cpp/logger/CMakeLists.darwin-arm64.txt b/library/cpp/logger/CMakeLists.darwin-arm64.txt index 92cf5b5d93af..757396fc7acc 100644 --- a/library/cpp/logger/CMakeLists.darwin-arm64.txt +++ b/library/cpp/logger/CMakeLists.darwin-arm64.txt @@ -23,6 +23,10 @@ target_link_libraries(library-cpp-logger PUBLIC cpp-deprecated-atomic ) target_sources(library-cpp-logger PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/logger/all.h + ${CMAKE_SOURCE_DIR}/library/cpp/logger/priority.h + ${CMAKE_SOURCE_DIR}/library/cpp/logger/record.h + ${CMAKE_SOURCE_DIR}/library/cpp/logger/reopen.h ${CMAKE_SOURCE_DIR}/library/cpp/logger/backend.cpp ${CMAKE_SOURCE_DIR}/library/cpp/logger/backend_creator.cpp ${CMAKE_SOURCE_DIR}/library/cpp/logger/composite.cpp diff --git a/library/cpp/logger/CMakeLists.darwin-x86_64.txt b/library/cpp/logger/CMakeLists.darwin-x86_64.txt index 92cf5b5d93af..757396fc7acc 100644 --- a/library/cpp/logger/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/logger/CMakeLists.darwin-x86_64.txt @@ -23,6 +23,10 @@ target_link_libraries(library-cpp-logger PUBLIC cpp-deprecated-atomic ) target_sources(library-cpp-logger PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/logger/all.h + ${CMAKE_SOURCE_DIR}/library/cpp/logger/priority.h + ${CMAKE_SOURCE_DIR}/library/cpp/logger/record.h + ${CMAKE_SOURCE_DIR}/library/cpp/logger/reopen.h ${CMAKE_SOURCE_DIR}/library/cpp/logger/backend.cpp ${CMAKE_SOURCE_DIR}/library/cpp/logger/backend_creator.cpp ${CMAKE_SOURCE_DIR}/library/cpp/logger/composite.cpp diff --git a/library/cpp/logger/CMakeLists.linux-aarch64.txt b/library/cpp/logger/CMakeLists.linux-aarch64.txt index 7656dd686183..7c30bc1d6e30 100644 --- a/library/cpp/logger/CMakeLists.linux-aarch64.txt +++ b/library/cpp/logger/CMakeLists.linux-aarch64.txt @@ -24,6 +24,10 @@ target_link_libraries(library-cpp-logger PUBLIC cpp-deprecated-atomic ) target_sources(library-cpp-logger PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/logger/all.h + ${CMAKE_SOURCE_DIR}/library/cpp/logger/priority.h + ${CMAKE_SOURCE_DIR}/library/cpp/logger/record.h + ${CMAKE_SOURCE_DIR}/library/cpp/logger/reopen.h ${CMAKE_SOURCE_DIR}/library/cpp/logger/backend.cpp ${CMAKE_SOURCE_DIR}/library/cpp/logger/backend_creator.cpp ${CMAKE_SOURCE_DIR}/library/cpp/logger/composite.cpp diff --git a/library/cpp/logger/CMakeLists.linux-x86_64.txt b/library/cpp/logger/CMakeLists.linux-x86_64.txt index 7656dd686183..7c30bc1d6e30 100644 --- a/library/cpp/logger/CMakeLists.linux-x86_64.txt +++ b/library/cpp/logger/CMakeLists.linux-x86_64.txt @@ -24,6 +24,10 @@ target_link_libraries(library-cpp-logger PUBLIC cpp-deprecated-atomic ) target_sources(library-cpp-logger PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/logger/all.h + ${CMAKE_SOURCE_DIR}/library/cpp/logger/priority.h + ${CMAKE_SOURCE_DIR}/library/cpp/logger/record.h + ${CMAKE_SOURCE_DIR}/library/cpp/logger/reopen.h ${CMAKE_SOURCE_DIR}/library/cpp/logger/backend.cpp ${CMAKE_SOURCE_DIR}/library/cpp/logger/backend_creator.cpp ${CMAKE_SOURCE_DIR}/library/cpp/logger/composite.cpp diff --git a/library/cpp/logger/CMakeLists.windows-x86_64.txt b/library/cpp/logger/CMakeLists.windows-x86_64.txt index 92cf5b5d93af..757396fc7acc 100644 --- a/library/cpp/logger/CMakeLists.windows-x86_64.txt +++ b/library/cpp/logger/CMakeLists.windows-x86_64.txt @@ -23,6 +23,10 @@ target_link_libraries(library-cpp-logger PUBLIC cpp-deprecated-atomic ) target_sources(library-cpp-logger PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/logger/all.h + ${CMAKE_SOURCE_DIR}/library/cpp/logger/priority.h + ${CMAKE_SOURCE_DIR}/library/cpp/logger/record.h + ${CMAKE_SOURCE_DIR}/library/cpp/logger/reopen.h ${CMAKE_SOURCE_DIR}/library/cpp/logger/backend.cpp ${CMAKE_SOURCE_DIR}/library/cpp/logger/backend_creator.cpp ${CMAKE_SOURCE_DIR}/library/cpp/logger/composite.cpp diff --git a/library/cpp/lwtrace/protos/CMakeLists.darwin-arm64.txt b/library/cpp/lwtrace/protos/CMakeLists.darwin-arm64.txt index 9caa6f58bf42..8cc894531eb2 100644 --- a/library/cpp/lwtrace/protos/CMakeLists.darwin-arm64.txt +++ b/library/cpp/lwtrace/protos/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(cpp-lwtrace-protos PUBLIC target_proto_messages(cpp-lwtrace-protos PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/lwtrace/protos/lwtrace.proto ) +target_sources(cpp-lwtrace-protos PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/lwtrace/protos/lwtrace.pb.h +) target_proto_addincls(cpp-lwtrace-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/lwtrace/protos/CMakeLists.darwin-x86_64.txt b/library/cpp/lwtrace/protos/CMakeLists.darwin-x86_64.txt index 9caa6f58bf42..8cc894531eb2 100644 --- a/library/cpp/lwtrace/protos/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/lwtrace/protos/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(cpp-lwtrace-protos PUBLIC target_proto_messages(cpp-lwtrace-protos PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/lwtrace/protos/lwtrace.proto ) +target_sources(cpp-lwtrace-protos PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/lwtrace/protos/lwtrace.pb.h +) target_proto_addincls(cpp-lwtrace-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/lwtrace/protos/CMakeLists.linux-aarch64.txt b/library/cpp/lwtrace/protos/CMakeLists.linux-aarch64.txt index f9321305c17f..9c7d33c0a102 100644 --- a/library/cpp/lwtrace/protos/CMakeLists.linux-aarch64.txt +++ b/library/cpp/lwtrace/protos/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(cpp-lwtrace-protos PUBLIC target_proto_messages(cpp-lwtrace-protos PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/lwtrace/protos/lwtrace.proto ) +target_sources(cpp-lwtrace-protos PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/lwtrace/protos/lwtrace.pb.h +) target_proto_addincls(cpp-lwtrace-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/lwtrace/protos/CMakeLists.linux-x86_64.txt b/library/cpp/lwtrace/protos/CMakeLists.linux-x86_64.txt index f9321305c17f..9c7d33c0a102 100644 --- a/library/cpp/lwtrace/protos/CMakeLists.linux-x86_64.txt +++ b/library/cpp/lwtrace/protos/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(cpp-lwtrace-protos PUBLIC target_proto_messages(cpp-lwtrace-protos PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/lwtrace/protos/lwtrace.proto ) +target_sources(cpp-lwtrace-protos PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/lwtrace/protos/lwtrace.pb.h +) target_proto_addincls(cpp-lwtrace-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/lwtrace/protos/CMakeLists.windows-x86_64.txt b/library/cpp/lwtrace/protos/CMakeLists.windows-x86_64.txt index 9caa6f58bf42..8cc894531eb2 100644 --- a/library/cpp/lwtrace/protos/CMakeLists.windows-x86_64.txt +++ b/library/cpp/lwtrace/protos/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(cpp-lwtrace-protos PUBLIC target_proto_messages(cpp-lwtrace-protos PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/lwtrace/protos/lwtrace.proto ) +target_sources(cpp-lwtrace-protos PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/lwtrace/protos/lwtrace.pb.h +) target_proto_addincls(cpp-lwtrace-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/messagebus/CMakeLists.darwin-arm64.txt b/library/cpp/messagebus/CMakeLists.darwin-arm64.txt index af2b7a200835..06eb9f1e4c95 100644 --- a/library/cpp/messagebus/CMakeLists.darwin-arm64.txt +++ b/library/cpp/messagebus/CMakeLists.darwin-arm64.txt @@ -32,6 +32,12 @@ target_link_libraries(library-cpp-messagebus PUBLIC cpp-deprecated-atomic ) target_sources(library-cpp-messagebus PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/atomic_box.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/granup.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/test_sync.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/tokenquota.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/weak_ptr.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/ybus.h ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/acceptor.cpp ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/acceptor_status.cpp ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/connection.cpp diff --git a/library/cpp/messagebus/CMakeLists.darwin-x86_64.txt b/library/cpp/messagebus/CMakeLists.darwin-x86_64.txt index af2b7a200835..06eb9f1e4c95 100644 --- a/library/cpp/messagebus/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/messagebus/CMakeLists.darwin-x86_64.txt @@ -32,6 +32,12 @@ target_link_libraries(library-cpp-messagebus PUBLIC cpp-deprecated-atomic ) target_sources(library-cpp-messagebus PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/atomic_box.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/granup.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/test_sync.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/tokenquota.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/weak_ptr.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/ybus.h ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/acceptor.cpp ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/acceptor_status.cpp ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/connection.cpp diff --git a/library/cpp/messagebus/CMakeLists.linux-aarch64.txt b/library/cpp/messagebus/CMakeLists.linux-aarch64.txt index e27549d923a8..082f332fbc11 100644 --- a/library/cpp/messagebus/CMakeLists.linux-aarch64.txt +++ b/library/cpp/messagebus/CMakeLists.linux-aarch64.txt @@ -33,6 +33,12 @@ target_link_libraries(library-cpp-messagebus PUBLIC cpp-deprecated-atomic ) target_sources(library-cpp-messagebus PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/atomic_box.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/granup.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/test_sync.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/tokenquota.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/weak_ptr.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/ybus.h ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/acceptor.cpp ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/acceptor_status.cpp ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/connection.cpp diff --git a/library/cpp/messagebus/CMakeLists.linux-x86_64.txt b/library/cpp/messagebus/CMakeLists.linux-x86_64.txt index e27549d923a8..082f332fbc11 100644 --- a/library/cpp/messagebus/CMakeLists.linux-x86_64.txt +++ b/library/cpp/messagebus/CMakeLists.linux-x86_64.txt @@ -33,6 +33,12 @@ target_link_libraries(library-cpp-messagebus PUBLIC cpp-deprecated-atomic ) target_sources(library-cpp-messagebus PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/atomic_box.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/granup.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/test_sync.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/tokenquota.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/weak_ptr.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/ybus.h ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/acceptor.cpp ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/acceptor_status.cpp ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/connection.cpp diff --git a/library/cpp/messagebus/CMakeLists.windows-x86_64.txt b/library/cpp/messagebus/CMakeLists.windows-x86_64.txt index af2b7a200835..06eb9f1e4c95 100644 --- a/library/cpp/messagebus/CMakeLists.windows-x86_64.txt +++ b/library/cpp/messagebus/CMakeLists.windows-x86_64.txt @@ -32,6 +32,12 @@ target_link_libraries(library-cpp-messagebus PUBLIC cpp-deprecated-atomic ) target_sources(library-cpp-messagebus PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/atomic_box.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/granup.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/test_sync.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/tokenquota.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/misc/weak_ptr.h + ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/ybus.h ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/acceptor.cpp ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/acceptor_status.cpp ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/connection.cpp diff --git a/library/cpp/messagebus/monitoring/CMakeLists.darwin-arm64.txt b/library/cpp/messagebus/monitoring/CMakeLists.darwin-arm64.txt index 0a5f1f85022a..eb89055ff017 100644 --- a/library/cpp/messagebus/monitoring/CMakeLists.darwin-arm64.txt +++ b/library/cpp/messagebus/monitoring/CMakeLists.darwin-arm64.txt @@ -29,6 +29,9 @@ target_link_libraries(cpp-messagebus-monitoring PUBLIC target_proto_messages(cpp-messagebus-monitoring PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/monitoring/mon_proto.proto ) +target_sources(cpp-messagebus-monitoring PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/messagebus/monitoring/mon_proto.pb.h +) target_proto_addincls(cpp-messagebus-monitoring ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/messagebus/monitoring/CMakeLists.darwin-x86_64.txt b/library/cpp/messagebus/monitoring/CMakeLists.darwin-x86_64.txt index 0a5f1f85022a..eb89055ff017 100644 --- a/library/cpp/messagebus/monitoring/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/messagebus/monitoring/CMakeLists.darwin-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(cpp-messagebus-monitoring PUBLIC target_proto_messages(cpp-messagebus-monitoring PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/monitoring/mon_proto.proto ) +target_sources(cpp-messagebus-monitoring PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/messagebus/monitoring/mon_proto.pb.h +) target_proto_addincls(cpp-messagebus-monitoring ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/messagebus/monitoring/CMakeLists.linux-aarch64.txt b/library/cpp/messagebus/monitoring/CMakeLists.linux-aarch64.txt index d7ac9c9c03f5..33f54b66f323 100644 --- a/library/cpp/messagebus/monitoring/CMakeLists.linux-aarch64.txt +++ b/library/cpp/messagebus/monitoring/CMakeLists.linux-aarch64.txt @@ -30,6 +30,9 @@ target_link_libraries(cpp-messagebus-monitoring PUBLIC target_proto_messages(cpp-messagebus-monitoring PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/monitoring/mon_proto.proto ) +target_sources(cpp-messagebus-monitoring PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/messagebus/monitoring/mon_proto.pb.h +) target_proto_addincls(cpp-messagebus-monitoring ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/messagebus/monitoring/CMakeLists.linux-x86_64.txt b/library/cpp/messagebus/monitoring/CMakeLists.linux-x86_64.txt index d7ac9c9c03f5..33f54b66f323 100644 --- a/library/cpp/messagebus/monitoring/CMakeLists.linux-x86_64.txt +++ b/library/cpp/messagebus/monitoring/CMakeLists.linux-x86_64.txt @@ -30,6 +30,9 @@ target_link_libraries(cpp-messagebus-monitoring PUBLIC target_proto_messages(cpp-messagebus-monitoring PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/monitoring/mon_proto.proto ) +target_sources(cpp-messagebus-monitoring PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/messagebus/monitoring/mon_proto.pb.h +) target_proto_addincls(cpp-messagebus-monitoring ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/messagebus/monitoring/CMakeLists.windows-x86_64.txt b/library/cpp/messagebus/monitoring/CMakeLists.windows-x86_64.txt index 0a5f1f85022a..eb89055ff017 100644 --- a/library/cpp/messagebus/monitoring/CMakeLists.windows-x86_64.txt +++ b/library/cpp/messagebus/monitoring/CMakeLists.windows-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(cpp-messagebus-monitoring PUBLIC target_proto_messages(cpp-messagebus-monitoring PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/messagebus/monitoring/mon_proto.proto ) +target_sources(cpp-messagebus-monitoring PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/messagebus/monitoring/mon_proto.pb.h +) target_proto_addincls(cpp-messagebus-monitoring ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/monlib/deprecated/json/CMakeLists.darwin-arm64.txt b/library/cpp/monlib/deprecated/json/CMakeLists.darwin-arm64.txt index 6bcb22f8ccb4..a018e8be700b 100644 --- a/library/cpp/monlib/deprecated/json/CMakeLists.darwin-arm64.txt +++ b/library/cpp/monlib/deprecated/json/CMakeLists.darwin-arm64.txt @@ -14,5 +14,6 @@ target_link_libraries(monlib-deprecated-json PUBLIC library-cpp-json ) target_sources(monlib-deprecated-json PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/deprecated/json/writer.h ${CMAKE_SOURCE_DIR}/library/cpp/monlib/deprecated/json/writer.cpp ) diff --git a/library/cpp/monlib/deprecated/json/CMakeLists.darwin-x86_64.txt b/library/cpp/monlib/deprecated/json/CMakeLists.darwin-x86_64.txt index 6bcb22f8ccb4..a018e8be700b 100644 --- a/library/cpp/monlib/deprecated/json/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/monlib/deprecated/json/CMakeLists.darwin-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(monlib-deprecated-json PUBLIC library-cpp-json ) target_sources(monlib-deprecated-json PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/deprecated/json/writer.h ${CMAKE_SOURCE_DIR}/library/cpp/monlib/deprecated/json/writer.cpp ) diff --git a/library/cpp/monlib/deprecated/json/CMakeLists.linux-aarch64.txt b/library/cpp/monlib/deprecated/json/CMakeLists.linux-aarch64.txt index c7cb3720d3e9..7a67eceaad20 100644 --- a/library/cpp/monlib/deprecated/json/CMakeLists.linux-aarch64.txt +++ b/library/cpp/monlib/deprecated/json/CMakeLists.linux-aarch64.txt @@ -15,5 +15,6 @@ target_link_libraries(monlib-deprecated-json PUBLIC library-cpp-json ) target_sources(monlib-deprecated-json PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/deprecated/json/writer.h ${CMAKE_SOURCE_DIR}/library/cpp/monlib/deprecated/json/writer.cpp ) diff --git a/library/cpp/monlib/deprecated/json/CMakeLists.linux-x86_64.txt b/library/cpp/monlib/deprecated/json/CMakeLists.linux-x86_64.txt index c7cb3720d3e9..7a67eceaad20 100644 --- a/library/cpp/monlib/deprecated/json/CMakeLists.linux-x86_64.txt +++ b/library/cpp/monlib/deprecated/json/CMakeLists.linux-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(monlib-deprecated-json PUBLIC library-cpp-json ) target_sources(monlib-deprecated-json PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/deprecated/json/writer.h ${CMAKE_SOURCE_DIR}/library/cpp/monlib/deprecated/json/writer.cpp ) diff --git a/library/cpp/monlib/deprecated/json/CMakeLists.windows-x86_64.txt b/library/cpp/monlib/deprecated/json/CMakeLists.windows-x86_64.txt index 6bcb22f8ccb4..a018e8be700b 100644 --- a/library/cpp/monlib/deprecated/json/CMakeLists.windows-x86_64.txt +++ b/library/cpp/monlib/deprecated/json/CMakeLists.windows-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(monlib-deprecated-json PUBLIC library-cpp-json ) target_sources(monlib-deprecated-json PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/deprecated/json/writer.h ${CMAKE_SOURCE_DIR}/library/cpp/monlib/deprecated/json/writer.cpp ) diff --git a/library/cpp/monlib/dynamic_counters/percentile/CMakeLists.darwin-arm64.txt b/library/cpp/monlib/dynamic_counters/percentile/CMakeLists.darwin-arm64.txt index fa99d9dc2f56..a34ae332ba99 100644 --- a/library/cpp/monlib/dynamic_counters/percentile/CMakeLists.darwin-arm64.txt +++ b/library/cpp/monlib/dynamic_counters/percentile/CMakeLists.darwin-arm64.txt @@ -14,3 +14,7 @@ target_link_libraries(monlib-dynamic_counters-percentile INTERFACE cpp-containers-stack_vector cpp-monlib-dynamic_counters ) +target_sources(monlib-dynamic_counters-percentile INTERFACE + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/dynamic_counters/percentile/percentile.h + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/dynamic_counters/percentile/percentile_lg.h +) diff --git a/library/cpp/monlib/dynamic_counters/percentile/CMakeLists.darwin-x86_64.txt b/library/cpp/monlib/dynamic_counters/percentile/CMakeLists.darwin-x86_64.txt index fa99d9dc2f56..a34ae332ba99 100644 --- a/library/cpp/monlib/dynamic_counters/percentile/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/monlib/dynamic_counters/percentile/CMakeLists.darwin-x86_64.txt @@ -14,3 +14,7 @@ target_link_libraries(monlib-dynamic_counters-percentile INTERFACE cpp-containers-stack_vector cpp-monlib-dynamic_counters ) +target_sources(monlib-dynamic_counters-percentile INTERFACE + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/dynamic_counters/percentile/percentile.h + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/dynamic_counters/percentile/percentile_lg.h +) diff --git a/library/cpp/monlib/dynamic_counters/percentile/CMakeLists.linux-aarch64.txt b/library/cpp/monlib/dynamic_counters/percentile/CMakeLists.linux-aarch64.txt index b6a771543e55..b724f85cd96b 100644 --- a/library/cpp/monlib/dynamic_counters/percentile/CMakeLists.linux-aarch64.txt +++ b/library/cpp/monlib/dynamic_counters/percentile/CMakeLists.linux-aarch64.txt @@ -15,3 +15,7 @@ target_link_libraries(monlib-dynamic_counters-percentile INTERFACE cpp-containers-stack_vector cpp-monlib-dynamic_counters ) +target_sources(monlib-dynamic_counters-percentile INTERFACE + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/dynamic_counters/percentile/percentile.h + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/dynamic_counters/percentile/percentile_lg.h +) diff --git a/library/cpp/monlib/dynamic_counters/percentile/CMakeLists.linux-x86_64.txt b/library/cpp/monlib/dynamic_counters/percentile/CMakeLists.linux-x86_64.txt index b6a771543e55..b724f85cd96b 100644 --- a/library/cpp/monlib/dynamic_counters/percentile/CMakeLists.linux-x86_64.txt +++ b/library/cpp/monlib/dynamic_counters/percentile/CMakeLists.linux-x86_64.txt @@ -15,3 +15,7 @@ target_link_libraries(monlib-dynamic_counters-percentile INTERFACE cpp-containers-stack_vector cpp-monlib-dynamic_counters ) +target_sources(monlib-dynamic_counters-percentile INTERFACE + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/dynamic_counters/percentile/percentile.h + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/dynamic_counters/percentile/percentile_lg.h +) diff --git a/library/cpp/monlib/dynamic_counters/percentile/CMakeLists.windows-x86_64.txt b/library/cpp/monlib/dynamic_counters/percentile/CMakeLists.windows-x86_64.txt index fa99d9dc2f56..a34ae332ba99 100644 --- a/library/cpp/monlib/dynamic_counters/percentile/CMakeLists.windows-x86_64.txt +++ b/library/cpp/monlib/dynamic_counters/percentile/CMakeLists.windows-x86_64.txt @@ -14,3 +14,7 @@ target_link_libraries(monlib-dynamic_counters-percentile INTERFACE cpp-containers-stack_vector cpp-monlib-dynamic_counters ) +target_sources(monlib-dynamic_counters-percentile INTERFACE + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/dynamic_counters/percentile/percentile.h + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/dynamic_counters/percentile/percentile_lg.h +) diff --git a/library/cpp/monlib/encode/CMakeLists.darwin-arm64.txt b/library/cpp/monlib/encode/CMakeLists.darwin-arm64.txt index a74b6d023d01..69cb06346346 100644 --- a/library/cpp/monlib/encode/CMakeLists.darwin-arm64.txt +++ b/library/cpp/monlib/encode/CMakeLists.darwin-arm64.txt @@ -27,6 +27,7 @@ target_link_libraries(cpp-monlib-encode PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(cpp-monlib-encode PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/monlib/encode/encoder_state_enum.h_serialized.h ${CMAKE_SOURCE_DIR}/library/cpp/monlib/encode/encoder.cpp ${CMAKE_SOURCE_DIR}/library/cpp/monlib/encode/encoder_state.cpp ${CMAKE_SOURCE_DIR}/library/cpp/monlib/encode/format.cpp diff --git a/library/cpp/monlib/encode/CMakeLists.darwin-x86_64.txt b/library/cpp/monlib/encode/CMakeLists.darwin-x86_64.txt index a74b6d023d01..69cb06346346 100644 --- a/library/cpp/monlib/encode/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/monlib/encode/CMakeLists.darwin-x86_64.txt @@ -27,6 +27,7 @@ target_link_libraries(cpp-monlib-encode PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(cpp-monlib-encode PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/monlib/encode/encoder_state_enum.h_serialized.h ${CMAKE_SOURCE_DIR}/library/cpp/monlib/encode/encoder.cpp ${CMAKE_SOURCE_DIR}/library/cpp/monlib/encode/encoder_state.cpp ${CMAKE_SOURCE_DIR}/library/cpp/monlib/encode/format.cpp diff --git a/library/cpp/monlib/encode/CMakeLists.linux-aarch64.txt b/library/cpp/monlib/encode/CMakeLists.linux-aarch64.txt index 6c319f9b6872..114b6bbf2054 100644 --- a/library/cpp/monlib/encode/CMakeLists.linux-aarch64.txt +++ b/library/cpp/monlib/encode/CMakeLists.linux-aarch64.txt @@ -28,6 +28,7 @@ target_link_libraries(cpp-monlib-encode PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(cpp-monlib-encode PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/monlib/encode/encoder_state_enum.h_serialized.h ${CMAKE_SOURCE_DIR}/library/cpp/monlib/encode/encoder.cpp ${CMAKE_SOURCE_DIR}/library/cpp/monlib/encode/encoder_state.cpp ${CMAKE_SOURCE_DIR}/library/cpp/monlib/encode/format.cpp diff --git a/library/cpp/monlib/encode/CMakeLists.linux-x86_64.txt b/library/cpp/monlib/encode/CMakeLists.linux-x86_64.txt index 6c319f9b6872..114b6bbf2054 100644 --- a/library/cpp/monlib/encode/CMakeLists.linux-x86_64.txt +++ b/library/cpp/monlib/encode/CMakeLists.linux-x86_64.txt @@ -28,6 +28,7 @@ target_link_libraries(cpp-monlib-encode PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(cpp-monlib-encode PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/monlib/encode/encoder_state_enum.h_serialized.h ${CMAKE_SOURCE_DIR}/library/cpp/monlib/encode/encoder.cpp ${CMAKE_SOURCE_DIR}/library/cpp/monlib/encode/encoder_state.cpp ${CMAKE_SOURCE_DIR}/library/cpp/monlib/encode/format.cpp diff --git a/library/cpp/monlib/encode/CMakeLists.windows-x86_64.txt b/library/cpp/monlib/encode/CMakeLists.windows-x86_64.txt index a74b6d023d01..69cb06346346 100644 --- a/library/cpp/monlib/encode/CMakeLists.windows-x86_64.txt +++ b/library/cpp/monlib/encode/CMakeLists.windows-x86_64.txt @@ -27,6 +27,7 @@ target_link_libraries(cpp-monlib-encode PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(cpp-monlib-encode PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/monlib/encode/encoder_state_enum.h_serialized.h ${CMAKE_SOURCE_DIR}/library/cpp/monlib/encode/encoder.cpp ${CMAKE_SOURCE_DIR}/library/cpp/monlib/encode/encoder_state.cpp ${CMAKE_SOURCE_DIR}/library/cpp/monlib/encode/format.cpp diff --git a/library/cpp/monlib/encode/legacy_protobuf/protos/CMakeLists.darwin-arm64.txt b/library/cpp/monlib/encode/legacy_protobuf/protos/CMakeLists.darwin-arm64.txt index bce491e67e59..197c383a0fbd 100644 --- a/library/cpp/monlib/encode/legacy_protobuf/protos/CMakeLists.darwin-arm64.txt +++ b/library/cpp/monlib/encode/legacy_protobuf/protos/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(encode-legacy_protobuf-protos PUBLIC target_proto_messages(encode-legacy_protobuf-protos PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/monlib/encode/legacy_protobuf/protos/metric_meta.proto ) +target_sources(encode-legacy_protobuf-protos PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/monlib/encode/legacy_protobuf/protos/metric_meta.pb.h +) target_proto_addincls(encode-legacy_protobuf-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/monlib/encode/legacy_protobuf/protos/CMakeLists.darwin-x86_64.txt b/library/cpp/monlib/encode/legacy_protobuf/protos/CMakeLists.darwin-x86_64.txt index bce491e67e59..197c383a0fbd 100644 --- a/library/cpp/monlib/encode/legacy_protobuf/protos/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/monlib/encode/legacy_protobuf/protos/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(encode-legacy_protobuf-protos PUBLIC target_proto_messages(encode-legacy_protobuf-protos PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/monlib/encode/legacy_protobuf/protos/metric_meta.proto ) +target_sources(encode-legacy_protobuf-protos PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/monlib/encode/legacy_protobuf/protos/metric_meta.pb.h +) target_proto_addincls(encode-legacy_protobuf-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/monlib/encode/legacy_protobuf/protos/CMakeLists.linux-aarch64.txt b/library/cpp/monlib/encode/legacy_protobuf/protos/CMakeLists.linux-aarch64.txt index a86da32e117c..c1b141733817 100644 --- a/library/cpp/monlib/encode/legacy_protobuf/protos/CMakeLists.linux-aarch64.txt +++ b/library/cpp/monlib/encode/legacy_protobuf/protos/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(encode-legacy_protobuf-protos PUBLIC target_proto_messages(encode-legacy_protobuf-protos PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/monlib/encode/legacy_protobuf/protos/metric_meta.proto ) +target_sources(encode-legacy_protobuf-protos PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/monlib/encode/legacy_protobuf/protos/metric_meta.pb.h +) target_proto_addincls(encode-legacy_protobuf-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/monlib/encode/legacy_protobuf/protos/CMakeLists.linux-x86_64.txt b/library/cpp/monlib/encode/legacy_protobuf/protos/CMakeLists.linux-x86_64.txt index a86da32e117c..c1b141733817 100644 --- a/library/cpp/monlib/encode/legacy_protobuf/protos/CMakeLists.linux-x86_64.txt +++ b/library/cpp/monlib/encode/legacy_protobuf/protos/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(encode-legacy_protobuf-protos PUBLIC target_proto_messages(encode-legacy_protobuf-protos PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/monlib/encode/legacy_protobuf/protos/metric_meta.proto ) +target_sources(encode-legacy_protobuf-protos PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/monlib/encode/legacy_protobuf/protos/metric_meta.pb.h +) target_proto_addincls(encode-legacy_protobuf-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/monlib/encode/legacy_protobuf/protos/CMakeLists.windows-x86_64.txt b/library/cpp/monlib/encode/legacy_protobuf/protos/CMakeLists.windows-x86_64.txt index bce491e67e59..197c383a0fbd 100644 --- a/library/cpp/monlib/encode/legacy_protobuf/protos/CMakeLists.windows-x86_64.txt +++ b/library/cpp/monlib/encode/legacy_protobuf/protos/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(encode-legacy_protobuf-protos PUBLIC target_proto_messages(encode-legacy_protobuf-protos PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/monlib/encode/legacy_protobuf/protos/metric_meta.proto ) +target_sources(encode-legacy_protobuf-protos PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/monlib/encode/legacy_protobuf/protos/metric_meta.pb.h +) target_proto_addincls(encode-legacy_protobuf-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/monlib/metrics/CMakeLists.darwin-arm64.txt b/library/cpp/monlib/metrics/CMakeLists.darwin-arm64.txt index 052ed067e171..9760edd92f9a 100644 --- a/library/cpp/monlib/metrics/CMakeLists.darwin-arm64.txt +++ b/library/cpp/monlib/metrics/CMakeLists.darwin-arm64.txt @@ -20,6 +20,7 @@ target_link_libraries(cpp-monlib-metrics PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(cpp-monlib-metrics PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/monlib/metrics/metric_value_type.h_serialized.h ${CMAKE_SOURCE_DIR}/library/cpp/monlib/metrics/ewma.cpp ${CMAKE_SOURCE_DIR}/library/cpp/monlib/metrics/fake.cpp ${CMAKE_SOURCE_DIR}/library/cpp/monlib/metrics/histogram_collector_explicit.cpp diff --git a/library/cpp/monlib/metrics/CMakeLists.darwin-x86_64.txt b/library/cpp/monlib/metrics/CMakeLists.darwin-x86_64.txt index 052ed067e171..9760edd92f9a 100644 --- a/library/cpp/monlib/metrics/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/monlib/metrics/CMakeLists.darwin-x86_64.txt @@ -20,6 +20,7 @@ target_link_libraries(cpp-monlib-metrics PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(cpp-monlib-metrics PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/monlib/metrics/metric_value_type.h_serialized.h ${CMAKE_SOURCE_DIR}/library/cpp/monlib/metrics/ewma.cpp ${CMAKE_SOURCE_DIR}/library/cpp/monlib/metrics/fake.cpp ${CMAKE_SOURCE_DIR}/library/cpp/monlib/metrics/histogram_collector_explicit.cpp diff --git a/library/cpp/monlib/metrics/CMakeLists.linux-aarch64.txt b/library/cpp/monlib/metrics/CMakeLists.linux-aarch64.txt index eb18b40c1891..0e1d18c3b16d 100644 --- a/library/cpp/monlib/metrics/CMakeLists.linux-aarch64.txt +++ b/library/cpp/monlib/metrics/CMakeLists.linux-aarch64.txt @@ -21,6 +21,7 @@ target_link_libraries(cpp-monlib-metrics PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(cpp-monlib-metrics PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/monlib/metrics/metric_value_type.h_serialized.h ${CMAKE_SOURCE_DIR}/library/cpp/monlib/metrics/ewma.cpp ${CMAKE_SOURCE_DIR}/library/cpp/monlib/metrics/fake.cpp ${CMAKE_SOURCE_DIR}/library/cpp/monlib/metrics/histogram_collector_explicit.cpp diff --git a/library/cpp/monlib/metrics/CMakeLists.linux-x86_64.txt b/library/cpp/monlib/metrics/CMakeLists.linux-x86_64.txt index eb18b40c1891..0e1d18c3b16d 100644 --- a/library/cpp/monlib/metrics/CMakeLists.linux-x86_64.txt +++ b/library/cpp/monlib/metrics/CMakeLists.linux-x86_64.txt @@ -21,6 +21,7 @@ target_link_libraries(cpp-monlib-metrics PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(cpp-monlib-metrics PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/monlib/metrics/metric_value_type.h_serialized.h ${CMAKE_SOURCE_DIR}/library/cpp/monlib/metrics/ewma.cpp ${CMAKE_SOURCE_DIR}/library/cpp/monlib/metrics/fake.cpp ${CMAKE_SOURCE_DIR}/library/cpp/monlib/metrics/histogram_collector_explicit.cpp diff --git a/library/cpp/monlib/metrics/CMakeLists.windows-x86_64.txt b/library/cpp/monlib/metrics/CMakeLists.windows-x86_64.txt index 052ed067e171..9760edd92f9a 100644 --- a/library/cpp/monlib/metrics/CMakeLists.windows-x86_64.txt +++ b/library/cpp/monlib/metrics/CMakeLists.windows-x86_64.txt @@ -20,6 +20,7 @@ target_link_libraries(cpp-monlib-metrics PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(cpp-monlib-metrics PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/monlib/metrics/metric_value_type.h_serialized.h ${CMAKE_SOURCE_DIR}/library/cpp/monlib/metrics/ewma.cpp ${CMAKE_SOURCE_DIR}/library/cpp/monlib/metrics/fake.cpp ${CMAKE_SOURCE_DIR}/library/cpp/monlib/metrics/histogram_collector_explicit.cpp diff --git a/library/cpp/monlib/service/pages/resources/CMakeLists.darwin-arm64.txt b/library/cpp/monlib/service/pages/resources/CMakeLists.darwin-arm64.txt index f74d5e30a397..d61b00e7cc12 100644 --- a/library/cpp/monlib/service/pages/resources/CMakeLists.darwin-arm64.txt +++ b/library/cpp/monlib/service/pages/resources/CMakeLists.darwin-arm64.txt @@ -20,6 +20,11 @@ target_link_libraries(service-pages-resources INTERFACE library-cpp-resource cpp-monlib-dynamic_counters ) +target_sources(service-pages-resources INTERFACE + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/service/pages/resources/css_mon_page.h + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/service/pages/resources/fonts_mon_page.h + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/service/pages/resources/js_mon_page.h +) add_global_library_for(service-pages-resources.global service-pages-resources) target_link_libraries(service-pages-resources.global PUBLIC diff --git a/library/cpp/monlib/service/pages/resources/CMakeLists.darwin-x86_64.txt b/library/cpp/monlib/service/pages/resources/CMakeLists.darwin-x86_64.txt index f74d5e30a397..d61b00e7cc12 100644 --- a/library/cpp/monlib/service/pages/resources/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/monlib/service/pages/resources/CMakeLists.darwin-x86_64.txt @@ -20,6 +20,11 @@ target_link_libraries(service-pages-resources INTERFACE library-cpp-resource cpp-monlib-dynamic_counters ) +target_sources(service-pages-resources INTERFACE + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/service/pages/resources/css_mon_page.h + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/service/pages/resources/fonts_mon_page.h + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/service/pages/resources/js_mon_page.h +) add_global_library_for(service-pages-resources.global service-pages-resources) target_link_libraries(service-pages-resources.global PUBLIC diff --git a/library/cpp/monlib/service/pages/resources/CMakeLists.linux-aarch64.txt b/library/cpp/monlib/service/pages/resources/CMakeLists.linux-aarch64.txt index b00466a43022..2680db6bdb70 100644 --- a/library/cpp/monlib/service/pages/resources/CMakeLists.linux-aarch64.txt +++ b/library/cpp/monlib/service/pages/resources/CMakeLists.linux-aarch64.txt @@ -21,6 +21,11 @@ target_link_libraries(service-pages-resources INTERFACE library-cpp-resource cpp-monlib-dynamic_counters ) +target_sources(service-pages-resources INTERFACE + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/service/pages/resources/css_mon_page.h + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/service/pages/resources/fonts_mon_page.h + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/service/pages/resources/js_mon_page.h +) add_global_library_for(service-pages-resources.global service-pages-resources) target_link_libraries(service-pages-resources.global PUBLIC diff --git a/library/cpp/monlib/service/pages/resources/CMakeLists.linux-x86_64.txt b/library/cpp/monlib/service/pages/resources/CMakeLists.linux-x86_64.txt index b00466a43022..2680db6bdb70 100644 --- a/library/cpp/monlib/service/pages/resources/CMakeLists.linux-x86_64.txt +++ b/library/cpp/monlib/service/pages/resources/CMakeLists.linux-x86_64.txt @@ -21,6 +21,11 @@ target_link_libraries(service-pages-resources INTERFACE library-cpp-resource cpp-monlib-dynamic_counters ) +target_sources(service-pages-resources INTERFACE + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/service/pages/resources/css_mon_page.h + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/service/pages/resources/fonts_mon_page.h + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/service/pages/resources/js_mon_page.h +) add_global_library_for(service-pages-resources.global service-pages-resources) target_link_libraries(service-pages-resources.global PUBLIC diff --git a/library/cpp/monlib/service/pages/resources/CMakeLists.windows-x86_64.txt b/library/cpp/monlib/service/pages/resources/CMakeLists.windows-x86_64.txt index f74d5e30a397..d61b00e7cc12 100644 --- a/library/cpp/monlib/service/pages/resources/CMakeLists.windows-x86_64.txt +++ b/library/cpp/monlib/service/pages/resources/CMakeLists.windows-x86_64.txt @@ -20,6 +20,11 @@ target_link_libraries(service-pages-resources INTERFACE library-cpp-resource cpp-monlib-dynamic_counters ) +target_sources(service-pages-resources INTERFACE + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/service/pages/resources/css_mon_page.h + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/service/pages/resources/fonts_mon_page.h + ${CMAKE_SOURCE_DIR}/library/cpp/monlib/service/pages/resources/js_mon_page.h +) add_global_library_for(service-pages-resources.global service-pages-resources) target_link_libraries(service-pages-resources.global PUBLIC diff --git a/library/cpp/packedtypes/CMakeLists.darwin-arm64.txt b/library/cpp/packedtypes/CMakeLists.darwin-arm64.txt index 9e3e6c0b53ee..0f2fb32b3c4c 100644 --- a/library/cpp/packedtypes/CMakeLists.darwin-arm64.txt +++ b/library/cpp/packedtypes/CMakeLists.darwin-arm64.txt @@ -14,6 +14,10 @@ target_link_libraries(library-cpp-packedtypes PUBLIC cpp-streams-zc_memory_input ) target_sources(library-cpp-packedtypes PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/fixed_point.h + ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/packed.h + ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/packedfloat.h + ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/zigzag.h ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/longs.cpp ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/packedfloat.cpp ) diff --git a/library/cpp/packedtypes/CMakeLists.darwin-x86_64.txt b/library/cpp/packedtypes/CMakeLists.darwin-x86_64.txt index 9e3e6c0b53ee..0f2fb32b3c4c 100644 --- a/library/cpp/packedtypes/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/packedtypes/CMakeLists.darwin-x86_64.txt @@ -14,6 +14,10 @@ target_link_libraries(library-cpp-packedtypes PUBLIC cpp-streams-zc_memory_input ) target_sources(library-cpp-packedtypes PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/fixed_point.h + ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/packed.h + ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/packedfloat.h + ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/zigzag.h ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/longs.cpp ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/packedfloat.cpp ) diff --git a/library/cpp/packedtypes/CMakeLists.linux-aarch64.txt b/library/cpp/packedtypes/CMakeLists.linux-aarch64.txt index d2705961bdff..68369683b45b 100644 --- a/library/cpp/packedtypes/CMakeLists.linux-aarch64.txt +++ b/library/cpp/packedtypes/CMakeLists.linux-aarch64.txt @@ -15,6 +15,10 @@ target_link_libraries(library-cpp-packedtypes PUBLIC cpp-streams-zc_memory_input ) target_sources(library-cpp-packedtypes PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/fixed_point.h + ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/packed.h + ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/packedfloat.h + ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/zigzag.h ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/longs.cpp ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/packedfloat.cpp ) diff --git a/library/cpp/packedtypes/CMakeLists.linux-x86_64.txt b/library/cpp/packedtypes/CMakeLists.linux-x86_64.txt index d2705961bdff..68369683b45b 100644 --- a/library/cpp/packedtypes/CMakeLists.linux-x86_64.txt +++ b/library/cpp/packedtypes/CMakeLists.linux-x86_64.txt @@ -15,6 +15,10 @@ target_link_libraries(library-cpp-packedtypes PUBLIC cpp-streams-zc_memory_input ) target_sources(library-cpp-packedtypes PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/fixed_point.h + ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/packed.h + ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/packedfloat.h + ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/zigzag.h ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/longs.cpp ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/packedfloat.cpp ) diff --git a/library/cpp/packedtypes/CMakeLists.windows-x86_64.txt b/library/cpp/packedtypes/CMakeLists.windows-x86_64.txt index 9e3e6c0b53ee..0f2fb32b3c4c 100644 --- a/library/cpp/packedtypes/CMakeLists.windows-x86_64.txt +++ b/library/cpp/packedtypes/CMakeLists.windows-x86_64.txt @@ -14,6 +14,10 @@ target_link_libraries(library-cpp-packedtypes PUBLIC cpp-streams-zc_memory_input ) target_sources(library-cpp-packedtypes PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/fixed_point.h + ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/packed.h + ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/packedfloat.h + ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/zigzag.h ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/longs.cpp ${CMAKE_SOURCE_DIR}/library/cpp/packedtypes/packedfloat.cpp ) diff --git a/library/cpp/protobuf/json/CMakeLists.darwin-arm64.txt b/library/cpp/protobuf/json/CMakeLists.darwin-arm64.txt index 6914995d2eed..7b73e78d9b99 100644 --- a/library/cpp/protobuf/json/CMakeLists.darwin-arm64.txt +++ b/library/cpp/protobuf/json/CMakeLists.darwin-arm64.txt @@ -19,6 +19,7 @@ target_link_libraries(cpp-protobuf-json PUBLIC cpp-string_utils-relaxed_escaper ) target_sources(cpp-protobuf-json PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/util.h ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/json2proto.cpp ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/json_output_create.cpp ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/json_value_output.cpp diff --git a/library/cpp/protobuf/json/CMakeLists.darwin-x86_64.txt b/library/cpp/protobuf/json/CMakeLists.darwin-x86_64.txt index 6914995d2eed..7b73e78d9b99 100644 --- a/library/cpp/protobuf/json/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/protobuf/json/CMakeLists.darwin-x86_64.txt @@ -19,6 +19,7 @@ target_link_libraries(cpp-protobuf-json PUBLIC cpp-string_utils-relaxed_escaper ) target_sources(cpp-protobuf-json PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/util.h ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/json2proto.cpp ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/json_output_create.cpp ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/json_value_output.cpp diff --git a/library/cpp/protobuf/json/CMakeLists.linux-aarch64.txt b/library/cpp/protobuf/json/CMakeLists.linux-aarch64.txt index e3f2a26102ac..547bb846c24c 100644 --- a/library/cpp/protobuf/json/CMakeLists.linux-aarch64.txt +++ b/library/cpp/protobuf/json/CMakeLists.linux-aarch64.txt @@ -20,6 +20,7 @@ target_link_libraries(cpp-protobuf-json PUBLIC cpp-string_utils-relaxed_escaper ) target_sources(cpp-protobuf-json PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/util.h ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/json2proto.cpp ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/json_output_create.cpp ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/json_value_output.cpp diff --git a/library/cpp/protobuf/json/CMakeLists.linux-x86_64.txt b/library/cpp/protobuf/json/CMakeLists.linux-x86_64.txt index e3f2a26102ac..547bb846c24c 100644 --- a/library/cpp/protobuf/json/CMakeLists.linux-x86_64.txt +++ b/library/cpp/protobuf/json/CMakeLists.linux-x86_64.txt @@ -20,6 +20,7 @@ target_link_libraries(cpp-protobuf-json PUBLIC cpp-string_utils-relaxed_escaper ) target_sources(cpp-protobuf-json PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/util.h ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/json2proto.cpp ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/json_output_create.cpp ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/json_value_output.cpp diff --git a/library/cpp/protobuf/json/CMakeLists.windows-x86_64.txt b/library/cpp/protobuf/json/CMakeLists.windows-x86_64.txt index 6914995d2eed..7b73e78d9b99 100644 --- a/library/cpp/protobuf/json/CMakeLists.windows-x86_64.txt +++ b/library/cpp/protobuf/json/CMakeLists.windows-x86_64.txt @@ -19,6 +19,7 @@ target_link_libraries(cpp-protobuf-json PUBLIC cpp-string_utils-relaxed_escaper ) target_sources(cpp-protobuf-json PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/util.h ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/json2proto.cpp ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/json_output_create.cpp ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/json_value_output.cpp diff --git a/library/cpp/protobuf/json/proto/CMakeLists.darwin-arm64.txt b/library/cpp/protobuf/json/proto/CMakeLists.darwin-arm64.txt index 6c6f4228c3a5..6dd50235e8b7 100644 --- a/library/cpp/protobuf/json/proto/CMakeLists.darwin-arm64.txt +++ b/library/cpp/protobuf/json/proto/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(protobuf-json-proto PUBLIC target_proto_messages(protobuf-json-proto PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/proto/enum_options.proto ) +target_sources(protobuf-json-proto PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/protobuf/json/proto/enum_options.pb.h +) target_proto_addincls(protobuf-json-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/protobuf/json/proto/CMakeLists.darwin-x86_64.txt b/library/cpp/protobuf/json/proto/CMakeLists.darwin-x86_64.txt index 6c6f4228c3a5..6dd50235e8b7 100644 --- a/library/cpp/protobuf/json/proto/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/protobuf/json/proto/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(protobuf-json-proto PUBLIC target_proto_messages(protobuf-json-proto PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/proto/enum_options.proto ) +target_sources(protobuf-json-proto PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/protobuf/json/proto/enum_options.pb.h +) target_proto_addincls(protobuf-json-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/protobuf/json/proto/CMakeLists.linux-aarch64.txt b/library/cpp/protobuf/json/proto/CMakeLists.linux-aarch64.txt index 1840a34ee654..84dd2c36ddd5 100644 --- a/library/cpp/protobuf/json/proto/CMakeLists.linux-aarch64.txt +++ b/library/cpp/protobuf/json/proto/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(protobuf-json-proto PUBLIC target_proto_messages(protobuf-json-proto PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/proto/enum_options.proto ) +target_sources(protobuf-json-proto PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/protobuf/json/proto/enum_options.pb.h +) target_proto_addincls(protobuf-json-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/protobuf/json/proto/CMakeLists.linux-x86_64.txt b/library/cpp/protobuf/json/proto/CMakeLists.linux-x86_64.txt index 1840a34ee654..84dd2c36ddd5 100644 --- a/library/cpp/protobuf/json/proto/CMakeLists.linux-x86_64.txt +++ b/library/cpp/protobuf/json/proto/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(protobuf-json-proto PUBLIC target_proto_messages(protobuf-json-proto PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/proto/enum_options.proto ) +target_sources(protobuf-json-proto PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/protobuf/json/proto/enum_options.pb.h +) target_proto_addincls(protobuf-json-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/protobuf/json/proto/CMakeLists.windows-x86_64.txt b/library/cpp/protobuf/json/proto/CMakeLists.windows-x86_64.txt index 6c6f4228c3a5..6dd50235e8b7 100644 --- a/library/cpp/protobuf/json/proto/CMakeLists.windows-x86_64.txt +++ b/library/cpp/protobuf/json/proto/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(protobuf-json-proto PUBLIC target_proto_messages(protobuf-json-proto PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/json/proto/enum_options.proto ) +target_sources(protobuf-json-proto PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/protobuf/json/proto/enum_options.pb.h +) target_proto_addincls(protobuf-json-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/protobuf/util/CMakeLists.darwin-arm64.txt b/library/cpp/protobuf/util/CMakeLists.darwin-arm64.txt index 51b65cd5b9be..dcf5a9eef72c 100644 --- a/library/cpp/protobuf/util/CMakeLists.darwin-arm64.txt +++ b/library/cpp/protobuf/util/CMakeLists.darwin-arm64.txt @@ -18,6 +18,9 @@ target_link_libraries(cpp-protobuf-util PUBLIC cpp-string_utils-base64 ) target_sources(cpp-protobuf-util PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/iterators.h + ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/pb_utils.h + ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/repeated_field_utils.h ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/is_equal.cpp ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/merge.cpp ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/path.cpp diff --git a/library/cpp/protobuf/util/CMakeLists.darwin-x86_64.txt b/library/cpp/protobuf/util/CMakeLists.darwin-x86_64.txt index 51b65cd5b9be..dcf5a9eef72c 100644 --- a/library/cpp/protobuf/util/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/protobuf/util/CMakeLists.darwin-x86_64.txt @@ -18,6 +18,9 @@ target_link_libraries(cpp-protobuf-util PUBLIC cpp-string_utils-base64 ) target_sources(cpp-protobuf-util PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/iterators.h + ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/pb_utils.h + ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/repeated_field_utils.h ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/is_equal.cpp ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/merge.cpp ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/path.cpp diff --git a/library/cpp/protobuf/util/CMakeLists.linux-aarch64.txt b/library/cpp/protobuf/util/CMakeLists.linux-aarch64.txt index 9ab7bb59e908..6f1e96e4fccd 100644 --- a/library/cpp/protobuf/util/CMakeLists.linux-aarch64.txt +++ b/library/cpp/protobuf/util/CMakeLists.linux-aarch64.txt @@ -19,6 +19,9 @@ target_link_libraries(cpp-protobuf-util PUBLIC cpp-string_utils-base64 ) target_sources(cpp-protobuf-util PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/iterators.h + ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/pb_utils.h + ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/repeated_field_utils.h ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/is_equal.cpp ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/merge.cpp ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/path.cpp diff --git a/library/cpp/protobuf/util/CMakeLists.linux-x86_64.txt b/library/cpp/protobuf/util/CMakeLists.linux-x86_64.txt index 9ab7bb59e908..6f1e96e4fccd 100644 --- a/library/cpp/protobuf/util/CMakeLists.linux-x86_64.txt +++ b/library/cpp/protobuf/util/CMakeLists.linux-x86_64.txt @@ -19,6 +19,9 @@ target_link_libraries(cpp-protobuf-util PUBLIC cpp-string_utils-base64 ) target_sources(cpp-protobuf-util PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/iterators.h + ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/pb_utils.h + ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/repeated_field_utils.h ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/is_equal.cpp ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/merge.cpp ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/path.cpp diff --git a/library/cpp/protobuf/util/CMakeLists.windows-x86_64.txt b/library/cpp/protobuf/util/CMakeLists.windows-x86_64.txt index 51b65cd5b9be..dcf5a9eef72c 100644 --- a/library/cpp/protobuf/util/CMakeLists.windows-x86_64.txt +++ b/library/cpp/protobuf/util/CMakeLists.windows-x86_64.txt @@ -18,6 +18,9 @@ target_link_libraries(cpp-protobuf-util PUBLIC cpp-string_utils-base64 ) target_sources(cpp-protobuf-util PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/iterators.h + ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/pb_utils.h + ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/repeated_field_utils.h ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/is_equal.cpp ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/merge.cpp ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/path.cpp diff --git a/library/cpp/protobuf/util/proto/CMakeLists.darwin-arm64.txt b/library/cpp/protobuf/util/proto/CMakeLists.darwin-arm64.txt index 7a58b4bfebdd..ed50e9c005bc 100644 --- a/library/cpp/protobuf/util/proto/CMakeLists.darwin-arm64.txt +++ b/library/cpp/protobuf/util/proto/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(protobuf-util-proto PUBLIC target_proto_messages(protobuf-util-proto PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/proto/merge.proto ) +target_sources(protobuf-util-proto PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/protobuf/util/proto/merge.pb.h +) target_proto_addincls(protobuf-util-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/protobuf/util/proto/CMakeLists.darwin-x86_64.txt b/library/cpp/protobuf/util/proto/CMakeLists.darwin-x86_64.txt index 7a58b4bfebdd..ed50e9c005bc 100644 --- a/library/cpp/protobuf/util/proto/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/protobuf/util/proto/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(protobuf-util-proto PUBLIC target_proto_messages(protobuf-util-proto PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/proto/merge.proto ) +target_sources(protobuf-util-proto PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/protobuf/util/proto/merge.pb.h +) target_proto_addincls(protobuf-util-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/protobuf/util/proto/CMakeLists.linux-aarch64.txt b/library/cpp/protobuf/util/proto/CMakeLists.linux-aarch64.txt index 5f08e7a6913d..0c512915cd23 100644 --- a/library/cpp/protobuf/util/proto/CMakeLists.linux-aarch64.txt +++ b/library/cpp/protobuf/util/proto/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(protobuf-util-proto PUBLIC target_proto_messages(protobuf-util-proto PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/proto/merge.proto ) +target_sources(protobuf-util-proto PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/protobuf/util/proto/merge.pb.h +) target_proto_addincls(protobuf-util-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/protobuf/util/proto/CMakeLists.linux-x86_64.txt b/library/cpp/protobuf/util/proto/CMakeLists.linux-x86_64.txt index 5f08e7a6913d..0c512915cd23 100644 --- a/library/cpp/protobuf/util/proto/CMakeLists.linux-x86_64.txt +++ b/library/cpp/protobuf/util/proto/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(protobuf-util-proto PUBLIC target_proto_messages(protobuf-util-proto PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/proto/merge.proto ) +target_sources(protobuf-util-proto PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/protobuf/util/proto/merge.pb.h +) target_proto_addincls(protobuf-util-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/protobuf/util/proto/CMakeLists.windows-x86_64.txt b/library/cpp/protobuf/util/proto/CMakeLists.windows-x86_64.txt index 7a58b4bfebdd..ed50e9c005bc 100644 --- a/library/cpp/protobuf/util/proto/CMakeLists.windows-x86_64.txt +++ b/library/cpp/protobuf/util/proto/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(protobuf-util-proto PUBLIC target_proto_messages(protobuf-util-proto PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/protobuf/util/proto/merge.proto ) +target_sources(protobuf-util-proto PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/protobuf/util/proto/merge.pb.h +) target_proto_addincls(protobuf-util-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/random_provider/CMakeLists.darwin-arm64.txt b/library/cpp/random_provider/CMakeLists.darwin-arm64.txt index ac70e71b915e..6bbb82259fea 100644 --- a/library/cpp/random_provider/CMakeLists.darwin-arm64.txt +++ b/library/cpp/random_provider/CMakeLists.darwin-arm64.txt @@ -13,5 +13,6 @@ target_link_libraries(library-cpp-random_provider PUBLIC yutil ) target_sources(library-cpp-random_provider PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/random_provider/random_provider.h ${CMAKE_SOURCE_DIR}/library/cpp/random_provider/random_provider.cpp ) diff --git a/library/cpp/random_provider/CMakeLists.darwin-x86_64.txt b/library/cpp/random_provider/CMakeLists.darwin-x86_64.txt index ac70e71b915e..6bbb82259fea 100644 --- a/library/cpp/random_provider/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/random_provider/CMakeLists.darwin-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(library-cpp-random_provider PUBLIC yutil ) target_sources(library-cpp-random_provider PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/random_provider/random_provider.h ${CMAKE_SOURCE_DIR}/library/cpp/random_provider/random_provider.cpp ) diff --git a/library/cpp/random_provider/CMakeLists.linux-aarch64.txt b/library/cpp/random_provider/CMakeLists.linux-aarch64.txt index 797bda818a9e..221fa29df124 100644 --- a/library/cpp/random_provider/CMakeLists.linux-aarch64.txt +++ b/library/cpp/random_provider/CMakeLists.linux-aarch64.txt @@ -14,5 +14,6 @@ target_link_libraries(library-cpp-random_provider PUBLIC yutil ) target_sources(library-cpp-random_provider PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/random_provider/random_provider.h ${CMAKE_SOURCE_DIR}/library/cpp/random_provider/random_provider.cpp ) diff --git a/library/cpp/random_provider/CMakeLists.linux-x86_64.txt b/library/cpp/random_provider/CMakeLists.linux-x86_64.txt index 797bda818a9e..221fa29df124 100644 --- a/library/cpp/random_provider/CMakeLists.linux-x86_64.txt +++ b/library/cpp/random_provider/CMakeLists.linux-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(library-cpp-random_provider PUBLIC yutil ) target_sources(library-cpp-random_provider PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/random_provider/random_provider.h ${CMAKE_SOURCE_DIR}/library/cpp/random_provider/random_provider.cpp ) diff --git a/library/cpp/random_provider/CMakeLists.windows-x86_64.txt b/library/cpp/random_provider/CMakeLists.windows-x86_64.txt index ac70e71b915e..6bbb82259fea 100644 --- a/library/cpp/random_provider/CMakeLists.windows-x86_64.txt +++ b/library/cpp/random_provider/CMakeLists.windows-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(library-cpp-random_provider PUBLIC yutil ) target_sources(library-cpp-random_provider PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/random_provider/random_provider.h ${CMAKE_SOURCE_DIR}/library/cpp/random_provider/random_provider.cpp ) diff --git a/library/cpp/regex/pire/CMakeLists.darwin-arm64.txt b/library/cpp/regex/pire/CMakeLists.darwin-arm64.txt index 1448b058e873..fe6fe744b6a5 100644 --- a/library/cpp/regex/pire/CMakeLists.darwin-arm64.txt +++ b/library/cpp/regex/pire/CMakeLists.darwin-arm64.txt @@ -21,6 +21,8 @@ target_link_libraries(cpp-regex-pire PUBLIC bison-bison-induced ) target_sources(cpp-regex-pire PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/regex/pire/__/__/__/__/contrib/libs/pire/pire/re_parser.h + ${CMAKE_SOURCE_DIR}/contrib/libs/pire/pire/minimize.h ${CMAKE_SOURCE_DIR}/library/cpp/regex/pire/pcre2pire.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/pire/pire/classes.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/pire/pire/encoding.cpp diff --git a/library/cpp/regex/pire/CMakeLists.darwin-x86_64.txt b/library/cpp/regex/pire/CMakeLists.darwin-x86_64.txt index 1448b058e873..fe6fe744b6a5 100644 --- a/library/cpp/regex/pire/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/regex/pire/CMakeLists.darwin-x86_64.txt @@ -21,6 +21,8 @@ target_link_libraries(cpp-regex-pire PUBLIC bison-bison-induced ) target_sources(cpp-regex-pire PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/regex/pire/__/__/__/__/contrib/libs/pire/pire/re_parser.h + ${CMAKE_SOURCE_DIR}/contrib/libs/pire/pire/minimize.h ${CMAKE_SOURCE_DIR}/library/cpp/regex/pire/pcre2pire.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/pire/pire/classes.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/pire/pire/encoding.cpp diff --git a/library/cpp/regex/pire/CMakeLists.linux-aarch64.txt b/library/cpp/regex/pire/CMakeLists.linux-aarch64.txt index 0fab775d7ab5..3f08e550520b 100644 --- a/library/cpp/regex/pire/CMakeLists.linux-aarch64.txt +++ b/library/cpp/regex/pire/CMakeLists.linux-aarch64.txt @@ -22,6 +22,8 @@ target_link_libraries(cpp-regex-pire PUBLIC bison-bison-induced ) target_sources(cpp-regex-pire PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/regex/pire/__/__/__/__/contrib/libs/pire/pire/re_parser.h + ${CMAKE_SOURCE_DIR}/contrib/libs/pire/pire/minimize.h ${CMAKE_SOURCE_DIR}/library/cpp/regex/pire/pcre2pire.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/pire/pire/classes.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/pire/pire/encoding.cpp diff --git a/library/cpp/regex/pire/CMakeLists.linux-x86_64.txt b/library/cpp/regex/pire/CMakeLists.linux-x86_64.txt index 0fab775d7ab5..3f08e550520b 100644 --- a/library/cpp/regex/pire/CMakeLists.linux-x86_64.txt +++ b/library/cpp/regex/pire/CMakeLists.linux-x86_64.txt @@ -22,6 +22,8 @@ target_link_libraries(cpp-regex-pire PUBLIC bison-bison-induced ) target_sources(cpp-regex-pire PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/regex/pire/__/__/__/__/contrib/libs/pire/pire/re_parser.h + ${CMAKE_SOURCE_DIR}/contrib/libs/pire/pire/minimize.h ${CMAKE_SOURCE_DIR}/library/cpp/regex/pire/pcre2pire.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/pire/pire/classes.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/pire/pire/encoding.cpp diff --git a/library/cpp/regex/pire/CMakeLists.windows-x86_64.txt b/library/cpp/regex/pire/CMakeLists.windows-x86_64.txt index 1448b058e873..fe6fe744b6a5 100644 --- a/library/cpp/regex/pire/CMakeLists.windows-x86_64.txt +++ b/library/cpp/regex/pire/CMakeLists.windows-x86_64.txt @@ -21,6 +21,8 @@ target_link_libraries(cpp-regex-pire PUBLIC bison-bison-induced ) target_sources(cpp-regex-pire PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/regex/pire/__/__/__/__/contrib/libs/pire/pire/re_parser.h + ${CMAKE_SOURCE_DIR}/contrib/libs/pire/pire/minimize.h ${CMAKE_SOURCE_DIR}/library/cpp/regex/pire/pcre2pire.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/pire/pire/classes.cpp ${CMAKE_SOURCE_DIR}/contrib/libs/pire/pire/encoding.cpp diff --git a/library/cpp/retry/protos/CMakeLists.darwin-arm64.txt b/library/cpp/retry/protos/CMakeLists.darwin-arm64.txt index ba41965df26d..7d924f8f6bb6 100644 --- a/library/cpp/retry/protos/CMakeLists.darwin-arm64.txt +++ b/library/cpp/retry/protos/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(cpp-retry-protos PUBLIC target_proto_messages(cpp-retry-protos PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/retry/protos/retry_options.proto ) +target_sources(cpp-retry-protos PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/retry/protos/retry_options.pb.h +) target_proto_addincls(cpp-retry-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/retry/protos/CMakeLists.darwin-x86_64.txt b/library/cpp/retry/protos/CMakeLists.darwin-x86_64.txt index ba41965df26d..7d924f8f6bb6 100644 --- a/library/cpp/retry/protos/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/retry/protos/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(cpp-retry-protos PUBLIC target_proto_messages(cpp-retry-protos PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/retry/protos/retry_options.proto ) +target_sources(cpp-retry-protos PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/retry/protos/retry_options.pb.h +) target_proto_addincls(cpp-retry-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/retry/protos/CMakeLists.linux-aarch64.txt b/library/cpp/retry/protos/CMakeLists.linux-aarch64.txt index 3c4f9aed25cd..361dffca6506 100644 --- a/library/cpp/retry/protos/CMakeLists.linux-aarch64.txt +++ b/library/cpp/retry/protos/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(cpp-retry-protos PUBLIC target_proto_messages(cpp-retry-protos PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/retry/protos/retry_options.proto ) +target_sources(cpp-retry-protos PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/retry/protos/retry_options.pb.h +) target_proto_addincls(cpp-retry-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/retry/protos/CMakeLists.linux-x86_64.txt b/library/cpp/retry/protos/CMakeLists.linux-x86_64.txt index 3c4f9aed25cd..361dffca6506 100644 --- a/library/cpp/retry/protos/CMakeLists.linux-x86_64.txt +++ b/library/cpp/retry/protos/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(cpp-retry-protos PUBLIC target_proto_messages(cpp-retry-protos PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/retry/protos/retry_options.proto ) +target_sources(cpp-retry-protos PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/retry/protos/retry_options.pb.h +) target_proto_addincls(cpp-retry-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/retry/protos/CMakeLists.windows-x86_64.txt b/library/cpp/retry/protos/CMakeLists.windows-x86_64.txt index ba41965df26d..7d924f8f6bb6 100644 --- a/library/cpp/retry/protos/CMakeLists.windows-x86_64.txt +++ b/library/cpp/retry/protos/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(cpp-retry-protos PUBLIC target_proto_messages(cpp-retry-protos PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/retry/protos/retry_options.proto ) +target_sources(cpp-retry-protos PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/retry/protos/retry_options.pb.h +) target_proto_addincls(cpp-retry-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/library/cpp/sanitizer/include/CMakeLists.darwin-arm64.txt b/library/cpp/sanitizer/include/CMakeLists.darwin-arm64.txt index a2871edfc28e..c6705a4cac02 100644 --- a/library/cpp/sanitizer/include/CMakeLists.darwin-arm64.txt +++ b/library/cpp/sanitizer/include/CMakeLists.darwin-arm64.txt @@ -9,5 +9,5 @@ add_library(cpp-sanitizer-include INTERFACE) target_include_directories(cpp-sanitizer-include INTERFACE - ${CMAKE_SOURCE_DIR}/contrib/libs/clang16-rt/include + ${CMAKE_SOURCE_DIR}/contrib/libs/clang14-rt/include ) diff --git a/library/cpp/sanitizer/include/CMakeLists.darwin-x86_64.txt b/library/cpp/sanitizer/include/CMakeLists.darwin-x86_64.txt index a2871edfc28e..c6705a4cac02 100644 --- a/library/cpp/sanitizer/include/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/sanitizer/include/CMakeLists.darwin-x86_64.txt @@ -9,5 +9,5 @@ add_library(cpp-sanitizer-include INTERFACE) target_include_directories(cpp-sanitizer-include INTERFACE - ${CMAKE_SOURCE_DIR}/contrib/libs/clang16-rt/include + ${CMAKE_SOURCE_DIR}/contrib/libs/clang14-rt/include ) diff --git a/library/cpp/sanitizer/include/CMakeLists.linux-aarch64.txt b/library/cpp/sanitizer/include/CMakeLists.linux-aarch64.txt index fa46dce697c1..ade2eca0b4ca 100644 --- a/library/cpp/sanitizer/include/CMakeLists.linux-aarch64.txt +++ b/library/cpp/sanitizer/include/CMakeLists.linux-aarch64.txt @@ -9,7 +9,7 @@ add_library(cpp-sanitizer-include INTERFACE) target_include_directories(cpp-sanitizer-include INTERFACE - ${CMAKE_SOURCE_DIR}/contrib/libs/clang16-rt/include + ${CMAKE_SOURCE_DIR}/contrib/libs/clang14-rt/include ) target_link_libraries(cpp-sanitizer-include INTERFACE contrib-libs-linux-headers diff --git a/library/cpp/sanitizer/include/CMakeLists.linux-x86_64.txt b/library/cpp/sanitizer/include/CMakeLists.linux-x86_64.txt index fa46dce697c1..ade2eca0b4ca 100644 --- a/library/cpp/sanitizer/include/CMakeLists.linux-x86_64.txt +++ b/library/cpp/sanitizer/include/CMakeLists.linux-x86_64.txt @@ -9,7 +9,7 @@ add_library(cpp-sanitizer-include INTERFACE) target_include_directories(cpp-sanitizer-include INTERFACE - ${CMAKE_SOURCE_DIR}/contrib/libs/clang16-rt/include + ${CMAKE_SOURCE_DIR}/contrib/libs/clang14-rt/include ) target_link_libraries(cpp-sanitizer-include INTERFACE contrib-libs-linux-headers diff --git a/library/cpp/scheme/CMakeLists.darwin-arm64.txt b/library/cpp/scheme/CMakeLists.darwin-arm64.txt index 851add2e6cd9..f791eb18d6fe 100644 --- a/library/cpp/scheme/CMakeLists.darwin-arm64.txt +++ b/library/cpp/scheme/CMakeLists.darwin-arm64.txt @@ -23,6 +23,9 @@ target_link_libraries(library-cpp-scheme PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(library-cpp-scheme PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scheme_cast.h + ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scimpl.h + ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scimpl_defs.h ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scheme.cpp ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scimpl_private.cpp ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scimpl_protobuf.cpp diff --git a/library/cpp/scheme/CMakeLists.darwin-x86_64.txt b/library/cpp/scheme/CMakeLists.darwin-x86_64.txt index 851add2e6cd9..f791eb18d6fe 100644 --- a/library/cpp/scheme/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/scheme/CMakeLists.darwin-x86_64.txt @@ -23,6 +23,9 @@ target_link_libraries(library-cpp-scheme PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(library-cpp-scheme PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scheme_cast.h + ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scimpl.h + ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scimpl_defs.h ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scheme.cpp ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scimpl_private.cpp ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scimpl_protobuf.cpp diff --git a/library/cpp/scheme/CMakeLists.linux-aarch64.txt b/library/cpp/scheme/CMakeLists.linux-aarch64.txt index 39139ce3c86a..a4c85102a843 100644 --- a/library/cpp/scheme/CMakeLists.linux-aarch64.txt +++ b/library/cpp/scheme/CMakeLists.linux-aarch64.txt @@ -24,6 +24,9 @@ target_link_libraries(library-cpp-scheme PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(library-cpp-scheme PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scheme_cast.h + ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scimpl.h + ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scimpl_defs.h ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scheme.cpp ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scimpl_private.cpp ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scimpl_protobuf.cpp diff --git a/library/cpp/scheme/CMakeLists.linux-x86_64.txt b/library/cpp/scheme/CMakeLists.linux-x86_64.txt index 39139ce3c86a..a4c85102a843 100644 --- a/library/cpp/scheme/CMakeLists.linux-x86_64.txt +++ b/library/cpp/scheme/CMakeLists.linux-x86_64.txt @@ -24,6 +24,9 @@ target_link_libraries(library-cpp-scheme PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(library-cpp-scheme PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scheme_cast.h + ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scimpl.h + ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scimpl_defs.h ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scheme.cpp ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scimpl_private.cpp ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scimpl_protobuf.cpp diff --git a/library/cpp/scheme/CMakeLists.windows-x86_64.txt b/library/cpp/scheme/CMakeLists.windows-x86_64.txt index a08385558d31..5621529bcd56 100644 --- a/library/cpp/scheme/CMakeLists.windows-x86_64.txt +++ b/library/cpp/scheme/CMakeLists.windows-x86_64.txt @@ -23,6 +23,9 @@ target_link_libraries(library-cpp-scheme PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(library-cpp-scheme PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scheme_cast.h + ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scimpl.h + ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scimpl_defs.h ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scheme.cpp ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scimpl_private.cpp ${CMAKE_SOURCE_DIR}/library/cpp/scheme/scimpl_protobuf.cpp diff --git a/library/cpp/sighandler/CMakeLists.darwin-arm64.txt b/library/cpp/sighandler/CMakeLists.darwin-arm64.txt index 3f330b9bb514..e5b921a59f45 100644 --- a/library/cpp/sighandler/CMakeLists.darwin-arm64.txt +++ b/library/cpp/sighandler/CMakeLists.darwin-arm64.txt @@ -14,5 +14,6 @@ target_link_libraries(library-cpp-sighandler PUBLIC cpp-deprecated-atomic ) target_sources(library-cpp-sighandler PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/sighandler/async_signals_handler.h ${CMAKE_SOURCE_DIR}/library/cpp/sighandler/async_signals_handler.cpp ) diff --git a/library/cpp/sighandler/CMakeLists.darwin-x86_64.txt b/library/cpp/sighandler/CMakeLists.darwin-x86_64.txt index 3f330b9bb514..e5b921a59f45 100644 --- a/library/cpp/sighandler/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/sighandler/CMakeLists.darwin-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(library-cpp-sighandler PUBLIC cpp-deprecated-atomic ) target_sources(library-cpp-sighandler PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/sighandler/async_signals_handler.h ${CMAKE_SOURCE_DIR}/library/cpp/sighandler/async_signals_handler.cpp ) diff --git a/library/cpp/sighandler/CMakeLists.linux-aarch64.txt b/library/cpp/sighandler/CMakeLists.linux-aarch64.txt index 73b4b95275cc..3ffae3f4259d 100644 --- a/library/cpp/sighandler/CMakeLists.linux-aarch64.txt +++ b/library/cpp/sighandler/CMakeLists.linux-aarch64.txt @@ -15,5 +15,6 @@ target_link_libraries(library-cpp-sighandler PUBLIC cpp-deprecated-atomic ) target_sources(library-cpp-sighandler PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/sighandler/async_signals_handler.h ${CMAKE_SOURCE_DIR}/library/cpp/sighandler/async_signals_handler.cpp ) diff --git a/library/cpp/sighandler/CMakeLists.linux-x86_64.txt b/library/cpp/sighandler/CMakeLists.linux-x86_64.txt index 73b4b95275cc..3ffae3f4259d 100644 --- a/library/cpp/sighandler/CMakeLists.linux-x86_64.txt +++ b/library/cpp/sighandler/CMakeLists.linux-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(library-cpp-sighandler PUBLIC cpp-deprecated-atomic ) target_sources(library-cpp-sighandler PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/sighandler/async_signals_handler.h ${CMAKE_SOURCE_DIR}/library/cpp/sighandler/async_signals_handler.cpp ) diff --git a/library/cpp/sighandler/CMakeLists.windows-x86_64.txt b/library/cpp/sighandler/CMakeLists.windows-x86_64.txt index 3f330b9bb514..e5b921a59f45 100644 --- a/library/cpp/sighandler/CMakeLists.windows-x86_64.txt +++ b/library/cpp/sighandler/CMakeLists.windows-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(library-cpp-sighandler PUBLIC cpp-deprecated-atomic ) target_sources(library-cpp-sighandler PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/sighandler/async_signals_handler.h ${CMAKE_SOURCE_DIR}/library/cpp/sighandler/async_signals_handler.cpp ) diff --git a/library/cpp/sliding_window/CMakeLists.darwin-arm64.txt b/library/cpp/sliding_window/CMakeLists.darwin-arm64.txt index 15be6f0095d8..f3a82f86431d 100644 --- a/library/cpp/sliding_window/CMakeLists.darwin-arm64.txt +++ b/library/cpp/sliding_window/CMakeLists.darwin-arm64.txt @@ -13,5 +13,6 @@ target_link_libraries(library-cpp-sliding_window PUBLIC yutil ) target_sources(library-cpp-sliding_window PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/sliding_window/sliding_window.h ${CMAKE_SOURCE_DIR}/library/cpp/sliding_window/sliding_window.cpp ) diff --git a/library/cpp/sliding_window/CMakeLists.darwin-x86_64.txt b/library/cpp/sliding_window/CMakeLists.darwin-x86_64.txt index 15be6f0095d8..f3a82f86431d 100644 --- a/library/cpp/sliding_window/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/sliding_window/CMakeLists.darwin-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(library-cpp-sliding_window PUBLIC yutil ) target_sources(library-cpp-sliding_window PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/sliding_window/sliding_window.h ${CMAKE_SOURCE_DIR}/library/cpp/sliding_window/sliding_window.cpp ) diff --git a/library/cpp/sliding_window/CMakeLists.linux-aarch64.txt b/library/cpp/sliding_window/CMakeLists.linux-aarch64.txt index 110e2807e9b8..df458ad81ac8 100644 --- a/library/cpp/sliding_window/CMakeLists.linux-aarch64.txt +++ b/library/cpp/sliding_window/CMakeLists.linux-aarch64.txt @@ -14,5 +14,6 @@ target_link_libraries(library-cpp-sliding_window PUBLIC yutil ) target_sources(library-cpp-sliding_window PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/sliding_window/sliding_window.h ${CMAKE_SOURCE_DIR}/library/cpp/sliding_window/sliding_window.cpp ) diff --git a/library/cpp/sliding_window/CMakeLists.linux-x86_64.txt b/library/cpp/sliding_window/CMakeLists.linux-x86_64.txt index 110e2807e9b8..df458ad81ac8 100644 --- a/library/cpp/sliding_window/CMakeLists.linux-x86_64.txt +++ b/library/cpp/sliding_window/CMakeLists.linux-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(library-cpp-sliding_window PUBLIC yutil ) target_sources(library-cpp-sliding_window PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/sliding_window/sliding_window.h ${CMAKE_SOURCE_DIR}/library/cpp/sliding_window/sliding_window.cpp ) diff --git a/library/cpp/sliding_window/CMakeLists.windows-x86_64.txt b/library/cpp/sliding_window/CMakeLists.windows-x86_64.txt index 15be6f0095d8..f3a82f86431d 100644 --- a/library/cpp/sliding_window/CMakeLists.windows-x86_64.txt +++ b/library/cpp/sliding_window/CMakeLists.windows-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(library-cpp-sliding_window PUBLIC yutil ) target_sources(library-cpp-sliding_window PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/sliding_window/sliding_window.h ${CMAKE_SOURCE_DIR}/library/cpp/sliding_window/sliding_window.cpp ) diff --git a/library/cpp/string_utils/parse_size/CMakeLists.darwin-arm64.txt b/library/cpp/string_utils/parse_size/CMakeLists.darwin-arm64.txt index 5cd758efec8f..d512fa26ee0d 100644 --- a/library/cpp/string_utils/parse_size/CMakeLists.darwin-arm64.txt +++ b/library/cpp/string_utils/parse_size/CMakeLists.darwin-arm64.txt @@ -13,5 +13,6 @@ target_link_libraries(cpp-string_utils-parse_size PUBLIC yutil ) target_sources(cpp-string_utils-parse_size PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/parse_size/parse_size.h ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/parse_size/parse_size.cpp ) diff --git a/library/cpp/string_utils/parse_size/CMakeLists.darwin-x86_64.txt b/library/cpp/string_utils/parse_size/CMakeLists.darwin-x86_64.txt index 5cd758efec8f..d512fa26ee0d 100644 --- a/library/cpp/string_utils/parse_size/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/string_utils/parse_size/CMakeLists.darwin-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(cpp-string_utils-parse_size PUBLIC yutil ) target_sources(cpp-string_utils-parse_size PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/parse_size/parse_size.h ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/parse_size/parse_size.cpp ) diff --git a/library/cpp/string_utils/parse_size/CMakeLists.linux-aarch64.txt b/library/cpp/string_utils/parse_size/CMakeLists.linux-aarch64.txt index c50fd344c4ec..529812f55d07 100644 --- a/library/cpp/string_utils/parse_size/CMakeLists.linux-aarch64.txt +++ b/library/cpp/string_utils/parse_size/CMakeLists.linux-aarch64.txt @@ -14,5 +14,6 @@ target_link_libraries(cpp-string_utils-parse_size PUBLIC yutil ) target_sources(cpp-string_utils-parse_size PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/parse_size/parse_size.h ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/parse_size/parse_size.cpp ) diff --git a/library/cpp/string_utils/parse_size/CMakeLists.linux-x86_64.txt b/library/cpp/string_utils/parse_size/CMakeLists.linux-x86_64.txt index c50fd344c4ec..529812f55d07 100644 --- a/library/cpp/string_utils/parse_size/CMakeLists.linux-x86_64.txt +++ b/library/cpp/string_utils/parse_size/CMakeLists.linux-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(cpp-string_utils-parse_size PUBLIC yutil ) target_sources(cpp-string_utils-parse_size PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/parse_size/parse_size.h ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/parse_size/parse_size.cpp ) diff --git a/library/cpp/string_utils/parse_size/CMakeLists.windows-x86_64.txt b/library/cpp/string_utils/parse_size/CMakeLists.windows-x86_64.txt index 5cd758efec8f..d512fa26ee0d 100644 --- a/library/cpp/string_utils/parse_size/CMakeLists.windows-x86_64.txt +++ b/library/cpp/string_utils/parse_size/CMakeLists.windows-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(cpp-string_utils-parse_size PUBLIC yutil ) target_sources(cpp-string_utils-parse_size PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/parse_size/parse_size.h ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/parse_size/parse_size.cpp ) diff --git a/library/cpp/string_utils/quote/CMakeLists.darwin-arm64.txt b/library/cpp/string_utils/quote/CMakeLists.darwin-arm64.txt index e2bedf1e187b..e374c709abee 100644 --- a/library/cpp/string_utils/quote/CMakeLists.darwin-arm64.txt +++ b/library/cpp/string_utils/quote/CMakeLists.darwin-arm64.txt @@ -13,5 +13,6 @@ target_link_libraries(cpp-string_utils-quote PUBLIC yutil ) target_sources(cpp-string_utils-quote PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/quote/quote.h ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/quote/quote.cpp ) diff --git a/library/cpp/string_utils/quote/CMakeLists.darwin-x86_64.txt b/library/cpp/string_utils/quote/CMakeLists.darwin-x86_64.txt index e2bedf1e187b..e374c709abee 100644 --- a/library/cpp/string_utils/quote/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/string_utils/quote/CMakeLists.darwin-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(cpp-string_utils-quote PUBLIC yutil ) target_sources(cpp-string_utils-quote PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/quote/quote.h ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/quote/quote.cpp ) diff --git a/library/cpp/string_utils/quote/CMakeLists.linux-aarch64.txt b/library/cpp/string_utils/quote/CMakeLists.linux-aarch64.txt index 28d1aabe8d24..bed3e277ffa0 100644 --- a/library/cpp/string_utils/quote/CMakeLists.linux-aarch64.txt +++ b/library/cpp/string_utils/quote/CMakeLists.linux-aarch64.txt @@ -14,5 +14,6 @@ target_link_libraries(cpp-string_utils-quote PUBLIC yutil ) target_sources(cpp-string_utils-quote PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/quote/quote.h ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/quote/quote.cpp ) diff --git a/library/cpp/string_utils/quote/CMakeLists.linux-x86_64.txt b/library/cpp/string_utils/quote/CMakeLists.linux-x86_64.txt index 28d1aabe8d24..bed3e277ffa0 100644 --- a/library/cpp/string_utils/quote/CMakeLists.linux-x86_64.txt +++ b/library/cpp/string_utils/quote/CMakeLists.linux-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(cpp-string_utils-quote PUBLIC yutil ) target_sources(cpp-string_utils-quote PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/quote/quote.h ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/quote/quote.cpp ) diff --git a/library/cpp/string_utils/quote/CMakeLists.windows-x86_64.txt b/library/cpp/string_utils/quote/CMakeLists.windows-x86_64.txt index e2bedf1e187b..e374c709abee 100644 --- a/library/cpp/string_utils/quote/CMakeLists.windows-x86_64.txt +++ b/library/cpp/string_utils/quote/CMakeLists.windows-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(cpp-string_utils-quote PUBLIC yutil ) target_sources(cpp-string_utils-quote PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/quote/quote.h ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/quote/quote.cpp ) diff --git a/library/cpp/string_utils/url/CMakeLists.darwin-arm64.txt b/library/cpp/string_utils/url/CMakeLists.darwin-arm64.txt index 672139e643ec..979c37081948 100644 --- a/library/cpp/string_utils/url/CMakeLists.darwin-arm64.txt +++ b/library/cpp/string_utils/url/CMakeLists.darwin-arm64.txt @@ -13,5 +13,6 @@ target_link_libraries(cpp-string_utils-url PUBLIC yutil ) target_sources(cpp-string_utils-url PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/url/url.h ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/url/url.cpp ) diff --git a/library/cpp/string_utils/url/CMakeLists.darwin-x86_64.txt b/library/cpp/string_utils/url/CMakeLists.darwin-x86_64.txt index 672139e643ec..979c37081948 100644 --- a/library/cpp/string_utils/url/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/string_utils/url/CMakeLists.darwin-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(cpp-string_utils-url PUBLIC yutil ) target_sources(cpp-string_utils-url PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/url/url.h ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/url/url.cpp ) diff --git a/library/cpp/string_utils/url/CMakeLists.linux-aarch64.txt b/library/cpp/string_utils/url/CMakeLists.linux-aarch64.txt index b84dcb3263d0..cdfdc913cd21 100644 --- a/library/cpp/string_utils/url/CMakeLists.linux-aarch64.txt +++ b/library/cpp/string_utils/url/CMakeLists.linux-aarch64.txt @@ -14,5 +14,6 @@ target_link_libraries(cpp-string_utils-url PUBLIC yutil ) target_sources(cpp-string_utils-url PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/url/url.h ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/url/url.cpp ) diff --git a/library/cpp/string_utils/url/CMakeLists.linux-x86_64.txt b/library/cpp/string_utils/url/CMakeLists.linux-x86_64.txt index b84dcb3263d0..cdfdc913cd21 100644 --- a/library/cpp/string_utils/url/CMakeLists.linux-x86_64.txt +++ b/library/cpp/string_utils/url/CMakeLists.linux-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(cpp-string_utils-url PUBLIC yutil ) target_sources(cpp-string_utils-url PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/url/url.h ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/url/url.cpp ) diff --git a/library/cpp/string_utils/url/CMakeLists.windows-x86_64.txt b/library/cpp/string_utils/url/CMakeLists.windows-x86_64.txt index 672139e643ec..979c37081948 100644 --- a/library/cpp/string_utils/url/CMakeLists.windows-x86_64.txt +++ b/library/cpp/string_utils/url/CMakeLists.windows-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(cpp-string_utils-url PUBLIC yutil ) target_sources(cpp-string_utils-url PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/url/url.h ${CMAKE_SOURCE_DIR}/library/cpp/string_utils/url/url.cpp ) diff --git a/library/cpp/tdigest/CMakeLists.darwin-arm64.txt b/library/cpp/tdigest/CMakeLists.darwin-arm64.txt index 9dd7437db0ae..8b8484722289 100644 --- a/library/cpp/tdigest/CMakeLists.darwin-arm64.txt +++ b/library/cpp/tdigest/CMakeLists.darwin-arm64.txt @@ -29,6 +29,7 @@ target_proto_messages(library-cpp-tdigest PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/tdigest/tdigest.proto ) target_sources(library-cpp-tdigest PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/tdigest/tdigest.pb.h ${CMAKE_SOURCE_DIR}/library/cpp/tdigest/tdigest.cpp ) target_proto_addincls(library-cpp-tdigest diff --git a/library/cpp/tdigest/CMakeLists.darwin-x86_64.txt b/library/cpp/tdigest/CMakeLists.darwin-x86_64.txt index 9dd7437db0ae..8b8484722289 100644 --- a/library/cpp/tdigest/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/tdigest/CMakeLists.darwin-x86_64.txt @@ -29,6 +29,7 @@ target_proto_messages(library-cpp-tdigest PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/tdigest/tdigest.proto ) target_sources(library-cpp-tdigest PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/tdigest/tdigest.pb.h ${CMAKE_SOURCE_DIR}/library/cpp/tdigest/tdigest.cpp ) target_proto_addincls(library-cpp-tdigest diff --git a/library/cpp/tdigest/CMakeLists.linux-aarch64.txt b/library/cpp/tdigest/CMakeLists.linux-aarch64.txt index 2fdc4b7b1259..de551fbf8acc 100644 --- a/library/cpp/tdigest/CMakeLists.linux-aarch64.txt +++ b/library/cpp/tdigest/CMakeLists.linux-aarch64.txt @@ -30,6 +30,7 @@ target_proto_messages(library-cpp-tdigest PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/tdigest/tdigest.proto ) target_sources(library-cpp-tdigest PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/tdigest/tdigest.pb.h ${CMAKE_SOURCE_DIR}/library/cpp/tdigest/tdigest.cpp ) target_proto_addincls(library-cpp-tdigest diff --git a/library/cpp/tdigest/CMakeLists.linux-x86_64.txt b/library/cpp/tdigest/CMakeLists.linux-x86_64.txt index 2fdc4b7b1259..de551fbf8acc 100644 --- a/library/cpp/tdigest/CMakeLists.linux-x86_64.txt +++ b/library/cpp/tdigest/CMakeLists.linux-x86_64.txt @@ -30,6 +30,7 @@ target_proto_messages(library-cpp-tdigest PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/tdigest/tdigest.proto ) target_sources(library-cpp-tdigest PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/tdigest/tdigest.pb.h ${CMAKE_SOURCE_DIR}/library/cpp/tdigest/tdigest.cpp ) target_proto_addincls(library-cpp-tdigest diff --git a/library/cpp/tdigest/CMakeLists.windows-x86_64.txt b/library/cpp/tdigest/CMakeLists.windows-x86_64.txt index 9dd7437db0ae..8b8484722289 100644 --- a/library/cpp/tdigest/CMakeLists.windows-x86_64.txt +++ b/library/cpp/tdigest/CMakeLists.windows-x86_64.txt @@ -29,6 +29,7 @@ target_proto_messages(library-cpp-tdigest PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/tdigest/tdigest.proto ) target_sources(library-cpp-tdigest PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/tdigest/tdigest.pb.h ${CMAKE_SOURCE_DIR}/library/cpp/tdigest/tdigest.cpp ) target_proto_addincls(library-cpp-tdigest diff --git a/library/cpp/threading/equeue/CMakeLists.darwin-arm64.txt b/library/cpp/threading/equeue/CMakeLists.darwin-arm64.txt index 902b6d7a9acd..5e20bafaf93d 100644 --- a/library/cpp/threading/equeue/CMakeLists.darwin-arm64.txt +++ b/library/cpp/threading/equeue/CMakeLists.darwin-arm64.txt @@ -14,5 +14,6 @@ target_link_libraries(cpp-threading-equeue PUBLIC cpp-deprecated-atomic ) target_sources(cpp-threading-equeue PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/threading/equeue/equeue.h ${CMAKE_SOURCE_DIR}/library/cpp/threading/equeue/equeue.cpp ) diff --git a/library/cpp/threading/equeue/CMakeLists.darwin-x86_64.txt b/library/cpp/threading/equeue/CMakeLists.darwin-x86_64.txt index 902b6d7a9acd..5e20bafaf93d 100644 --- a/library/cpp/threading/equeue/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/threading/equeue/CMakeLists.darwin-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(cpp-threading-equeue PUBLIC cpp-deprecated-atomic ) target_sources(cpp-threading-equeue PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/threading/equeue/equeue.h ${CMAKE_SOURCE_DIR}/library/cpp/threading/equeue/equeue.cpp ) diff --git a/library/cpp/threading/equeue/CMakeLists.linux-aarch64.txt b/library/cpp/threading/equeue/CMakeLists.linux-aarch64.txt index 5653d3d3f3fd..e8744435557e 100644 --- a/library/cpp/threading/equeue/CMakeLists.linux-aarch64.txt +++ b/library/cpp/threading/equeue/CMakeLists.linux-aarch64.txt @@ -15,5 +15,6 @@ target_link_libraries(cpp-threading-equeue PUBLIC cpp-deprecated-atomic ) target_sources(cpp-threading-equeue PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/threading/equeue/equeue.h ${CMAKE_SOURCE_DIR}/library/cpp/threading/equeue/equeue.cpp ) diff --git a/library/cpp/threading/equeue/CMakeLists.linux-x86_64.txt b/library/cpp/threading/equeue/CMakeLists.linux-x86_64.txt index 5653d3d3f3fd..e8744435557e 100644 --- a/library/cpp/threading/equeue/CMakeLists.linux-x86_64.txt +++ b/library/cpp/threading/equeue/CMakeLists.linux-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(cpp-threading-equeue PUBLIC cpp-deprecated-atomic ) target_sources(cpp-threading-equeue PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/threading/equeue/equeue.h ${CMAKE_SOURCE_DIR}/library/cpp/threading/equeue/equeue.cpp ) diff --git a/library/cpp/threading/equeue/CMakeLists.windows-x86_64.txt b/library/cpp/threading/equeue/CMakeLists.windows-x86_64.txt index 902b6d7a9acd..5e20bafaf93d 100644 --- a/library/cpp/threading/equeue/CMakeLists.windows-x86_64.txt +++ b/library/cpp/threading/equeue/CMakeLists.windows-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(cpp-threading-equeue PUBLIC cpp-deprecated-atomic ) target_sources(cpp-threading-equeue PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/threading/equeue/equeue.h ${CMAKE_SOURCE_DIR}/library/cpp/threading/equeue/equeue.cpp ) diff --git a/library/cpp/threading/light_rw_lock/CMakeLists.darwin-arm64.txt b/library/cpp/threading/light_rw_lock/CMakeLists.darwin-arm64.txt index 934c52018ecc..d31cb4ca9104 100644 --- a/library/cpp/threading/light_rw_lock/CMakeLists.darwin-arm64.txt +++ b/library/cpp/threading/light_rw_lock/CMakeLists.darwin-arm64.txt @@ -13,5 +13,6 @@ target_link_libraries(cpp-threading-light_rw_lock PUBLIC yutil ) target_sources(cpp-threading-light_rw_lock PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/threading/light_rw_lock/lightrwlock.h ${CMAKE_SOURCE_DIR}/library/cpp/threading/light_rw_lock/lightrwlock.cpp ) diff --git a/library/cpp/threading/light_rw_lock/CMakeLists.darwin-x86_64.txt b/library/cpp/threading/light_rw_lock/CMakeLists.darwin-x86_64.txt index 934c52018ecc..d31cb4ca9104 100644 --- a/library/cpp/threading/light_rw_lock/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/threading/light_rw_lock/CMakeLists.darwin-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(cpp-threading-light_rw_lock PUBLIC yutil ) target_sources(cpp-threading-light_rw_lock PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/threading/light_rw_lock/lightrwlock.h ${CMAKE_SOURCE_DIR}/library/cpp/threading/light_rw_lock/lightrwlock.cpp ) diff --git a/library/cpp/threading/light_rw_lock/CMakeLists.linux-aarch64.txt b/library/cpp/threading/light_rw_lock/CMakeLists.linux-aarch64.txt index 2f54f7fe5b7b..d42b5f1c2b24 100644 --- a/library/cpp/threading/light_rw_lock/CMakeLists.linux-aarch64.txt +++ b/library/cpp/threading/light_rw_lock/CMakeLists.linux-aarch64.txt @@ -14,5 +14,6 @@ target_link_libraries(cpp-threading-light_rw_lock PUBLIC yutil ) target_sources(cpp-threading-light_rw_lock PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/threading/light_rw_lock/lightrwlock.h ${CMAKE_SOURCE_DIR}/library/cpp/threading/light_rw_lock/lightrwlock.cpp ) diff --git a/library/cpp/threading/light_rw_lock/CMakeLists.linux-x86_64.txt b/library/cpp/threading/light_rw_lock/CMakeLists.linux-x86_64.txt index 2f54f7fe5b7b..d42b5f1c2b24 100644 --- a/library/cpp/threading/light_rw_lock/CMakeLists.linux-x86_64.txt +++ b/library/cpp/threading/light_rw_lock/CMakeLists.linux-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(cpp-threading-light_rw_lock PUBLIC yutil ) target_sources(cpp-threading-light_rw_lock PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/threading/light_rw_lock/lightrwlock.h ${CMAKE_SOURCE_DIR}/library/cpp/threading/light_rw_lock/lightrwlock.cpp ) diff --git a/library/cpp/threading/light_rw_lock/CMakeLists.windows-x86_64.txt b/library/cpp/threading/light_rw_lock/CMakeLists.windows-x86_64.txt index 934c52018ecc..d31cb4ca9104 100644 --- a/library/cpp/threading/light_rw_lock/CMakeLists.windows-x86_64.txt +++ b/library/cpp/threading/light_rw_lock/CMakeLists.windows-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(cpp-threading-light_rw_lock PUBLIC yutil ) target_sources(cpp-threading-light_rw_lock PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/threading/light_rw_lock/lightrwlock.h ${CMAKE_SOURCE_DIR}/library/cpp/threading/light_rw_lock/lightrwlock.cpp ) diff --git a/library/cpp/threading/queue/CMakeLists.darwin-arm64.txt b/library/cpp/threading/queue/CMakeLists.darwin-arm64.txt index ff0797688e72..410d713d74f6 100644 --- a/library/cpp/threading/queue/CMakeLists.darwin-arm64.txt +++ b/library/cpp/threading/queue/CMakeLists.darwin-arm64.txt @@ -14,6 +14,11 @@ target_link_libraries(cpp-threading-queue PUBLIC cpp-deprecated-atomic ) target_sources(cpp-threading-queue PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpmc_unordered_ring.h + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_htswap.h + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_intrusive_unordered.h + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_read_as_filled.h + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_vinfarr_obstructive.h ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpmc_unordered_ring.cpp ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_htswap.cpp ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_intrusive_unordered.cpp diff --git a/library/cpp/threading/queue/CMakeLists.darwin-x86_64.txt b/library/cpp/threading/queue/CMakeLists.darwin-x86_64.txt index ff0797688e72..410d713d74f6 100644 --- a/library/cpp/threading/queue/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/threading/queue/CMakeLists.darwin-x86_64.txt @@ -14,6 +14,11 @@ target_link_libraries(cpp-threading-queue PUBLIC cpp-deprecated-atomic ) target_sources(cpp-threading-queue PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpmc_unordered_ring.h + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_htswap.h + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_intrusive_unordered.h + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_read_as_filled.h + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_vinfarr_obstructive.h ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpmc_unordered_ring.cpp ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_htswap.cpp ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_intrusive_unordered.cpp diff --git a/library/cpp/threading/queue/CMakeLists.linux-aarch64.txt b/library/cpp/threading/queue/CMakeLists.linux-aarch64.txt index c6338ea17b00..caf9b0fd1684 100644 --- a/library/cpp/threading/queue/CMakeLists.linux-aarch64.txt +++ b/library/cpp/threading/queue/CMakeLists.linux-aarch64.txt @@ -15,6 +15,11 @@ target_link_libraries(cpp-threading-queue PUBLIC cpp-deprecated-atomic ) target_sources(cpp-threading-queue PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpmc_unordered_ring.h + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_htswap.h + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_intrusive_unordered.h + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_read_as_filled.h + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_vinfarr_obstructive.h ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpmc_unordered_ring.cpp ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_htswap.cpp ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_intrusive_unordered.cpp diff --git a/library/cpp/threading/queue/CMakeLists.linux-x86_64.txt b/library/cpp/threading/queue/CMakeLists.linux-x86_64.txt index c6338ea17b00..caf9b0fd1684 100644 --- a/library/cpp/threading/queue/CMakeLists.linux-x86_64.txt +++ b/library/cpp/threading/queue/CMakeLists.linux-x86_64.txt @@ -15,6 +15,11 @@ target_link_libraries(cpp-threading-queue PUBLIC cpp-deprecated-atomic ) target_sources(cpp-threading-queue PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpmc_unordered_ring.h + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_htswap.h + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_intrusive_unordered.h + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_read_as_filled.h + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_vinfarr_obstructive.h ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpmc_unordered_ring.cpp ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_htswap.cpp ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_intrusive_unordered.cpp diff --git a/library/cpp/threading/queue/CMakeLists.windows-x86_64.txt b/library/cpp/threading/queue/CMakeLists.windows-x86_64.txt index ff0797688e72..410d713d74f6 100644 --- a/library/cpp/threading/queue/CMakeLists.windows-x86_64.txt +++ b/library/cpp/threading/queue/CMakeLists.windows-x86_64.txt @@ -14,6 +14,11 @@ target_link_libraries(cpp-threading-queue PUBLIC cpp-deprecated-atomic ) target_sources(cpp-threading-queue PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpmc_unordered_ring.h + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_htswap.h + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_intrusive_unordered.h + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_read_as_filled.h + ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_vinfarr_obstructive.h ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpmc_unordered_ring.cpp ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_htswap.cpp ${CMAKE_SOURCE_DIR}/library/cpp/threading/queue/mpsc_intrusive_unordered.cpp diff --git a/library/cpp/tld/CMakeLists.darwin-arm64.txt b/library/cpp/tld/CMakeLists.darwin-arm64.txt index cf90e8b74f36..8c72fd8a48b4 100644 --- a/library/cpp/tld/CMakeLists.darwin-arm64.txt +++ b/library/cpp/tld/CMakeLists.darwin-arm64.txt @@ -15,6 +15,7 @@ target_link_libraries(library-cpp-tld PUBLIC cpp-digest-lower_case ) target_sources(library-cpp-tld PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/tld/tld.inc ${CMAKE_SOURCE_DIR}/library/cpp/tld/tld.cpp ${CMAKE_BINARY_DIR}/library/cpp/tld/tld.inc ) diff --git a/library/cpp/tld/CMakeLists.darwin-x86_64.txt b/library/cpp/tld/CMakeLists.darwin-x86_64.txt index cf90e8b74f36..8c72fd8a48b4 100644 --- a/library/cpp/tld/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/tld/CMakeLists.darwin-x86_64.txt @@ -15,6 +15,7 @@ target_link_libraries(library-cpp-tld PUBLIC cpp-digest-lower_case ) target_sources(library-cpp-tld PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/tld/tld.inc ${CMAKE_SOURCE_DIR}/library/cpp/tld/tld.cpp ${CMAKE_BINARY_DIR}/library/cpp/tld/tld.inc ) diff --git a/library/cpp/tld/CMakeLists.linux-aarch64.txt b/library/cpp/tld/CMakeLists.linux-aarch64.txt index 30fe4361801b..9d5d73f21d4f 100644 --- a/library/cpp/tld/CMakeLists.linux-aarch64.txt +++ b/library/cpp/tld/CMakeLists.linux-aarch64.txt @@ -16,6 +16,7 @@ target_link_libraries(library-cpp-tld PUBLIC cpp-digest-lower_case ) target_sources(library-cpp-tld PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/tld/tld.inc ${CMAKE_SOURCE_DIR}/library/cpp/tld/tld.cpp ${CMAKE_BINARY_DIR}/library/cpp/tld/tld.inc ) diff --git a/library/cpp/tld/CMakeLists.linux-x86_64.txt b/library/cpp/tld/CMakeLists.linux-x86_64.txt index 30fe4361801b..9d5d73f21d4f 100644 --- a/library/cpp/tld/CMakeLists.linux-x86_64.txt +++ b/library/cpp/tld/CMakeLists.linux-x86_64.txt @@ -16,6 +16,7 @@ target_link_libraries(library-cpp-tld PUBLIC cpp-digest-lower_case ) target_sources(library-cpp-tld PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/tld/tld.inc ${CMAKE_SOURCE_DIR}/library/cpp/tld/tld.cpp ${CMAKE_BINARY_DIR}/library/cpp/tld/tld.inc ) diff --git a/library/cpp/tld/CMakeLists.windows-x86_64.txt b/library/cpp/tld/CMakeLists.windows-x86_64.txt index cf90e8b74f36..8c72fd8a48b4 100644 --- a/library/cpp/tld/CMakeLists.windows-x86_64.txt +++ b/library/cpp/tld/CMakeLists.windows-x86_64.txt @@ -15,6 +15,7 @@ target_link_libraries(library-cpp-tld PUBLIC cpp-digest-lower_case ) target_sources(library-cpp-tld PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/tld/tld.inc ${CMAKE_SOURCE_DIR}/library/cpp/tld/tld.cpp ${CMAKE_BINARY_DIR}/library/cpp/tld/tld.inc ) diff --git a/library/cpp/unicode/normalization/CMakeLists.darwin-arm64.txt b/library/cpp/unicode/normalization/CMakeLists.darwin-arm64.txt index faa65c7f2bae..4a02aa194d47 100644 --- a/library/cpp/unicode/normalization/CMakeLists.darwin-arm64.txt +++ b/library/cpp/unicode/normalization/CMakeLists.darwin-arm64.txt @@ -12,6 +12,7 @@ target_link_libraries(cpp-unicode-normalization PUBLIC contrib-libs-cxxsupp ) target_sources(cpp-unicode-normalization PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/unicode/normalization/decomposition_table.h ${CMAKE_SOURCE_DIR}/library/cpp/unicode/normalization/generated/composition.cpp ${CMAKE_SOURCE_DIR}/library/cpp/unicode/normalization/generated/decomposition.cpp ${CMAKE_SOURCE_DIR}/library/cpp/unicode/normalization/normalization.cpp diff --git a/library/cpp/unicode/normalization/CMakeLists.darwin-x86_64.txt b/library/cpp/unicode/normalization/CMakeLists.darwin-x86_64.txt index faa65c7f2bae..4a02aa194d47 100644 --- a/library/cpp/unicode/normalization/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/unicode/normalization/CMakeLists.darwin-x86_64.txt @@ -12,6 +12,7 @@ target_link_libraries(cpp-unicode-normalization PUBLIC contrib-libs-cxxsupp ) target_sources(cpp-unicode-normalization PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/unicode/normalization/decomposition_table.h ${CMAKE_SOURCE_DIR}/library/cpp/unicode/normalization/generated/composition.cpp ${CMAKE_SOURCE_DIR}/library/cpp/unicode/normalization/generated/decomposition.cpp ${CMAKE_SOURCE_DIR}/library/cpp/unicode/normalization/normalization.cpp diff --git a/library/cpp/unicode/normalization/CMakeLists.linux-aarch64.txt b/library/cpp/unicode/normalization/CMakeLists.linux-aarch64.txt index 8f5bf5189e10..d848ee2ac0ae 100644 --- a/library/cpp/unicode/normalization/CMakeLists.linux-aarch64.txt +++ b/library/cpp/unicode/normalization/CMakeLists.linux-aarch64.txt @@ -13,6 +13,7 @@ target_link_libraries(cpp-unicode-normalization PUBLIC contrib-libs-cxxsupp ) target_sources(cpp-unicode-normalization PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/unicode/normalization/decomposition_table.h ${CMAKE_SOURCE_DIR}/library/cpp/unicode/normalization/generated/composition.cpp ${CMAKE_SOURCE_DIR}/library/cpp/unicode/normalization/generated/decomposition.cpp ${CMAKE_SOURCE_DIR}/library/cpp/unicode/normalization/normalization.cpp diff --git a/library/cpp/unicode/normalization/CMakeLists.linux-x86_64.txt b/library/cpp/unicode/normalization/CMakeLists.linux-x86_64.txt index 8f5bf5189e10..d848ee2ac0ae 100644 --- a/library/cpp/unicode/normalization/CMakeLists.linux-x86_64.txt +++ b/library/cpp/unicode/normalization/CMakeLists.linux-x86_64.txt @@ -13,6 +13,7 @@ target_link_libraries(cpp-unicode-normalization PUBLIC contrib-libs-cxxsupp ) target_sources(cpp-unicode-normalization PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/unicode/normalization/decomposition_table.h ${CMAKE_SOURCE_DIR}/library/cpp/unicode/normalization/generated/composition.cpp ${CMAKE_SOURCE_DIR}/library/cpp/unicode/normalization/generated/decomposition.cpp ${CMAKE_SOURCE_DIR}/library/cpp/unicode/normalization/normalization.cpp diff --git a/library/cpp/unicode/normalization/CMakeLists.windows-x86_64.txt b/library/cpp/unicode/normalization/CMakeLists.windows-x86_64.txt index faa65c7f2bae..4a02aa194d47 100644 --- a/library/cpp/unicode/normalization/CMakeLists.windows-x86_64.txt +++ b/library/cpp/unicode/normalization/CMakeLists.windows-x86_64.txt @@ -12,6 +12,7 @@ target_link_libraries(cpp-unicode-normalization PUBLIC contrib-libs-cxxsupp ) target_sources(cpp-unicode-normalization PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/unicode/normalization/decomposition_table.h ${CMAKE_SOURCE_DIR}/library/cpp/unicode/normalization/generated/composition.cpp ${CMAKE_SOURCE_DIR}/library/cpp/unicode/normalization/generated/decomposition.cpp ${CMAKE_SOURCE_DIR}/library/cpp/unicode/normalization/normalization.cpp diff --git a/library/cpp/unified_agent_client/proto/CMakeLists.darwin-arm64.txt b/library/cpp/unified_agent_client/proto/CMakeLists.darwin-arm64.txt index 6f12b2aa5eee..80cbac9ae255 100644 --- a/library/cpp/unified_agent_client/proto/CMakeLists.darwin-arm64.txt +++ b/library/cpp/unified_agent_client/proto/CMakeLists.darwin-arm64.txt @@ -45,6 +45,10 @@ target_link_libraries(cpp-unified_agent_client-proto PUBLIC target_proto_messages(cpp-unified_agent_client-proto PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/unified_agent_client/proto/unified_agent.proto ) +target_sources(cpp-unified_agent_client-proto PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/unified_agent_client/proto/unified_agent.pb.h + ${CMAKE_BINARY_DIR}/library/cpp/unified_agent_client/proto/unified_agent.grpc.pb.h +) generate_enum_serilization(cpp-unified_agent_client-proto ${CMAKE_BINARY_DIR}/library/cpp/unified_agent_client/proto/unified_agent.pb.h INCLUDE_HEADERS diff --git a/library/cpp/unified_agent_client/proto/CMakeLists.darwin-x86_64.txt b/library/cpp/unified_agent_client/proto/CMakeLists.darwin-x86_64.txt index 6f12b2aa5eee..80cbac9ae255 100644 --- a/library/cpp/unified_agent_client/proto/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/unified_agent_client/proto/CMakeLists.darwin-x86_64.txt @@ -45,6 +45,10 @@ target_link_libraries(cpp-unified_agent_client-proto PUBLIC target_proto_messages(cpp-unified_agent_client-proto PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/unified_agent_client/proto/unified_agent.proto ) +target_sources(cpp-unified_agent_client-proto PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/unified_agent_client/proto/unified_agent.pb.h + ${CMAKE_BINARY_DIR}/library/cpp/unified_agent_client/proto/unified_agent.grpc.pb.h +) generate_enum_serilization(cpp-unified_agent_client-proto ${CMAKE_BINARY_DIR}/library/cpp/unified_agent_client/proto/unified_agent.pb.h INCLUDE_HEADERS diff --git a/library/cpp/unified_agent_client/proto/CMakeLists.linux-aarch64.txt b/library/cpp/unified_agent_client/proto/CMakeLists.linux-aarch64.txt index 571e21b861eb..bc8c5e7c30e7 100644 --- a/library/cpp/unified_agent_client/proto/CMakeLists.linux-aarch64.txt +++ b/library/cpp/unified_agent_client/proto/CMakeLists.linux-aarch64.txt @@ -46,6 +46,10 @@ target_link_libraries(cpp-unified_agent_client-proto PUBLIC target_proto_messages(cpp-unified_agent_client-proto PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/unified_agent_client/proto/unified_agent.proto ) +target_sources(cpp-unified_agent_client-proto PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/unified_agent_client/proto/unified_agent.pb.h + ${CMAKE_BINARY_DIR}/library/cpp/unified_agent_client/proto/unified_agent.grpc.pb.h +) generate_enum_serilization(cpp-unified_agent_client-proto ${CMAKE_BINARY_DIR}/library/cpp/unified_agent_client/proto/unified_agent.pb.h INCLUDE_HEADERS diff --git a/library/cpp/unified_agent_client/proto/CMakeLists.linux-x86_64.txt b/library/cpp/unified_agent_client/proto/CMakeLists.linux-x86_64.txt index 571e21b861eb..bc8c5e7c30e7 100644 --- a/library/cpp/unified_agent_client/proto/CMakeLists.linux-x86_64.txt +++ b/library/cpp/unified_agent_client/proto/CMakeLists.linux-x86_64.txt @@ -46,6 +46,10 @@ target_link_libraries(cpp-unified_agent_client-proto PUBLIC target_proto_messages(cpp-unified_agent_client-proto PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/unified_agent_client/proto/unified_agent.proto ) +target_sources(cpp-unified_agent_client-proto PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/unified_agent_client/proto/unified_agent.pb.h + ${CMAKE_BINARY_DIR}/library/cpp/unified_agent_client/proto/unified_agent.grpc.pb.h +) generate_enum_serilization(cpp-unified_agent_client-proto ${CMAKE_BINARY_DIR}/library/cpp/unified_agent_client/proto/unified_agent.pb.h INCLUDE_HEADERS diff --git a/library/cpp/unified_agent_client/proto/CMakeLists.windows-x86_64.txt b/library/cpp/unified_agent_client/proto/CMakeLists.windows-x86_64.txt index 6f12b2aa5eee..80cbac9ae255 100644 --- a/library/cpp/unified_agent_client/proto/CMakeLists.windows-x86_64.txt +++ b/library/cpp/unified_agent_client/proto/CMakeLists.windows-x86_64.txt @@ -45,6 +45,10 @@ target_link_libraries(cpp-unified_agent_client-proto PUBLIC target_proto_messages(cpp-unified_agent_client-proto PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/unified_agent_client/proto/unified_agent.proto ) +target_sources(cpp-unified_agent_client-proto PRIVATE + ${CMAKE_BINARY_DIR}/library/cpp/unified_agent_client/proto/unified_agent.pb.h + ${CMAKE_BINARY_DIR}/library/cpp/unified_agent_client/proto/unified_agent.grpc.pb.h +) generate_enum_serilization(cpp-unified_agent_client-proto ${CMAKE_BINARY_DIR}/library/cpp/unified_agent_client/proto/unified_agent.pb.h INCLUDE_HEADERS diff --git a/library/cpp/uri/CMakeLists.darwin-arm64.txt b/library/cpp/uri/CMakeLists.darwin-arm64.txt index f4437a0a2b4d..411f67ad161b 100644 --- a/library/cpp/uri/CMakeLists.darwin-arm64.txt +++ b/library/cpp/uri/CMakeLists.darwin-arm64.txt @@ -16,6 +16,7 @@ target_link_libraries(library-cpp-uri PUBLIC library-cpp-charset ) target_sources(library-cpp-uri PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/uri/http_url.h ${CMAKE_SOURCE_DIR}/library/cpp/uri/assign.cpp ${CMAKE_SOURCE_DIR}/library/cpp/uri/common.cpp ${CMAKE_SOURCE_DIR}/library/cpp/uri/encode.cpp diff --git a/library/cpp/uri/CMakeLists.darwin-x86_64.txt b/library/cpp/uri/CMakeLists.darwin-x86_64.txt index f4437a0a2b4d..411f67ad161b 100644 --- a/library/cpp/uri/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/uri/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,7 @@ target_link_libraries(library-cpp-uri PUBLIC library-cpp-charset ) target_sources(library-cpp-uri PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/uri/http_url.h ${CMAKE_SOURCE_DIR}/library/cpp/uri/assign.cpp ${CMAKE_SOURCE_DIR}/library/cpp/uri/common.cpp ${CMAKE_SOURCE_DIR}/library/cpp/uri/encode.cpp diff --git a/library/cpp/uri/CMakeLists.linux-aarch64.txt b/library/cpp/uri/CMakeLists.linux-aarch64.txt index e5d2e1e2813c..97b15055171d 100644 --- a/library/cpp/uri/CMakeLists.linux-aarch64.txt +++ b/library/cpp/uri/CMakeLists.linux-aarch64.txt @@ -17,6 +17,7 @@ target_link_libraries(library-cpp-uri PUBLIC library-cpp-charset ) target_sources(library-cpp-uri PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/uri/http_url.h ${CMAKE_SOURCE_DIR}/library/cpp/uri/assign.cpp ${CMAKE_SOURCE_DIR}/library/cpp/uri/common.cpp ${CMAKE_SOURCE_DIR}/library/cpp/uri/encode.cpp diff --git a/library/cpp/uri/CMakeLists.linux-x86_64.txt b/library/cpp/uri/CMakeLists.linux-x86_64.txt index e5d2e1e2813c..97b15055171d 100644 --- a/library/cpp/uri/CMakeLists.linux-x86_64.txt +++ b/library/cpp/uri/CMakeLists.linux-x86_64.txt @@ -17,6 +17,7 @@ target_link_libraries(library-cpp-uri PUBLIC library-cpp-charset ) target_sources(library-cpp-uri PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/uri/http_url.h ${CMAKE_SOURCE_DIR}/library/cpp/uri/assign.cpp ${CMAKE_SOURCE_DIR}/library/cpp/uri/common.cpp ${CMAKE_SOURCE_DIR}/library/cpp/uri/encode.cpp diff --git a/library/cpp/uri/CMakeLists.windows-x86_64.txt b/library/cpp/uri/CMakeLists.windows-x86_64.txt index a9fe2359ba49..f9b970c559cd 100644 --- a/library/cpp/uri/CMakeLists.windows-x86_64.txt +++ b/library/cpp/uri/CMakeLists.windows-x86_64.txt @@ -16,6 +16,7 @@ target_link_libraries(library-cpp-uri PUBLIC library-cpp-charset ) target_sources(library-cpp-uri PRIVATE + ${CMAKE_SOURCE_DIR}/library/cpp/uri/http_url.h ${CMAKE_SOURCE_DIR}/library/cpp/uri/assign.cpp ${CMAKE_SOURCE_DIR}/library/cpp/uri/common.cpp ${CMAKE_SOURCE_DIR}/library/cpp/uri/encode.cpp diff --git a/library/cpp/yt/CMakeLists.darwin-arm64.txt b/library/cpp/yt/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..b1dc1594fc1a --- /dev/null +++ b/library/cpp/yt/CMakeLists.darwin-arm64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(assert) +add_subdirectory(backtrace) +add_subdirectory(coding) +add_subdirectory(containers) +add_subdirectory(cpu_clock) +add_subdirectory(exception) +add_subdirectory(logging) +add_subdirectory(malloc) +add_subdirectory(memory) +add_subdirectory(misc) +add_subdirectory(small_containers) +add_subdirectory(string) +add_subdirectory(system) +add_subdirectory(threading) +add_subdirectory(yson) +add_subdirectory(yson_string) diff --git a/library/cpp/yt/CMakeLists.darwin-x86_64.txt b/library/cpp/yt/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..b1dc1594fc1a --- /dev/null +++ b/library/cpp/yt/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(assert) +add_subdirectory(backtrace) +add_subdirectory(coding) +add_subdirectory(containers) +add_subdirectory(cpu_clock) +add_subdirectory(exception) +add_subdirectory(logging) +add_subdirectory(malloc) +add_subdirectory(memory) +add_subdirectory(misc) +add_subdirectory(small_containers) +add_subdirectory(string) +add_subdirectory(system) +add_subdirectory(threading) +add_subdirectory(yson) +add_subdirectory(yson_string) diff --git a/library/cpp/yt/CMakeLists.linux-aarch64.txt b/library/cpp/yt/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..d05e8fb68e83 --- /dev/null +++ b/library/cpp/yt/CMakeLists.linux-aarch64.txt @@ -0,0 +1,26 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(assert) +add_subdirectory(backtrace) +add_subdirectory(coding) +add_subdirectory(containers) +add_subdirectory(cpu_clock) +add_subdirectory(exception) +add_subdirectory(logging) +add_subdirectory(malloc) +add_subdirectory(memory) +add_subdirectory(misc) +add_subdirectory(mlock) +add_subdirectory(small_containers) +add_subdirectory(stockpile) +add_subdirectory(string) +add_subdirectory(system) +add_subdirectory(threading) +add_subdirectory(yson) +add_subdirectory(yson_string) diff --git a/library/cpp/yt/CMakeLists.linux-x86_64.txt b/library/cpp/yt/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..d05e8fb68e83 --- /dev/null +++ b/library/cpp/yt/CMakeLists.linux-x86_64.txt @@ -0,0 +1,26 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(assert) +add_subdirectory(backtrace) +add_subdirectory(coding) +add_subdirectory(containers) +add_subdirectory(cpu_clock) +add_subdirectory(exception) +add_subdirectory(logging) +add_subdirectory(malloc) +add_subdirectory(memory) +add_subdirectory(misc) +add_subdirectory(mlock) +add_subdirectory(small_containers) +add_subdirectory(stockpile) +add_subdirectory(string) +add_subdirectory(system) +add_subdirectory(threading) +add_subdirectory(yson) +add_subdirectory(yson_string) diff --git a/library/cpp/yt/CMakeLists.txt b/library/cpp/yt/CMakeLists.txt index d05e8fb68e83..d863ebd18067 100644 --- a/library/cpp/yt/CMakeLists.txt +++ b/library/cpp/yt/CMakeLists.txt @@ -6,21 +6,14 @@ # original buildsystem will not be accepted. -add_subdirectory(assert) -add_subdirectory(backtrace) -add_subdirectory(coding) -add_subdirectory(containers) -add_subdirectory(cpu_clock) -add_subdirectory(exception) -add_subdirectory(logging) -add_subdirectory(malloc) -add_subdirectory(memory) -add_subdirectory(misc) -add_subdirectory(mlock) -add_subdirectory(small_containers) -add_subdirectory(stockpile) -add_subdirectory(string) -add_subdirectory(system) -add_subdirectory(threading) -add_subdirectory(yson) -add_subdirectory(yson_string) +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/library/cpp/yt/CMakeLists.windows-x86_64.txt b/library/cpp/yt/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..b1dc1594fc1a --- /dev/null +++ b/library/cpp/yt/CMakeLists.windows-x86_64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(assert) +add_subdirectory(backtrace) +add_subdirectory(coding) +add_subdirectory(containers) +add_subdirectory(cpu_clock) +add_subdirectory(exception) +add_subdirectory(logging) +add_subdirectory(malloc) +add_subdirectory(memory) +add_subdirectory(misc) +add_subdirectory(small_containers) +add_subdirectory(string) +add_subdirectory(system) +add_subdirectory(threading) +add_subdirectory(yson) +add_subdirectory(yson_string) diff --git a/library/cpp/yt/backtrace/cursors/CMakeLists.darwin-arm64.txt b/library/cpp/yt/backtrace/cursors/CMakeLists.darwin-arm64.txt index 76c3eda332ef..6c6f5d1c5091 100644 --- a/library/cpp/yt/backtrace/cursors/CMakeLists.darwin-arm64.txt +++ b/library/cpp/yt/backtrace/cursors/CMakeLists.darwin-arm64.txt @@ -6,6 +6,4 @@ # original buildsystem will not be accepted. -add_subdirectory(frame_pointer) -add_subdirectory(interop) add_subdirectory(libunwind) diff --git a/library/cpp/yt/backtrace/cursors/CMakeLists.darwin-x86_64.txt b/library/cpp/yt/backtrace/cursors/CMakeLists.darwin-x86_64.txt index 76c3eda332ef..6c6f5d1c5091 100644 --- a/library/cpp/yt/backtrace/cursors/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/yt/backtrace/cursors/CMakeLists.darwin-x86_64.txt @@ -6,6 +6,4 @@ # original buildsystem will not be accepted. -add_subdirectory(frame_pointer) -add_subdirectory(interop) add_subdirectory(libunwind) diff --git a/library/cpp/yt/backtrace/cursors/CMakeLists.windows-x86_64.txt b/library/cpp/yt/backtrace/cursors/CMakeLists.windows-x86_64.txt index 27fb2d841759..961a9a908b1c 100644 --- a/library/cpp/yt/backtrace/cursors/CMakeLists.windows-x86_64.txt +++ b/library/cpp/yt/backtrace/cursors/CMakeLists.windows-x86_64.txt @@ -7,6 +7,3 @@ add_subdirectory(dummy) -add_subdirectory(frame_pointer) -add_subdirectory(interop) -add_subdirectory(libunwind) diff --git a/library/cpp/yt/backtrace/cursors/frame_pointer/CMakeLists.txt b/library/cpp/yt/backtrace/cursors/frame_pointer/CMakeLists.txt index d863ebd18067..d6c5c0bbeb44 100644 --- a/library/cpp/yt/backtrace/cursors/frame_pointer/CMakeLists.txt +++ b/library/cpp/yt/backtrace/cursors/frame_pointer/CMakeLists.txt @@ -10,10 +10,4 @@ if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_ include(CMakeLists.linux-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) endif() diff --git a/library/cpp/yt/backtrace/cursors/interop/CMakeLists.txt b/library/cpp/yt/backtrace/cursors/interop/CMakeLists.txt index d863ebd18067..d6c5c0bbeb44 100644 --- a/library/cpp/yt/backtrace/cursors/interop/CMakeLists.txt +++ b/library/cpp/yt/backtrace/cursors/interop/CMakeLists.txt @@ -10,10 +10,4 @@ if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_ include(CMakeLists.linux-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) endif() diff --git a/library/cpp/yt/backtrace/cursors/libunwind/CMakeLists.txt b/library/cpp/yt/backtrace/cursors/libunwind/CMakeLists.txt index d863ebd18067..380079ac7b4a 100644 --- a/library/cpp/yt/backtrace/cursors/libunwind/CMakeLists.txt +++ b/library/cpp/yt/backtrace/cursors/libunwind/CMakeLists.txt @@ -14,6 +14,4 @@ elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL include(CMakeLists.darwin-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) endif() diff --git a/library/cpp/yt/misc/CMakeLists.darwin-arm64.txt b/library/cpp/yt/misc/CMakeLists.darwin-arm64.txt index bb8ae6f36801..84fff69dad57 100644 --- a/library/cpp/yt/misc/CMakeLists.darwin-arm64.txt +++ b/library/cpp/yt/misc/CMakeLists.darwin-arm64.txt @@ -15,6 +15,7 @@ target_link_libraries(cpp-yt-misc PUBLIC contrib-libs-cxxsupp yutil cpp-yt-exception + cpp-yt-assert ) target_sources(cpp-yt-misc PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/yt/misc/guid.cpp diff --git a/library/cpp/yt/misc/CMakeLists.darwin-x86_64.txt b/library/cpp/yt/misc/CMakeLists.darwin-x86_64.txt index bb8ae6f36801..84fff69dad57 100644 --- a/library/cpp/yt/misc/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/yt/misc/CMakeLists.darwin-x86_64.txt @@ -15,6 +15,7 @@ target_link_libraries(cpp-yt-misc PUBLIC contrib-libs-cxxsupp yutil cpp-yt-exception + cpp-yt-assert ) target_sources(cpp-yt-misc PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/yt/misc/guid.cpp diff --git a/library/cpp/yt/misc/CMakeLists.linux-aarch64.txt b/library/cpp/yt/misc/CMakeLists.linux-aarch64.txt index 7715f3febe99..15b686711c2d 100644 --- a/library/cpp/yt/misc/CMakeLists.linux-aarch64.txt +++ b/library/cpp/yt/misc/CMakeLists.linux-aarch64.txt @@ -16,6 +16,7 @@ target_link_libraries(cpp-yt-misc PUBLIC contrib-libs-cxxsupp yutil cpp-yt-exception + cpp-yt-assert ) target_sources(cpp-yt-misc PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/yt/misc/guid.cpp diff --git a/library/cpp/yt/misc/CMakeLists.linux-x86_64.txt b/library/cpp/yt/misc/CMakeLists.linux-x86_64.txt index 7715f3febe99..15b686711c2d 100644 --- a/library/cpp/yt/misc/CMakeLists.linux-x86_64.txt +++ b/library/cpp/yt/misc/CMakeLists.linux-x86_64.txt @@ -16,6 +16,7 @@ target_link_libraries(cpp-yt-misc PUBLIC contrib-libs-cxxsupp yutil cpp-yt-exception + cpp-yt-assert ) target_sources(cpp-yt-misc PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/yt/misc/guid.cpp diff --git a/library/cpp/yt/misc/CMakeLists.windows-x86_64.txt b/library/cpp/yt/misc/CMakeLists.windows-x86_64.txt index 0d302cdb6d93..305d47e0f03e 100644 --- a/library/cpp/yt/misc/CMakeLists.windows-x86_64.txt +++ b/library/cpp/yt/misc/CMakeLists.windows-x86_64.txt @@ -12,6 +12,7 @@ target_link_libraries(cpp-yt-misc PUBLIC contrib-libs-cxxsupp yutil cpp-yt-exception + cpp-yt-assert ) target_sources(cpp-yt-misc PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/yt/misc/guid.cpp diff --git a/library/cpp/yt/mlock/CMakeLists.txt b/library/cpp/yt/mlock/CMakeLists.txt index d863ebd18067..d6c5c0bbeb44 100644 --- a/library/cpp/yt/mlock/CMakeLists.txt +++ b/library/cpp/yt/mlock/CMakeLists.txt @@ -10,10 +10,4 @@ if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_ include(CMakeLists.linux-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) endif() diff --git a/library/cpp/yt/stockpile/CMakeLists.txt b/library/cpp/yt/stockpile/CMakeLists.txt index d863ebd18067..d6c5c0bbeb44 100644 --- a/library/cpp/yt/stockpile/CMakeLists.txt +++ b/library/cpp/yt/stockpile/CMakeLists.txt @@ -10,10 +10,4 @@ if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_ include(CMakeLists.linux-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) endif() diff --git a/library/cpp/ytalloc/api/CMakeLists.darwin-arm64.txt b/library/cpp/ytalloc/api/CMakeLists.darwin-arm64.txt index a550e54f0019..dd85d46945c8 100644 --- a/library/cpp/ytalloc/api/CMakeLists.darwin-arm64.txt +++ b/library/cpp/ytalloc/api/CMakeLists.darwin-arm64.txt @@ -12,6 +12,7 @@ target_link_libraries(cpp-ytalloc-api PUBLIC contrib-libs-cxxsupp yutil cpp-yt-misc + cpp-yt-containers ) target_sources(cpp-ytalloc-api PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/ytalloc/api/fallback.cpp diff --git a/library/cpp/ytalloc/api/CMakeLists.darwin-x86_64.txt b/library/cpp/ytalloc/api/CMakeLists.darwin-x86_64.txt index a550e54f0019..dd85d46945c8 100644 --- a/library/cpp/ytalloc/api/CMakeLists.darwin-x86_64.txt +++ b/library/cpp/ytalloc/api/CMakeLists.darwin-x86_64.txt @@ -12,6 +12,7 @@ target_link_libraries(cpp-ytalloc-api PUBLIC contrib-libs-cxxsupp yutil cpp-yt-misc + cpp-yt-containers ) target_sources(cpp-ytalloc-api PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/ytalloc/api/fallback.cpp diff --git a/library/cpp/ytalloc/api/CMakeLists.linux-aarch64.txt b/library/cpp/ytalloc/api/CMakeLists.linux-aarch64.txt index 3557a63ea82e..ad3ea51dca24 100644 --- a/library/cpp/ytalloc/api/CMakeLists.linux-aarch64.txt +++ b/library/cpp/ytalloc/api/CMakeLists.linux-aarch64.txt @@ -13,6 +13,7 @@ target_link_libraries(cpp-ytalloc-api PUBLIC contrib-libs-cxxsupp yutil cpp-yt-misc + cpp-yt-containers ) target_sources(cpp-ytalloc-api PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/ytalloc/api/fallback.cpp diff --git a/library/cpp/ytalloc/api/CMakeLists.linux-x86_64.txt b/library/cpp/ytalloc/api/CMakeLists.linux-x86_64.txt index 3557a63ea82e..ad3ea51dca24 100644 --- a/library/cpp/ytalloc/api/CMakeLists.linux-x86_64.txt +++ b/library/cpp/ytalloc/api/CMakeLists.linux-x86_64.txt @@ -13,6 +13,7 @@ target_link_libraries(cpp-ytalloc-api PUBLIC contrib-libs-cxxsupp yutil cpp-yt-misc + cpp-yt-containers ) target_sources(cpp-ytalloc-api PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/ytalloc/api/fallback.cpp diff --git a/library/cpp/ytalloc/api/CMakeLists.windows-x86_64.txt b/library/cpp/ytalloc/api/CMakeLists.windows-x86_64.txt index a550e54f0019..dd85d46945c8 100644 --- a/library/cpp/ytalloc/api/CMakeLists.windows-x86_64.txt +++ b/library/cpp/ytalloc/api/CMakeLists.windows-x86_64.txt @@ -12,6 +12,7 @@ target_link_libraries(cpp-ytalloc-api PUBLIC contrib-libs-cxxsupp yutil cpp-yt-misc + cpp-yt-containers ) target_sources(cpp-ytalloc-api PRIVATE ${CMAKE_SOURCE_DIR}/library/cpp/ytalloc/api/fallback.cpp diff --git a/tools/archiver/CMakeLists.linux-aarch64.txt b/tools/archiver/CMakeLists.linux-aarch64.txt index d3947a906d35..84309748c819 100644 --- a/tools/archiver/CMakeLists.linux-aarch64.txt +++ b/tools/archiver/CMakeLists.linux-aarch64.txt @@ -22,9 +22,6 @@ target_link_options(archiver PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(archiver PRIVATE ${CMAKE_SOURCE_DIR}/tools/archiver/main.cpp diff --git a/tools/archiver/CMakeLists.linux-x86_64.txt b/tools/archiver/CMakeLists.linux-x86_64.txt index 7ae5f5ed7f20..c4b4c40e8811 100644 --- a/tools/archiver/CMakeLists.linux-x86_64.txt +++ b/tools/archiver/CMakeLists.linux-x86_64.txt @@ -23,9 +23,6 @@ target_link_options(archiver PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(archiver PRIVATE ${CMAKE_SOURCE_DIR}/tools/archiver/main.cpp diff --git a/tools/enum_parser/enum_parser/CMakeLists.linux-aarch64.txt b/tools/enum_parser/enum_parser/CMakeLists.linux-aarch64.txt index 04196e5f087f..c22d4430d3bf 100644 --- a/tools/enum_parser/enum_parser/CMakeLists.linux-aarch64.txt +++ b/tools/enum_parser/enum_parser/CMakeLists.linux-aarch64.txt @@ -21,9 +21,6 @@ target_link_options(enum_parser PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(enum_parser PRIVATE ${CMAKE_SOURCE_DIR}/tools/enum_parser/enum_parser/main.cpp diff --git a/tools/enum_parser/enum_parser/CMakeLists.linux-x86_64.txt b/tools/enum_parser/enum_parser/CMakeLists.linux-x86_64.txt index 18ccff5c5522..56fabecd3bfe 100644 --- a/tools/enum_parser/enum_parser/CMakeLists.linux-x86_64.txt +++ b/tools/enum_parser/enum_parser/CMakeLists.linux-x86_64.txt @@ -22,9 +22,6 @@ target_link_options(enum_parser PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(enum_parser PRIVATE ${CMAKE_SOURCE_DIR}/tools/enum_parser/enum_parser/main.cpp diff --git a/tools/rescompiler/bin/CMakeLists.linux-aarch64.txt b/tools/rescompiler/bin/CMakeLists.linux-aarch64.txt index 149f6f4225b6..c716fcd7c954 100644 --- a/tools/rescompiler/bin/CMakeLists.linux-aarch64.txt +++ b/tools/rescompiler/bin/CMakeLists.linux-aarch64.txt @@ -20,9 +20,6 @@ target_link_options(rescompiler PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(rescompiler PRIVATE ${CMAKE_SOURCE_DIR}/tools/rescompiler/main.cpp diff --git a/tools/rescompiler/bin/CMakeLists.linux-x86_64.txt b/tools/rescompiler/bin/CMakeLists.linux-x86_64.txt index dda1f62fe383..3a09473cdf26 100644 --- a/tools/rescompiler/bin/CMakeLists.linux-x86_64.txt +++ b/tools/rescompiler/bin/CMakeLists.linux-x86_64.txt @@ -21,9 +21,6 @@ target_link_options(rescompiler PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(rescompiler PRIVATE ${CMAKE_SOURCE_DIR}/tools/rescompiler/main.cpp diff --git a/util/CMakeLists.windows-x86_64.txt b/util/CMakeLists.windows-x86_64.txt index c906d00cad0d..fa8e52e246ab 100644 --- a/util/CMakeLists.windows-x86_64.txt +++ b/util/CMakeLists.windows-x86_64.txt @@ -10,9 +10,6 @@ add_subdirectory(charset) add_subdirectory(draft) add_library(yutil) -target_compile_options(yutil PRIVATE - -Wnarrowing -) target_link_libraries(yutil PUBLIC contrib-libs-cxxsupp util-charset diff --git a/util/charset/CMakeLists.windows-x86_64.txt b/util/charset/CMakeLists.windows-x86_64.txt index b63f9cf0470a..a13d66250fea 100644 --- a/util/charset/CMakeLists.windows-x86_64.txt +++ b/util/charset/CMakeLists.windows-x86_64.txt @@ -25,5 +25,5 @@ target_sources_custom(util-charset SRCS ${CMAKE_SOURCE_DIR}/util/charset/wide_sse41.cpp CUSTOM_FLAGS - -msse4.1 + /D__SSE4_1__=1 ) diff --git a/ydb/CMakeLists.txt b/ydb/CMakeLists.txt index 066036e84b3e..0f0a2d60411f 100644 --- a/ydb/CMakeLists.txt +++ b/ydb/CMakeLists.txt @@ -12,6 +12,7 @@ add_subdirectory(library) add_subdirectory(public) add_subdirectory(services) add_subdirectory(tests) +add_subdirectory(tools) add_custom_target(ydb_py_protos) add_custom_command( diff --git a/ydb/apps/pgwire/CMakeLists.darwin-arm64.txt b/ydb/apps/pgwire/CMakeLists.darwin-arm64.txt index c690091c8ad8..b23b1fa63c23 100644 --- a/ydb/apps/pgwire/CMakeLists.darwin-arm64.txt +++ b/ydb/apps/pgwire/CMakeLists.darwin-arm64.txt @@ -25,10 +25,14 @@ target_link_options(pgwire PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(pgwire PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/appdata.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pg_ydb_connection.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pg_ydb_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pgwire.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/signals.h ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/main.cpp ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pg_ydb_connection.cpp ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pg_ydb_proxy.cpp diff --git a/ydb/apps/pgwire/CMakeLists.darwin-x86_64.txt b/ydb/apps/pgwire/CMakeLists.darwin-x86_64.txt index 0b58afab88a0..193dbe465126 100644 --- a/ydb/apps/pgwire/CMakeLists.darwin-x86_64.txt +++ b/ydb/apps/pgwire/CMakeLists.darwin-x86_64.txt @@ -26,10 +26,14 @@ target_link_options(pgwire PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(pgwire PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/appdata.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pg_ydb_connection.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pg_ydb_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pgwire.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/signals.h ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/main.cpp ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pg_ydb_connection.cpp ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pg_ydb_proxy.cpp diff --git a/ydb/apps/pgwire/CMakeLists.linux-aarch64.txt b/ydb/apps/pgwire/CMakeLists.linux-aarch64.txt index 29022b358bcd..877af26e9392 100644 --- a/ydb/apps/pgwire/CMakeLists.linux-aarch64.txt +++ b/ydb/apps/pgwire/CMakeLists.linux-aarch64.txt @@ -28,11 +28,14 @@ target_link_options(pgwire PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(pgwire PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/appdata.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pg_ydb_connection.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pg_ydb_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pgwire.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/signals.h ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/main.cpp ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pg_ydb_connection.cpp ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pg_ydb_proxy.cpp diff --git a/ydb/apps/pgwire/CMakeLists.linux-x86_64.txt b/ydb/apps/pgwire/CMakeLists.linux-x86_64.txt index 2cb4b411b95b..1ee3fd6a1a3e 100644 --- a/ydb/apps/pgwire/CMakeLists.linux-x86_64.txt +++ b/ydb/apps/pgwire/CMakeLists.linux-x86_64.txt @@ -29,11 +29,14 @@ target_link_options(pgwire PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(pgwire PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/appdata.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pg_ydb_connection.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pg_ydb_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pgwire.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/signals.h ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/main.cpp ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pg_ydb_connection.cpp ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pg_ydb_proxy.cpp diff --git a/ydb/apps/pgwire/CMakeLists.windows-x86_64.txt b/ydb/apps/pgwire/CMakeLists.windows-x86_64.txt index 542ff8e33c82..c3b707609028 100644 --- a/ydb/apps/pgwire/CMakeLists.windows-x86_64.txt +++ b/ydb/apps/pgwire/CMakeLists.windows-x86_64.txt @@ -23,6 +23,12 @@ target_link_libraries(pgwire PUBLIC udf-service-exception_policy ) target_sources(pgwire PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/appdata.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pg_ydb_connection.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pg_ydb_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pgwire.h + ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/signals.h ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/main.cpp ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pg_ydb_connection.cpp ${CMAKE_SOURCE_DIR}/ydb/apps/pgwire/pg_ydb_proxy.cpp diff --git a/ydb/apps/ydb/CMakeLists.darwin-arm64.txt b/ydb/apps/ydb/CMakeLists.darwin-arm64.txt index 4cc7165a1ad5..a4fc00d12181 100644 --- a/ydb/apps/ydb/CMakeLists.darwin-arm64.txt +++ b/ydb/apps/ydb/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(ydb PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb PRIVATE ${CMAKE_SOURCE_DIR}/ydb/apps/ydb/main.cpp diff --git a/ydb/apps/ydb/CMakeLists.darwin-x86_64.txt b/ydb/apps/ydb/CMakeLists.darwin-x86_64.txt index 87e7b9d72a89..f26e80a52a79 100644 --- a/ydb/apps/ydb/CMakeLists.darwin-x86_64.txt +++ b/ydb/apps/ydb/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(ydb PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb PRIVATE ${CMAKE_SOURCE_DIR}/ydb/apps/ydb/main.cpp diff --git a/ydb/apps/ydb/CMakeLists.linux-aarch64.txt b/ydb/apps/ydb/CMakeLists.linux-aarch64.txt index 619d67ad354a..85974a40d7f0 100644 --- a/ydb/apps/ydb/CMakeLists.linux-aarch64.txt +++ b/ydb/apps/ydb/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb PRIVATE ${CMAKE_SOURCE_DIR}/ydb/apps/ydb/main.cpp diff --git a/ydb/apps/ydb/CMakeLists.linux-x86_64.txt b/ydb/apps/ydb/CMakeLists.linux-x86_64.txt index ab7446e04241..43fb744390ff 100644 --- a/ydb/apps/ydb/CMakeLists.linux-x86_64.txt +++ b/ydb/apps/ydb/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb PRIVATE ${CMAKE_SOURCE_DIR}/ydb/apps/ydb/main.cpp diff --git a/ydb/apps/ydb/ut/CMakeLists.linux-aarch64.txt b/ydb/apps/ydb/ut/CMakeLists.linux-aarch64.txt index 8b6e16f12afb..b39c65f5ffcf 100644 --- a/ydb/apps/ydb/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/apps/ydb/ut/CMakeLists.linux-aarch64.txt @@ -22,9 +22,6 @@ target_link_options(ydb-apps-ydb-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-apps-ydb-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/apps/ydb/ut/workload-topic.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/apps/ydb/ut/CMakeLists.linux-x86_64.txt b/ydb/apps/ydb/ut/CMakeLists.linux-x86_64.txt index 077cbbdad073..d282351a9f0d 100644 --- a/ydb/apps/ydb/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/apps/ydb/ut/CMakeLists.linux-x86_64.txt @@ -23,9 +23,6 @@ target_link_options(ydb-apps-ydb-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-apps-ydb-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/apps/ydb/ut/workload-topic.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/apps/ydbd/CMakeLists.darwin-arm64.txt b/ydb/apps/ydbd/CMakeLists.darwin-arm64.txt index 4516b5c7c8ec..55cb758927dd 100644 --- a/ydb/apps/ydbd/CMakeLists.darwin-arm64.txt +++ b/ydb/apps/ydbd/CMakeLists.darwin-arm64.txt @@ -53,10 +53,9 @@ target_link_options(ydbd PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydbd PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/apps/ydbd/export.h ${CMAKE_SOURCE_DIR}/ydb/apps/ydbd/export.cpp ${CMAKE_SOURCE_DIR}/ydb/apps/ydbd/main.cpp ) diff --git a/ydb/apps/ydbd/CMakeLists.darwin-x86_64.txt b/ydb/apps/ydbd/CMakeLists.darwin-x86_64.txt index b7b8faa6d08e..c14caccd9816 100644 --- a/ydb/apps/ydbd/CMakeLists.darwin-x86_64.txt +++ b/ydb/apps/ydbd/CMakeLists.darwin-x86_64.txt @@ -55,10 +55,9 @@ target_link_options(ydbd PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydbd PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/apps/ydbd/export.h ${CMAKE_SOURCE_DIR}/ydb/apps/ydbd/export.cpp ${CMAKE_SOURCE_DIR}/ydb/apps/ydbd/main.cpp ) diff --git a/ydb/apps/ydbd/CMakeLists.linux-aarch64.txt b/ydb/apps/ydbd/CMakeLists.linux-aarch64.txt index f44a2cbc9449..39d8a56655d5 100644 --- a/ydb/apps/ydbd/CMakeLists.linux-aarch64.txt +++ b/ydb/apps/ydbd/CMakeLists.linux-aarch64.txt @@ -56,11 +56,9 @@ target_link_options(ydbd PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydbd PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/apps/ydbd/export.h ${CMAKE_SOURCE_DIR}/ydb/apps/ydbd/export.cpp ${CMAKE_SOURCE_DIR}/ydb/apps/ydbd/main.cpp ) diff --git a/ydb/apps/ydbd/CMakeLists.linux-x86_64.txt b/ydb/apps/ydbd/CMakeLists.linux-x86_64.txt index 5f9d4bf8df83..c1e2d6955ed2 100644 --- a/ydb/apps/ydbd/CMakeLists.linux-x86_64.txt +++ b/ydb/apps/ydbd/CMakeLists.linux-x86_64.txt @@ -58,11 +58,9 @@ target_link_options(ydbd PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydbd PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/apps/ydbd/export.h ${CMAKE_SOURCE_DIR}/ydb/apps/ydbd/export.cpp ${CMAKE_SOURCE_DIR}/ydb/apps/ydbd/main.cpp ) diff --git a/ydb/apps/ydbd/CMakeLists.windows-x86_64.txt b/ydb/apps/ydbd/CMakeLists.windows-x86_64.txt index c0296c58f8e4..92044a6688cf 100644 --- a/ydb/apps/ydbd/CMakeLists.windows-x86_64.txt +++ b/ydb/apps/ydbd/CMakeLists.windows-x86_64.txt @@ -53,6 +53,7 @@ target_link_libraries(ydbd PUBLIC client-ydb_persqueue_public-codecs ) target_sources(ydbd PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/apps/ydbd/export.h ${CMAKE_SOURCE_DIR}/ydb/apps/ydbd/export.cpp ${CMAKE_SOURCE_DIR}/ydb/apps/ydbd/main.cpp ) diff --git a/ydb/core/CMakeLists.txt b/ydb/core/CMakeLists.txt index 3436fc14bd8c..9255620f7c65 100644 --- a/ydb/core/CMakeLists.txt +++ b/ydb/core/CMakeLists.txt @@ -12,6 +12,7 @@ add_subdirectory(base) add_subdirectory(blob_depot) add_subdirectory(blobstorage) add_subdirectory(blockstore) +add_subdirectory(change_exchange) add_subdirectory(client) add_subdirectory(cms) add_subdirectory(control) @@ -26,6 +27,7 @@ add_subdirectory(external_sources) add_subdirectory(filestore) add_subdirectory(formats) add_subdirectory(fq) +add_subdirectory(graph) add_subdirectory(grpc_caching) add_subdirectory(grpc_services) add_subdirectory(grpc_streaming) diff --git a/ydb/core/actorlib_impl/CMakeLists.darwin-arm64.txt b/ydb/core/actorlib_impl/CMakeLists.darwin-arm64.txt index 5255accbc3ec..44857f123d07 100644 --- a/ydb/core/actorlib_impl/CMakeLists.darwin-arm64.txt +++ b/ydb/core/actorlib_impl/CMakeLists.darwin-arm64.txt @@ -37,6 +37,21 @@ target_link_libraries(ydb-core-actorlib_impl PUBLIC ydb-core-util ) target_sources(ydb-core-actorlib_impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/actor_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/async_destroyer.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/connect_socket_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/destruct_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/http_request_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/load_network.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/long_timer.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/mad_squirrel.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/name_service_client_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/proto_ready_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/read_data_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/read_http_reply_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/router_rr.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/send_data_protocol.h ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/actor_tracker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/connect_socket_protocol.cpp ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/load_network.cpp diff --git a/ydb/core/actorlib_impl/CMakeLists.darwin-x86_64.txt b/ydb/core/actorlib_impl/CMakeLists.darwin-x86_64.txt index 5255accbc3ec..44857f123d07 100644 --- a/ydb/core/actorlib_impl/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/actorlib_impl/CMakeLists.darwin-x86_64.txt @@ -37,6 +37,21 @@ target_link_libraries(ydb-core-actorlib_impl PUBLIC ydb-core-util ) target_sources(ydb-core-actorlib_impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/actor_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/async_destroyer.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/connect_socket_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/destruct_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/http_request_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/load_network.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/long_timer.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/mad_squirrel.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/name_service_client_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/proto_ready_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/read_data_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/read_http_reply_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/router_rr.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/send_data_protocol.h ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/actor_tracker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/connect_socket_protocol.cpp ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/load_network.cpp diff --git a/ydb/core/actorlib_impl/CMakeLists.linux-aarch64.txt b/ydb/core/actorlib_impl/CMakeLists.linux-aarch64.txt index 039f2bbc20c3..f544cba4c8f4 100644 --- a/ydb/core/actorlib_impl/CMakeLists.linux-aarch64.txt +++ b/ydb/core/actorlib_impl/CMakeLists.linux-aarch64.txt @@ -38,6 +38,21 @@ target_link_libraries(ydb-core-actorlib_impl PUBLIC ydb-core-util ) target_sources(ydb-core-actorlib_impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/actor_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/async_destroyer.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/connect_socket_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/destruct_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/http_request_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/load_network.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/long_timer.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/mad_squirrel.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/name_service_client_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/proto_ready_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/read_data_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/read_http_reply_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/router_rr.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/send_data_protocol.h ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/actor_tracker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/connect_socket_protocol.cpp ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/load_network.cpp diff --git a/ydb/core/actorlib_impl/CMakeLists.linux-x86_64.txt b/ydb/core/actorlib_impl/CMakeLists.linux-x86_64.txt index 039f2bbc20c3..f544cba4c8f4 100644 --- a/ydb/core/actorlib_impl/CMakeLists.linux-x86_64.txt +++ b/ydb/core/actorlib_impl/CMakeLists.linux-x86_64.txt @@ -38,6 +38,21 @@ target_link_libraries(ydb-core-actorlib_impl PUBLIC ydb-core-util ) target_sources(ydb-core-actorlib_impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/actor_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/async_destroyer.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/connect_socket_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/destruct_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/http_request_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/load_network.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/long_timer.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/mad_squirrel.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/name_service_client_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/proto_ready_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/read_data_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/read_http_reply_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/router_rr.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/send_data_protocol.h ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/actor_tracker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/connect_socket_protocol.cpp ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/load_network.cpp diff --git a/ydb/core/actorlib_impl/CMakeLists.windows-x86_64.txt b/ydb/core/actorlib_impl/CMakeLists.windows-x86_64.txt index 5255accbc3ec..44857f123d07 100644 --- a/ydb/core/actorlib_impl/CMakeLists.windows-x86_64.txt +++ b/ydb/core/actorlib_impl/CMakeLists.windows-x86_64.txt @@ -37,6 +37,21 @@ target_link_libraries(ydb-core-actorlib_impl PUBLIC ydb-core-util ) target_sources(ydb-core-actorlib_impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/actor_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/async_destroyer.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/connect_socket_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/destruct_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/http_request_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/load_network.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/long_timer.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/mad_squirrel.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/name_service_client_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/proto_ready_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/read_data_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/read_http_reply_protocol.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/router_rr.h + ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/send_data_protocol.h ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/actor_tracker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/connect_socket_protocol.cpp ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/load_network.cpp diff --git a/ydb/core/actorlib_impl/ut/CMakeLists.darwin-arm64.txt b/ydb/core/actorlib_impl/ut/CMakeLists.darwin-arm64.txt index 8af6e8854fca..b23f1701861d 100644 --- a/ydb/core/actorlib_impl/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/actorlib_impl/ut/CMakeLists.darwin-arm64.txt @@ -25,13 +25,12 @@ target_link_libraries(ydb-core-actorlib_impl-ut PUBLIC library-cpp-svnversion core-testlib-actors testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-core-actorlib_impl-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-actorlib_impl-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/actor_activity_ut.cpp @@ -65,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/actorlib_impl/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/actorlib_impl/ut/CMakeLists.darwin-x86_64.txt index b9973a4830cb..97b02c598742 100644 --- a/ydb/core/actorlib_impl/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/actorlib_impl/ut/CMakeLists.darwin-x86_64.txt @@ -26,13 +26,12 @@ target_link_libraries(ydb-core-actorlib_impl-ut PUBLIC library-cpp-svnversion core-testlib-actors testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-core-actorlib_impl-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-actorlib_impl-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/actor_activity_ut.cpp @@ -66,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/actorlib_impl/ut/CMakeLists.linux-aarch64.txt b/ydb/core/actorlib_impl/ut/CMakeLists.linux-aarch64.txt index 42d60e26b33b..8884fae6ef3e 100644 --- a/ydb/core/actorlib_impl/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/actorlib_impl/ut/CMakeLists.linux-aarch64.txt @@ -26,6 +26,7 @@ target_link_libraries(ydb-core-actorlib_impl-ut PUBLIC library-cpp-svnversion core-testlib-actors testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-core-actorlib_impl-ut PRIVATE -ldl @@ -33,9 +34,6 @@ target_link_options(ydb-core-actorlib_impl-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-actorlib_impl-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/actor_activity_ut.cpp @@ -69,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/actorlib_impl/ut/CMakeLists.linux-x86_64.txt b/ydb/core/actorlib_impl/ut/CMakeLists.linux-x86_64.txt index 6f3a983e6926..cc8f189feba3 100644 --- a/ydb/core/actorlib_impl/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/actorlib_impl/ut/CMakeLists.linux-x86_64.txt @@ -27,6 +27,7 @@ target_link_libraries(ydb-core-actorlib_impl-ut PUBLIC library-cpp-svnversion core-testlib-actors testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-core-actorlib_impl-ut PRIVATE -ldl @@ -34,9 +35,6 @@ target_link_options(ydb-core-actorlib_impl-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-actorlib_impl-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/actor_activity_ut.cpp @@ -70,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/actorlib_impl/ut/CMakeLists.windows-x86_64.txt b/ydb/core/actorlib_impl/ut/CMakeLists.windows-x86_64.txt index 056946a8b432..cc5c27df7c96 100644 --- a/ydb/core/actorlib_impl/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/actorlib_impl/ut/CMakeLists.windows-x86_64.txt @@ -26,6 +26,7 @@ target_link_libraries(ydb-core-actorlib_impl-ut PUBLIC library-cpp-svnversion core-testlib-actors testlib-basics-default + minikql-comp_nodes-llvm14 ) target_sources(ydb-core-actorlib_impl-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/actorlib_impl/actor_activity_ut.cpp @@ -59,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/audit/CMakeLists.darwin-arm64.txt b/ydb/core/audit/CMakeLists.darwin-arm64.txt index c66501c4bb2b..66c4ee2b9394 100644 --- a/ydb/core/audit/CMakeLists.darwin-arm64.txt +++ b/ydb/core/audit/CMakeLists.darwin-arm64.txt @@ -24,6 +24,8 @@ target_link_libraries(ydb-core-audit PUBLIC library-cpp-resource ) target_sources(ydb-core-audit PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/audit/audit_log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/audit/audit_log.h ${CMAKE_SOURCE_DIR}/ydb/core/audit/audit_log_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/audit/audit_log.cpp ) diff --git a/ydb/core/audit/CMakeLists.darwin-x86_64.txt b/ydb/core/audit/CMakeLists.darwin-x86_64.txt index c66501c4bb2b..66c4ee2b9394 100644 --- a/ydb/core/audit/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/audit/CMakeLists.darwin-x86_64.txt @@ -24,6 +24,8 @@ target_link_libraries(ydb-core-audit PUBLIC library-cpp-resource ) target_sources(ydb-core-audit PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/audit/audit_log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/audit/audit_log.h ${CMAKE_SOURCE_DIR}/ydb/core/audit/audit_log_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/audit/audit_log.cpp ) diff --git a/ydb/core/audit/CMakeLists.linux-aarch64.txt b/ydb/core/audit/CMakeLists.linux-aarch64.txt index aeec46ea8451..c7b451b2dded 100644 --- a/ydb/core/audit/CMakeLists.linux-aarch64.txt +++ b/ydb/core/audit/CMakeLists.linux-aarch64.txt @@ -25,6 +25,8 @@ target_link_libraries(ydb-core-audit PUBLIC library-cpp-resource ) target_sources(ydb-core-audit PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/audit/audit_log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/audit/audit_log.h ${CMAKE_SOURCE_DIR}/ydb/core/audit/audit_log_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/audit/audit_log.cpp ) diff --git a/ydb/core/audit/CMakeLists.linux-x86_64.txt b/ydb/core/audit/CMakeLists.linux-x86_64.txt index aeec46ea8451..c7b451b2dded 100644 --- a/ydb/core/audit/CMakeLists.linux-x86_64.txt +++ b/ydb/core/audit/CMakeLists.linux-x86_64.txt @@ -25,6 +25,8 @@ target_link_libraries(ydb-core-audit PUBLIC library-cpp-resource ) target_sources(ydb-core-audit PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/audit/audit_log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/audit/audit_log.h ${CMAKE_SOURCE_DIR}/ydb/core/audit/audit_log_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/audit/audit_log.cpp ) diff --git a/ydb/core/audit/CMakeLists.windows-x86_64.txt b/ydb/core/audit/CMakeLists.windows-x86_64.txt index c66501c4bb2b..66c4ee2b9394 100644 --- a/ydb/core/audit/CMakeLists.windows-x86_64.txt +++ b/ydb/core/audit/CMakeLists.windows-x86_64.txt @@ -24,6 +24,8 @@ target_link_libraries(ydb-core-audit PUBLIC library-cpp-resource ) target_sources(ydb-core-audit PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/audit/audit_log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/audit/audit_log.h ${CMAKE_SOURCE_DIR}/ydb/core/audit/audit_log_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/audit/audit_log.cpp ) diff --git a/ydb/core/base/CMakeLists.darwin-arm64.txt b/ydb/core/base/CMakeLists.darwin-arm64.txt index c6b5d1ae705e..9006334ad342 100644 --- a/ydb/core/base/CMakeLists.darwin-arm64.txt +++ b/ydb/core/base/CMakeLists.darwin-arm64.txt @@ -28,9 +28,9 @@ target_link_libraries(ydb-core-base PUBLIC core-base-services ydb-core-debug ydb-core-erasure + core-graph-api ydb-core-protos core-protos-out - ydb-core-scheme ydb-library-aclib ydb-library-login ydb-library-pdisk_io @@ -42,6 +42,42 @@ target_link_libraries(ydb-core-base PUBLIC library-cpp-dwarf_backtrace ) target_sources(ydb-core-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/base/appdata.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/backtrace.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/blobstorage.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/channel_profiles.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/domain.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/event_filter.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/group_stat.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/hive.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/interconnect_channels.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/localdb.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/location.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/logoblob.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/memobserver.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/nameservice.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/pool_stats_collector.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/resource_profile.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/row_version.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/shared_quota.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/statestorage.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/statestorage_guardian_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/statestorage_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/storage_pools.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/subdomain.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet_pipe.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet_pipecache.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tabletid.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/traceid.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tracing.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tx_processing.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/user_registry.h ${CMAKE_SOURCE_DIR}/ydb/core/base/actor_activity_names.cpp ${CMAKE_SOURCE_DIR}/ydb/core/base/appdata.cpp ${CMAKE_SOURCE_DIR}/ydb/core/base/backtrace.cpp diff --git a/ydb/core/base/CMakeLists.darwin-x86_64.txt b/ydb/core/base/CMakeLists.darwin-x86_64.txt index c6b5d1ae705e..9006334ad342 100644 --- a/ydb/core/base/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/base/CMakeLists.darwin-x86_64.txt @@ -28,9 +28,9 @@ target_link_libraries(ydb-core-base PUBLIC core-base-services ydb-core-debug ydb-core-erasure + core-graph-api ydb-core-protos core-protos-out - ydb-core-scheme ydb-library-aclib ydb-library-login ydb-library-pdisk_io @@ -42,6 +42,42 @@ target_link_libraries(ydb-core-base PUBLIC library-cpp-dwarf_backtrace ) target_sources(ydb-core-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/base/appdata.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/backtrace.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/blobstorage.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/channel_profiles.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/domain.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/event_filter.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/group_stat.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/hive.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/interconnect_channels.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/localdb.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/location.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/logoblob.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/memobserver.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/nameservice.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/pool_stats_collector.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/resource_profile.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/row_version.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/shared_quota.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/statestorage.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/statestorage_guardian_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/statestorage_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/storage_pools.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/subdomain.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet_pipe.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet_pipecache.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tabletid.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/traceid.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tracing.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tx_processing.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/user_registry.h ${CMAKE_SOURCE_DIR}/ydb/core/base/actor_activity_names.cpp ${CMAKE_SOURCE_DIR}/ydb/core/base/appdata.cpp ${CMAKE_SOURCE_DIR}/ydb/core/base/backtrace.cpp diff --git a/ydb/core/base/CMakeLists.linux-aarch64.txt b/ydb/core/base/CMakeLists.linux-aarch64.txt index 8439bb743e78..90c5ec4c5b9a 100644 --- a/ydb/core/base/CMakeLists.linux-aarch64.txt +++ b/ydb/core/base/CMakeLists.linux-aarch64.txt @@ -29,9 +29,9 @@ target_link_libraries(ydb-core-base PUBLIC core-base-services ydb-core-debug ydb-core-erasure + core-graph-api ydb-core-protos core-protos-out - ydb-core-scheme ydb-library-aclib ydb-library-login ydb-library-pdisk_io @@ -43,6 +43,42 @@ target_link_libraries(ydb-core-base PUBLIC library-cpp-dwarf_backtrace ) target_sources(ydb-core-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/base/appdata.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/backtrace.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/blobstorage.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/channel_profiles.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/domain.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/event_filter.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/group_stat.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/hive.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/interconnect_channels.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/localdb.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/location.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/logoblob.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/memobserver.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/nameservice.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/pool_stats_collector.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/resource_profile.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/row_version.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/shared_quota.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/statestorage.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/statestorage_guardian_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/statestorage_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/storage_pools.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/subdomain.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet_pipe.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet_pipecache.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tabletid.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/traceid.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tracing.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tx_processing.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/user_registry.h ${CMAKE_SOURCE_DIR}/ydb/core/base/actor_activity_names.cpp ${CMAKE_SOURCE_DIR}/ydb/core/base/appdata.cpp ${CMAKE_SOURCE_DIR}/ydb/core/base/backtrace.cpp diff --git a/ydb/core/base/CMakeLists.linux-x86_64.txt b/ydb/core/base/CMakeLists.linux-x86_64.txt index 8439bb743e78..90c5ec4c5b9a 100644 --- a/ydb/core/base/CMakeLists.linux-x86_64.txt +++ b/ydb/core/base/CMakeLists.linux-x86_64.txt @@ -29,9 +29,9 @@ target_link_libraries(ydb-core-base PUBLIC core-base-services ydb-core-debug ydb-core-erasure + core-graph-api ydb-core-protos core-protos-out - ydb-core-scheme ydb-library-aclib ydb-library-login ydb-library-pdisk_io @@ -43,6 +43,42 @@ target_link_libraries(ydb-core-base PUBLIC library-cpp-dwarf_backtrace ) target_sources(ydb-core-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/base/appdata.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/backtrace.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/blobstorage.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/channel_profiles.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/domain.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/event_filter.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/group_stat.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/hive.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/interconnect_channels.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/localdb.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/location.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/logoblob.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/memobserver.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/nameservice.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/pool_stats_collector.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/resource_profile.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/row_version.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/shared_quota.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/statestorage.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/statestorage_guardian_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/statestorage_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/storage_pools.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/subdomain.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet_pipe.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet_pipecache.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tabletid.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/traceid.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tracing.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tx_processing.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/user_registry.h ${CMAKE_SOURCE_DIR}/ydb/core/base/actor_activity_names.cpp ${CMAKE_SOURCE_DIR}/ydb/core/base/appdata.cpp ${CMAKE_SOURCE_DIR}/ydb/core/base/backtrace.cpp diff --git a/ydb/core/base/CMakeLists.windows-x86_64.txt b/ydb/core/base/CMakeLists.windows-x86_64.txt index dfa768a96b98..7b53d11c64bb 100644 --- a/ydb/core/base/CMakeLists.windows-x86_64.txt +++ b/ydb/core/base/CMakeLists.windows-x86_64.txt @@ -28,9 +28,9 @@ target_link_libraries(ydb-core-base PUBLIC core-base-services ydb-core-debug ydb-core-erasure + core-graph-api ydb-core-protos core-protos-out - ydb-core-scheme ydb-library-aclib ydb-library-login ydb-library-pdisk_io @@ -41,6 +41,42 @@ target_link_libraries(ydb-core-base PUBLIC cpp-deprecated-atomic ) target_sources(ydb-core-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/base/appdata.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/backtrace.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/blobstorage.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/channel_profiles.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/domain.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/event_filter.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/group_stat.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/hive.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/interconnect_channels.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/localdb.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/location.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/logoblob.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/memobserver.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/nameservice.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/pool_stats_collector.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/resource_profile.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/row_version.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/shared_quota.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/statestorage.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/statestorage_guardian_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/statestorage_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/storage_pools.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/subdomain.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet_pipe.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet_pipecache.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tabletid.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tablet_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/traceid.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tracing.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/tx_processing.h + ${CMAKE_SOURCE_DIR}/ydb/core/base/user_registry.h ${CMAKE_SOURCE_DIR}/ydb/core/base/actor_activity_names.cpp ${CMAKE_SOURCE_DIR}/ydb/core/base/appdata.cpp ${CMAKE_SOURCE_DIR}/ydb/core/base/backtrace.cpp diff --git a/ydb/core/base/services/CMakeLists.darwin-arm64.txt b/ydb/core/base/services/CMakeLists.darwin-arm64.txt index 9104faa00c4f..3563fd08aefc 100644 --- a/ydb/core/base/services/CMakeLists.darwin-arm64.txt +++ b/ydb/core/base/services/CMakeLists.darwin-arm64.txt @@ -16,3 +16,6 @@ target_link_libraries(core-base-services INTERFACE library-actors-interconnect library-actors-helpers ) +target_sources(core-base-services INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/base/services/blobstorage_service_id.h +) diff --git a/ydb/core/base/services/CMakeLists.darwin-x86_64.txt b/ydb/core/base/services/CMakeLists.darwin-x86_64.txt index 9104faa00c4f..3563fd08aefc 100644 --- a/ydb/core/base/services/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/base/services/CMakeLists.darwin-x86_64.txt @@ -16,3 +16,6 @@ target_link_libraries(core-base-services INTERFACE library-actors-interconnect library-actors-helpers ) +target_sources(core-base-services INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/base/services/blobstorage_service_id.h +) diff --git a/ydb/core/base/services/CMakeLists.linux-aarch64.txt b/ydb/core/base/services/CMakeLists.linux-aarch64.txt index 171dae54225e..8925b1e8b391 100644 --- a/ydb/core/base/services/CMakeLists.linux-aarch64.txt +++ b/ydb/core/base/services/CMakeLists.linux-aarch64.txt @@ -17,3 +17,6 @@ target_link_libraries(core-base-services INTERFACE library-actors-interconnect library-actors-helpers ) +target_sources(core-base-services INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/base/services/blobstorage_service_id.h +) diff --git a/ydb/core/base/services/CMakeLists.linux-x86_64.txt b/ydb/core/base/services/CMakeLists.linux-x86_64.txt index 171dae54225e..8925b1e8b391 100644 --- a/ydb/core/base/services/CMakeLists.linux-x86_64.txt +++ b/ydb/core/base/services/CMakeLists.linux-x86_64.txt @@ -17,3 +17,6 @@ target_link_libraries(core-base-services INTERFACE library-actors-interconnect library-actors-helpers ) +target_sources(core-base-services INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/base/services/blobstorage_service_id.h +) diff --git a/ydb/core/base/services/CMakeLists.windows-x86_64.txt b/ydb/core/base/services/CMakeLists.windows-x86_64.txt index 9104faa00c4f..3563fd08aefc 100644 --- a/ydb/core/base/services/CMakeLists.windows-x86_64.txt +++ b/ydb/core/base/services/CMakeLists.windows-x86_64.txt @@ -16,3 +16,6 @@ target_link_libraries(core-base-services INTERFACE library-actors-interconnect library-actors-helpers ) +target_sources(core-base-services INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/base/services/blobstorage_service_id.h +) diff --git a/ydb/core/base/ut/CMakeLists.darwin-arm64.txt b/ydb/core/base/ut/CMakeLists.darwin-arm64.txt index 0846008a4eba..2181112608b4 100644 --- a/ydb/core/base/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/base/ut/CMakeLists.darwin-arm64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-core-base-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-base-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/base/ut/path_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/base/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/base/ut/CMakeLists.darwin-x86_64.txt index 3b942310d6f1..0431707e6423 100644 --- a/ydb/core/base/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/base/ut/CMakeLists.darwin-x86_64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-core-base-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-base-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/base/ut/path_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/base/ut/CMakeLists.linux-aarch64.txt b/ydb/core/base/ut/CMakeLists.linux-aarch64.txt index c95512a9d830..21a9249cd7dc 100644 --- a/ydb/core/base/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/base/ut/CMakeLists.linux-aarch64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-core-base-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-base-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/base/ut/path_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/base/ut/CMakeLists.linux-x86_64.txt b/ydb/core/base/ut/CMakeLists.linux-x86_64.txt index febb0aba96e9..7b754b8142fb 100644 --- a/ydb/core/base/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/base/ut/CMakeLists.linux-x86_64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-core-base-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-base-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/base/ut/path_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/base/ut/CMakeLists.windows-x86_64.txt b/ydb/core/base/ut/CMakeLists.windows-x86_64.txt index 4f061c51af01..96ee4500fd60 100644 --- a/ydb/core/base/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/base/ut/CMakeLists.windows-x86_64.txt @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/base/ut_board_subscriber/CMakeLists.darwin-arm64.txt b/ydb/core/base/ut_board_subscriber/CMakeLists.darwin-arm64.txt index 525cc9a7955d..068c3470cb73 100644 --- a/ydb/core/base/ut_board_subscriber/CMakeLists.darwin-arm64.txt +++ b/ydb/core/base/ut_board_subscriber/CMakeLists.darwin-arm64.txt @@ -24,13 +24,12 @@ target_link_libraries(ydb-core-base-ut_board_subscriber PUBLIC cpp-testing-unittest core-testlib-basics testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-core-base-ut_board_subscriber PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-base-ut_board_subscriber PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/base/board_subscriber_ut.cpp @@ -60,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/base/ut_board_subscriber/CMakeLists.darwin-x86_64.txt b/ydb/core/base/ut_board_subscriber/CMakeLists.darwin-x86_64.txt index a23759b69aac..bb3888b0fecc 100644 --- a/ydb/core/base/ut_board_subscriber/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/base/ut_board_subscriber/CMakeLists.darwin-x86_64.txt @@ -25,13 +25,12 @@ target_link_libraries(ydb-core-base-ut_board_subscriber PUBLIC cpp-testing-unittest core-testlib-basics testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-core-base-ut_board_subscriber PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-base-ut_board_subscriber PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/base/board_subscriber_ut.cpp @@ -61,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/base/ut_board_subscriber/CMakeLists.linux-aarch64.txt b/ydb/core/base/ut_board_subscriber/CMakeLists.linux-aarch64.txt index cfbe3f4a2863..c08325091b37 100644 --- a/ydb/core/base/ut_board_subscriber/CMakeLists.linux-aarch64.txt +++ b/ydb/core/base/ut_board_subscriber/CMakeLists.linux-aarch64.txt @@ -25,6 +25,7 @@ target_link_libraries(ydb-core-base-ut_board_subscriber PUBLIC cpp-testing-unittest core-testlib-basics testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-core-base-ut_board_subscriber PRIVATE -ldl @@ -32,9 +33,6 @@ target_link_options(ydb-core-base-ut_board_subscriber PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-base-ut_board_subscriber PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/base/board_subscriber_ut.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/base/ut_board_subscriber/CMakeLists.linux-x86_64.txt b/ydb/core/base/ut_board_subscriber/CMakeLists.linux-x86_64.txt index 505cee05908e..247bc95f6727 100644 --- a/ydb/core/base/ut_board_subscriber/CMakeLists.linux-x86_64.txt +++ b/ydb/core/base/ut_board_subscriber/CMakeLists.linux-x86_64.txt @@ -26,6 +26,7 @@ target_link_libraries(ydb-core-base-ut_board_subscriber PUBLIC cpp-testing-unittest core-testlib-basics testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-core-base-ut_board_subscriber PRIVATE -ldl @@ -33,9 +34,6 @@ target_link_options(ydb-core-base-ut_board_subscriber PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-base-ut_board_subscriber PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/base/board_subscriber_ut.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/base/ut_board_subscriber/CMakeLists.windows-x86_64.txt b/ydb/core/base/ut_board_subscriber/CMakeLists.windows-x86_64.txt index 44d92d40f408..c022d883a6f7 100644 --- a/ydb/core/base/ut_board_subscriber/CMakeLists.windows-x86_64.txt +++ b/ydb/core/base/ut_board_subscriber/CMakeLists.windows-x86_64.txt @@ -25,6 +25,7 @@ target_link_libraries(ydb-core-base-ut_board_subscriber PUBLIC cpp-testing-unittest core-testlib-basics testlib-basics-default + minikql-comp_nodes-llvm14 ) target_sources(ydb-core-base-ut_board_subscriber PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/base/board_subscriber_ut.cpp @@ -54,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blob_depot/CMakeLists.darwin-arm64.txt b/ydb/core/blob_depot/CMakeLists.darwin-arm64.txt index 601a05c08f34..6058c9f1f4d7 100644 --- a/ydb/core/blob_depot/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blob_depot/CMakeLists.darwin-arm64.txt @@ -18,6 +18,22 @@ target_link_libraries(ydb-core-blob_depot PUBLIC ydb-core-protos ) target_sources(ydb-core-blob_depot PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/blob_depot.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/types.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/assimilator.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/blob_depot_tablet.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/blocks.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/coro_tx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/data.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/data_resolve.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/data_uncertain.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/garbage_collection.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/mon_main.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/space_monitor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/testing.h ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/blob_depot.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/assimilator.cpp diff --git a/ydb/core/blob_depot/CMakeLists.darwin-x86_64.txt b/ydb/core/blob_depot/CMakeLists.darwin-x86_64.txt index 601a05c08f34..6058c9f1f4d7 100644 --- a/ydb/core/blob_depot/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blob_depot/CMakeLists.darwin-x86_64.txt @@ -18,6 +18,22 @@ target_link_libraries(ydb-core-blob_depot PUBLIC ydb-core-protos ) target_sources(ydb-core-blob_depot PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/blob_depot.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/types.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/assimilator.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/blob_depot_tablet.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/blocks.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/coro_tx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/data.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/data_resolve.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/data_uncertain.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/garbage_collection.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/mon_main.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/space_monitor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/testing.h ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/blob_depot.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/assimilator.cpp diff --git a/ydb/core/blob_depot/CMakeLists.linux-aarch64.txt b/ydb/core/blob_depot/CMakeLists.linux-aarch64.txt index e12fd5266e98..ddb31981d098 100644 --- a/ydb/core/blob_depot/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blob_depot/CMakeLists.linux-aarch64.txt @@ -19,6 +19,22 @@ target_link_libraries(ydb-core-blob_depot PUBLIC ydb-core-protos ) target_sources(ydb-core-blob_depot PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/blob_depot.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/types.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/assimilator.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/blob_depot_tablet.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/blocks.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/coro_tx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/data.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/data_resolve.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/data_uncertain.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/garbage_collection.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/mon_main.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/space_monitor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/testing.h ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/blob_depot.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/assimilator.cpp diff --git a/ydb/core/blob_depot/CMakeLists.linux-x86_64.txt b/ydb/core/blob_depot/CMakeLists.linux-x86_64.txt index e12fd5266e98..ddb31981d098 100644 --- a/ydb/core/blob_depot/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blob_depot/CMakeLists.linux-x86_64.txt @@ -19,6 +19,22 @@ target_link_libraries(ydb-core-blob_depot PUBLIC ydb-core-protos ) target_sources(ydb-core-blob_depot PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/blob_depot.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/types.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/assimilator.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/blob_depot_tablet.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/blocks.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/coro_tx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/data.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/data_resolve.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/data_uncertain.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/garbage_collection.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/mon_main.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/space_monitor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/testing.h ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/blob_depot.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/assimilator.cpp diff --git a/ydb/core/blob_depot/CMakeLists.windows-x86_64.txt b/ydb/core/blob_depot/CMakeLists.windows-x86_64.txt index 601a05c08f34..6058c9f1f4d7 100644 --- a/ydb/core/blob_depot/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blob_depot/CMakeLists.windows-x86_64.txt @@ -18,6 +18,22 @@ target_link_libraries(ydb-core-blob_depot PUBLIC ydb-core-protos ) target_sources(ydb-core-blob_depot PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/blob_depot.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/types.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/assimilator.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/blob_depot_tablet.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/blocks.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/coro_tx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/data.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/data_resolve.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/data_uncertain.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/garbage_collection.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/mon_main.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/space_monitor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/testing.h ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/blob_depot.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/assimilator.cpp diff --git a/ydb/core/blob_depot/agent/CMakeLists.darwin-arm64.txt b/ydb/core/blob_depot/agent/CMakeLists.darwin-arm64.txt index c18d69d6cf9f..924636a6f417 100644 --- a/ydb/core/blob_depot/agent/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blob_depot/agent/CMakeLists.darwin-arm64.txt @@ -16,6 +16,12 @@ target_link_libraries(core-blob_depot-agent PUBLIC ydb-core-protos ) target_sources(core-blob_depot-agent PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/agent.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/agent_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/blob_mapping_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/blocks.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/resolved_value.h ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/agent.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/blob_mapping_cache.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/blocks.cpp diff --git a/ydb/core/blob_depot/agent/CMakeLists.darwin-x86_64.txt b/ydb/core/blob_depot/agent/CMakeLists.darwin-x86_64.txt index c18d69d6cf9f..924636a6f417 100644 --- a/ydb/core/blob_depot/agent/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blob_depot/agent/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,12 @@ target_link_libraries(core-blob_depot-agent PUBLIC ydb-core-protos ) target_sources(core-blob_depot-agent PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/agent.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/agent_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/blob_mapping_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/blocks.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/resolved_value.h ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/agent.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/blob_mapping_cache.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/blocks.cpp diff --git a/ydb/core/blob_depot/agent/CMakeLists.linux-aarch64.txt b/ydb/core/blob_depot/agent/CMakeLists.linux-aarch64.txt index 37da1726ef2a..408074da382f 100644 --- a/ydb/core/blob_depot/agent/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blob_depot/agent/CMakeLists.linux-aarch64.txt @@ -17,6 +17,12 @@ target_link_libraries(core-blob_depot-agent PUBLIC ydb-core-protos ) target_sources(core-blob_depot-agent PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/agent.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/agent_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/blob_mapping_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/blocks.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/resolved_value.h ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/agent.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/blob_mapping_cache.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/blocks.cpp diff --git a/ydb/core/blob_depot/agent/CMakeLists.linux-x86_64.txt b/ydb/core/blob_depot/agent/CMakeLists.linux-x86_64.txt index 37da1726ef2a..408074da382f 100644 --- a/ydb/core/blob_depot/agent/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blob_depot/agent/CMakeLists.linux-x86_64.txt @@ -17,6 +17,12 @@ target_link_libraries(core-blob_depot-agent PUBLIC ydb-core-protos ) target_sources(core-blob_depot-agent PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/agent.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/agent_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/blob_mapping_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/blocks.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/resolved_value.h ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/agent.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/blob_mapping_cache.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/blocks.cpp diff --git a/ydb/core/blob_depot/agent/CMakeLists.windows-x86_64.txt b/ydb/core/blob_depot/agent/CMakeLists.windows-x86_64.txt index c18d69d6cf9f..924636a6f417 100644 --- a/ydb/core/blob_depot/agent/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blob_depot/agent/CMakeLists.windows-x86_64.txt @@ -16,6 +16,12 @@ target_link_libraries(core-blob_depot-agent PUBLIC ydb-core-protos ) target_sources(core-blob_depot-agent PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/agent.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/agent_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/blob_mapping_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/blocks.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/resolved_value.h ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/agent.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/blob_mapping_cache.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/agent/blocks.cpp diff --git a/ydb/core/blob_depot/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blob_depot/ut/CMakeLists.darwin-arm64.txt index c74fa9a7d068..017232c5bef6 100644 --- a/ydb/core/blob_depot/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blob_depot/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-core-blob_depot-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blob_depot-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/closed_interval_set_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blob_depot/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blob_depot/ut/CMakeLists.darwin-x86_64.txt index 88c56c58f2fd..fbafba6738fc 100644 --- a/ydb/core/blob_depot/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blob_depot/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-core-blob_depot-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blob_depot-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/closed_interval_set_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blob_depot/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blob_depot/ut/CMakeLists.linux-aarch64.txt index 941634f5f7f0..84ddb021cf8a 100644 --- a/ydb/core/blob_depot/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blob_depot/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-core-blob_depot-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blob_depot-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/closed_interval_set_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blob_depot/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blob_depot/ut/CMakeLists.linux-x86_64.txt index dabbcfcf71cb..e7660e7a4e13 100644 --- a/ydb/core/blob_depot/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blob_depot/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-core-blob_depot-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blob_depot-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blob_depot/closed_interval_set_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blob_depot/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blob_depot/ut/CMakeLists.windows-x86_64.txt index 12c675dd52dc..fc9826b6b3c3 100644 --- a/ydb/core/blob_depot/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blob_depot/ut/CMakeLists.windows-x86_64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/CMakeLists.darwin-arm64.txt index 68b0f9d3f56c..9587189349c9 100644 --- a/ydb/core/blobstorage/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/CMakeLists.darwin-arm64.txt @@ -45,3 +45,6 @@ target_link_libraries(ydb-core-blobstorage INTERFACE core-blobstorage-storagepoolmon core-blobstorage-vdisk ) +target_sources(ydb-core-blobstorage INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/defs.h +) diff --git a/ydb/core/blobstorage/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/CMakeLists.darwin-x86_64.txt index 68b0f9d3f56c..9587189349c9 100644 --- a/ydb/core/blobstorage/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/CMakeLists.darwin-x86_64.txt @@ -45,3 +45,6 @@ target_link_libraries(ydb-core-blobstorage INTERFACE core-blobstorage-storagepoolmon core-blobstorage-vdisk ) +target_sources(ydb-core-blobstorage INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/defs.h +) diff --git a/ydb/core/blobstorage/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/CMakeLists.linux-aarch64.txt index 93d433b2b5fc..8ccf2f330f46 100644 --- a/ydb/core/blobstorage/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/CMakeLists.linux-aarch64.txt @@ -46,3 +46,6 @@ target_link_libraries(ydb-core-blobstorage INTERFACE core-blobstorage-storagepoolmon core-blobstorage-vdisk ) +target_sources(ydb-core-blobstorage INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/defs.h +) diff --git a/ydb/core/blobstorage/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/CMakeLists.linux-x86_64.txt index 93d433b2b5fc..8ccf2f330f46 100644 --- a/ydb/core/blobstorage/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/CMakeLists.linux-x86_64.txt @@ -46,3 +46,6 @@ target_link_libraries(ydb-core-blobstorage INTERFACE core-blobstorage-storagepoolmon core-blobstorage-vdisk ) +target_sources(ydb-core-blobstorage INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/defs.h +) diff --git a/ydb/core/blobstorage/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/CMakeLists.windows-x86_64.txt index 68b0f9d3f56c..9587189349c9 100644 --- a/ydb/core/blobstorage/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/CMakeLists.windows-x86_64.txt @@ -45,3 +45,6 @@ target_link_libraries(ydb-core-blobstorage INTERFACE core-blobstorage-storagepoolmon core-blobstorage-vdisk ) +target_sources(ydb-core-blobstorage INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/defs.h +) diff --git a/ydb/core/blobstorage/backpressure/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/backpressure/CMakeLists.darwin-arm64.txt index e5d77fdae0b7..ceac6e237594 100644 --- a/ydb/core/blobstorage/backpressure/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/backpressure/CMakeLists.darwin-arm64.txt @@ -23,6 +23,14 @@ target_link_libraries(core-blobstorage-backpressure PUBLIC ydb-core-protos ) target_sources(core-blobstorage-backpressure PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/event.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_client.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_server.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/unisched.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/event.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_client.cpp diff --git a/ydb/core/blobstorage/backpressure/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/backpressure/CMakeLists.darwin-x86_64.txt index e5d77fdae0b7..ceac6e237594 100644 --- a/ydb/core/blobstorage/backpressure/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/backpressure/CMakeLists.darwin-x86_64.txt @@ -23,6 +23,14 @@ target_link_libraries(core-blobstorage-backpressure PUBLIC ydb-core-protos ) target_sources(core-blobstorage-backpressure PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/event.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_client.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_server.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/unisched.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/event.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_client.cpp diff --git a/ydb/core/blobstorage/backpressure/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/backpressure/CMakeLists.linux-aarch64.txt index bfa651249a60..688b733df828 100644 --- a/ydb/core/blobstorage/backpressure/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/backpressure/CMakeLists.linux-aarch64.txt @@ -24,6 +24,14 @@ target_link_libraries(core-blobstorage-backpressure PUBLIC ydb-core-protos ) target_sources(core-blobstorage-backpressure PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/event.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_client.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_server.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/unisched.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/event.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_client.cpp diff --git a/ydb/core/blobstorage/backpressure/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/backpressure/CMakeLists.linux-x86_64.txt index bfa651249a60..688b733df828 100644 --- a/ydb/core/blobstorage/backpressure/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/backpressure/CMakeLists.linux-x86_64.txt @@ -24,6 +24,14 @@ target_link_libraries(core-blobstorage-backpressure PUBLIC ydb-core-protos ) target_sources(core-blobstorage-backpressure PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/event.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_client.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_server.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/unisched.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/event.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_client.cpp diff --git a/ydb/core/blobstorage/backpressure/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/backpressure/CMakeLists.windows-x86_64.txt index e5d77fdae0b7..ceac6e237594 100644 --- a/ydb/core/blobstorage/backpressure/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/backpressure/CMakeLists.windows-x86_64.txt @@ -23,6 +23,14 @@ target_link_libraries(core-blobstorage-backpressure PUBLIC ydb-core-protos ) target_sources(core-blobstorage-backpressure PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/event.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_client.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_server.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/unisched.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/event.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_client.cpp diff --git a/ydb/core/blobstorage/backpressure/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/backpressure/ut/CMakeLists.darwin-arm64.txt index fb8a0c70c893..8808bc35e755 100644 --- a/ydb/core/blobstorage/backpressure/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/backpressure/ut/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-blobstorage-backpressure-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-backpressure-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_client_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/backpressure/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/backpressure/ut/CMakeLists.darwin-x86_64.txt index 92ecd9ad5e5f..ec766c95179c 100644 --- a/ydb/core/blobstorage/backpressure/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/backpressure/ut/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-blobstorage-backpressure-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-backpressure-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_client_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/backpressure/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/backpressure/ut/CMakeLists.linux-aarch64.txt index f75e12197e13..c0f8ce04fc4f 100644 --- a/ydb/core/blobstorage/backpressure/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/backpressure/ut/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-blobstorage-backpressure-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-backpressure-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_client_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/backpressure/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/backpressure/ut/CMakeLists.linux-x86_64.txt index b03121d6cfab..277d8ee21c28 100644 --- a/ydb/core/blobstorage/backpressure/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/backpressure/ut/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-blobstorage-backpressure-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-backpressure-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/queue_backpressure_client_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/backpressure/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/backpressure/ut/CMakeLists.windows-x86_64.txt index a1c24d85862a..ea550cc88871 100644 --- a/ydb/core/blobstorage/backpressure/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/backpressure/ut/CMakeLists.windows-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/backpressure/ut_client/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/backpressure/ut_client/CMakeLists.darwin-arm64.txt index 1e8fec3fcafd..2da82393bbcf 100644 --- a/ydb/core/blobstorage/backpressure/ut_client/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/backpressure/ut_client/CMakeLists.darwin-arm64.txt @@ -27,10 +27,11 @@ target_link_options(ydb-core-blobstorage-backpressure-ut_client PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-backpressure-ut_client PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/ut_client/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/ut_client/loader.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/ut_client/skeleton_front_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/ut_client/backpressure_ut.cpp ) set_property( @@ -58,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/backpressure/ut_client/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/backpressure/ut_client/CMakeLists.darwin-x86_64.txt index 11ec47d4904d..c8c9193df2f3 100644 --- a/ydb/core/blobstorage/backpressure/ut_client/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/backpressure/ut_client/CMakeLists.darwin-x86_64.txt @@ -28,10 +28,11 @@ target_link_options(ydb-core-blobstorage-backpressure-ut_client PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-backpressure-ut_client PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/ut_client/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/ut_client/loader.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/ut_client/skeleton_front_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/ut_client/backpressure_ut.cpp ) set_property( @@ -59,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/backpressure/ut_client/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/backpressure/ut_client/CMakeLists.linux-aarch64.txt index ca1852fce5fc..d4e478db4cf7 100644 --- a/ydb/core/blobstorage/backpressure/ut_client/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/backpressure/ut_client/CMakeLists.linux-aarch64.txt @@ -30,11 +30,11 @@ target_link_options(ydb-core-blobstorage-backpressure-ut_client PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-backpressure-ut_client PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/ut_client/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/ut_client/loader.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/ut_client/skeleton_front_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/ut_client/backpressure_ut.cpp ) set_property( @@ -62,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/backpressure/ut_client/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/backpressure/ut_client/CMakeLists.linux-x86_64.txt index b3845044aa30..fc97f175542f 100644 --- a/ydb/core/blobstorage/backpressure/ut_client/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/backpressure/ut_client/CMakeLists.linux-x86_64.txt @@ -31,11 +31,11 @@ target_link_options(ydb-core-blobstorage-backpressure-ut_client PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-backpressure-ut_client PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/ut_client/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/ut_client/loader.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/ut_client/skeleton_front_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/ut_client/backpressure_ut.cpp ) set_property( @@ -63,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/backpressure/ut_client/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/backpressure/ut_client/CMakeLists.windows-x86_64.txt index 882f909a7699..fd47ffdceb9d 100644 --- a/ydb/core/blobstorage/backpressure/ut_client/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/backpressure/ut_client/CMakeLists.windows-x86_64.txt @@ -25,6 +25,9 @@ target_link_libraries(ydb-core-blobstorage-backpressure-ut_client PUBLIC udf-service-stub ) target_sources(ydb-core-blobstorage-backpressure-ut_client PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/ut_client/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/ut_client/loader.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/ut_client/skeleton_front_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/backpressure/ut_client/backpressure_ut.cpp ) set_property( @@ -52,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/base/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/base/CMakeLists.darwin-arm64.txt index 1de126851572..bd547d6706f4 100644 --- a/ydb/core/blobstorage/base/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/base/CMakeLists.darwin-arm64.txt @@ -18,6 +18,18 @@ target_link_libraries(core-blobstorage-base PUBLIC ydb-core-protos ) target_sources(core-blobstorage-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/batched_vec.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_oos_defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_vdiskid.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_syncstate.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/html.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/ptr.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/vdisk_lsn.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/vdisk_sync_common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/vdisk_priorities.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/utility.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_events.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_vdiskid.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_syncstate.cpp diff --git a/ydb/core/blobstorage/base/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/base/CMakeLists.darwin-x86_64.txt index 1de126851572..bd547d6706f4 100644 --- a/ydb/core/blobstorage/base/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/base/CMakeLists.darwin-x86_64.txt @@ -18,6 +18,18 @@ target_link_libraries(core-blobstorage-base PUBLIC ydb-core-protos ) target_sources(core-blobstorage-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/batched_vec.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_oos_defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_vdiskid.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_syncstate.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/html.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/ptr.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/vdisk_lsn.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/vdisk_sync_common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/vdisk_priorities.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/utility.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_events.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_vdiskid.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_syncstate.cpp diff --git a/ydb/core/blobstorage/base/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/base/CMakeLists.linux-aarch64.txt index a0586c525fbc..e355846bebe0 100644 --- a/ydb/core/blobstorage/base/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/base/CMakeLists.linux-aarch64.txt @@ -19,6 +19,18 @@ target_link_libraries(core-blobstorage-base PUBLIC ydb-core-protos ) target_sources(core-blobstorage-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/batched_vec.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_oos_defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_vdiskid.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_syncstate.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/html.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/ptr.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/vdisk_lsn.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/vdisk_sync_common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/vdisk_priorities.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/utility.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_events.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_vdiskid.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_syncstate.cpp diff --git a/ydb/core/blobstorage/base/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/base/CMakeLists.linux-x86_64.txt index a0586c525fbc..e355846bebe0 100644 --- a/ydb/core/blobstorage/base/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/base/CMakeLists.linux-x86_64.txt @@ -19,6 +19,18 @@ target_link_libraries(core-blobstorage-base PUBLIC ydb-core-protos ) target_sources(core-blobstorage-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/batched_vec.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_oos_defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_vdiskid.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_syncstate.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/html.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/ptr.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/vdisk_lsn.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/vdisk_sync_common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/vdisk_priorities.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/utility.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_events.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_vdiskid.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_syncstate.cpp diff --git a/ydb/core/blobstorage/base/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/base/CMakeLists.windows-x86_64.txt index 1de126851572..bd547d6706f4 100644 --- a/ydb/core/blobstorage/base/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/base/CMakeLists.windows-x86_64.txt @@ -18,6 +18,18 @@ target_link_libraries(core-blobstorage-base PUBLIC ydb-core-protos ) target_sources(core-blobstorage-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/batched_vec.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_oos_defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_vdiskid.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_syncstate.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/html.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/ptr.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/vdisk_lsn.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/vdisk_sync_common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/vdisk_priorities.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/utility.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_events.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_vdiskid.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/blobstorage_syncstate.cpp diff --git a/ydb/core/blobstorage/base/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/base/ut/CMakeLists.darwin-arm64.txt index e2ed31e39866..cc79b86a8aea 100644 --- a/ydb/core/blobstorage/base/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/base/ut/CMakeLists.darwin-arm64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-core-blobstorage-base-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-base-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/batched_vec_ut.cpp @@ -43,6 +41,7 @@ set_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_property( TEST diff --git a/ydb/core/blobstorage/base/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/base/ut/CMakeLists.darwin-x86_64.txt index 27587b97f51e..ef09be7659a5 100644 --- a/ydb/core/blobstorage/base/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/base/ut/CMakeLists.darwin-x86_64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-core-blobstorage-base-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-base-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/batched_vec_ut.cpp @@ -44,6 +42,7 @@ set_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_property( TEST diff --git a/ydb/core/blobstorage/base/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/base/ut/CMakeLists.linux-aarch64.txt index f93bc0867b2a..ac3826de7ea9 100644 --- a/ydb/core/blobstorage/base/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/base/ut/CMakeLists.linux-aarch64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-core-blobstorage-base-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-base-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/batched_vec_ut.cpp @@ -47,6 +44,7 @@ set_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_property( TEST diff --git a/ydb/core/blobstorage/base/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/base/ut/CMakeLists.linux-x86_64.txt index 8eb4be35d7fc..2730d79b4ef7 100644 --- a/ydb/core/blobstorage/base/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/base/ut/CMakeLists.linux-x86_64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-core-blobstorage-base-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-base-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/base/batched_vec_ut.cpp @@ -48,6 +45,7 @@ set_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_property( TEST diff --git a/ydb/core/blobstorage/base/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/base/ut/CMakeLists.windows-x86_64.txt index 7faedc25739d..5f88274eaee5 100644 --- a/ydb/core/blobstorage/base/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/base/ut/CMakeLists.windows-x86_64.txt @@ -37,6 +37,7 @@ set_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_property( TEST diff --git a/ydb/core/blobstorage/crypto/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/crypto/CMakeLists.darwin-arm64.txt index 5fb7db780812..2118ab2f7f0a 100644 --- a/ydb/core/blobstorage/crypto/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/crypto/CMakeLists.darwin-arm64.txt @@ -17,6 +17,7 @@ target_link_libraries(core-blobstorage-crypto PUBLIC library-actors-util ) target_sources(core-blobstorage-crypto PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/crypto.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/chacha.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/crypto.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/poly1305.cpp diff --git a/ydb/core/blobstorage/crypto/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/crypto/CMakeLists.darwin-x86_64.txt index 0d5aaf0045fd..6ee87adff500 100644 --- a/ydb/core/blobstorage/crypto/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/crypto/CMakeLists.darwin-x86_64.txt @@ -17,6 +17,7 @@ target_link_libraries(core-blobstorage-crypto PUBLIC library-actors-util ) target_sources(core-blobstorage-crypto PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/crypto.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/chacha.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/crypto.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/poly1305.cpp diff --git a/ydb/core/blobstorage/crypto/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/crypto/CMakeLists.linux-aarch64.txt index 475ed669f39f..5f306a04ccae 100644 --- a/ydb/core/blobstorage/crypto/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/crypto/CMakeLists.linux-aarch64.txt @@ -18,6 +18,7 @@ target_link_libraries(core-blobstorage-crypto PUBLIC library-actors-util ) target_sources(core-blobstorage-crypto PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/crypto.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/chacha.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/crypto.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/poly1305.cpp diff --git a/ydb/core/blobstorage/crypto/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/crypto/CMakeLists.linux-x86_64.txt index 5f644bf8f458..34154392a738 100644 --- a/ydb/core/blobstorage/crypto/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/crypto/CMakeLists.linux-x86_64.txt @@ -18,6 +18,7 @@ target_link_libraries(core-blobstorage-crypto PUBLIC library-actors-util ) target_sources(core-blobstorage-crypto PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/crypto.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/chacha.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/crypto.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/poly1305.cpp diff --git a/ydb/core/blobstorage/crypto/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/crypto/CMakeLists.windows-x86_64.txt index 5fb7db780812..2118ab2f7f0a 100644 --- a/ydb/core/blobstorage/crypto/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/crypto/CMakeLists.windows-x86_64.txt @@ -17,6 +17,7 @@ target_link_libraries(core-blobstorage-crypto PUBLIC library-actors-util ) target_sources(core-blobstorage-crypto PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/crypto.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/chacha.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/crypto.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/poly1305.cpp diff --git a/ydb/core/blobstorage/crypto/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/crypto/ut/CMakeLists.darwin-arm64.txt index 23ddb219a971..10c2c001fe78 100644 --- a/ydb/core/blobstorage/crypto/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/crypto/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-core-blobstorage-crypto-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-crypto-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/chacha_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/crypto/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/crypto/ut/CMakeLists.darwin-x86_64.txt index 8a9975fbf263..3bc5bcd005a8 100644 --- a/ydb/core/blobstorage/crypto/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/crypto/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-core-blobstorage-crypto-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-crypto-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/chacha_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/crypto/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/crypto/ut/CMakeLists.linux-aarch64.txt index e43314a95b96..a229cc05bffe 100644 --- a/ydb/core/blobstorage/crypto/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/crypto/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-core-blobstorage-crypto-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-crypto-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/chacha_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/crypto/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/crypto/ut/CMakeLists.linux-x86_64.txt index 7e4159190903..049bad8ab231 100644 --- a/ydb/core/blobstorage/crypto/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/crypto/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-core-blobstorage-crypto-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-crypto-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/crypto/chacha_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/crypto/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/crypto/ut/CMakeLists.windows-x86_64.txt index 5fbf413500a4..c995a8707b18 100644 --- a/ydb/core/blobstorage/crypto/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/crypto/ut/CMakeLists.windows-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/dsproxy/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/dsproxy/CMakeLists.darwin-arm64.txt index cc7101fad7de..7af3483fb28f 100644 --- a/ydb/core/blobstorage/dsproxy/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/dsproxy/CMakeLists.darwin-arm64.txt @@ -10,6 +10,7 @@ add_subdirectory(mock) add_subdirectory(ut) add_subdirectory(ut_fat) add_subdirectory(ut_ftol) +add_subdirectory(ut_strategy) add_library(core-blobstorage-dsproxy) target_link_libraries(core-blobstorage-dsproxy PUBLIC @@ -26,6 +27,32 @@ target_link_libraries(core-blobstorage-dsproxy PUBLIC ydb-core-util ) target_sources(core-blobstorage-dsproxy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_blackboard.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_get_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_monactor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_nodemon.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_nodemonactor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_put_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_quorum_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_responsiveness.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_accelerate_put.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_accelerate_put_m3dc.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_base.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_bold.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_m3dc_basic.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_m3dc_restore.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_m3of4.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_min_iops_block.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_min_iops_mirror.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_m3of4_base.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_put_m3dc.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_put_m3of4.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_restore.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/group_sessions.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/log_acc.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_encrypt.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_request.cpp diff --git a/ydb/core/blobstorage/dsproxy/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/dsproxy/CMakeLists.darwin-x86_64.txt index cc7101fad7de..7af3483fb28f 100644 --- a/ydb/core/blobstorage/dsproxy/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/dsproxy/CMakeLists.darwin-x86_64.txt @@ -10,6 +10,7 @@ add_subdirectory(mock) add_subdirectory(ut) add_subdirectory(ut_fat) add_subdirectory(ut_ftol) +add_subdirectory(ut_strategy) add_library(core-blobstorage-dsproxy) target_link_libraries(core-blobstorage-dsproxy PUBLIC @@ -26,6 +27,32 @@ target_link_libraries(core-blobstorage-dsproxy PUBLIC ydb-core-util ) target_sources(core-blobstorage-dsproxy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_blackboard.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_get_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_monactor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_nodemon.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_nodemonactor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_put_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_quorum_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_responsiveness.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_accelerate_put.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_accelerate_put_m3dc.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_base.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_bold.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_m3dc_basic.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_m3dc_restore.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_m3of4.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_min_iops_block.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_min_iops_mirror.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_m3of4_base.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_put_m3dc.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_put_m3of4.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_restore.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/group_sessions.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/log_acc.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_encrypt.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_request.cpp diff --git a/ydb/core/blobstorage/dsproxy/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/dsproxy/CMakeLists.linux-aarch64.txt index 478beeec5a89..514c72308304 100644 --- a/ydb/core/blobstorage/dsproxy/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/dsproxy/CMakeLists.linux-aarch64.txt @@ -10,6 +10,7 @@ add_subdirectory(mock) add_subdirectory(ut) add_subdirectory(ut_fat) add_subdirectory(ut_ftol) +add_subdirectory(ut_strategy) add_library(core-blobstorage-dsproxy) target_link_libraries(core-blobstorage-dsproxy PUBLIC @@ -27,6 +28,32 @@ target_link_libraries(core-blobstorage-dsproxy PUBLIC ydb-core-util ) target_sources(core-blobstorage-dsproxy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_blackboard.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_get_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_monactor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_nodemon.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_nodemonactor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_put_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_quorum_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_responsiveness.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_accelerate_put.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_accelerate_put_m3dc.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_base.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_bold.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_m3dc_basic.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_m3dc_restore.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_m3of4.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_min_iops_block.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_min_iops_mirror.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_m3of4_base.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_put_m3dc.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_put_m3of4.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_restore.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/group_sessions.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/log_acc.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_encrypt.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_request.cpp diff --git a/ydb/core/blobstorage/dsproxy/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/dsproxy/CMakeLists.linux-x86_64.txt index 478beeec5a89..514c72308304 100644 --- a/ydb/core/blobstorage/dsproxy/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/dsproxy/CMakeLists.linux-x86_64.txt @@ -10,6 +10,7 @@ add_subdirectory(mock) add_subdirectory(ut) add_subdirectory(ut_fat) add_subdirectory(ut_ftol) +add_subdirectory(ut_strategy) add_library(core-blobstorage-dsproxy) target_link_libraries(core-blobstorage-dsproxy PUBLIC @@ -27,6 +28,32 @@ target_link_libraries(core-blobstorage-dsproxy PUBLIC ydb-core-util ) target_sources(core-blobstorage-dsproxy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_blackboard.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_get_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_monactor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_nodemon.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_nodemonactor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_put_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_quorum_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_responsiveness.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_accelerate_put.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_accelerate_put_m3dc.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_base.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_bold.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_m3dc_basic.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_m3dc_restore.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_m3of4.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_min_iops_block.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_min_iops_mirror.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_m3of4_base.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_put_m3dc.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_put_m3of4.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_restore.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/group_sessions.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/log_acc.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_encrypt.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_request.cpp diff --git a/ydb/core/blobstorage/dsproxy/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/dsproxy/CMakeLists.windows-x86_64.txt index cc7101fad7de..7af3483fb28f 100644 --- a/ydb/core/blobstorage/dsproxy/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/dsproxy/CMakeLists.windows-x86_64.txt @@ -10,6 +10,7 @@ add_subdirectory(mock) add_subdirectory(ut) add_subdirectory(ut_fat) add_subdirectory(ut_ftol) +add_subdirectory(ut_strategy) add_library(core-blobstorage-dsproxy) target_link_libraries(core-blobstorage-dsproxy PUBLIC @@ -26,6 +27,32 @@ target_link_libraries(core-blobstorage-dsproxy PUBLIC ydb-core-util ) target_sources(core-blobstorage-dsproxy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_blackboard.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_get_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_monactor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_nodemon.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_nodemonactor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_put_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_quorum_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_responsiveness.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_accelerate_put.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_accelerate_put_m3dc.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_base.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_bold.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_m3dc_basic.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_m3dc_restore.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_m3of4.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_min_iops_block.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_get_min_iops_mirror.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_m3of4_base.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_put_m3dc.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_put_m3of4.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_strategy_restore.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/group_sessions.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/log_acc.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_encrypt.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/dsproxy_request.cpp diff --git a/ydb/core/blobstorage/dsproxy/mock/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/dsproxy/mock/CMakeLists.darwin-arm64.txt index 52990414c993..4c3adac11511 100644 --- a/ydb/core/blobstorage/dsproxy/mock/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/dsproxy/mock/CMakeLists.darwin-arm64.txt @@ -15,5 +15,7 @@ target_link_libraries(blobstorage-dsproxy-mock PUBLIC blobstorage-vdisk-common ) target_sources(blobstorage-dsproxy-mock PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/mock/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/mock/dsproxy_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/mock/dsproxy_mock.cpp ) diff --git a/ydb/core/blobstorage/dsproxy/mock/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/dsproxy/mock/CMakeLists.darwin-x86_64.txt index 52990414c993..4c3adac11511 100644 --- a/ydb/core/blobstorage/dsproxy/mock/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/dsproxy/mock/CMakeLists.darwin-x86_64.txt @@ -15,5 +15,7 @@ target_link_libraries(blobstorage-dsproxy-mock PUBLIC blobstorage-vdisk-common ) target_sources(blobstorage-dsproxy-mock PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/mock/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/mock/dsproxy_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/mock/dsproxy_mock.cpp ) diff --git a/ydb/core/blobstorage/dsproxy/mock/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/dsproxy/mock/CMakeLists.linux-aarch64.txt index a8ae37f8d290..1b9964e0d441 100644 --- a/ydb/core/blobstorage/dsproxy/mock/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/dsproxy/mock/CMakeLists.linux-aarch64.txt @@ -16,5 +16,7 @@ target_link_libraries(blobstorage-dsproxy-mock PUBLIC blobstorage-vdisk-common ) target_sources(blobstorage-dsproxy-mock PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/mock/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/mock/dsproxy_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/mock/dsproxy_mock.cpp ) diff --git a/ydb/core/blobstorage/dsproxy/mock/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/dsproxy/mock/CMakeLists.linux-x86_64.txt index a8ae37f8d290..1b9964e0d441 100644 --- a/ydb/core/blobstorage/dsproxy/mock/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/dsproxy/mock/CMakeLists.linux-x86_64.txt @@ -16,5 +16,7 @@ target_link_libraries(blobstorage-dsproxy-mock PUBLIC blobstorage-vdisk-common ) target_sources(blobstorage-dsproxy-mock PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/mock/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/mock/dsproxy_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/mock/dsproxy_mock.cpp ) diff --git a/ydb/core/blobstorage/dsproxy/mock/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/dsproxy/mock/CMakeLists.windows-x86_64.txt index 52990414c993..4c3adac11511 100644 --- a/ydb/core/blobstorage/dsproxy/mock/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/dsproxy/mock/CMakeLists.windows-x86_64.txt @@ -15,5 +15,7 @@ target_link_libraries(blobstorage-dsproxy-mock PUBLIC blobstorage-vdisk-common ) target_sources(blobstorage-dsproxy-mock PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/mock/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/mock/dsproxy_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/mock/dsproxy_mock.cpp ) diff --git a/ydb/core/blobstorage/dsproxy/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/dsproxy/ut/CMakeLists.darwin-arm64.txt index 3f3cf032b762..903ec2c8d7e3 100644 --- a/ydb/core/blobstorage/dsproxy/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/dsproxy/ut/CMakeLists.darwin-arm64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-core-blobstorage-dsproxy-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-dsproxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/ut/dsproxy_put_ut.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/dsproxy/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/dsproxy/ut/CMakeLists.darwin-x86_64.txt index 525589312059..2645bd0cde13 100644 --- a/ydb/core/blobstorage/dsproxy/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/dsproxy/ut/CMakeLists.darwin-x86_64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-core-blobstorage-dsproxy-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-dsproxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/ut/dsproxy_put_ut.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/dsproxy/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/dsproxy/ut/CMakeLists.linux-aarch64.txt index e1c639e2911c..acf029fef69a 100644 --- a/ydb/core/blobstorage/dsproxy/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/dsproxy/ut/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-core-blobstorage-dsproxy-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-dsproxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/ut/dsproxy_put_ut.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/dsproxy/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/dsproxy/ut/CMakeLists.linux-x86_64.txt index 2590054db34d..6b67baea4995 100644 --- a/ydb/core/blobstorage/dsproxy/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/dsproxy/ut/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-core-blobstorage-dsproxy-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-dsproxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/ut/dsproxy_put_ut.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/dsproxy/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/dsproxy/ut/CMakeLists.windows-x86_64.txt index 70bbe8545ef1..b44e9810a522 100644 --- a/ydb/core/blobstorage/dsproxy/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/dsproxy/ut/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/dsproxy/ut_fat/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/dsproxy/ut_fat/CMakeLists.darwin-arm64.txt index d18658c8624d..8896650fbc52 100644 --- a/ydb/core/blobstorage/dsproxy/ut_fat/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/dsproxy/ut_fat/CMakeLists.darwin-arm64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-core-blobstorage-dsproxy-ut_fat PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-dsproxy-ut_fat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/ut_fat/dsproxy_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/dsproxy/ut_fat/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/dsproxy/ut_fat/CMakeLists.darwin-x86_64.txt index 9358d3056af5..4eb0bef8cb98 100644 --- a/ydb/core/blobstorage/dsproxy/ut_fat/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/dsproxy/ut_fat/CMakeLists.darwin-x86_64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-blobstorage-dsproxy-ut_fat PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-dsproxy-ut_fat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/ut_fat/dsproxy_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/dsproxy/ut_fat/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/dsproxy/ut_fat/CMakeLists.linux-aarch64.txt index ca7b2f12ce05..c7b2e662b4ca 100644 --- a/ydb/core/blobstorage/dsproxy/ut_fat/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/dsproxy/ut_fat/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-core-blobstorage-dsproxy-ut_fat PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-dsproxy-ut_fat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/ut_fat/dsproxy_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/dsproxy/ut_fat/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/dsproxy/ut_fat/CMakeLists.linux-x86_64.txt index 176ce94d18d4..86686501f91f 100644 --- a/ydb/core/blobstorage/dsproxy/ut_fat/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/dsproxy/ut_fat/CMakeLists.linux-x86_64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-blobstorage-dsproxy-ut_fat PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-dsproxy-ut_fat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/ut_fat/dsproxy_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/dsproxy/ut_fat/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/dsproxy/ut_fat/CMakeLists.windows-x86_64.txt index b25573de03a1..33eef8230001 100644 --- a/ydb/core/blobstorage/dsproxy/ut_fat/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/dsproxy/ut_fat/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/dsproxy/ut_ftol/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/dsproxy/ut_ftol/CMakeLists.darwin-arm64.txt index 732d50edbd02..d2948bbea5b5 100644 --- a/ydb/core/blobstorage/dsproxy/ut_ftol/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/dsproxy/ut_ftol/CMakeLists.darwin-arm64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-core-blobstorage-dsproxy-ut_ftol PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-dsproxy-ut_ftol PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/ut_ftol/dsproxy_fault_tolerance_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/dsproxy/ut_ftol/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/dsproxy/ut_ftol/CMakeLists.darwin-x86_64.txt index 8565fad5859f..83bd446ccf84 100644 --- a/ydb/core/blobstorage/dsproxy/ut_ftol/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/dsproxy/ut_ftol/CMakeLists.darwin-x86_64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-core-blobstorage-dsproxy-ut_ftol PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-dsproxy-ut_ftol PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/ut_ftol/dsproxy_fault_tolerance_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/dsproxy/ut_ftol/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/dsproxy/ut_ftol/CMakeLists.linux-aarch64.txt index 537490c37716..dd18caa561d3 100644 --- a/ydb/core/blobstorage/dsproxy/ut_ftol/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/dsproxy/ut_ftol/CMakeLists.linux-aarch64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-core-blobstorage-dsproxy-ut_ftol PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-dsproxy-ut_ftol PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/ut_ftol/dsproxy_fault_tolerance_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/dsproxy/ut_ftol/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/dsproxy/ut_ftol/CMakeLists.linux-x86_64.txt index 8a6cbf6a91e5..6095509cda85 100644 --- a/ydb/core/blobstorage/dsproxy/ut_ftol/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/dsproxy/ut_ftol/CMakeLists.linux-x86_64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-core-blobstorage-dsproxy-ut_ftol PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-dsproxy-ut_ftol PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/ut_ftol/dsproxy_fault_tolerance_ut.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/dsproxy/ut_ftol/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/dsproxy/ut_ftol/CMakeLists.windows-x86_64.txt index 7a45dbfbe6bc..864bc2da586c 100644 --- a/ydb/core/blobstorage/dsproxy/ut_ftol/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/dsproxy/ut_ftol/CMakeLists.windows-x86_64.txt @@ -55,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..fbc34903928d --- /dev/null +++ b/ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.darwin-arm64.txt @@ -0,0 +1,72 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-blobstorage-dsproxy-ut_strategy) +target_compile_options(ydb-core-blobstorage-dsproxy-ut_strategy PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-core-blobstorage-dsproxy-ut_strategy PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + core-blobstorage-dsproxy +) +target_link_options(ydb-core-blobstorage-dsproxy-ut_strategy PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-core-blobstorage-dsproxy-ut_strategy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/ut_strategy/strategy_ut.cpp +) +set_property( + TARGET + ydb-core-blobstorage-dsproxy-ut_strategy + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-core-blobstorage-dsproxy-ut_strategy + TEST_TARGET + ydb-core-blobstorage-dsproxy-ut_strategy + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-blobstorage-dsproxy-ut_strategy + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-blobstorage-dsproxy-ut_strategy + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-blobstorage-dsproxy-ut_strategy + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-blobstorage-dsproxy-ut_strategy + system_allocator +) +vcs_info(ydb-core-blobstorage-dsproxy-ut_strategy) diff --git a/ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..bc0c3b027f3e --- /dev/null +++ b/ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,73 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-blobstorage-dsproxy-ut_strategy) +target_compile_options(ydb-core-blobstorage-dsproxy-ut_strategy PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-core-blobstorage-dsproxy-ut_strategy PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + core-blobstorage-dsproxy +) +target_link_options(ydb-core-blobstorage-dsproxy-ut_strategy PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-core-blobstorage-dsproxy-ut_strategy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/ut_strategy/strategy_ut.cpp +) +set_property( + TARGET + ydb-core-blobstorage-dsproxy-ut_strategy + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-core-blobstorage-dsproxy-ut_strategy + TEST_TARGET + ydb-core-blobstorage-dsproxy-ut_strategy + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-blobstorage-dsproxy-ut_strategy + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-blobstorage-dsproxy-ut_strategy + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-blobstorage-dsproxy-ut_strategy + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-blobstorage-dsproxy-ut_strategy + system_allocator +) +vcs_info(ydb-core-blobstorage-dsproxy-ut_strategy) diff --git a/ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..ed3f4db6d96f --- /dev/null +++ b/ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.linux-aarch64.txt @@ -0,0 +1,75 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-blobstorage-dsproxy-ut_strategy) +target_compile_options(ydb-core-blobstorage-dsproxy-ut_strategy PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-core-blobstorage-dsproxy-ut_strategy PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + core-blobstorage-dsproxy +) +target_link_options(ydb-core-blobstorage-dsproxy-ut_strategy PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-core-blobstorage-dsproxy-ut_strategy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/ut_strategy/strategy_ut.cpp +) +set_property( + TARGET + ydb-core-blobstorage-dsproxy-ut_strategy + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-core-blobstorage-dsproxy-ut_strategy + TEST_TARGET + ydb-core-blobstorage-dsproxy-ut_strategy + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-blobstorage-dsproxy-ut_strategy + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-blobstorage-dsproxy-ut_strategy + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-blobstorage-dsproxy-ut_strategy + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-blobstorage-dsproxy-ut_strategy + cpp-malloc-jemalloc +) +vcs_info(ydb-core-blobstorage-dsproxy-ut_strategy) diff --git a/ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..cef69009de3c --- /dev/null +++ b/ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.linux-x86_64.txt @@ -0,0 +1,77 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-blobstorage-dsproxy-ut_strategy) +target_compile_options(ydb-core-blobstorage-dsproxy-ut_strategy PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-core-blobstorage-dsproxy-ut_strategy PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + core-blobstorage-dsproxy +) +target_link_options(ydb-core-blobstorage-dsproxy-ut_strategy PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-core-blobstorage-dsproxy-ut_strategy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/ut_strategy/strategy_ut.cpp +) +set_property( + TARGET + ydb-core-blobstorage-dsproxy-ut_strategy + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-core-blobstorage-dsproxy-ut_strategy + TEST_TARGET + ydb-core-blobstorage-dsproxy-ut_strategy + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-blobstorage-dsproxy-ut_strategy + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-blobstorage-dsproxy-ut_strategy + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-blobstorage-dsproxy-ut_strategy + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-blobstorage-dsproxy-ut_strategy + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(ydb-core-blobstorage-dsproxy-ut_strategy) diff --git a/ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.txt b/ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..bec8faf15f4e --- /dev/null +++ b/ydb/core/blobstorage/dsproxy/ut_strategy/CMakeLists.windows-x86_64.txt @@ -0,0 +1,68 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-blobstorage-dsproxy-ut_strategy) +target_compile_options(ydb-core-blobstorage-dsproxy-ut_strategy PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-core-blobstorage-dsproxy-ut_strategy PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + core-blobstorage-dsproxy +) +target_sources(ydb-core-blobstorage-dsproxy-ut_strategy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/dsproxy/ut_strategy/strategy_ut.cpp +) +set_property( + TARGET + ydb-core-blobstorage-dsproxy-ut_strategy + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-core-blobstorage-dsproxy-ut_strategy + TEST_TARGET + ydb-core-blobstorage-dsproxy-ut_strategy + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-blobstorage-dsproxy-ut_strategy + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-blobstorage-dsproxy-ut_strategy + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-blobstorage-dsproxy-ut_strategy + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-blobstorage-dsproxy-ut_strategy + system_allocator +) +vcs_info(ydb-core-blobstorage-dsproxy-ut_strategy) diff --git a/ydb/core/blobstorage/groupinfo/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/groupinfo/CMakeLists.darwin-arm64.txt index 4d5277077bfe..5b2a2180a106 100644 --- a/ydb/core/blobstorage/groupinfo/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/groupinfo/CMakeLists.darwin-arm64.txt @@ -22,6 +22,12 @@ target_link_libraries(core-blobstorage-groupinfo PUBLIC ydb-core-protos ) target_sources(core-blobstorage-groupinfo PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_blobmap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_iter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_partlayout.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_sets.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_blobmap.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_partlayout.cpp diff --git a/ydb/core/blobstorage/groupinfo/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/groupinfo/CMakeLists.darwin-x86_64.txt index 4d5277077bfe..5b2a2180a106 100644 --- a/ydb/core/blobstorage/groupinfo/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/groupinfo/CMakeLists.darwin-x86_64.txt @@ -22,6 +22,12 @@ target_link_libraries(core-blobstorage-groupinfo PUBLIC ydb-core-protos ) target_sources(core-blobstorage-groupinfo PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_blobmap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_iter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_partlayout.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_sets.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_blobmap.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_partlayout.cpp diff --git a/ydb/core/blobstorage/groupinfo/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/groupinfo/CMakeLists.linux-aarch64.txt index 40c85cd80854..47e17a014ab7 100644 --- a/ydb/core/blobstorage/groupinfo/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/groupinfo/CMakeLists.linux-aarch64.txt @@ -23,6 +23,12 @@ target_link_libraries(core-blobstorage-groupinfo PUBLIC ydb-core-protos ) target_sources(core-blobstorage-groupinfo PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_blobmap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_iter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_partlayout.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_sets.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_blobmap.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_partlayout.cpp diff --git a/ydb/core/blobstorage/groupinfo/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/groupinfo/CMakeLists.linux-x86_64.txt index 40c85cd80854..47e17a014ab7 100644 --- a/ydb/core/blobstorage/groupinfo/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/groupinfo/CMakeLists.linux-x86_64.txt @@ -23,6 +23,12 @@ target_link_libraries(core-blobstorage-groupinfo PUBLIC ydb-core-protos ) target_sources(core-blobstorage-groupinfo PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_blobmap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_iter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_partlayout.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_sets.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_blobmap.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_partlayout.cpp diff --git a/ydb/core/blobstorage/groupinfo/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/groupinfo/CMakeLists.windows-x86_64.txt index 4d5277077bfe..5b2a2180a106 100644 --- a/ydb/core/blobstorage/groupinfo/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/groupinfo/CMakeLists.windows-x86_64.txt @@ -22,6 +22,12 @@ target_link_libraries(core-blobstorage-groupinfo PUBLIC ydb-core-protos ) target_sources(core-blobstorage-groupinfo PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_blobmap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_iter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_partlayout.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_sets.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_blobmap.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_partlayout.cpp diff --git a/ydb/core/blobstorage/groupinfo/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/groupinfo/ut/CMakeLists.darwin-arm64.txt index f1335e87fe9c..2e40819d8e21 100644 --- a/ydb/core/blobstorage/groupinfo/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/groupinfo/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-blobstorage-groupinfo-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-groupinfo-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_iter_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/groupinfo/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/groupinfo/ut/CMakeLists.darwin-x86_64.txt index b9a8c76ed682..9ff01a021ce9 100644 --- a/ydb/core/blobstorage/groupinfo/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/groupinfo/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-blobstorage-groupinfo-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-groupinfo-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_iter_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/groupinfo/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/groupinfo/ut/CMakeLists.linux-aarch64.txt index a3976a5db303..b9fbffb1a07f 100644 --- a/ydb/core/blobstorage/groupinfo/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/groupinfo/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-blobstorage-groupinfo-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-groupinfo-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_iter_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/groupinfo/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/groupinfo/ut/CMakeLists.linux-x86_64.txt index 7fd129a03995..9c8b9f6a8483 100644 --- a/ydb/core/blobstorage/groupinfo/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/groupinfo/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-blobstorage-groupinfo-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-groupinfo-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_iter_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/groupinfo/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/groupinfo/ut/CMakeLists.windows-x86_64.txt index 7c6fa0404d9c..cff3ead97aa0 100644 --- a/ydb/core/blobstorage/groupinfo/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/groupinfo/ut/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/incrhuge/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/incrhuge/CMakeLists.darwin-arm64.txt index 25ce270b595b..d571b90bfd5e 100644 --- a/ydb/core/blobstorage/incrhuge/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/incrhuge/CMakeLists.darwin-arm64.txt @@ -16,6 +16,21 @@ target_link_libraries(core-blobstorage-incrhuge PUBLIC ydb-core-protos ) target_sources(core-blobstorage-incrhuge PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_id_dict.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_alloc.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_defrag.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_delete.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_read.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_recovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_recovery_read_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_recovery_scan.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_write.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_alloc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_common.cpp diff --git a/ydb/core/blobstorage/incrhuge/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/incrhuge/CMakeLists.darwin-x86_64.txt index 25ce270b595b..d571b90bfd5e 100644 --- a/ydb/core/blobstorage/incrhuge/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/incrhuge/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,21 @@ target_link_libraries(core-blobstorage-incrhuge PUBLIC ydb-core-protos ) target_sources(core-blobstorage-incrhuge PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_id_dict.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_alloc.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_defrag.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_delete.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_read.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_recovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_recovery_read_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_recovery_scan.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_write.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_alloc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_common.cpp diff --git a/ydb/core/blobstorage/incrhuge/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/incrhuge/CMakeLists.linux-aarch64.txt index 5b78d857a599..69fc54c1cd24 100644 --- a/ydb/core/blobstorage/incrhuge/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/incrhuge/CMakeLists.linux-aarch64.txt @@ -17,6 +17,21 @@ target_link_libraries(core-blobstorage-incrhuge PUBLIC ydb-core-protos ) target_sources(core-blobstorage-incrhuge PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_id_dict.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_alloc.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_defrag.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_delete.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_read.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_recovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_recovery_read_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_recovery_scan.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_write.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_alloc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_common.cpp diff --git a/ydb/core/blobstorage/incrhuge/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/incrhuge/CMakeLists.linux-x86_64.txt index 5b78d857a599..69fc54c1cd24 100644 --- a/ydb/core/blobstorage/incrhuge/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/incrhuge/CMakeLists.linux-x86_64.txt @@ -17,6 +17,21 @@ target_link_libraries(core-blobstorage-incrhuge PUBLIC ydb-core-protos ) target_sources(core-blobstorage-incrhuge PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_id_dict.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_alloc.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_defrag.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_delete.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_read.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_recovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_recovery_read_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_recovery_scan.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_write.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_alloc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_common.cpp diff --git a/ydb/core/blobstorage/incrhuge/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/incrhuge/CMakeLists.windows-x86_64.txt index 25ce270b595b..d571b90bfd5e 100644 --- a/ydb/core/blobstorage/incrhuge/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/incrhuge/CMakeLists.windows-x86_64.txt @@ -16,6 +16,21 @@ target_link_libraries(core-blobstorage-incrhuge PUBLIC ydb-core-protos ) target_sources(core-blobstorage-incrhuge PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_id_dict.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_alloc.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_defrag.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_delete.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_read.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_recovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_recovery_read_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_recovery_scan.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_write.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_alloc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/incrhuge_keeper_common.cpp diff --git a/ydb/core/blobstorage/incrhuge/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/incrhuge/ut/CMakeLists.darwin-arm64.txt index c33b5ff2738f..6f2136d8d1d8 100644 --- a/ydb/core/blobstorage/incrhuge/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/incrhuge/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-core-blobstorage-incrhuge-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-incrhuge-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/ut/incrhuge_basic_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/incrhuge/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/incrhuge/ut/CMakeLists.darwin-x86_64.txt index b6ac197143be..832140620685 100644 --- a/ydb/core/blobstorage/incrhuge/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/incrhuge/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-core-blobstorage-incrhuge-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-incrhuge-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/ut/incrhuge_basic_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/incrhuge/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/incrhuge/ut/CMakeLists.linux-aarch64.txt index 649f6c2f4bad..0966d091dc40 100644 --- a/ydb/core/blobstorage/incrhuge/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/incrhuge/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-core-blobstorage-incrhuge-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-incrhuge-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/ut/incrhuge_basic_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/incrhuge/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/incrhuge/ut/CMakeLists.linux-x86_64.txt index 88e1549f8860..88ae35a5387f 100644 --- a/ydb/core/blobstorage/incrhuge/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/incrhuge/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-core-blobstorage-incrhuge-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-incrhuge-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/incrhuge/ut/incrhuge_basic_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/incrhuge/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/incrhuge/ut/CMakeLists.windows-x86_64.txt index 2defcb2ad82e..c81f9ff136bf 100644 --- a/ydb/core/blobstorage/incrhuge/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/incrhuge/ut/CMakeLists.windows-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/nodewarden/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/nodewarden/CMakeLists.darwin-arm64.txt index 64591dd97008..30edce11625c 100644 --- a/ydb/core/blobstorage/nodewarden/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/nodewarden/CMakeLists.darwin-arm64.txt @@ -24,6 +24,12 @@ target_link_libraries(core-blobstorage-nodewarden PUBLIC ydb-library-pdisk_io ) target_sources(core-blobstorage-nodewarden PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/group_stat_aggregator.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/distconf.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/node_warden.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/node_warden_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/node_warden_impl.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/group_stat_aggregator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/distconf.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/distconf_binding.cpp diff --git a/ydb/core/blobstorage/nodewarden/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/nodewarden/CMakeLists.darwin-x86_64.txt index 64591dd97008..30edce11625c 100644 --- a/ydb/core/blobstorage/nodewarden/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/nodewarden/CMakeLists.darwin-x86_64.txt @@ -24,6 +24,12 @@ target_link_libraries(core-blobstorage-nodewarden PUBLIC ydb-library-pdisk_io ) target_sources(core-blobstorage-nodewarden PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/group_stat_aggregator.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/distconf.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/node_warden.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/node_warden_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/node_warden_impl.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/group_stat_aggregator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/distconf.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/distconf_binding.cpp diff --git a/ydb/core/blobstorage/nodewarden/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/nodewarden/CMakeLists.linux-aarch64.txt index e5d3a29006f2..bb9a1f8f0511 100644 --- a/ydb/core/blobstorage/nodewarden/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/nodewarden/CMakeLists.linux-aarch64.txt @@ -25,6 +25,12 @@ target_link_libraries(core-blobstorage-nodewarden PUBLIC ydb-library-pdisk_io ) target_sources(core-blobstorage-nodewarden PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/group_stat_aggregator.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/distconf.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/node_warden.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/node_warden_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/node_warden_impl.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/group_stat_aggregator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/distconf.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/distconf_binding.cpp diff --git a/ydb/core/blobstorage/nodewarden/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/nodewarden/CMakeLists.linux-x86_64.txt index e5d3a29006f2..bb9a1f8f0511 100644 --- a/ydb/core/blobstorage/nodewarden/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/nodewarden/CMakeLists.linux-x86_64.txt @@ -25,6 +25,12 @@ target_link_libraries(core-blobstorage-nodewarden PUBLIC ydb-library-pdisk_io ) target_sources(core-blobstorage-nodewarden PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/group_stat_aggregator.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/distconf.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/node_warden.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/node_warden_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/node_warden_impl.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/group_stat_aggregator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/distconf.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/distconf_binding.cpp diff --git a/ydb/core/blobstorage/nodewarden/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/nodewarden/CMakeLists.windows-x86_64.txt index 64591dd97008..30edce11625c 100644 --- a/ydb/core/blobstorage/nodewarden/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/nodewarden/CMakeLists.windows-x86_64.txt @@ -24,6 +24,12 @@ target_link_libraries(core-blobstorage-nodewarden PUBLIC ydb-library-pdisk_io ) target_sources(core-blobstorage-nodewarden PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/group_stat_aggregator.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/distconf.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/node_warden.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/node_warden_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/node_warden_impl.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/group_stat_aggregator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/distconf.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/distconf_binding.cpp diff --git a/ydb/core/blobstorage/nodewarden/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/nodewarden/ut/CMakeLists.darwin-arm64.txt index 04c755901c42..2b77875aa78f 100644 --- a/ydb/core/blobstorage/nodewarden/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/nodewarden/ut/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-blobstorage-nodewarden-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-nodewarden-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/blobstorage_node_warden_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/nodewarden/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/nodewarden/ut/CMakeLists.darwin-x86_64.txt index e11ea74cfdb0..6efb6711f2a2 100644 --- a/ydb/core/blobstorage/nodewarden/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/nodewarden/ut/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-blobstorage-nodewarden-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-nodewarden-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/blobstorage_node_warden_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/nodewarden/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/nodewarden/ut/CMakeLists.linux-aarch64.txt index e7405aebada6..17c290d39c9e 100644 --- a/ydb/core/blobstorage/nodewarden/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/nodewarden/ut/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-blobstorage-nodewarden-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-nodewarden-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/blobstorage_node_warden_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/nodewarden/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/nodewarden/ut/CMakeLists.linux-x86_64.txt index ae54868da3fb..bd0591a4f1c2 100644 --- a/ydb/core/blobstorage/nodewarden/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/nodewarden/ut/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-blobstorage-nodewarden-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-nodewarden-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/blobstorage_node_warden_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/nodewarden/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/nodewarden/ut/CMakeLists.windows-x86_64.txt index 42365ea45558..dfc5894e5dfc 100644 --- a/ydb/core/blobstorage/nodewarden/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/nodewarden/ut/CMakeLists.windows-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/nodewarden/ut_sequence/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/nodewarden/ut_sequence/CMakeLists.darwin-arm64.txt index 4675693f0eec..0276f9ad2bed 100644 --- a/ydb/core/blobstorage/nodewarden/ut_sequence/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/nodewarden/ut_sequence/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-blobstorage-nodewarden-ut_sequence PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-nodewarden-ut_sequence PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/ut_sequence/dsproxy_config_retrieval.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/nodewarden/ut_sequence/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/nodewarden/ut_sequence/CMakeLists.darwin-x86_64.txt index d28c194572c4..3b203cece4a0 100644 --- a/ydb/core/blobstorage/nodewarden/ut_sequence/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/nodewarden/ut_sequence/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-blobstorage-nodewarden-ut_sequence PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-nodewarden-ut_sequence PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/ut_sequence/dsproxy_config_retrieval.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/nodewarden/ut_sequence/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/nodewarden/ut_sequence/CMakeLists.linux-aarch64.txt index 0e8834eb5bb8..75d86ab06a1f 100644 --- a/ydb/core/blobstorage/nodewarden/ut_sequence/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/nodewarden/ut_sequence/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-blobstorage-nodewarden-ut_sequence PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-nodewarden-ut_sequence PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/ut_sequence/dsproxy_config_retrieval.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/nodewarden/ut_sequence/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/nodewarden/ut_sequence/CMakeLists.linux-x86_64.txt index 0b2b3e673f03..17867237e89e 100644 --- a/ydb/core/blobstorage/nodewarden/ut_sequence/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/nodewarden/ut_sequence/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-blobstorage-nodewarden-ut_sequence PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-nodewarden-ut_sequence PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/nodewarden/ut_sequence/dsproxy_config_retrieval.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/nodewarden/ut_sequence/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/nodewarden/ut_sequence/CMakeLists.windows-x86_64.txt index 955c0388ed4b..8385a796fb08 100644 --- a/ydb/core/blobstorage/nodewarden/ut_sequence/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/nodewarden/ut_sequence/CMakeLists.windows-x86_64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/other/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/other/CMakeLists.darwin-arm64.txt index c4b11025238a..95544ba5d686 100644 --- a/ydb/core/blobstorage/other/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/other/CMakeLists.darwin-arm64.txt @@ -18,6 +18,10 @@ target_link_libraries(core-blobstorage-other PUBLIC core-blobstorage-base ) target_sources(core-blobstorage-other PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_blob_range_page.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_get_blob_page.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_vdisk_stream.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_blob_range_page.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_get_blob_page.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_vdisk_stream.cpp diff --git a/ydb/core/blobstorage/other/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/other/CMakeLists.darwin-x86_64.txt index c4b11025238a..95544ba5d686 100644 --- a/ydb/core/blobstorage/other/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/other/CMakeLists.darwin-x86_64.txt @@ -18,6 +18,10 @@ target_link_libraries(core-blobstorage-other PUBLIC core-blobstorage-base ) target_sources(core-blobstorage-other PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_blob_range_page.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_get_blob_page.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_vdisk_stream.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_blob_range_page.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_get_blob_page.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_vdisk_stream.cpp diff --git a/ydb/core/blobstorage/other/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/other/CMakeLists.linux-aarch64.txt index 0cba04d287e2..3eb6b7c17586 100644 --- a/ydb/core/blobstorage/other/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/other/CMakeLists.linux-aarch64.txt @@ -19,6 +19,10 @@ target_link_libraries(core-blobstorage-other PUBLIC core-blobstorage-base ) target_sources(core-blobstorage-other PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_blob_range_page.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_get_blob_page.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_vdisk_stream.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_blob_range_page.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_get_blob_page.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_vdisk_stream.cpp diff --git a/ydb/core/blobstorage/other/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/other/CMakeLists.linux-x86_64.txt index 0cba04d287e2..3eb6b7c17586 100644 --- a/ydb/core/blobstorage/other/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/other/CMakeLists.linux-x86_64.txt @@ -19,6 +19,10 @@ target_link_libraries(core-blobstorage-other PUBLIC core-blobstorage-base ) target_sources(core-blobstorage-other PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_blob_range_page.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_get_blob_page.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_vdisk_stream.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_blob_range_page.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_get_blob_page.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_vdisk_stream.cpp diff --git a/ydb/core/blobstorage/other/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/other/CMakeLists.windows-x86_64.txt index c4b11025238a..95544ba5d686 100644 --- a/ydb/core/blobstorage/other/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/other/CMakeLists.windows-x86_64.txt @@ -18,6 +18,10 @@ target_link_libraries(core-blobstorage-other PUBLIC core-blobstorage-base ) target_sources(core-blobstorage-other PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_blob_range_page.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_get_blob_page.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_vdisk_stream.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_blob_range_page.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_get_blob_page.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/other/mon_vdisk_stream.cpp diff --git a/ydb/core/blobstorage/pdisk/mock/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/pdisk/mock/CMakeLists.darwin-arm64.txt index 0f825d0c45bc..a5f9954a239d 100644 --- a/ydb/core/blobstorage/pdisk/mock/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/pdisk/mock/CMakeLists.darwin-arm64.txt @@ -15,5 +15,6 @@ target_link_libraries(blobstorage-pdisk-mock PUBLIC core-blobstorage-pdisk ) target_sources(blobstorage-pdisk-mock PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/pdisk/mock/pdisk_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/pdisk/mock/pdisk_mock.cpp ) diff --git a/ydb/core/blobstorage/pdisk/mock/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/pdisk/mock/CMakeLists.darwin-x86_64.txt index 0f825d0c45bc..a5f9954a239d 100644 --- a/ydb/core/blobstorage/pdisk/mock/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/pdisk/mock/CMakeLists.darwin-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(blobstorage-pdisk-mock PUBLIC core-blobstorage-pdisk ) target_sources(blobstorage-pdisk-mock PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/pdisk/mock/pdisk_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/pdisk/mock/pdisk_mock.cpp ) diff --git a/ydb/core/blobstorage/pdisk/mock/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/pdisk/mock/CMakeLists.linux-aarch64.txt index 8e03928b8a1b..29322a4dd02b 100644 --- a/ydb/core/blobstorage/pdisk/mock/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/pdisk/mock/CMakeLists.linux-aarch64.txt @@ -16,5 +16,6 @@ target_link_libraries(blobstorage-pdisk-mock PUBLIC core-blobstorage-pdisk ) target_sources(blobstorage-pdisk-mock PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/pdisk/mock/pdisk_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/pdisk/mock/pdisk_mock.cpp ) diff --git a/ydb/core/blobstorage/pdisk/mock/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/pdisk/mock/CMakeLists.linux-x86_64.txt index 8e03928b8a1b..29322a4dd02b 100644 --- a/ydb/core/blobstorage/pdisk/mock/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/pdisk/mock/CMakeLists.linux-x86_64.txt @@ -16,5 +16,6 @@ target_link_libraries(blobstorage-pdisk-mock PUBLIC core-blobstorage-pdisk ) target_sources(blobstorage-pdisk-mock PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/pdisk/mock/pdisk_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/pdisk/mock/pdisk_mock.cpp ) diff --git a/ydb/core/blobstorage/pdisk/mock/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/pdisk/mock/CMakeLists.windows-x86_64.txt index 0f825d0c45bc..a5f9954a239d 100644 --- a/ydb/core/blobstorage/pdisk/mock/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/pdisk/mock/CMakeLists.windows-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(blobstorage-pdisk-mock PUBLIC core-blobstorage-pdisk ) target_sources(blobstorage-pdisk-mock PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/pdisk/mock/pdisk_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/pdisk/mock/pdisk_mock.cpp ) diff --git a/ydb/core/blobstorage/pdisk/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/pdisk/ut/CMakeLists.darwin-arm64.txt index fdd6b5c2d58c..ac297f84317c 100644 --- a/ydb/core/blobstorage/pdisk/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/pdisk/ut/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-blobstorage-pdisk-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-pdisk-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/pdisk/blobstorage_pdisk_blockdevice_ut.cpp @@ -69,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/pdisk/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/pdisk/ut/CMakeLists.darwin-x86_64.txt index 95f69321e94b..a47374333f55 100644 --- a/ydb/core/blobstorage/pdisk/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/pdisk/ut/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-blobstorage-pdisk-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-pdisk-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/pdisk/blobstorage_pdisk_blockdevice_ut.cpp @@ -70,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/pdisk/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/pdisk/ut/CMakeLists.linux-aarch64.txt index faef05f81f8c..11acaf98d0fc 100644 --- a/ydb/core/blobstorage/pdisk/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/pdisk/ut/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-blobstorage-pdisk-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-pdisk-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/pdisk/blobstorage_pdisk_blockdevice_ut.cpp @@ -73,6 +70,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/pdisk/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/pdisk/ut/CMakeLists.linux-x86_64.txt index 268016dec16e..3a8c2527c6bb 100644 --- a/ydb/core/blobstorage/pdisk/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/pdisk/ut/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-blobstorage-pdisk-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-pdisk-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/pdisk/blobstorage_pdisk_blockdevice_ut.cpp @@ -74,6 +71,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/pdisk/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/pdisk/ut/CMakeLists.windows-x86_64.txt index 0533f6adb7df..2d781494a242 100644 --- a/ydb/core/blobstorage/pdisk/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/pdisk/ut/CMakeLists.windows-x86_64.txt @@ -63,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/storagepoolmon/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/storagepoolmon/CMakeLists.darwin-arm64.txt index d5c1a02d8f86..42075072ba12 100644 --- a/ydb/core/blobstorage/storagepoolmon/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/storagepoolmon/CMakeLists.darwin-arm64.txt @@ -16,3 +16,6 @@ target_link_libraries(core-blobstorage-storagepoolmon INTERFACE ydb-core-base core-blobstorage-base ) +target_sources(core-blobstorage-storagepoolmon INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/storagepoolmon/storagepool_counters.h +) diff --git a/ydb/core/blobstorage/storagepoolmon/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/storagepoolmon/CMakeLists.darwin-x86_64.txt index d5c1a02d8f86..42075072ba12 100644 --- a/ydb/core/blobstorage/storagepoolmon/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/storagepoolmon/CMakeLists.darwin-x86_64.txt @@ -16,3 +16,6 @@ target_link_libraries(core-blobstorage-storagepoolmon INTERFACE ydb-core-base core-blobstorage-base ) +target_sources(core-blobstorage-storagepoolmon INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/storagepoolmon/storagepool_counters.h +) diff --git a/ydb/core/blobstorage/storagepoolmon/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/storagepoolmon/CMakeLists.linux-aarch64.txt index ccd7e3d8914b..667d6e845037 100644 --- a/ydb/core/blobstorage/storagepoolmon/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/storagepoolmon/CMakeLists.linux-aarch64.txt @@ -17,3 +17,6 @@ target_link_libraries(core-blobstorage-storagepoolmon INTERFACE ydb-core-base core-blobstorage-base ) +target_sources(core-blobstorage-storagepoolmon INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/storagepoolmon/storagepool_counters.h +) diff --git a/ydb/core/blobstorage/storagepoolmon/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/storagepoolmon/CMakeLists.linux-x86_64.txt index ccd7e3d8914b..667d6e845037 100644 --- a/ydb/core/blobstorage/storagepoolmon/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/storagepoolmon/CMakeLists.linux-x86_64.txt @@ -17,3 +17,6 @@ target_link_libraries(core-blobstorage-storagepoolmon INTERFACE ydb-core-base core-blobstorage-base ) +target_sources(core-blobstorage-storagepoolmon INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/storagepoolmon/storagepool_counters.h +) diff --git a/ydb/core/blobstorage/storagepoolmon/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/storagepoolmon/CMakeLists.windows-x86_64.txt index d5c1a02d8f86..42075072ba12 100644 --- a/ydb/core/blobstorage/storagepoolmon/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/storagepoolmon/CMakeLists.windows-x86_64.txt @@ -16,3 +16,6 @@ target_link_libraries(core-blobstorage-storagepoolmon INTERFACE ydb-core-base core-blobstorage-base ) +target_sources(core-blobstorage-storagepoolmon INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/storagepoolmon/storagepool_counters.h +) diff --git a/ydb/core/blobstorage/storagepoolmon/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/storagepoolmon/ut/CMakeLists.darwin-arm64.txt index 16be7a9ac167..52c513166112 100644 --- a/ydb/core/blobstorage/storagepoolmon/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/storagepoolmon/ut/CMakeLists.darwin-arm64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-core-blobstorage-storagepoolmon-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-storagepoolmon-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/storagepoolmon/ut/storagepoolmon_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/storagepoolmon/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/storagepoolmon/ut/CMakeLists.darwin-x86_64.txt index 5c007a5507fa..22110cc1a298 100644 --- a/ydb/core/blobstorage/storagepoolmon/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/storagepoolmon/ut/CMakeLists.darwin-x86_64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-core-blobstorage-storagepoolmon-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-storagepoolmon-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/storagepoolmon/ut/storagepoolmon_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/storagepoolmon/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/storagepoolmon/ut/CMakeLists.linux-aarch64.txt index f44ef37435f4..e1f6cf1efed2 100644 --- a/ydb/core/blobstorage/storagepoolmon/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/storagepoolmon/ut/CMakeLists.linux-aarch64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-core-blobstorage-storagepoolmon-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-storagepoolmon-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/storagepoolmon/ut/storagepoolmon_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/storagepoolmon/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/storagepoolmon/ut/CMakeLists.linux-x86_64.txt index 6b624e17873b..5ebe34b7fd22 100644 --- a/ydb/core/blobstorage/storagepoolmon/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/storagepoolmon/ut/CMakeLists.linux-x86_64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-core-blobstorage-storagepoolmon-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-storagepoolmon-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/storagepoolmon/ut/storagepoolmon_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/storagepoolmon/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/storagepoolmon/ut/CMakeLists.windows-x86_64.txt index ab57ae25dd30..77e06560d70f 100644 --- a/ydb/core/blobstorage/storagepoolmon/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/storagepoolmon/ut/CMakeLists.windows-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/testing/group_overseer/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/testing/group_overseer/CMakeLists.darwin-arm64.txt index 65ce705be6dc..618263929d00 100644 --- a/ydb/core/blobstorage/testing/group_overseer/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/testing/group_overseer/CMakeLists.darwin-arm64.txt @@ -15,6 +15,9 @@ target_link_libraries(blobstorage-testing-group_overseer PUBLIC contrib-libs-t1ha ) target_sources(blobstorage-testing-group_overseer PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/group_overseer.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/group_state.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/group_overseer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/group_state.cpp ) diff --git a/ydb/core/blobstorage/testing/group_overseer/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/testing/group_overseer/CMakeLists.darwin-x86_64.txt index 65ce705be6dc..618263929d00 100644 --- a/ydb/core/blobstorage/testing/group_overseer/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/testing/group_overseer/CMakeLists.darwin-x86_64.txt @@ -15,6 +15,9 @@ target_link_libraries(blobstorage-testing-group_overseer PUBLIC contrib-libs-t1ha ) target_sources(blobstorage-testing-group_overseer PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/group_overseer.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/group_state.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/group_overseer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/group_state.cpp ) diff --git a/ydb/core/blobstorage/testing/group_overseer/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/testing/group_overseer/CMakeLists.linux-aarch64.txt index 372c18f418a4..6cd423972175 100644 --- a/ydb/core/blobstorage/testing/group_overseer/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/testing/group_overseer/CMakeLists.linux-aarch64.txt @@ -16,6 +16,9 @@ target_link_libraries(blobstorage-testing-group_overseer PUBLIC contrib-libs-t1ha ) target_sources(blobstorage-testing-group_overseer PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/group_overseer.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/group_state.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/group_overseer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/group_state.cpp ) diff --git a/ydb/core/blobstorage/testing/group_overseer/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/testing/group_overseer/CMakeLists.linux-x86_64.txt index 372c18f418a4..6cd423972175 100644 --- a/ydb/core/blobstorage/testing/group_overseer/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/testing/group_overseer/CMakeLists.linux-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(blobstorage-testing-group_overseer PUBLIC contrib-libs-t1ha ) target_sources(blobstorage-testing-group_overseer PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/group_overseer.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/group_state.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/group_overseer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/group_state.cpp ) diff --git a/ydb/core/blobstorage/testing/group_overseer/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/testing/group_overseer/CMakeLists.windows-x86_64.txt index 65ce705be6dc..618263929d00 100644 --- a/ydb/core/blobstorage/testing/group_overseer/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/testing/group_overseer/CMakeLists.windows-x86_64.txt @@ -15,6 +15,9 @@ target_link_libraries(blobstorage-testing-group_overseer PUBLIC contrib-libs-t1ha ) target_sources(blobstorage-testing-group_overseer PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/group_overseer.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/group_state.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/group_overseer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/testing/group_overseer/group_state.cpp ) diff --git a/ydb/core/blobstorage/ut_blobstorage/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_blobstorage/CMakeLists.darwin-arm64.txt index 207b619e9bce..45dbafa31b91 100644 --- a/ydb/core/blobstorage/ut_blobstorage/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/CMakeLists.darwin-arm64.txt @@ -7,6 +7,7 @@ add_subdirectory(lib) +add_subdirectory(ut_balancing) add_subdirectory(ut_blob_depot) add_subdirectory(ut_blob_depot_fat) add_subdirectory(ut_donor) @@ -33,8 +34,6 @@ target_link_options(ydb-core-blobstorage-ut_blobstorage PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-ut_blobstorage PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/assimilation.cpp @@ -49,6 +48,7 @@ target_sources(ydb-core-blobstorage-ut_blobstorage PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/incorrect_queries.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/index_restore_get.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/main.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/mirror3dc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/mirror3of4.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/monitoring.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/recovery.cpp @@ -87,6 +87,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/CMakeLists.darwin-x86_64.txt index 2428e80682a9..0e4ff7a29c48 100644 --- a/ydb/core/blobstorage/ut_blobstorage/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/CMakeLists.darwin-x86_64.txt @@ -7,6 +7,7 @@ add_subdirectory(lib) +add_subdirectory(ut_balancing) add_subdirectory(ut_blob_depot) add_subdirectory(ut_blob_depot_fat) add_subdirectory(ut_donor) @@ -34,8 +35,6 @@ target_link_options(ydb-core-blobstorage-ut_blobstorage PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-ut_blobstorage PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/assimilation.cpp @@ -50,6 +49,7 @@ target_sources(ydb-core-blobstorage-ut_blobstorage PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/incorrect_queries.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/index_restore_get.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/main.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/mirror3dc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/mirror3of4.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/monitoring.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/recovery.cpp @@ -88,6 +88,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_blobstorage/CMakeLists.linux-aarch64.txt index 994ec6ce40c9..7fc91b877652 100644 --- a/ydb/core/blobstorage/ut_blobstorage/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/CMakeLists.linux-aarch64.txt @@ -7,6 +7,7 @@ add_subdirectory(lib) +add_subdirectory(ut_balancing) add_subdirectory(ut_blob_depot) add_subdirectory(ut_blob_depot_fat) add_subdirectory(ut_donor) @@ -36,9 +37,6 @@ target_link_options(ydb-core-blobstorage-ut_blobstorage PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-ut_blobstorage PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/assimilation.cpp @@ -53,6 +51,7 @@ target_sources(ydb-core-blobstorage-ut_blobstorage PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/incorrect_queries.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/index_restore_get.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/main.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/mirror3dc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/mirror3of4.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/monitoring.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/recovery.cpp @@ -91,6 +90,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/CMakeLists.linux-x86_64.txt index 8fdd87322a18..eb33b3473b6b 100644 --- a/ydb/core/blobstorage/ut_blobstorage/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/CMakeLists.linux-x86_64.txt @@ -7,6 +7,7 @@ add_subdirectory(lib) +add_subdirectory(ut_balancing) add_subdirectory(ut_blob_depot) add_subdirectory(ut_blob_depot_fat) add_subdirectory(ut_donor) @@ -37,9 +38,6 @@ target_link_options(ydb-core-blobstorage-ut_blobstorage PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-ut_blobstorage PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/assimilation.cpp @@ -54,6 +52,7 @@ target_sources(ydb-core-blobstorage-ut_blobstorage PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/incorrect_queries.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/index_restore_get.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/main.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/mirror3dc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/mirror3of4.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/monitoring.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/recovery.cpp @@ -92,6 +91,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/CMakeLists.windows-x86_64.txt index 711abadf8a86..6c44db0c05d3 100644 --- a/ydb/core/blobstorage/ut_blobstorage/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/CMakeLists.windows-x86_64.txt @@ -7,6 +7,7 @@ add_subdirectory(lib) +add_subdirectory(ut_balancing) add_subdirectory(ut_blob_depot) add_subdirectory(ut_blob_depot_fat) add_subdirectory(ut_donor) @@ -43,6 +44,7 @@ target_sources(ydb-core-blobstorage-ut_blobstorage PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/incorrect_queries.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/index_restore_get.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/main.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/mirror3dc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/mirror3of4.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/monitoring.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/recovery.cpp @@ -81,6 +83,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.darwin-arm64.txt index 2eaad09f8358..5e5bdff5c9c6 100644 --- a/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.darwin-arm64.txt @@ -30,10 +30,18 @@ target_link_libraries(blobstorage-ut_blobstorage-lib PUBLIC core-tx-mediator core-tx-coordinator ydb-core-util + minikql-comp_nodes-llvm14 udf-service-exception_policy yql-sql-pg_dummy ) target_sources(blobstorage-ut_blobstorage-lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/activity.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/env.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_state.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_vdisk.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_bsc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_pipe.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_state.cpp diff --git a/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.darwin-x86_64.txt index 2eaad09f8358..5e5bdff5c9c6 100644 --- a/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.darwin-x86_64.txt @@ -30,10 +30,18 @@ target_link_libraries(blobstorage-ut_blobstorage-lib PUBLIC core-tx-mediator core-tx-coordinator ydb-core-util + minikql-comp_nodes-llvm14 udf-service-exception_policy yql-sql-pg_dummy ) target_sources(blobstorage-ut_blobstorage-lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/activity.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/env.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_state.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_vdisk.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_bsc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_pipe.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_state.cpp diff --git a/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.linux-aarch64.txt index 80ebb80f6f95..be9f296fefb5 100644 --- a/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.linux-aarch64.txt @@ -31,10 +31,18 @@ target_link_libraries(blobstorage-ut_blobstorage-lib PUBLIC core-tx-mediator core-tx-coordinator ydb-core-util + minikql-comp_nodes-llvm14 udf-service-exception_policy yql-sql-pg_dummy ) target_sources(blobstorage-ut_blobstorage-lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/activity.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/env.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_state.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_vdisk.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_bsc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_pipe.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_state.cpp diff --git a/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.linux-x86_64.txt index 80ebb80f6f95..be9f296fefb5 100644 --- a/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.linux-x86_64.txt @@ -31,10 +31,18 @@ target_link_libraries(blobstorage-ut_blobstorage-lib PUBLIC core-tx-mediator core-tx-coordinator ydb-core-util + minikql-comp_nodes-llvm14 udf-service-exception_policy yql-sql-pg_dummy ) target_sources(blobstorage-ut_blobstorage-lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/activity.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/env.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_state.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_vdisk.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_bsc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_pipe.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_state.cpp diff --git a/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.windows-x86_64.txt index 2eaad09f8358..5e5bdff5c9c6 100644 --- a/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.windows-x86_64.txt @@ -30,10 +30,18 @@ target_link_libraries(blobstorage-ut_blobstorage-lib PUBLIC core-tx-mediator core-tx-coordinator ydb-core-util + minikql-comp_nodes-llvm14 udf-service-exception_policy yql-sql-pg_dummy ) target_sources(blobstorage-ut_blobstorage-lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/activity.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/common.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/env.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_state.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_vdisk.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_bsc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_pipe.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/lib/node_warden_mock_state.cpp diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..00d4ca23aa52 --- /dev/null +++ b/ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.darwin-arm64.txt @@ -0,0 +1,72 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-blobstorage-ut_blobstorage-ut_balancing) +target_include_directories(ydb-core-blobstorage-ut_blobstorage-ut_balancing PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage +) +target_link_libraries(ydb-core-blobstorage-ut_blobstorage-ut_balancing PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + blobstorage-ut_blobstorage-lib +) +target_link_options(ydb-core-blobstorage-ut_blobstorage-ut_balancing PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-core-blobstorage-ut_blobstorage-ut_balancing PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/balancing.cpp +) +set_property( + TARGET + ydb-core-blobstorage-ut_blobstorage-ut_balancing + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-blobstorage-ut_blobstorage-ut_balancing + TEST_TARGET + ydb-core-blobstorage-ut_blobstorage-ut_balancing + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-blobstorage-ut_blobstorage-ut_balancing + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-blobstorage-ut_blobstorage-ut_balancing + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-blobstorage-ut_blobstorage-ut_balancing + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-blobstorage-ut_blobstorage-ut_balancing + system_allocator +) +vcs_info(ydb-core-blobstorage-ut_blobstorage-ut_balancing) diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..a50052a8c024 --- /dev/null +++ b/ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,73 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-blobstorage-ut_blobstorage-ut_balancing) +target_include_directories(ydb-core-blobstorage-ut_blobstorage-ut_balancing PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage +) +target_link_libraries(ydb-core-blobstorage-ut_blobstorage-ut_balancing PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + blobstorage-ut_blobstorage-lib +) +target_link_options(ydb-core-blobstorage-ut_blobstorage-ut_balancing PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-core-blobstorage-ut_blobstorage-ut_balancing PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/balancing.cpp +) +set_property( + TARGET + ydb-core-blobstorage-ut_blobstorage-ut_balancing + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-blobstorage-ut_blobstorage-ut_balancing + TEST_TARGET + ydb-core-blobstorage-ut_blobstorage-ut_balancing + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-blobstorage-ut_blobstorage-ut_balancing + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-blobstorage-ut_blobstorage-ut_balancing + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-blobstorage-ut_blobstorage-ut_balancing + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-blobstorage-ut_blobstorage-ut_balancing + system_allocator +) +vcs_info(ydb-core-blobstorage-ut_blobstorage-ut_balancing) diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..6f421c6a52f3 --- /dev/null +++ b/ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.linux-aarch64.txt @@ -0,0 +1,75 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-blobstorage-ut_blobstorage-ut_balancing) +target_include_directories(ydb-core-blobstorage-ut_blobstorage-ut_balancing PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage +) +target_link_libraries(ydb-core-blobstorage-ut_blobstorage-ut_balancing PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + blobstorage-ut_blobstorage-lib +) +target_link_options(ydb-core-blobstorage-ut_blobstorage-ut_balancing PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-core-blobstorage-ut_blobstorage-ut_balancing PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/balancing.cpp +) +set_property( + TARGET + ydb-core-blobstorage-ut_blobstorage-ut_balancing + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-blobstorage-ut_blobstorage-ut_balancing + TEST_TARGET + ydb-core-blobstorage-ut_blobstorage-ut_balancing + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-blobstorage-ut_blobstorage-ut_balancing + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-blobstorage-ut_blobstorage-ut_balancing + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-blobstorage-ut_blobstorage-ut_balancing + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-blobstorage-ut_blobstorage-ut_balancing + cpp-malloc-jemalloc +) +vcs_info(ydb-core-blobstorage-ut_blobstorage-ut_balancing) diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..de4f30680d54 --- /dev/null +++ b/ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.linux-x86_64.txt @@ -0,0 +1,77 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-blobstorage-ut_blobstorage-ut_balancing) +target_include_directories(ydb-core-blobstorage-ut_blobstorage-ut_balancing PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage +) +target_link_libraries(ydb-core-blobstorage-ut_blobstorage-ut_balancing PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + blobstorage-ut_blobstorage-lib +) +target_link_options(ydb-core-blobstorage-ut_blobstorage-ut_balancing PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-core-blobstorage-ut_blobstorage-ut_balancing PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/balancing.cpp +) +set_property( + TARGET + ydb-core-blobstorage-ut_blobstorage-ut_balancing + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-blobstorage-ut_blobstorage-ut_balancing + TEST_TARGET + ydb-core-blobstorage-ut_blobstorage-ut_balancing + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-blobstorage-ut_blobstorage-ut_balancing + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-blobstorage-ut_blobstorage-ut_balancing + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-blobstorage-ut_blobstorage-ut_balancing + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-blobstorage-ut_blobstorage-ut_balancing + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(ydb-core-blobstorage-ut_blobstorage-ut_balancing) diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.txt b/ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..4f77da71866a --- /dev/null +++ b/ydb/core/blobstorage/ut_blobstorage/ut_balancing/CMakeLists.windows-x86_64.txt @@ -0,0 +1,68 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-blobstorage-ut_blobstorage-ut_balancing) +target_include_directories(ydb-core-blobstorage-ut_blobstorage-ut_balancing PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage +) +target_link_libraries(ydb-core-blobstorage-ut_blobstorage-ut_balancing PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + blobstorage-ut_blobstorage-lib +) +target_sources(ydb-core-blobstorage-ut_blobstorage-ut_balancing PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/balancing.cpp +) +set_property( + TARGET + ydb-core-blobstorage-ut_blobstorage-ut_balancing + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-blobstorage-ut_blobstorage-ut_balancing + TEST_TARGET + ydb-core-blobstorage-ut_blobstorage-ut_balancing + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-blobstorage-ut_blobstorage-ut_balancing + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-blobstorage-ut_blobstorage-ut_balancing + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-blobstorage-ut_blobstorage-ut_balancing + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-blobstorage-ut_blobstorage-ut_balancing + system_allocator +) +vcs_info(ydb-core-blobstorage-ut_blobstorage-ut_balancing) diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot/CMakeLists.darwin-arm64.txt index de835e3fa1e2..da1e3346c4a9 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-core-blobstorage-ut_blobstorage-ut_blob_depot PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-ut_blobstorage-ut_blob_depot PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/blob_depot.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot/CMakeLists.darwin-x86_64.txt index c5983e76e01d..afcbb89df2ca 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-core-blobstorage-ut_blobstorage-ut_blob_depot PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-ut_blobstorage-ut_blob_depot PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/blob_depot.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot/CMakeLists.linux-aarch64.txt index a37e1d7dccc6..cab33b33698d 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-core-blobstorage-ut_blobstorage-ut_blob_depot PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-ut_blobstorage-ut_blob_depot PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/blob_depot.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot/CMakeLists.linux-x86_64.txt index fcf9cb636a29..1cd0cac8cbcf 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-core-blobstorage-ut_blobstorage-ut_blob_depot PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-ut_blobstorage-ut_blob_depot PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/blob_depot.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot/CMakeLists.windows-x86_64.txt index 5bef89226dbf..c59959ce1bac 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot/CMakeLists.windows-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot_fat/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot_fat/CMakeLists.darwin-arm64.txt index 83dad0658d3e..b78cfbfe529e 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot_fat/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot_fat/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(blobstorage-ut_blobstorage-ut_blob_depot_fat PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(blobstorage-ut_blobstorage-ut_blob_depot_fat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/blob_depot_fat.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot_fat/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot_fat/CMakeLists.darwin-x86_64.txt index af6ef29380db..17aa316b2790 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot_fat/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot_fat/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(blobstorage-ut_blobstorage-ut_blob_depot_fat PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(blobstorage-ut_blobstorage-ut_blob_depot_fat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/blob_depot_fat.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot_fat/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot_fat/CMakeLists.linux-aarch64.txt index 13abf54784c8..15f5009db74a 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot_fat/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot_fat/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(blobstorage-ut_blobstorage-ut_blob_depot_fat PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(blobstorage-ut_blobstorage-ut_blob_depot_fat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/blob_depot_fat.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot_fat/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot_fat/CMakeLists.linux-x86_64.txt index 9e37b9151e23..600263620167 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot_fat/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot_fat/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(blobstorage-ut_blobstorage-ut_blob_depot_fat PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(blobstorage-ut_blobstorage-ut_blob_depot_fat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/blob_depot_fat.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot_fat/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot_fat/CMakeLists.windows-x86_64.txt index 0c0fbb91a35f..b5b8364963d3 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot_fat/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_blob_depot_fat/CMakeLists.windows-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_donor/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_donor/CMakeLists.darwin-arm64.txt index 029d60eec34b..95320234e747 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_donor/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_donor/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-core-blobstorage-ut_blobstorage-ut_donor PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-ut_blobstorage-ut_donor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/donor.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_donor/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_donor/CMakeLists.darwin-x86_64.txt index 1aeb0e9ad189..b572a2387fbf 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_donor/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_donor/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-core-blobstorage-ut_blobstorage-ut_donor PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-ut_blobstorage-ut_donor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/donor.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_donor/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_donor/CMakeLists.linux-aarch64.txt index 37630a5c953f..1bc865239255 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_donor/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_donor/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-core-blobstorage-ut_blobstorage-ut_donor PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-ut_blobstorage-ut_donor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/donor.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_donor/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_donor/CMakeLists.linux-x86_64.txt index e9d5423fc2c6..4d7e00d1ebac 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_donor/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_donor/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-core-blobstorage-ut_blobstorage-ut_donor PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-ut_blobstorage-ut_donor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/donor.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_donor/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_donor/CMakeLists.windows-x86_64.txt index b1536564b09a..75564b28847f 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_donor/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_donor/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_group_reconfiguration/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_group_reconfiguration/CMakeLists.darwin-arm64.txt index 554b2bcd1f2d..f13612193059 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_group_reconfiguration/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_group_reconfiguration/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ut_group_reconfiguration PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ut_group_reconfiguration PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/race.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_group_reconfiguration/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_group_reconfiguration/CMakeLists.darwin-x86_64.txt index 57e1fd626616..9f050947e9ca 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_group_reconfiguration/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_group_reconfiguration/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ut_group_reconfiguration PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ut_group_reconfiguration PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/race.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_group_reconfiguration/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_group_reconfiguration/CMakeLists.linux-aarch64.txt index c839fe105508..ae433a83f937 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_group_reconfiguration/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_group_reconfiguration/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ut_group_reconfiguration PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ut_group_reconfiguration PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/race.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_group_reconfiguration/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_group_reconfiguration/CMakeLists.linux-x86_64.txt index 86c5607b924c..a9e6d6ad4eb0 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_group_reconfiguration/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_group_reconfiguration/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ut_group_reconfiguration PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ut_group_reconfiguration PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/race.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_group_reconfiguration/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_group_reconfiguration/CMakeLists.windows-x86_64.txt index a7d9fd10889f..e26431bbdb61 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_group_reconfiguration/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_group_reconfiguration/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_osiris/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_osiris/CMakeLists.darwin-arm64.txt index 018d2d0dafe7..425a85812b9b 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_osiris/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_osiris/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-core-blobstorage-ut_blobstorage-ut_osiris PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-ut_blobstorage-ut_osiris PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/osiris.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_osiris/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_osiris/CMakeLists.darwin-x86_64.txt index 2b1ddf17679b..bb1268cbb1f2 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_osiris/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_osiris/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-core-blobstorage-ut_blobstorage-ut_osiris PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-ut_blobstorage-ut_osiris PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/osiris.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_osiris/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_osiris/CMakeLists.linux-aarch64.txt index aaf59a02476c..4f4043f6c410 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_osiris/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_osiris/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-core-blobstorage-ut_blobstorage-ut_osiris PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-ut_blobstorage-ut_osiris PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/osiris.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_osiris/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_osiris/CMakeLists.linux-x86_64.txt index 1ea280b18053..68f0cde904e6 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_osiris/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_osiris/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-core-blobstorage-ut_blobstorage-ut_osiris PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-ut_blobstorage-ut_osiris PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/osiris.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_osiris/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_osiris/CMakeLists.windows-x86_64.txt index 86f90085f3c2..ff8511d77ce8 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_osiris/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_osiris/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk/CMakeLists.darwin-arm64.txt index 051c7b6a05f1..2a6449c41359 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk/CMakeLists.darwin-arm64.txt @@ -22,8 +22,6 @@ target_link_options(ut_blobstorage-ut_read_only_vdisk PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ut_blobstorage-ut_read_only_vdisk PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/read_only_vdisk.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk/CMakeLists.darwin-x86_64.txt index 120d5a11a61f..5658485cc033 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk/CMakeLists.darwin-x86_64.txt @@ -23,8 +23,6 @@ target_link_options(ut_blobstorage-ut_read_only_vdisk PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ut_blobstorage-ut_read_only_vdisk PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/read_only_vdisk.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk/CMakeLists.linux-aarch64.txt index c70807e76756..f59715ea20b9 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(ut_blobstorage-ut_read_only_vdisk PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ut_blobstorage-ut_read_only_vdisk PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/read_only_vdisk.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk/CMakeLists.linux-x86_64.txt index cc9423575fd3..c15e203918bd 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(ut_blobstorage-ut_read_only_vdisk PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ut_blobstorage-ut_read_only_vdisk PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/read_only_vdisk.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk/CMakeLists.windows-x86_64.txt index 2b7653193c1c..4ca4a37f2527 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_read_only_vdisk/CMakeLists.windows-x86_64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_replication/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_replication/CMakeLists.darwin-arm64.txt index 874e28d34160..93cfee2de94d 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_replication/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_replication/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(core-blobstorage-ut_blobstorage-ut_replication PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(core-blobstorage-ut_blobstorage-ut_replication PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/replication.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_replication/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_replication/CMakeLists.darwin-x86_64.txt index 4ac02bb68300..42030ce6c975 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_replication/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_replication/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(core-blobstorage-ut_blobstorage-ut_replication PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(core-blobstorage-ut_blobstorage-ut_replication PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/replication.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_replication/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_replication/CMakeLists.linux-aarch64.txt index 88c3d2dbe0a4..40925cdc6e75 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_replication/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_replication/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(core-blobstorage-ut_blobstorage-ut_replication PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(core-blobstorage-ut_blobstorage-ut_replication PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/replication.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_replication/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_replication/CMakeLists.linux-x86_64.txt index bff6c1407f91..d7161827fd5c 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_replication/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_replication/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(core-blobstorage-ut_blobstorage-ut_replication PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(core-blobstorage-ut_blobstorage-ut_replication PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/replication.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_replication/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_replication/CMakeLists.windows-x86_64.txt index 60ff0fa24d40..f59838786b3b 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_replication/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_replication/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_scrub/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_scrub/CMakeLists.darwin-arm64.txt index b1e9a8ac9e34..7b35793aae39 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_scrub/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_scrub/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-core-blobstorage-ut_blobstorage-ut_scrub PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-ut_blobstorage-ut_scrub PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/scrub.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_scrub/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_scrub/CMakeLists.darwin-x86_64.txt index 275607dedad1..9ed0fb8e6cab 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_scrub/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_scrub/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-core-blobstorage-ut_blobstorage-ut_scrub PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-ut_blobstorage-ut_scrub PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/scrub.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_scrub/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_scrub/CMakeLists.linux-aarch64.txt index 07dac5c320f4..a9b6034300fd 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_scrub/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_scrub/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-core-blobstorage-ut_blobstorage-ut_scrub PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-ut_blobstorage-ut_scrub PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/scrub.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_scrub/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_scrub/CMakeLists.linux-x86_64.txt index 07f21ccbde3b..eefd5b6fd4eb 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_scrub/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_scrub/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-core-blobstorage-ut_blobstorage-ut_scrub PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-ut_blobstorage-ut_scrub PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/scrub.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_scrub/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_scrub/CMakeLists.windows-x86_64.txt index 0bb270a82d61..5a1bbe744c3f 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_scrub/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_scrub/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_vdisk_restart/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_vdisk_restart/CMakeLists.darwin-arm64.txt index 36a04655d0e6..103d3b192b95 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_vdisk_restart/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_vdisk_restart/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(blobstorage-ut_blobstorage-ut_vdisk_restart PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(blobstorage-ut_blobstorage-ut_vdisk_restart PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/vdisk_restart.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_vdisk_restart/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_vdisk_restart/CMakeLists.darwin-x86_64.txt index 379dd6aafcac..c47437c3dd05 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_vdisk_restart/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_vdisk_restart/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(blobstorage-ut_blobstorage-ut_vdisk_restart PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(blobstorage-ut_blobstorage-ut_vdisk_restart PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/vdisk_restart.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_vdisk_restart/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_vdisk_restart/CMakeLists.linux-aarch64.txt index 1026c68db9f1..1ee47adce63f 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_vdisk_restart/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_vdisk_restart/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(blobstorage-ut_blobstorage-ut_vdisk_restart PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(blobstorage-ut_blobstorage-ut_vdisk_restart PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/vdisk_restart.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_vdisk_restart/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_vdisk_restart/CMakeLists.linux-x86_64.txt index 7d6211c77808..134f615e24e5 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_vdisk_restart/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_vdisk_restart/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(blobstorage-ut_blobstorage-ut_vdisk_restart PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(blobstorage-ut_blobstorage-ut_vdisk_restart PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_blobstorage/vdisk_restart.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_blobstorage/ut_vdisk_restart/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/ut_vdisk_restart/CMakeLists.windows-x86_64.txt index 40828e092235..54455d2dae71 100644 --- a/ydb/core/blobstorage/ut_blobstorage/ut_vdisk_restart/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/ut_vdisk_restart/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_group/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_group/CMakeLists.darwin-arm64.txt index 7b7b0305ef00..353b5cf2d3de 100644 --- a/ydb/core/blobstorage/ut_group/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_group/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-blobstorage-ut_group PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-ut_group PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_group/main.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_group/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_group/CMakeLists.darwin-x86_64.txt index 08d864c7dd26..6312ab3ac606 100644 --- a/ydb/core/blobstorage/ut_group/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_group/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-blobstorage-ut_group PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-ut_group PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_group/main.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_group/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_group/CMakeLists.linux-aarch64.txt index 37f052af9207..746f31afd9b7 100644 --- a/ydb/core/blobstorage/ut_group/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_group/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-blobstorage-ut_group PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-ut_group PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_group/main.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_group/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_group/CMakeLists.linux-x86_64.txt index d73cc840a2e6..9d161e135ce8 100644 --- a/ydb/core/blobstorage/ut_group/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_group/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-blobstorage-ut_group PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-ut_group PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_group/main.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_group/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_group/CMakeLists.windows-x86_64.txt index 61c4d57b0bab..2d97bd8714b7 100644 --- a/ydb/core/blobstorage/ut_group/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_group/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.darwin-arm64.txt index 9820fee5f6e5..cd619388db4d 100644 --- a/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.darwin-arm64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-core-blobstorage-ut_mirror3of4 PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-ut_mirror3of4 PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_mirror3of4/main.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.darwin-x86_64.txt index 3318697df854..23d89529f7cc 100644 --- a/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.darwin-x86_64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-blobstorage-ut_mirror3of4 PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-ut_mirror3of4 PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_mirror3of4/main.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.linux-aarch64.txt index 5f05c475eed5..e6a8877d5f34 100644 --- a/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-core-blobstorage-ut_mirror3of4 PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-ut_mirror3of4 PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_mirror3of4/main.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.linux-x86_64.txt index c741d4810c98..9f496b5c44c0 100644 --- a/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.linux-x86_64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-blobstorage-ut_mirror3of4 PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-ut_mirror3of4 PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_mirror3of4/main.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.windows-x86_64.txt index 01ab56d5efdc..37faed49d804 100644 --- a/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_pdiskfit/pdiskfit/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_pdiskfit/pdiskfit/CMakeLists.linux-aarch64.txt index eed53b79d90d..c4f854dfecec 100644 --- a/ydb/core/blobstorage/ut_pdiskfit/pdiskfit/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_pdiskfit/pdiskfit/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(pdiskfit PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(pdiskfit PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_pdiskfit/pdiskfit/pdiskfit.cpp diff --git a/ydb/core/blobstorage/ut_pdiskfit/pdiskfit/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_pdiskfit/pdiskfit/CMakeLists.linux-x86_64.txt index 1f4e24ee467e..ff3d93d99608 100644 --- a/ydb/core/blobstorage/ut_pdiskfit/pdiskfit/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_pdiskfit/pdiskfit/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(pdiskfit PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(pdiskfit PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_pdiskfit/pdiskfit/pdiskfit.cpp diff --git a/ydb/core/blobstorage/ut_pdiskfit/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_pdiskfit/ut/CMakeLists.linux-aarch64.txt index a07a565bbb10..629ca9bf1cd2 100644 --- a/ydb/core/blobstorage/ut_pdiskfit/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_pdiskfit/ut/CMakeLists.linux-aarch64.txt @@ -22,9 +22,6 @@ target_link_options(ydb-core-blobstorage-ut_pdiskfit-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-ut_pdiskfit-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_pdiskfit/ut/main.cpp @@ -54,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_pdiskfit/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_pdiskfit/ut/CMakeLists.linux-x86_64.txt index 6ca5988b753f..ea899890610e 100644 --- a/ydb/core/blobstorage/ut_pdiskfit/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_pdiskfit/ut/CMakeLists.linux-x86_64.txt @@ -23,9 +23,6 @@ target_link_options(ydb-core-blobstorage-ut_pdiskfit-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-ut_pdiskfit-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_pdiskfit/ut/main.cpp @@ -55,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_testshard/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_testshard/CMakeLists.darwin-arm64.txt index cb1989c3bb3e..46b220972149 100644 --- a/ydb/core/blobstorage/ut_testshard/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_testshard/CMakeLists.darwin-arm64.txt @@ -38,8 +38,6 @@ target_link_options(ydb-core-blobstorage-ut_testshard PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-ut_testshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_testshard/main.cpp @@ -69,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_testshard/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_testshard/CMakeLists.darwin-x86_64.txt index f47f514347e3..5c635e0b11b3 100644 --- a/ydb/core/blobstorage/ut_testshard/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_testshard/CMakeLists.darwin-x86_64.txt @@ -39,8 +39,6 @@ target_link_options(ydb-core-blobstorage-ut_testshard PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-ut_testshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_testshard/main.cpp @@ -70,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_testshard/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_testshard/CMakeLists.linux-aarch64.txt index 40b4796e9b3b..13632cba37ce 100644 --- a/ydb/core/blobstorage/ut_testshard/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_testshard/CMakeLists.linux-aarch64.txt @@ -41,9 +41,6 @@ target_link_options(ydb-core-blobstorage-ut_testshard PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-ut_testshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_testshard/main.cpp @@ -73,6 +70,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_testshard/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_testshard/CMakeLists.linux-x86_64.txt index bd5bce128abf..9e02e5a34a5b 100644 --- a/ydb/core/blobstorage/ut_testshard/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_testshard/CMakeLists.linux-x86_64.txt @@ -42,9 +42,6 @@ target_link_options(ydb-core-blobstorage-ut_testshard PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-ut_testshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_testshard/main.cpp @@ -74,6 +71,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_testshard/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_testshard/CMakeLists.windows-x86_64.txt index d3f264e8d3ca..0fd1655f0b30 100644 --- a/ydb/core/blobstorage/ut_testshard/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_testshard/CMakeLists.windows-x86_64.txt @@ -63,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_vdisk/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_vdisk/CMakeLists.darwin-arm64.txt index 73b173a9b8d6..84b2321057db 100644 --- a/ydb/core/blobstorage/ut_vdisk/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_vdisk/CMakeLists.darwin-arm64.txt @@ -34,10 +34,10 @@ target_link_options(ydb-core-blobstorage-ut_vdisk PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-ut_vdisk PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/defaults.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/gen_restarts.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/gen_restarts.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/huge_migration_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/mon_reregister_ut.cpp @@ -68,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_vdisk/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_vdisk/CMakeLists.darwin-x86_64.txt index 2370736f2720..0c581b6e4f34 100644 --- a/ydb/core/blobstorage/ut_vdisk/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_vdisk/CMakeLists.darwin-x86_64.txt @@ -35,10 +35,10 @@ target_link_options(ydb-core-blobstorage-ut_vdisk PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-ut_vdisk PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/defaults.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/gen_restarts.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/gen_restarts.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/huge_migration_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/mon_reregister_ut.cpp @@ -69,6 +69,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_vdisk/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_vdisk/CMakeLists.linux-aarch64.txt index 9a25566fc5f5..2260e8b0bcb1 100644 --- a/ydb/core/blobstorage/ut_vdisk/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_vdisk/CMakeLists.linux-aarch64.txt @@ -37,11 +37,10 @@ target_link_options(ydb-core-blobstorage-ut_vdisk PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-ut_vdisk PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/defaults.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/gen_restarts.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/gen_restarts.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/huge_migration_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/mon_reregister_ut.cpp @@ -72,6 +71,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_vdisk/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_vdisk/CMakeLists.linux-x86_64.txt index e1c234e58800..9d8dbd248282 100644 --- a/ydb/core/blobstorage/ut_vdisk/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_vdisk/CMakeLists.linux-x86_64.txt @@ -38,11 +38,10 @@ target_link_options(ydb-core-blobstorage-ut_vdisk PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-ut_vdisk PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/defaults.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/gen_restarts.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/gen_restarts.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/huge_migration_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/mon_reregister_ut.cpp @@ -73,6 +72,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_vdisk/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_vdisk/CMakeLists.windows-x86_64.txt index a3e798825411..7a391ae50e24 100644 --- a/ydb/core/blobstorage/ut_vdisk/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_vdisk/CMakeLists.windows-x86_64.txt @@ -32,6 +32,8 @@ target_link_libraries(ydb-core-blobstorage-ut_vdisk PUBLIC yql-sql-pg_dummy ) target_sources(ydb-core-blobstorage-ut_vdisk PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/defaults.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/gen_restarts.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/gen_restarts.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/huge_migration_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/mon_reregister_ut.cpp @@ -62,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_vdisk/lib/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_vdisk/lib/CMakeLists.darwin-arm64.txt index b1a6bb04cb68..d89b7b260dc5 100644 --- a/ydb/core/blobstorage/ut_vdisk/lib/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_vdisk/lib/CMakeLists.darwin-arm64.txt @@ -33,6 +33,28 @@ target_link_libraries(blobstorage-ut_vdisk-lib PUBLIC ydb-library-pdisk_io ) target_sources(blobstorage-ut_vdisk-lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/astest.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/dataset.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/helpers_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/http_client.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/prepare.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/setup.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_brokendevice.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_dbstat.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_defrag.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_faketablet.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_gc.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_huge.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_load.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_localrecovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_many.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_outofspace.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_repl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_simplebs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_synclog.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/vdisk_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/dataset.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/http_client.cpp diff --git a/ydb/core/blobstorage/ut_vdisk/lib/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_vdisk/lib/CMakeLists.darwin-x86_64.txt index b1a6bb04cb68..d89b7b260dc5 100644 --- a/ydb/core/blobstorage/ut_vdisk/lib/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_vdisk/lib/CMakeLists.darwin-x86_64.txt @@ -33,6 +33,28 @@ target_link_libraries(blobstorage-ut_vdisk-lib PUBLIC ydb-library-pdisk_io ) target_sources(blobstorage-ut_vdisk-lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/astest.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/dataset.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/helpers_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/http_client.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/prepare.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/setup.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_brokendevice.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_dbstat.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_defrag.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_faketablet.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_gc.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_huge.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_load.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_localrecovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_many.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_outofspace.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_repl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_simplebs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_synclog.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/vdisk_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/dataset.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/http_client.cpp diff --git a/ydb/core/blobstorage/ut_vdisk/lib/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_vdisk/lib/CMakeLists.linux-aarch64.txt index c5950cc05d10..d41161fb30e5 100644 --- a/ydb/core/blobstorage/ut_vdisk/lib/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_vdisk/lib/CMakeLists.linux-aarch64.txt @@ -34,6 +34,28 @@ target_link_libraries(blobstorage-ut_vdisk-lib PUBLIC ydb-library-pdisk_io ) target_sources(blobstorage-ut_vdisk-lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/astest.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/dataset.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/helpers_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/http_client.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/prepare.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/setup.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_brokendevice.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_dbstat.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_defrag.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_faketablet.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_gc.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_huge.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_load.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_localrecovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_many.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_outofspace.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_repl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_simplebs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_synclog.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/vdisk_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/dataset.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/http_client.cpp diff --git a/ydb/core/blobstorage/ut_vdisk/lib/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_vdisk/lib/CMakeLists.linux-x86_64.txt index c5950cc05d10..d41161fb30e5 100644 --- a/ydb/core/blobstorage/ut_vdisk/lib/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_vdisk/lib/CMakeLists.linux-x86_64.txt @@ -34,6 +34,28 @@ target_link_libraries(blobstorage-ut_vdisk-lib PUBLIC ydb-library-pdisk_io ) target_sources(blobstorage-ut_vdisk-lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/astest.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/dataset.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/helpers_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/http_client.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/prepare.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/setup.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_brokendevice.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_dbstat.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_defrag.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_faketablet.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_gc.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_huge.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_load.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_localrecovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_many.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_outofspace.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_repl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_simplebs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_synclog.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/vdisk_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/dataset.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/http_client.cpp diff --git a/ydb/core/blobstorage/ut_vdisk/lib/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_vdisk/lib/CMakeLists.windows-x86_64.txt index b1a6bb04cb68..d89b7b260dc5 100644 --- a/ydb/core/blobstorage/ut_vdisk/lib/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_vdisk/lib/CMakeLists.windows-x86_64.txt @@ -33,6 +33,28 @@ target_link_libraries(blobstorage-ut_vdisk-lib PUBLIC ydb-library-pdisk_io ) target_sources(blobstorage-ut_vdisk-lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/astest.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/dataset.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/helpers_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/http_client.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/prepare.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/setup.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_brokendevice.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_dbstat.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_defrag.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_faketablet.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_gc.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_huge.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_load.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_localrecovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_many.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_outofspace.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_repl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_simplebs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/test_synclog.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/vdisk_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/dataset.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk/lib/http_client.cpp diff --git a/ydb/core/blobstorage/ut_vdisk2/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_vdisk2/CMakeLists.darwin-arm64.txt index 1ddc6153fbe2..ca0fee8a8348 100644 --- a/ydb/core/blobstorage/ut_vdisk2/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_vdisk2/CMakeLists.darwin-arm64.txt @@ -25,10 +25,10 @@ target_link_options(ydb-core-blobstorage-ut_vdisk2 PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-ut_vdisk2 PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk2/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk2/env.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk2/huge.cpp ) set_property( @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_vdisk2/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_vdisk2/CMakeLists.darwin-x86_64.txt index c9c054200586..0a4fdd94186d 100644 --- a/ydb/core/blobstorage/ut_vdisk2/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_vdisk2/CMakeLists.darwin-x86_64.txt @@ -26,10 +26,10 @@ target_link_options(ydb-core-blobstorage-ut_vdisk2 PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-ut_vdisk2 PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk2/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk2/env.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk2/huge.cpp ) set_property( @@ -57,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_vdisk2/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_vdisk2/CMakeLists.linux-aarch64.txt index 210d080cf96e..137fc6d3b9af 100644 --- a/ydb/core/blobstorage/ut_vdisk2/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_vdisk2/CMakeLists.linux-aarch64.txt @@ -28,11 +28,10 @@ target_link_options(ydb-core-blobstorage-ut_vdisk2 PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-ut_vdisk2 PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk2/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk2/env.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk2/huge.cpp ) set_property( @@ -60,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_vdisk2/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_vdisk2/CMakeLists.linux-x86_64.txt index 2fbd10f34ad1..dff8445d7de9 100644 --- a/ydb/core/blobstorage/ut_vdisk2/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_vdisk2/CMakeLists.linux-x86_64.txt @@ -29,11 +29,10 @@ target_link_options(ydb-core-blobstorage-ut_vdisk2 PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-ut_vdisk2 PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk2/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk2/env.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk2/huge.cpp ) set_property( @@ -61,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/ut_vdisk2/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_vdisk2/CMakeLists.windows-x86_64.txt index 9f290235a737..b4109c6cb45b 100644 --- a/ydb/core/blobstorage/ut_vdisk2/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_vdisk2/CMakeLists.windows-x86_64.txt @@ -23,6 +23,8 @@ target_link_libraries(ydb-core-blobstorage-ut_vdisk2 PUBLIC udf-service-stub ) target_sources(ydb-core-blobstorage-ut_vdisk2 PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk2/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk2/env.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/ut_vdisk2/huge.cpp ) set_property( @@ -50,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/CMakeLists.darwin-arm64.txt index 2632812048ef..5c642863c60f 100644 --- a/ydb/core/blobstorage/vdisk/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/CMakeLists.darwin-arm64.txt @@ -7,6 +7,7 @@ add_subdirectory(anubis_osiris) +add_subdirectory(balance) add_subdirectory(common) add_subdirectory(defrag) add_subdirectory(handoff) @@ -45,5 +46,8 @@ target_link_libraries(core-blobstorage-vdisk PUBLIC blobstorage-vdisk-synclog ) target_sources(core-blobstorage-vdisk PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/vdisk_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/vdisk_services.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/vdisk_actor.cpp ) diff --git a/ydb/core/blobstorage/vdisk/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/CMakeLists.darwin-x86_64.txt index 2632812048ef..5c642863c60f 100644 --- a/ydb/core/blobstorage/vdisk/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/CMakeLists.darwin-x86_64.txt @@ -7,6 +7,7 @@ add_subdirectory(anubis_osiris) +add_subdirectory(balance) add_subdirectory(common) add_subdirectory(defrag) add_subdirectory(handoff) @@ -45,5 +46,8 @@ target_link_libraries(core-blobstorage-vdisk PUBLIC blobstorage-vdisk-synclog ) target_sources(core-blobstorage-vdisk PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/vdisk_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/vdisk_services.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/vdisk_actor.cpp ) diff --git a/ydb/core/blobstorage/vdisk/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/CMakeLists.linux-aarch64.txt index 9428ff308e7b..4b1efaa44dcc 100644 --- a/ydb/core/blobstorage/vdisk/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/CMakeLists.linux-aarch64.txt @@ -7,6 +7,7 @@ add_subdirectory(anubis_osiris) +add_subdirectory(balance) add_subdirectory(common) add_subdirectory(defrag) add_subdirectory(handoff) @@ -46,5 +47,8 @@ target_link_libraries(core-blobstorage-vdisk PUBLIC blobstorage-vdisk-synclog ) target_sources(core-blobstorage-vdisk PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/vdisk_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/vdisk_services.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/vdisk_actor.cpp ) diff --git a/ydb/core/blobstorage/vdisk/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/CMakeLists.linux-x86_64.txt index 9428ff308e7b..4b1efaa44dcc 100644 --- a/ydb/core/blobstorage/vdisk/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/CMakeLists.linux-x86_64.txt @@ -7,6 +7,7 @@ add_subdirectory(anubis_osiris) +add_subdirectory(balance) add_subdirectory(common) add_subdirectory(defrag) add_subdirectory(handoff) @@ -46,5 +47,8 @@ target_link_libraries(core-blobstorage-vdisk PUBLIC blobstorage-vdisk-synclog ) target_sources(core-blobstorage-vdisk PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/vdisk_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/vdisk_services.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/vdisk_actor.cpp ) diff --git a/ydb/core/blobstorage/vdisk/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/CMakeLists.windows-x86_64.txt index 2632812048ef..5c642863c60f 100644 --- a/ydb/core/blobstorage/vdisk/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/CMakeLists.windows-x86_64.txt @@ -7,6 +7,7 @@ add_subdirectory(anubis_osiris) +add_subdirectory(balance) add_subdirectory(common) add_subdirectory(defrag) add_subdirectory(handoff) @@ -45,5 +46,8 @@ target_link_libraries(core-blobstorage-vdisk PUBLIC blobstorage-vdisk-synclog ) target_sources(core-blobstorage-vdisk PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/vdisk_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/vdisk_services.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/vdisk_actor.cpp ) diff --git a/ydb/core/blobstorage/vdisk/anubis_osiris/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/anubis_osiris/CMakeLists.darwin-arm64.txt index 308e5d11ad1c..38ce022d34c8 100644 --- a/ydb/core/blobstorage/vdisk/anubis_osiris/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/anubis_osiris/CMakeLists.darwin-arm64.txt @@ -24,6 +24,7 @@ target_link_libraries(blobstorage-vdisk-anubis_osiris PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-anubis_osiris PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/blobstorage_anubis.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/blobstorage_anubis_algo.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/blobstorage_anubis_osiris.cpp diff --git a/ydb/core/blobstorage/vdisk/anubis_osiris/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/anubis_osiris/CMakeLists.darwin-x86_64.txt index 308e5d11ad1c..38ce022d34c8 100644 --- a/ydb/core/blobstorage/vdisk/anubis_osiris/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/anubis_osiris/CMakeLists.darwin-x86_64.txt @@ -24,6 +24,7 @@ target_link_libraries(blobstorage-vdisk-anubis_osiris PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-anubis_osiris PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/blobstorage_anubis.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/blobstorage_anubis_algo.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/blobstorage_anubis_osiris.cpp diff --git a/ydb/core/blobstorage/vdisk/anubis_osiris/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/anubis_osiris/CMakeLists.linux-aarch64.txt index c73f259c813b..ff58974819fb 100644 --- a/ydb/core/blobstorage/vdisk/anubis_osiris/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/anubis_osiris/CMakeLists.linux-aarch64.txt @@ -25,6 +25,7 @@ target_link_libraries(blobstorage-vdisk-anubis_osiris PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-anubis_osiris PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/blobstorage_anubis.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/blobstorage_anubis_algo.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/blobstorage_anubis_osiris.cpp diff --git a/ydb/core/blobstorage/vdisk/anubis_osiris/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/anubis_osiris/CMakeLists.linux-x86_64.txt index c73f259c813b..ff58974819fb 100644 --- a/ydb/core/blobstorage/vdisk/anubis_osiris/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/anubis_osiris/CMakeLists.linux-x86_64.txt @@ -25,6 +25,7 @@ target_link_libraries(blobstorage-vdisk-anubis_osiris PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-anubis_osiris PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/blobstorage_anubis.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/blobstorage_anubis_algo.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/blobstorage_anubis_osiris.cpp diff --git a/ydb/core/blobstorage/vdisk/anubis_osiris/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/anubis_osiris/CMakeLists.windows-x86_64.txt index 308e5d11ad1c..38ce022d34c8 100644 --- a/ydb/core/blobstorage/vdisk/anubis_osiris/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/anubis_osiris/CMakeLists.windows-x86_64.txt @@ -24,6 +24,7 @@ target_link_libraries(blobstorage-vdisk-anubis_osiris PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-anubis_osiris PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/blobstorage_anubis.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/blobstorage_anubis_algo.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/blobstorage_anubis_osiris.cpp diff --git a/ydb/core/blobstorage/vdisk/anubis_osiris/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/anubis_osiris/ut/CMakeLists.darwin-arm64.txt index 4ffcd6efbca5..5f7666f59222 100644 --- a/ydb/core/blobstorage/vdisk/anubis_osiris/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/anubis_osiris/ut/CMakeLists.darwin-arm64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-core-blobstorage-vdisk-anubis_osiris-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-anubis_osiris-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/blobstorage_anubis_algo_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/anubis_osiris/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/anubis_osiris/ut/CMakeLists.darwin-x86_64.txt index 18783cd684a8..4324ab1f5136 100644 --- a/ydb/core/blobstorage/vdisk/anubis_osiris/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/anubis_osiris/ut/CMakeLists.darwin-x86_64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-blobstorage-vdisk-anubis_osiris-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-anubis_osiris-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/blobstorage_anubis_algo_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/anubis_osiris/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/anubis_osiris/ut/CMakeLists.linux-aarch64.txt index dbf401412f85..5f2834527b7f 100644 --- a/ydb/core/blobstorage/vdisk/anubis_osiris/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/anubis_osiris/ut/CMakeLists.linux-aarch64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-core-blobstorage-vdisk-anubis_osiris-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-anubis_osiris-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/blobstorage_anubis_algo_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/anubis_osiris/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/anubis_osiris/ut/CMakeLists.linux-x86_64.txt index b23696e67419..92d2f44edd52 100644 --- a/ydb/core/blobstorage/vdisk/anubis_osiris/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/anubis_osiris/ut/CMakeLists.linux-x86_64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-blobstorage-vdisk-anubis_osiris-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-anubis_osiris-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/anubis_osiris/blobstorage_anubis_algo_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/anubis_osiris/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/anubis_osiris/ut/CMakeLists.windows-x86_64.txt index d9a75e334908..c6617449f9ec 100644 --- a/ydb/core/blobstorage/vdisk/anubis_osiris/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/anubis_osiris/ut/CMakeLists.windows-x86_64.txt @@ -49,6 +49,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/balance/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/balance/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..d42ed53dd56c --- /dev/null +++ b/ydb/core/blobstorage/vdisk/balance/CMakeLists.darwin-arm64.txt @@ -0,0 +1,23 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(blobstorage-vdisk-balance) +target_link_libraries(blobstorage-vdisk-balance PUBLIC + contrib-libs-cxxsupp + yutil + core-blobstorage-base + core-blobstorage-groupinfo + blobstorage-vdisk-common + blobstorage-vdisk-hulldb + blobstorage-vdisk-ingress + blobstorage-vdisk-repl +) +target_sources(blobstorage-vdisk-balance PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/balance/balancing_actor.cpp +) diff --git a/ydb/core/blobstorage/vdisk/balance/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/balance/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..d42ed53dd56c --- /dev/null +++ b/ydb/core/blobstorage/vdisk/balance/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,23 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(blobstorage-vdisk-balance) +target_link_libraries(blobstorage-vdisk-balance PUBLIC + contrib-libs-cxxsupp + yutil + core-blobstorage-base + core-blobstorage-groupinfo + blobstorage-vdisk-common + blobstorage-vdisk-hulldb + blobstorage-vdisk-ingress + blobstorage-vdisk-repl +) +target_sources(blobstorage-vdisk-balance PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/balance/balancing_actor.cpp +) diff --git a/ydb/core/blobstorage/vdisk/balance/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/balance/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..b9e3ca7f7a4b --- /dev/null +++ b/ydb/core/blobstorage/vdisk/balance/CMakeLists.linux-aarch64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(blobstorage-vdisk-balance) +target_link_libraries(blobstorage-vdisk-balance PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + core-blobstorage-base + core-blobstorage-groupinfo + blobstorage-vdisk-common + blobstorage-vdisk-hulldb + blobstorage-vdisk-ingress + blobstorage-vdisk-repl +) +target_sources(blobstorage-vdisk-balance PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/balance/balancing_actor.cpp +) diff --git a/ydb/core/blobstorage/vdisk/balance/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/balance/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..b9e3ca7f7a4b --- /dev/null +++ b/ydb/core/blobstorage/vdisk/balance/CMakeLists.linux-x86_64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(blobstorage-vdisk-balance) +target_link_libraries(blobstorage-vdisk-balance PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + core-blobstorage-base + core-blobstorage-groupinfo + blobstorage-vdisk-common + blobstorage-vdisk-hulldb + blobstorage-vdisk-ingress + blobstorage-vdisk-repl +) +target_sources(blobstorage-vdisk-balance PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/balance/balancing_actor.cpp +) diff --git a/ydb/core/blobstorage/vdisk/balance/CMakeLists.txt b/ydb/core/blobstorage/vdisk/balance/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/blobstorage/vdisk/balance/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/blobstorage/vdisk/balance/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/balance/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..d42ed53dd56c --- /dev/null +++ b/ydb/core/blobstorage/vdisk/balance/CMakeLists.windows-x86_64.txt @@ -0,0 +1,23 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(blobstorage-vdisk-balance) +target_link_libraries(blobstorage-vdisk-balance PUBLIC + contrib-libs-cxxsupp + yutil + core-blobstorage-base + core-blobstorage-groupinfo + blobstorage-vdisk-common + blobstorage-vdisk-hulldb + blobstorage-vdisk-ingress + blobstorage-vdisk-repl +) +target_sources(blobstorage-vdisk-balance PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/balance/balancing_actor.cpp +) diff --git a/ydb/core/blobstorage/vdisk/common/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/common/CMakeLists.darwin-arm64.txt index f746d947c182..bb93784e376e 100644 --- a/ydb/core/blobstorage/vdisk/common/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/common/CMakeLists.darwin-arm64.txt @@ -20,6 +20,38 @@ target_link_libraries(blobstorage-vdisk-common PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/align.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_dblogcutter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_event_filter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_status.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_vdisk_guids.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/disk_part.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/sublog.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_context.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_costmodel.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_dbtype.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_defrag.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_handle_class.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_histogram_latency.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_histograms.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_hugeblobctx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_hulllogctx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_lsnmngr.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_mongroups.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_outofspace.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_pdisk_error.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_pdiskctx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_private_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_queues.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_recoverylogwriter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_response.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_syncneighbors.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_cost_tracker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_dblogcutter.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_event_filter.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_status.cpp diff --git a/ydb/core/blobstorage/vdisk/common/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/common/CMakeLists.darwin-x86_64.txt index f746d947c182..bb93784e376e 100644 --- a/ydb/core/blobstorage/vdisk/common/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/common/CMakeLists.darwin-x86_64.txt @@ -20,6 +20,38 @@ target_link_libraries(blobstorage-vdisk-common PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/align.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_dblogcutter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_event_filter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_status.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_vdisk_guids.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/disk_part.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/sublog.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_context.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_costmodel.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_dbtype.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_defrag.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_handle_class.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_histogram_latency.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_histograms.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_hugeblobctx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_hulllogctx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_lsnmngr.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_mongroups.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_outofspace.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_pdisk_error.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_pdiskctx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_private_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_queues.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_recoverylogwriter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_response.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_syncneighbors.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_cost_tracker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_dblogcutter.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_event_filter.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_status.cpp diff --git a/ydb/core/blobstorage/vdisk/common/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/common/CMakeLists.linux-aarch64.txt index b1e8f91af068..abc6c9a88083 100644 --- a/ydb/core/blobstorage/vdisk/common/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/common/CMakeLists.linux-aarch64.txt @@ -21,6 +21,38 @@ target_link_libraries(blobstorage-vdisk-common PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/align.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_dblogcutter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_event_filter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_status.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_vdisk_guids.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/disk_part.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/sublog.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_context.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_costmodel.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_dbtype.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_defrag.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_handle_class.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_histogram_latency.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_histograms.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_hugeblobctx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_hulllogctx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_lsnmngr.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_mongroups.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_outofspace.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_pdisk_error.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_pdiskctx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_private_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_queues.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_recoverylogwriter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_response.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_syncneighbors.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_cost_tracker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_dblogcutter.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_event_filter.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_status.cpp diff --git a/ydb/core/blobstorage/vdisk/common/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/common/CMakeLists.linux-x86_64.txt index b1e8f91af068..abc6c9a88083 100644 --- a/ydb/core/blobstorage/vdisk/common/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/common/CMakeLists.linux-x86_64.txt @@ -21,6 +21,38 @@ target_link_libraries(blobstorage-vdisk-common PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/align.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_dblogcutter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_event_filter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_status.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_vdisk_guids.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/disk_part.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/sublog.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_context.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_costmodel.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_dbtype.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_defrag.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_handle_class.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_histogram_latency.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_histograms.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_hugeblobctx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_hulllogctx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_lsnmngr.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_mongroups.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_outofspace.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_pdisk_error.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_pdiskctx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_private_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_queues.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_recoverylogwriter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_response.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_syncneighbors.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_cost_tracker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_dblogcutter.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_event_filter.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_status.cpp diff --git a/ydb/core/blobstorage/vdisk/common/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/common/CMakeLists.windows-x86_64.txt index f746d947c182..bb93784e376e 100644 --- a/ydb/core/blobstorage/vdisk/common/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/common/CMakeLists.windows-x86_64.txt @@ -20,6 +20,38 @@ target_link_libraries(blobstorage-vdisk-common PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/align.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_dblogcutter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_event_filter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_status.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_vdisk_guids.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/disk_part.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/sublog.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_context.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_costmodel.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_dbtype.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_defrag.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_handle_class.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_histogram_latency.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_histograms.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_hugeblobctx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_hulllogctx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_lsnmngr.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_mongroups.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_outofspace.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_pdisk_error.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_pdiskctx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_private_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_queues.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_recoverylogwriter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_response.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/vdisk_syncneighbors.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_cost_tracker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_dblogcutter.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_event_filter.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/blobstorage_status.cpp diff --git a/ydb/core/blobstorage/vdisk/common/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/common/ut/CMakeLists.darwin-arm64.txt index d2830e33d7d4..dc0200148a9b 100644 --- a/ydb/core/blobstorage/vdisk/common/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/common/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-blobstorage-vdisk-common-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-common-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/circlebufresize_ut.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/common/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/common/ut/CMakeLists.darwin-x86_64.txt index 4db5b1a24d58..d2c6159332d9 100644 --- a/ydb/core/blobstorage/vdisk/common/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/common/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-blobstorage-vdisk-common-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-common-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/circlebufresize_ut.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/common/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/common/ut/CMakeLists.linux-aarch64.txt index 854e38b0dec1..45ac0cbcd14a 100644 --- a/ydb/core/blobstorage/vdisk/common/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/common/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-blobstorage-vdisk-common-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-common-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/circlebufresize_ut.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/common/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/common/ut/CMakeLists.linux-x86_64.txt index cae0ebc50fb2..deb2980faa3a 100644 --- a/ydb/core/blobstorage/vdisk/common/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/common/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-blobstorage-vdisk-common-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-common-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/common/circlebufresize_ut.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/common/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/common/ut/CMakeLists.windows-x86_64.txt index 13f43bbab632..4cc23b384a7e 100644 --- a/ydb/core/blobstorage/vdisk/common/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/common/ut/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/defrag/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/defrag/CMakeLists.darwin-arm64.txt index 7e3b60a43400..808278b352d6 100644 --- a/ydb/core/blobstorage/vdisk/defrag/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/defrag/CMakeLists.darwin-arm64.txt @@ -17,6 +17,11 @@ target_link_libraries(blobstorage-vdisk-defrag PUBLIC blobstorage-vdisk-hulldb ) target_sources(blobstorage-vdisk-defrag PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_quantum.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_rewriter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_search.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_quantum.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_rewriter.cpp diff --git a/ydb/core/blobstorage/vdisk/defrag/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/defrag/CMakeLists.darwin-x86_64.txt index 7e3b60a43400..808278b352d6 100644 --- a/ydb/core/blobstorage/vdisk/defrag/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/defrag/CMakeLists.darwin-x86_64.txt @@ -17,6 +17,11 @@ target_link_libraries(blobstorage-vdisk-defrag PUBLIC blobstorage-vdisk-hulldb ) target_sources(blobstorage-vdisk-defrag PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_quantum.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_rewriter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_search.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_quantum.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_rewriter.cpp diff --git a/ydb/core/blobstorage/vdisk/defrag/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/defrag/CMakeLists.linux-aarch64.txt index 8bef9d5b299e..29c43b96cff5 100644 --- a/ydb/core/blobstorage/vdisk/defrag/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/defrag/CMakeLists.linux-aarch64.txt @@ -18,6 +18,11 @@ target_link_libraries(blobstorage-vdisk-defrag PUBLIC blobstorage-vdisk-hulldb ) target_sources(blobstorage-vdisk-defrag PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_quantum.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_rewriter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_search.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_quantum.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_rewriter.cpp diff --git a/ydb/core/blobstorage/vdisk/defrag/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/defrag/CMakeLists.linux-x86_64.txt index 8bef9d5b299e..29c43b96cff5 100644 --- a/ydb/core/blobstorage/vdisk/defrag/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/defrag/CMakeLists.linux-x86_64.txt @@ -18,6 +18,11 @@ target_link_libraries(blobstorage-vdisk-defrag PUBLIC blobstorage-vdisk-hulldb ) target_sources(blobstorage-vdisk-defrag PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_quantum.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_rewriter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_search.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_quantum.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_rewriter.cpp diff --git a/ydb/core/blobstorage/vdisk/defrag/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/defrag/CMakeLists.windows-x86_64.txt index 7e3b60a43400..808278b352d6 100644 --- a/ydb/core/blobstorage/vdisk/defrag/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/defrag/CMakeLists.windows-x86_64.txt @@ -17,6 +17,11 @@ target_link_libraries(blobstorage-vdisk-defrag PUBLIC blobstorage-vdisk-hulldb ) target_sources(blobstorage-vdisk-defrag PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_quantum.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_rewriter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_search.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_quantum.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_rewriter.cpp diff --git a/ydb/core/blobstorage/vdisk/defrag/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/defrag/ut/CMakeLists.darwin-arm64.txt index 0bf470301287..3c6f8d5222d4 100644 --- a/ydb/core/blobstorage/vdisk/defrag/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/defrag/ut/CMakeLists.darwin-arm64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-core-blobstorage-vdisk-defrag-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-defrag-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_actor_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/defrag/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/defrag/ut/CMakeLists.darwin-x86_64.txt index a81810a624cb..468f090fd276 100644 --- a/ydb/core/blobstorage/vdisk/defrag/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/defrag/ut/CMakeLists.darwin-x86_64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-blobstorage-vdisk-defrag-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-defrag-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_actor_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/defrag/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/defrag/ut/CMakeLists.linux-aarch64.txt index 24e3bb98e69b..a6627759c35a 100644 --- a/ydb/core/blobstorage/vdisk/defrag/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/defrag/ut/CMakeLists.linux-aarch64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-core-blobstorage-vdisk-defrag-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-defrag-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_actor_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/defrag/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/defrag/ut/CMakeLists.linux-x86_64.txt index 065b8481b8bd..b854f5ce66fd 100644 --- a/ydb/core/blobstorage/vdisk/defrag/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/defrag/ut/CMakeLists.linux-x86_64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-blobstorage-vdisk-defrag-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-defrag-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/defrag/defrag_actor_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/defrag/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/defrag/ut/CMakeLists.windows-x86_64.txt index 16ab544bef69..59189ed28566 100644 --- a/ydb/core/blobstorage/vdisk/defrag/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/defrag/ut/CMakeLists.windows-x86_64.txt @@ -49,6 +49,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/handoff/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/handoff/CMakeLists.darwin-arm64.txt index 30d79a88ff93..5b8495fa234e 100644 --- a/ydb/core/blobstorage/vdisk/handoff/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/handoff/CMakeLists.darwin-arm64.txt @@ -21,6 +21,13 @@ target_link_libraries(blobstorage-vdisk-handoff PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-handoff PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_basic.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_delegate.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_map.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_synclogproxy.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_basic.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_delegate.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_map.cpp diff --git a/ydb/core/blobstorage/vdisk/handoff/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/handoff/CMakeLists.darwin-x86_64.txt index 30d79a88ff93..5b8495fa234e 100644 --- a/ydb/core/blobstorage/vdisk/handoff/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/handoff/CMakeLists.darwin-x86_64.txt @@ -21,6 +21,13 @@ target_link_libraries(blobstorage-vdisk-handoff PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-handoff PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_basic.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_delegate.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_map.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_synclogproxy.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_basic.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_delegate.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_map.cpp diff --git a/ydb/core/blobstorage/vdisk/handoff/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/handoff/CMakeLists.linux-aarch64.txt index 1c646bc1a975..b66c3a5ff1f6 100644 --- a/ydb/core/blobstorage/vdisk/handoff/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/handoff/CMakeLists.linux-aarch64.txt @@ -22,6 +22,13 @@ target_link_libraries(blobstorage-vdisk-handoff PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-handoff PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_basic.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_delegate.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_map.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_synclogproxy.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_basic.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_delegate.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_map.cpp diff --git a/ydb/core/blobstorage/vdisk/handoff/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/handoff/CMakeLists.linux-x86_64.txt index 1c646bc1a975..b66c3a5ff1f6 100644 --- a/ydb/core/blobstorage/vdisk/handoff/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/handoff/CMakeLists.linux-x86_64.txt @@ -22,6 +22,13 @@ target_link_libraries(blobstorage-vdisk-handoff PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-handoff PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_basic.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_delegate.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_map.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_synclogproxy.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_basic.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_delegate.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_map.cpp diff --git a/ydb/core/blobstorage/vdisk/handoff/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/handoff/CMakeLists.windows-x86_64.txt index 30d79a88ff93..5b8495fa234e 100644 --- a/ydb/core/blobstorage/vdisk/handoff/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/handoff/CMakeLists.windows-x86_64.txt @@ -21,6 +21,13 @@ target_link_libraries(blobstorage-vdisk-handoff PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-handoff PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_basic.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_delegate.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_map.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_synclogproxy.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_basic.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_delegate.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/handoff/handoff_map.cpp diff --git a/ydb/core/blobstorage/vdisk/huge/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/huge/CMakeLists.darwin-arm64.txt index 589355bf844f..0ba4e848b1f3 100644 --- a/ydb/core/blobstorage/vdisk/huge/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/huge/CMakeLists.darwin-arm64.txt @@ -18,6 +18,12 @@ target_link_libraries(blobstorage-vdisk-huge PUBLIC vdisk-hulldb-base ) target_sources(blobstorage-vdisk-huge PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugedefs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhuge.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugeheap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugerecovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/booltt.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhuge.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugedefs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugeheap.cpp diff --git a/ydb/core/blobstorage/vdisk/huge/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/huge/CMakeLists.darwin-x86_64.txt index 589355bf844f..0ba4e848b1f3 100644 --- a/ydb/core/blobstorage/vdisk/huge/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/huge/CMakeLists.darwin-x86_64.txt @@ -18,6 +18,12 @@ target_link_libraries(blobstorage-vdisk-huge PUBLIC vdisk-hulldb-base ) target_sources(blobstorage-vdisk-huge PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugedefs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhuge.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugeheap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugerecovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/booltt.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhuge.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugedefs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugeheap.cpp diff --git a/ydb/core/blobstorage/vdisk/huge/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/huge/CMakeLists.linux-aarch64.txt index 00d7bccd97ed..bbb968b4a651 100644 --- a/ydb/core/blobstorage/vdisk/huge/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/huge/CMakeLists.linux-aarch64.txt @@ -19,6 +19,12 @@ target_link_libraries(blobstorage-vdisk-huge PUBLIC vdisk-hulldb-base ) target_sources(blobstorage-vdisk-huge PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugedefs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhuge.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugeheap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugerecovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/booltt.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhuge.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugedefs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugeheap.cpp diff --git a/ydb/core/blobstorage/vdisk/huge/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/huge/CMakeLists.linux-x86_64.txt index 00d7bccd97ed..bbb968b4a651 100644 --- a/ydb/core/blobstorage/vdisk/huge/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/huge/CMakeLists.linux-x86_64.txt @@ -19,6 +19,12 @@ target_link_libraries(blobstorage-vdisk-huge PUBLIC vdisk-hulldb-base ) target_sources(blobstorage-vdisk-huge PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugedefs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhuge.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugeheap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugerecovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/booltt.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhuge.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugedefs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugeheap.cpp diff --git a/ydb/core/blobstorage/vdisk/huge/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/huge/CMakeLists.windows-x86_64.txt index 589355bf844f..0ba4e848b1f3 100644 --- a/ydb/core/blobstorage/vdisk/huge/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/huge/CMakeLists.windows-x86_64.txt @@ -18,6 +18,12 @@ target_link_libraries(blobstorage-vdisk-huge PUBLIC vdisk-hulldb-base ) target_sources(blobstorage-vdisk-huge PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugedefs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhuge.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugeheap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugerecovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/booltt.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhuge.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugedefs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugeheap.cpp diff --git a/ydb/core/blobstorage/vdisk/huge/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/huge/ut/CMakeLists.darwin-arm64.txt index aa7cac164447..bfaddbbb0b6f 100644 --- a/ydb/core/blobstorage/vdisk/huge/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/huge/ut/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-blobstorage-vdisk-huge-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-huge-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugedefs_ut.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/huge/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/huge/ut/CMakeLists.darwin-x86_64.txt index 1618be180a0e..6e0be114ebf0 100644 --- a/ydb/core/blobstorage/vdisk/huge/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/huge/ut/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-blobstorage-vdisk-huge-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-huge-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugedefs_ut.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/huge/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/huge/ut/CMakeLists.linux-aarch64.txt index aae603091521..5f4254f66e5e 100644 --- a/ydb/core/blobstorage/vdisk/huge/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/huge/ut/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-blobstorage-vdisk-huge-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-huge-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugedefs_ut.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/huge/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/huge/ut/CMakeLists.linux-x86_64.txt index 82d176152e97..565a2cdb41ef 100644 --- a/ydb/core/blobstorage/vdisk/huge/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/huge/ut/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-blobstorage-vdisk-huge-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-huge-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/huge/blobstorage_hullhugedefs_ut.cpp @@ -68,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/huge/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/huge/ut/CMakeLists.windows-x86_64.txt index 0d45fed9825c..804ba166c36a 100644 --- a/ydb/core/blobstorage/vdisk/huge/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/huge/ut/CMakeLists.windows-x86_64.txt @@ -57,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/hulldb/CMakeLists.darwin-arm64.txt index 880fd7ff67d7..09fc1162c0a6 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/CMakeLists.darwin-arm64.txt @@ -31,3 +31,8 @@ target_link_libraries(blobstorage-vdisk-hulldb INTERFACE vdisk-hulldb-bulksst_add ydb-core-protos ) +target_sources(blobstorage-vdisk-hulldb INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/blobstorage_hullgcmap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/hull_ds_all.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/hull_ds_all_snap.h +) diff --git a/ydb/core/blobstorage/vdisk/hulldb/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/CMakeLists.darwin-x86_64.txt index 880fd7ff67d7..09fc1162c0a6 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/CMakeLists.darwin-x86_64.txt @@ -31,3 +31,8 @@ target_link_libraries(blobstorage-vdisk-hulldb INTERFACE vdisk-hulldb-bulksst_add ydb-core-protos ) +target_sources(blobstorage-vdisk-hulldb INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/blobstorage_hullgcmap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/hull_ds_all.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/hull_ds_all_snap.h +) diff --git a/ydb/core/blobstorage/vdisk/hulldb/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/hulldb/CMakeLists.linux-aarch64.txt index 0774dd133fa1..11be52afc343 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/CMakeLists.linux-aarch64.txt @@ -32,3 +32,8 @@ target_link_libraries(blobstorage-vdisk-hulldb INTERFACE vdisk-hulldb-bulksst_add ydb-core-protos ) +target_sources(blobstorage-vdisk-hulldb INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/blobstorage_hullgcmap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/hull_ds_all.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/hull_ds_all_snap.h +) diff --git a/ydb/core/blobstorage/vdisk/hulldb/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/CMakeLists.linux-x86_64.txt index 0774dd133fa1..11be52afc343 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/CMakeLists.linux-x86_64.txt @@ -32,3 +32,8 @@ target_link_libraries(blobstorage-vdisk-hulldb INTERFACE vdisk-hulldb-bulksst_add ydb-core-protos ) +target_sources(blobstorage-vdisk-hulldb INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/blobstorage_hullgcmap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/hull_ds_all.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/hull_ds_all_snap.h +) diff --git a/ydb/core/blobstorage/vdisk/hulldb/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/CMakeLists.windows-x86_64.txt index 880fd7ff67d7..09fc1162c0a6 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/CMakeLists.windows-x86_64.txt @@ -31,3 +31,8 @@ target_link_libraries(blobstorage-vdisk-hulldb INTERFACE vdisk-hulldb-bulksst_add ydb-core-protos ) +target_sources(blobstorage-vdisk-hulldb INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/blobstorage_hullgcmap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/hull_ds_all.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/hull_ds_all_snap.h +) diff --git a/ydb/core/blobstorage/vdisk/hulldb/barriers/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/hulldb/barriers/CMakeLists.darwin-arm64.txt index 4a479fb693d4..81f7ff4b884f 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/barriers/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/barriers/CMakeLists.darwin-arm64.txt @@ -18,6 +18,13 @@ target_link_libraries(vdisk-hulldb-barriers PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-barriers PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_chain.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_essence.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_public.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_tree.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/hullds_cache_barrier.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/hullds_gcessence_defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_chain.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_essence.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_public.cpp diff --git a/ydb/core/blobstorage/vdisk/hulldb/barriers/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/barriers/CMakeLists.darwin-x86_64.txt index 4a479fb693d4..81f7ff4b884f 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/barriers/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/barriers/CMakeLists.darwin-x86_64.txt @@ -18,6 +18,13 @@ target_link_libraries(vdisk-hulldb-barriers PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-barriers PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_chain.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_essence.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_public.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_tree.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/hullds_cache_barrier.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/hullds_gcessence_defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_chain.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_essence.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_public.cpp diff --git a/ydb/core/blobstorage/vdisk/hulldb/barriers/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/hulldb/barriers/CMakeLists.linux-aarch64.txt index 0d1e93397260..3b6620b01ec9 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/barriers/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/barriers/CMakeLists.linux-aarch64.txt @@ -19,6 +19,13 @@ target_link_libraries(vdisk-hulldb-barriers PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-barriers PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_chain.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_essence.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_public.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_tree.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/hullds_cache_barrier.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/hullds_gcessence_defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_chain.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_essence.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_public.cpp diff --git a/ydb/core/blobstorage/vdisk/hulldb/barriers/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/barriers/CMakeLists.linux-x86_64.txt index 0d1e93397260..3b6620b01ec9 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/barriers/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/barriers/CMakeLists.linux-x86_64.txt @@ -19,6 +19,13 @@ target_link_libraries(vdisk-hulldb-barriers PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-barriers PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_chain.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_essence.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_public.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_tree.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/hullds_cache_barrier.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/hullds_gcessence_defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_chain.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_essence.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_public.cpp diff --git a/ydb/core/blobstorage/vdisk/hulldb/barriers/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/barriers/CMakeLists.windows-x86_64.txt index 4a479fb693d4..81f7ff4b884f 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/barriers/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/barriers/CMakeLists.windows-x86_64.txt @@ -18,6 +18,13 @@ target_link_libraries(vdisk-hulldb-barriers PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-barriers PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_chain.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_essence.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_public.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_tree.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/hullds_cache_barrier.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/hullds_gcessence_defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_chain.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_essence.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_public.cpp diff --git a/ydb/core/blobstorage/vdisk/hulldb/barriers/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/hulldb/barriers/ut/CMakeLists.darwin-arm64.txt index 9816a491f6b9..b9bd48732dea 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/barriers/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/barriers/ut/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-barriers-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-hulldb-barriers-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_tree_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/barriers/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/barriers/ut/CMakeLists.darwin-x86_64.txt index b6c054d5bc69..a29502202c16 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/barriers/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/barriers/ut/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-barriers-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-hulldb-barriers-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_tree_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/barriers/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/hulldb/barriers/ut/CMakeLists.linux-aarch64.txt index 2bb83912d89c..5892f0da3acc 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/barriers/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/barriers/ut/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-barriers-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-hulldb-barriers-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_tree_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/barriers/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/barriers/ut/CMakeLists.linux-x86_64.txt index e0ad742c38f6..4a4f0c023c2b 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/barriers/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/barriers/ut/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-barriers-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-hulldb-barriers-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/barriers/barriers_tree_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/barriers/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/barriers/ut/CMakeLists.windows-x86_64.txt index 327e8f1673d7..484936dd6f7c 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/barriers/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/barriers/ut/CMakeLists.windows-x86_64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/base/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/hulldb/base/CMakeLists.darwin-arm64.txt index 6db91dc19dd6..00376f3b3831 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/base/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/base/CMakeLists.darwin-arm64.txt @@ -18,6 +18,18 @@ target_link_libraries(vdisk-hulldb-base PUBLIC blobstorage-vdisk-protos ) target_sources(vdisk-hulldb-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_blob.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hulldefs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hullsatisfactionrank.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hullstorageratio.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullbase_barrier.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullbase_block.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullbase_logoblob.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullds_arena.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullds_generic_it.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullds_glue.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullds_settings.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hulldefs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hullsatisfactionrank.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullbase_barrier.cpp diff --git a/ydb/core/blobstorage/vdisk/hulldb/base/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/base/CMakeLists.darwin-x86_64.txt index 6db91dc19dd6..00376f3b3831 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/base/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/base/CMakeLists.darwin-x86_64.txt @@ -18,6 +18,18 @@ target_link_libraries(vdisk-hulldb-base PUBLIC blobstorage-vdisk-protos ) target_sources(vdisk-hulldb-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_blob.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hulldefs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hullsatisfactionrank.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hullstorageratio.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullbase_barrier.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullbase_block.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullbase_logoblob.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullds_arena.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullds_generic_it.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullds_glue.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullds_settings.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hulldefs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hullsatisfactionrank.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullbase_barrier.cpp diff --git a/ydb/core/blobstorage/vdisk/hulldb/base/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/hulldb/base/CMakeLists.linux-aarch64.txt index ca7e9fc114db..13a65568bb2f 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/base/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/base/CMakeLists.linux-aarch64.txt @@ -19,6 +19,18 @@ target_link_libraries(vdisk-hulldb-base PUBLIC blobstorage-vdisk-protos ) target_sources(vdisk-hulldb-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_blob.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hulldefs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hullsatisfactionrank.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hullstorageratio.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullbase_barrier.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullbase_block.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullbase_logoblob.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullds_arena.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullds_generic_it.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullds_glue.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullds_settings.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hulldefs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hullsatisfactionrank.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullbase_barrier.cpp diff --git a/ydb/core/blobstorage/vdisk/hulldb/base/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/base/CMakeLists.linux-x86_64.txt index ca7e9fc114db..13a65568bb2f 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/base/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/base/CMakeLists.linux-x86_64.txt @@ -19,6 +19,18 @@ target_link_libraries(vdisk-hulldb-base PUBLIC blobstorage-vdisk-protos ) target_sources(vdisk-hulldb-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_blob.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hulldefs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hullsatisfactionrank.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hullstorageratio.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullbase_barrier.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullbase_block.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullbase_logoblob.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullds_arena.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullds_generic_it.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullds_glue.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullds_settings.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hulldefs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hullsatisfactionrank.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullbase_barrier.cpp diff --git a/ydb/core/blobstorage/vdisk/hulldb/base/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/base/CMakeLists.windows-x86_64.txt index 6db91dc19dd6..00376f3b3831 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/base/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/base/CMakeLists.windows-x86_64.txt @@ -18,6 +18,18 @@ target_link_libraries(vdisk-hulldb-base PUBLIC blobstorage-vdisk-protos ) target_sources(vdisk-hulldb-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_blob.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hulldefs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hullsatisfactionrank.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hullstorageratio.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullbase_barrier.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullbase_block.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullbase_logoblob.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullds_arena.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullds_generic_it.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullds_glue.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullds_settings.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hulldefs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_hullsatisfactionrank.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/hullbase_barrier.cpp diff --git a/ydb/core/blobstorage/vdisk/hulldb/base/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/hulldb/base/ut/CMakeLists.darwin-arm64.txt index 34b87d524977..55fb6ba9eeb5 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/base/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/base/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-base-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-hulldb-base-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_blob_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/base/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/base/ut/CMakeLists.darwin-x86_64.txt index 6fab6f907538..22a7ac8720af 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/base/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/base/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-base-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-hulldb-base-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_blob_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/base/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/hulldb/base/ut/CMakeLists.linux-aarch64.txt index 07bdc935fd6e..6a702c5a5cf8 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/base/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/base/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-base-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-hulldb-base-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_blob_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/base/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/base/ut/CMakeLists.linux-x86_64.txt index a71b32991af3..716a82532422 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/base/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/base/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-base-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-hulldb-base-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/base/blobstorage_blob_ut.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/base/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/base/ut/CMakeLists.windows-x86_64.txt index 9257f2e0b72c..85396e761605 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/base/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/base/ut/CMakeLists.windows-x86_64.txt @@ -55,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/CMakeLists.darwin-arm64.txt index 24bf99401fe4..bac4536f3d88 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/CMakeLists.darwin-arm64.txt @@ -15,5 +15,6 @@ target_link_libraries(vdisk-hulldb-bulksst_add PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-bulksst_add PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/hulldb_bulksst_add.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/hulldb_bulksst_add.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/CMakeLists.darwin-x86_64.txt index 24bf99401fe4..bac4536f3d88 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/CMakeLists.darwin-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(vdisk-hulldb-bulksst_add PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-bulksst_add PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/hulldb_bulksst_add.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/hulldb_bulksst_add.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/CMakeLists.linux-aarch64.txt index f9372dcb37f4..41dc489b2adb 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/CMakeLists.linux-aarch64.txt @@ -16,5 +16,6 @@ target_link_libraries(vdisk-hulldb-bulksst_add PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-bulksst_add PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/hulldb_bulksst_add.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/hulldb_bulksst_add.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/CMakeLists.linux-x86_64.txt index f9372dcb37f4..41dc489b2adb 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/CMakeLists.linux-x86_64.txt @@ -16,5 +16,6 @@ target_link_libraries(vdisk-hulldb-bulksst_add PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-bulksst_add PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/hulldb_bulksst_add.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/hulldb_bulksst_add.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/CMakeLists.windows-x86_64.txt index 24bf99401fe4..bac4536f3d88 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/CMakeLists.windows-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(vdisk-hulldb-bulksst_add PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-bulksst_add PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/hulldb_bulksst_add.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/bulksst_add/hulldb_bulksst_add.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hulldb/cache_block/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/hulldb/cache_block/ut/CMakeLists.darwin-arm64.txt index 7fb5712363e0..51a692fe587e 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/cache_block/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/cache_block/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-cache_block-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-hulldb-cache_block-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/cache_block/cache_block_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/cache_block/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/cache_block/ut/CMakeLists.darwin-x86_64.txt index 8a08a1b8d263..3f866225fa0e 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/cache_block/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/cache_block/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-cache_block-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-hulldb-cache_block-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/cache_block/cache_block_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/cache_block/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/hulldb/cache_block/ut/CMakeLists.linux-aarch64.txt index ecd42d5893ff..e38d35a241f7 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/cache_block/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/cache_block/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-cache_block-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-hulldb-cache_block-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/cache_block/cache_block_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/cache_block/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/cache_block/ut/CMakeLists.linux-x86_64.txt index 90e503919f14..2b32e4df3613 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/cache_block/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/cache_block/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-cache_block-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-hulldb-cache_block-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/cache_block/cache_block_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/cache_block/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/cache_block/ut/CMakeLists.windows-x86_64.txt index b2d993e4b779..87e7a9bb22ef 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/cache_block/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/cache_block/ut/CMakeLists.windows-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/compstrat/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/hulldb/compstrat/CMakeLists.darwin-arm64.txt index 7c9fa1b94717..fa1bb770218e 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/compstrat/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/compstrat/CMakeLists.darwin-arm64.txt @@ -17,6 +17,17 @@ target_link_libraries(vdisk-hulldb-compstrat PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-compstrat PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_balance.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_delsst.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_lazy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_promote.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_ratio.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_selector.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_space.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_squeeze.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_utils.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_defs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_selector.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hulldb/compstrat/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/compstrat/CMakeLists.darwin-x86_64.txt index 7c9fa1b94717..fa1bb770218e 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/compstrat/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/compstrat/CMakeLists.darwin-x86_64.txt @@ -17,6 +17,17 @@ target_link_libraries(vdisk-hulldb-compstrat PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-compstrat PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_balance.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_delsst.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_lazy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_promote.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_ratio.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_selector.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_space.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_squeeze.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_utils.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_defs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_selector.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hulldb/compstrat/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/hulldb/compstrat/CMakeLists.linux-aarch64.txt index cf6ffe3ed47e..49f0ec0e450a 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/compstrat/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/compstrat/CMakeLists.linux-aarch64.txt @@ -18,6 +18,17 @@ target_link_libraries(vdisk-hulldb-compstrat PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-compstrat PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_balance.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_delsst.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_lazy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_promote.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_ratio.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_selector.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_space.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_squeeze.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_utils.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_defs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_selector.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hulldb/compstrat/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/compstrat/CMakeLists.linux-x86_64.txt index cf6ffe3ed47e..49f0ec0e450a 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/compstrat/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/compstrat/CMakeLists.linux-x86_64.txt @@ -18,6 +18,17 @@ target_link_libraries(vdisk-hulldb-compstrat PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-compstrat PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_balance.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_delsst.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_lazy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_promote.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_ratio.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_selector.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_space.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_squeeze.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_utils.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_defs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_selector.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hulldb/compstrat/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/compstrat/CMakeLists.windows-x86_64.txt index 7c9fa1b94717..fa1bb770218e 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/compstrat/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/compstrat/CMakeLists.windows-x86_64.txt @@ -17,6 +17,17 @@ target_link_libraries(vdisk-hulldb-compstrat PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-compstrat PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_balance.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_delsst.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_lazy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_promote.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_ratio.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_selector.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_space.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_squeeze.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_utils.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_defs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_selector.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hulldb/compstrat/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/hulldb/compstrat/ut/CMakeLists.darwin-arm64.txt index b6acc247940a..ebf13044ef3f 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/compstrat/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/compstrat/ut/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-compstrat-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-hulldb-compstrat-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/compstrat/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/compstrat/ut/CMakeLists.darwin-x86_64.txt index eb2ac2468fc7..fbf677f13a88 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/compstrat/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/compstrat/ut/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-compstrat-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-hulldb-compstrat-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/compstrat/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/hulldb/compstrat/ut/CMakeLists.linux-aarch64.txt index 36eda4424dd4..d3b972185201 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/compstrat/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/compstrat/ut/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-compstrat-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-hulldb-compstrat-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/compstrat/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/compstrat/ut/CMakeLists.linux-x86_64.txt index 7119d16d9651..a7f3e4da60e4 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/compstrat/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/compstrat/ut/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-compstrat-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-hulldb-compstrat-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/compstrat/hulldb_compstrat_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/compstrat/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/compstrat/ut/CMakeLists.windows-x86_64.txt index be411b678eb4..b8d832f949c7 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/compstrat/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/compstrat/ut/CMakeLists.windows-x86_64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/fresh/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/hulldb/fresh/CMakeLists.darwin-arm64.txt index c43891962ef1..f0c7cc97e260 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/fresh/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/fresh/CMakeLists.darwin-arm64.txt @@ -18,6 +18,13 @@ target_link_libraries(vdisk-hulldb-fresh PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-fresh PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_appendix.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_datasnap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_segment.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_segment_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/snap_vec.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_appendix.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_data.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_datasnap.cpp diff --git a/ydb/core/blobstorage/vdisk/hulldb/fresh/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/fresh/CMakeLists.darwin-x86_64.txt index c43891962ef1..f0c7cc97e260 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/fresh/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/fresh/CMakeLists.darwin-x86_64.txt @@ -18,6 +18,13 @@ target_link_libraries(vdisk-hulldb-fresh PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-fresh PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_appendix.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_datasnap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_segment.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_segment_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/snap_vec.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_appendix.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_data.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_datasnap.cpp diff --git a/ydb/core/blobstorage/vdisk/hulldb/fresh/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/hulldb/fresh/CMakeLists.linux-aarch64.txt index b9411234446d..8f9cd362cefb 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/fresh/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/fresh/CMakeLists.linux-aarch64.txt @@ -19,6 +19,13 @@ target_link_libraries(vdisk-hulldb-fresh PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-fresh PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_appendix.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_datasnap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_segment.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_segment_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/snap_vec.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_appendix.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_data.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_datasnap.cpp diff --git a/ydb/core/blobstorage/vdisk/hulldb/fresh/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/fresh/CMakeLists.linux-x86_64.txt index b9411234446d..8f9cd362cefb 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/fresh/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/fresh/CMakeLists.linux-x86_64.txt @@ -19,6 +19,13 @@ target_link_libraries(vdisk-hulldb-fresh PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-fresh PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_appendix.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_datasnap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_segment.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_segment_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/snap_vec.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_appendix.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_data.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_datasnap.cpp diff --git a/ydb/core/blobstorage/vdisk/hulldb/fresh/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/fresh/CMakeLists.windows-x86_64.txt index c43891962ef1..f0c7cc97e260 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/fresh/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/fresh/CMakeLists.windows-x86_64.txt @@ -18,6 +18,13 @@ target_link_libraries(vdisk-hulldb-fresh PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-fresh PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_appendix.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_datasnap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_segment.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_segment_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/snap_vec.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_appendix.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_data.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_datasnap.cpp diff --git a/ydb/core/blobstorage/vdisk/hulldb/fresh/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/hulldb/fresh/ut/CMakeLists.darwin-arm64.txt index f95e1f7634ef..d83b48d13eef 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/fresh/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/fresh/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-fresh-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-hulldb-fresh-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_appendix_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/fresh/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/fresh/ut/CMakeLists.darwin-x86_64.txt index 59a813f7d8c3..d1a922c260b2 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/fresh/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/fresh/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-fresh-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-hulldb-fresh-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_appendix_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/fresh/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/hulldb/fresh/ut/CMakeLists.linux-aarch64.txt index 5e242c602e4b..ed34ebfd4da7 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/fresh/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/fresh/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-fresh-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-hulldb-fresh-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_appendix_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/fresh/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/fresh/ut/CMakeLists.linux-x86_64.txt index d41b6f2895fb..0b026f7d573c 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/fresh/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/fresh/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-fresh-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-hulldb-fresh-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/fresh/fresh_appendix_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/fresh/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/fresh/ut/CMakeLists.windows-x86_64.txt index 0e79645ecddc..1fe3a7b31fe8 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/fresh/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/fresh/ut/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/generic/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/hulldb/generic/CMakeLists.darwin-arm64.txt index ff0ea8a96ce2..b2c5c37204be 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/generic/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/generic/CMakeLists.darwin-arm64.txt @@ -18,6 +18,24 @@ target_link_libraries(vdisk-hulldb-generic PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-generic PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hulldatamerger.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hullmergeits.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hulloptlsn.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hullrecmerger.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hullwritesst.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hulldb_bulksstloaded.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hulldb_bulksstmngr.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_idx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_idxsnap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_idxsnap_it.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_leveledssts.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sst.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sst_it.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sstslice.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sstslice_it.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sstvec.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sstvec_it.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hulloptlsn.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hulldb_bulksstmngr.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_idx.cpp diff --git a/ydb/core/blobstorage/vdisk/hulldb/generic/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/generic/CMakeLists.darwin-x86_64.txt index ff0ea8a96ce2..b2c5c37204be 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/generic/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/generic/CMakeLists.darwin-x86_64.txt @@ -18,6 +18,24 @@ target_link_libraries(vdisk-hulldb-generic PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-generic PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hulldatamerger.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hullmergeits.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hulloptlsn.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hullrecmerger.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hullwritesst.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hulldb_bulksstloaded.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hulldb_bulksstmngr.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_idx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_idxsnap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_idxsnap_it.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_leveledssts.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sst.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sst_it.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sstslice.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sstslice_it.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sstvec.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sstvec_it.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hulloptlsn.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hulldb_bulksstmngr.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_idx.cpp diff --git a/ydb/core/blobstorage/vdisk/hulldb/generic/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/hulldb/generic/CMakeLists.linux-aarch64.txt index d29505f4b957..e95757619a3b 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/generic/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/generic/CMakeLists.linux-aarch64.txt @@ -19,6 +19,24 @@ target_link_libraries(vdisk-hulldb-generic PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-generic PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hulldatamerger.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hullmergeits.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hulloptlsn.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hullrecmerger.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hullwritesst.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hulldb_bulksstloaded.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hulldb_bulksstmngr.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_idx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_idxsnap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_idxsnap_it.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_leveledssts.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sst.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sst_it.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sstslice.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sstslice_it.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sstvec.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sstvec_it.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hulloptlsn.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hulldb_bulksstmngr.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_idx.cpp diff --git a/ydb/core/blobstorage/vdisk/hulldb/generic/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/generic/CMakeLists.linux-x86_64.txt index d29505f4b957..e95757619a3b 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/generic/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/generic/CMakeLists.linux-x86_64.txt @@ -19,6 +19,24 @@ target_link_libraries(vdisk-hulldb-generic PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-generic PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hulldatamerger.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hullmergeits.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hulloptlsn.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hullrecmerger.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hullwritesst.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hulldb_bulksstloaded.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hulldb_bulksstmngr.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_idx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_idxsnap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_idxsnap_it.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_leveledssts.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sst.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sst_it.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sstslice.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sstslice_it.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sstvec.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sstvec_it.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hulloptlsn.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hulldb_bulksstmngr.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_idx.cpp diff --git a/ydb/core/blobstorage/vdisk/hulldb/generic/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/generic/CMakeLists.windows-x86_64.txt index ff0ea8a96ce2..b2c5c37204be 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/generic/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/generic/CMakeLists.windows-x86_64.txt @@ -18,6 +18,24 @@ target_link_libraries(vdisk-hulldb-generic PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-generic PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hulldatamerger.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hullmergeits.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hulloptlsn.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hullrecmerger.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hullwritesst.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hulldb_bulksstloaded.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hulldb_bulksstmngr.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_idx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_idxsnap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_idxsnap_it.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_leveledssts.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sst.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sst_it.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sstslice.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sstslice_it.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sstvec.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sstvec_it.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/blobstorage_hulloptlsn.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hulldb_bulksstmngr.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_idx.cpp diff --git a/ydb/core/blobstorage/vdisk/hulldb/generic/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/hulldb/generic/ut/CMakeLists.darwin-arm64.txt index c9ccec73fe00..d3a60bb8f681 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/generic/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/generic/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-generic-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-hulldb-generic-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sst_it_all_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/generic/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/generic/ut/CMakeLists.darwin-x86_64.txt index 24be005d68ac..4d25d4ffcbf5 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/generic/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/generic/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-generic-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-hulldb-generic-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sst_it_all_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/generic/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/hulldb/generic/ut/CMakeLists.linux-aarch64.txt index 011355907fea..008fefb68e45 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/generic/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/generic/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-generic-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-hulldb-generic-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sst_it_all_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/generic/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/generic/ut/CMakeLists.linux-x86_64.txt index a7b32bc5af73..173e98a5443b 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/generic/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/generic/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hulldb-generic-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-hulldb-generic-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/generic/hullds_sst_it_all_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/generic/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/generic/ut/CMakeLists.windows-x86_64.txt index 08f67bab0c18..7d523978fdf2 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/generic/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/generic/ut/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hulldb/recovery/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/hulldb/recovery/CMakeLists.darwin-arm64.txt index 50e400c52544..389e3fc7c0da 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/recovery/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/recovery/CMakeLists.darwin-arm64.txt @@ -17,5 +17,6 @@ target_link_libraries(vdisk-hulldb-recovery PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-recovery PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/recovery/hulldb_recovery.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/recovery/hulldb_recovery.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hulldb/recovery/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/recovery/CMakeLists.darwin-x86_64.txt index 50e400c52544..389e3fc7c0da 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/recovery/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/recovery/CMakeLists.darwin-x86_64.txt @@ -17,5 +17,6 @@ target_link_libraries(vdisk-hulldb-recovery PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-recovery PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/recovery/hulldb_recovery.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/recovery/hulldb_recovery.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hulldb/recovery/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/hulldb/recovery/CMakeLists.linux-aarch64.txt index cad216c5d3c7..38536cc6789d 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/recovery/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/recovery/CMakeLists.linux-aarch64.txt @@ -18,5 +18,6 @@ target_link_libraries(vdisk-hulldb-recovery PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-recovery PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/recovery/hulldb_recovery.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/recovery/hulldb_recovery.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hulldb/recovery/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/recovery/CMakeLists.linux-x86_64.txt index cad216c5d3c7..38536cc6789d 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/recovery/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/recovery/CMakeLists.linux-x86_64.txt @@ -18,5 +18,6 @@ target_link_libraries(vdisk-hulldb-recovery PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-recovery PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/recovery/hulldb_recovery.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/recovery/hulldb_recovery.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hulldb/recovery/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/recovery/CMakeLists.windows-x86_64.txt index 50e400c52544..389e3fc7c0da 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/recovery/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/recovery/CMakeLists.windows-x86_64.txt @@ -17,5 +17,6 @@ target_link_libraries(vdisk-hulldb-recovery PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-recovery PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/recovery/hulldb_recovery.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/recovery/hulldb_recovery.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hulldb/test/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/hulldb/test/CMakeLists.darwin-arm64.txt index 279e7bdb8f0e..8c74216684ec 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/test/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/test/CMakeLists.darwin-arm64.txt @@ -16,5 +16,7 @@ target_link_libraries(vdisk-hulldb-test PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-test PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/test/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/test/testhull_index.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/test/testhull_index.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hulldb/test/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/test/CMakeLists.darwin-x86_64.txt index 279e7bdb8f0e..8c74216684ec 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/test/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/test/CMakeLists.darwin-x86_64.txt @@ -16,5 +16,7 @@ target_link_libraries(vdisk-hulldb-test PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-test PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/test/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/test/testhull_index.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/test/testhull_index.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hulldb/test/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/hulldb/test/CMakeLists.linux-aarch64.txt index ec53987ef5e7..fff6db36eb7b 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/test/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/test/CMakeLists.linux-aarch64.txt @@ -17,5 +17,7 @@ target_link_libraries(vdisk-hulldb-test PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-test PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/test/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/test/testhull_index.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/test/testhull_index.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hulldb/test/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/test/CMakeLists.linux-x86_64.txt index ec53987ef5e7..fff6db36eb7b 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/test/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/test/CMakeLists.linux-x86_64.txt @@ -17,5 +17,7 @@ target_link_libraries(vdisk-hulldb-test PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-test PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/test/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/test/testhull_index.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/test/testhull_index.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hulldb/test/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/hulldb/test/CMakeLists.windows-x86_64.txt index 279e7bdb8f0e..8c74216684ec 100644 --- a/ydb/core/blobstorage/vdisk/hulldb/test/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hulldb/test/CMakeLists.windows-x86_64.txt @@ -16,5 +16,7 @@ target_link_libraries(vdisk-hulldb-test PUBLIC ydb-core-protos ) target_sources(vdisk-hulldb-test PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/test/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/test/testhull_index.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hulldb/test/testhull_index.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hullop/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/hullop/CMakeLists.darwin-arm64.txt index 525fefdd9aeb..babe957c9bd9 100644 --- a/ydb/core/blobstorage/vdisk/hullop/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/hullop/CMakeLists.darwin-arm64.txt @@ -26,6 +26,21 @@ target_link_libraries(blobstorage-vdisk-hullop PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-hullop PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_buildslice.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hull.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullactor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcommit.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcompactdeferredqueue.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcompact.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcompactworker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullload.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hulllog.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hulllogcutternotify.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_readbatch.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullop_compactfreshappendix.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullop_delayedresp.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullop_entryserialize.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hull.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullactor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hulllog.cpp diff --git a/ydb/core/blobstorage/vdisk/hullop/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/hullop/CMakeLists.darwin-x86_64.txt index 525fefdd9aeb..babe957c9bd9 100644 --- a/ydb/core/blobstorage/vdisk/hullop/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hullop/CMakeLists.darwin-x86_64.txt @@ -26,6 +26,21 @@ target_link_libraries(blobstorage-vdisk-hullop PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-hullop PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_buildslice.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hull.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullactor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcommit.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcompactdeferredqueue.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcompact.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcompactworker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullload.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hulllog.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hulllogcutternotify.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_readbatch.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullop_compactfreshappendix.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullop_delayedresp.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullop_entryserialize.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hull.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullactor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hulllog.cpp diff --git a/ydb/core/blobstorage/vdisk/hullop/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/hullop/CMakeLists.linux-aarch64.txt index c96aa5c05282..9cfe6439cdc8 100644 --- a/ydb/core/blobstorage/vdisk/hullop/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/hullop/CMakeLists.linux-aarch64.txt @@ -27,6 +27,21 @@ target_link_libraries(blobstorage-vdisk-hullop PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-hullop PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_buildslice.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hull.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullactor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcommit.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcompactdeferredqueue.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcompact.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcompactworker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullload.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hulllog.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hulllogcutternotify.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_readbatch.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullop_compactfreshappendix.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullop_delayedresp.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullop_entryserialize.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hull.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullactor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hulllog.cpp diff --git a/ydb/core/blobstorage/vdisk/hullop/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/hullop/CMakeLists.linux-x86_64.txt index c96aa5c05282..9cfe6439cdc8 100644 --- a/ydb/core/blobstorage/vdisk/hullop/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hullop/CMakeLists.linux-x86_64.txt @@ -27,6 +27,21 @@ target_link_libraries(blobstorage-vdisk-hullop PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-hullop PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_buildslice.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hull.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullactor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcommit.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcompactdeferredqueue.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcompact.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcompactworker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullload.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hulllog.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hulllogcutternotify.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_readbatch.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullop_compactfreshappendix.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullop_delayedresp.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullop_entryserialize.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hull.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullactor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hulllog.cpp diff --git a/ydb/core/blobstorage/vdisk/hullop/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/hullop/CMakeLists.windows-x86_64.txt index 525fefdd9aeb..babe957c9bd9 100644 --- a/ydb/core/blobstorage/vdisk/hullop/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hullop/CMakeLists.windows-x86_64.txt @@ -26,6 +26,21 @@ target_link_libraries(blobstorage-vdisk-hullop PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-hullop PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_buildslice.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hull.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullactor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcommit.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcompactdeferredqueue.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcompact.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcompactworker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullload.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hulllog.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hulllogcutternotify.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_readbatch.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullop_compactfreshappendix.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullop_delayedresp.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullop_entryserialize.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hull.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullactor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hulllog.cpp diff --git a/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/CMakeLists.darwin-arm64.txt index 9c6c88c18a04..7102fc51f19a 100644 --- a/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/CMakeLists.darwin-arm64.txt @@ -15,5 +15,6 @@ target_link_libraries(vdisk-hullop-hullcompdelete PUBLIC ydb-core-protos ) target_sources(vdisk-hullop-hullcompdelete PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/blobstorage_hullcompdelete.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/blobstorage_hullcompdelete.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/CMakeLists.darwin-x86_64.txt index 9c6c88c18a04..7102fc51f19a 100644 --- a/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/CMakeLists.darwin-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(vdisk-hullop-hullcompdelete PUBLIC ydb-core-protos ) target_sources(vdisk-hullop-hullcompdelete PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/blobstorage_hullcompdelete.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/blobstorage_hullcompdelete.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/CMakeLists.linux-aarch64.txt index 4bb7d4621322..b4f8506123d5 100644 --- a/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/CMakeLists.linux-aarch64.txt @@ -16,5 +16,6 @@ target_link_libraries(vdisk-hullop-hullcompdelete PUBLIC ydb-core-protos ) target_sources(vdisk-hullop-hullcompdelete PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/blobstorage_hullcompdelete.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/blobstorage_hullcompdelete.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/CMakeLists.linux-x86_64.txt index 4bb7d4621322..b4f8506123d5 100644 --- a/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/CMakeLists.linux-x86_64.txt @@ -16,5 +16,6 @@ target_link_libraries(vdisk-hullop-hullcompdelete PUBLIC ydb-core-protos ) target_sources(vdisk-hullop-hullcompdelete PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/blobstorage_hullcompdelete.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/blobstorage_hullcompdelete.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/CMakeLists.windows-x86_64.txt index 9c6c88c18a04..7102fc51f19a 100644 --- a/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/CMakeLists.windows-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(vdisk-hullop-hullcompdelete PUBLIC ydb-core-protos ) target_sources(vdisk-hullop-hullcompdelete PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/blobstorage_hullcompdelete.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/hullcompdelete/blobstorage_hullcompdelete.cpp ) diff --git a/ydb/core/blobstorage/vdisk/hullop/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/hullop/ut/CMakeLists.darwin-arm64.txt index 38eef49949a1..7080754e2838 100644 --- a/ydb/core/blobstorage/vdisk/hullop/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/hullop/ut/CMakeLists.darwin-arm64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hullop-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-hullop-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcompactdeferredqueue_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hullop/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/hullop/ut/CMakeLists.darwin-x86_64.txt index a26709914db8..eb8a8c3d445e 100644 --- a/ydb/core/blobstorage/vdisk/hullop/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hullop/ut/CMakeLists.darwin-x86_64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hullop-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-hullop-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcompactdeferredqueue_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hullop/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/hullop/ut/CMakeLists.linux-aarch64.txt index b4c2d5d343ae..aacf856fea81 100644 --- a/ydb/core/blobstorage/vdisk/hullop/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/hullop/ut/CMakeLists.linux-aarch64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hullop-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-hullop-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcompactdeferredqueue_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hullop/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/hullop/ut/CMakeLists.linux-x86_64.txt index f00eba32fb30..a5ad00bd39e3 100644 --- a/ydb/core/blobstorage/vdisk/hullop/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hullop/ut/CMakeLists.linux-x86_64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-blobstorage-vdisk-hullop-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-hullop-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/hullop/blobstorage_hullcompactdeferredqueue_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/hullop/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/hullop/ut/CMakeLists.windows-x86_64.txt index da2ca8673379..4c47ca881a93 100644 --- a/ydb/core/blobstorage/vdisk/hullop/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/hullop/ut/CMakeLists.windows-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/ingress/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/ingress/CMakeLists.darwin-arm64.txt index 097ee5fb7ffc..e5f5c5fc841a 100644 --- a/ydb/core/blobstorage/vdisk/ingress/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/ingress/CMakeLists.darwin-arm64.txt @@ -18,6 +18,9 @@ target_link_libraries(blobstorage-vdisk-ingress PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-ingress PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress_matrix.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress_matrix.cpp ) diff --git a/ydb/core/blobstorage/vdisk/ingress/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/ingress/CMakeLists.darwin-x86_64.txt index 097ee5fb7ffc..e5f5c5fc841a 100644 --- a/ydb/core/blobstorage/vdisk/ingress/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/ingress/CMakeLists.darwin-x86_64.txt @@ -18,6 +18,9 @@ target_link_libraries(blobstorage-vdisk-ingress PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-ingress PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress_matrix.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress_matrix.cpp ) diff --git a/ydb/core/blobstorage/vdisk/ingress/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/ingress/CMakeLists.linux-aarch64.txt index 289d40aed815..04a0370a64f0 100644 --- a/ydb/core/blobstorage/vdisk/ingress/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/ingress/CMakeLists.linux-aarch64.txt @@ -19,6 +19,9 @@ target_link_libraries(blobstorage-vdisk-ingress PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-ingress PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress_matrix.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress_matrix.cpp ) diff --git a/ydb/core/blobstorage/vdisk/ingress/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/ingress/CMakeLists.linux-x86_64.txt index 289d40aed815..04a0370a64f0 100644 --- a/ydb/core/blobstorage/vdisk/ingress/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/ingress/CMakeLists.linux-x86_64.txt @@ -19,6 +19,9 @@ target_link_libraries(blobstorage-vdisk-ingress PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-ingress PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress_matrix.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress_matrix.cpp ) diff --git a/ydb/core/blobstorage/vdisk/ingress/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/ingress/CMakeLists.windows-x86_64.txt index 097ee5fb7ffc..e5f5c5fc841a 100644 --- a/ydb/core/blobstorage/vdisk/ingress/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/ingress/CMakeLists.windows-x86_64.txt @@ -18,6 +18,9 @@ target_link_libraries(blobstorage-vdisk-ingress PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-ingress PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress_matrix.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress_matrix.cpp ) diff --git a/ydb/core/blobstorage/vdisk/ingress/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/ingress/ut/CMakeLists.darwin-arm64.txt index 3970efad7540..3220b9565c4c 100644 --- a/ydb/core/blobstorage/vdisk/ingress/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/ingress/ut/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-blobstorage-vdisk-ingress-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-ingress-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress_matrix_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/ingress/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/ingress/ut/CMakeLists.darwin-x86_64.txt index 88d30cdd302c..8d5f646f2f93 100644 --- a/ydb/core/blobstorage/vdisk/ingress/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/ingress/ut/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-blobstorage-vdisk-ingress-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-ingress-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress_matrix_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/ingress/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/ingress/ut/CMakeLists.linux-aarch64.txt index 5babbbdc7ff6..33ae9f44d63f 100644 --- a/ydb/core/blobstorage/vdisk/ingress/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/ingress/ut/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-blobstorage-vdisk-ingress-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-ingress-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress_matrix_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/ingress/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/ingress/ut/CMakeLists.linux-x86_64.txt index 14e5d5bc0b4f..1db620acddf7 100644 --- a/ydb/core/blobstorage/vdisk/ingress/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/ingress/ut/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-blobstorage-vdisk-ingress-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-ingress-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/ingress/blobstorage_ingress_matrix_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/ingress/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/ingress/ut/CMakeLists.windows-x86_64.txt index 5b43ec10ab80..460a4489aaf5 100644 --- a/ydb/core/blobstorage/vdisk/ingress/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/ingress/ut/CMakeLists.windows-x86_64.txt @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/localrecovery/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/localrecovery/CMakeLists.darwin-arm64.txt index 797ce866c9c0..54899d07f91c 100644 --- a/ydb/core/blobstorage/vdisk/localrecovery/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/localrecovery/CMakeLists.darwin-arm64.txt @@ -17,6 +17,11 @@ target_link_libraries(blobstorage-vdisk-localrecovery PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-localrecovery PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_logreplay.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_public.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_readbulksst.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_defs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_logreplay.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_public.cpp diff --git a/ydb/core/blobstorage/vdisk/localrecovery/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/localrecovery/CMakeLists.darwin-x86_64.txt index 797ce866c9c0..54899d07f91c 100644 --- a/ydb/core/blobstorage/vdisk/localrecovery/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/localrecovery/CMakeLists.darwin-x86_64.txt @@ -17,6 +17,11 @@ target_link_libraries(blobstorage-vdisk-localrecovery PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-localrecovery PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_logreplay.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_public.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_readbulksst.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_defs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_logreplay.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_public.cpp diff --git a/ydb/core/blobstorage/vdisk/localrecovery/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/localrecovery/CMakeLists.linux-aarch64.txt index 6f01238c284f..bc444b561cb2 100644 --- a/ydb/core/blobstorage/vdisk/localrecovery/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/localrecovery/CMakeLists.linux-aarch64.txt @@ -18,6 +18,11 @@ target_link_libraries(blobstorage-vdisk-localrecovery PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-localrecovery PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_logreplay.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_public.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_readbulksst.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_defs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_logreplay.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_public.cpp diff --git a/ydb/core/blobstorage/vdisk/localrecovery/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/localrecovery/CMakeLists.linux-x86_64.txt index 6f01238c284f..bc444b561cb2 100644 --- a/ydb/core/blobstorage/vdisk/localrecovery/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/localrecovery/CMakeLists.linux-x86_64.txt @@ -18,6 +18,11 @@ target_link_libraries(blobstorage-vdisk-localrecovery PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-localrecovery PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_logreplay.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_public.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_readbulksst.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_defs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_logreplay.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_public.cpp diff --git a/ydb/core/blobstorage/vdisk/localrecovery/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/localrecovery/CMakeLists.windows-x86_64.txt index 797ce866c9c0..54899d07f91c 100644 --- a/ydb/core/blobstorage/vdisk/localrecovery/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/localrecovery/CMakeLists.windows-x86_64.txt @@ -17,6 +17,11 @@ target_link_libraries(blobstorage-vdisk-localrecovery PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-localrecovery PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_logreplay.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_public.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_readbulksst.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_defs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_logreplay.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/localrecovery/localrecovery_public.cpp diff --git a/ydb/core/blobstorage/vdisk/protos/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/protos/CMakeLists.darwin-arm64.txt index 83c328d60b8f..fac99e9a47f9 100644 --- a/ydb/core/blobstorage/vdisk/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/protos/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(blobstorage-vdisk-protos PUBLIC target_proto_messages(blobstorage-vdisk-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/protos/events.proto ) +target_sources(blobstorage-vdisk-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/blobstorage/vdisk/protos/events.pb.h +) target_proto_addincls(blobstorage-vdisk-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/blobstorage/vdisk/protos/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/protos/CMakeLists.darwin-x86_64.txt index 83c328d60b8f..fac99e9a47f9 100644 --- a/ydb/core/blobstorage/vdisk/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/protos/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(blobstorage-vdisk-protos PUBLIC target_proto_messages(blobstorage-vdisk-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/protos/events.proto ) +target_sources(blobstorage-vdisk-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/blobstorage/vdisk/protos/events.pb.h +) target_proto_addincls(blobstorage-vdisk-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/blobstorage/vdisk/protos/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/protos/CMakeLists.linux-aarch64.txt index 5a4de11188f5..b6f8ae32958f 100644 --- a/ydb/core/blobstorage/vdisk/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/protos/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(blobstorage-vdisk-protos PUBLIC target_proto_messages(blobstorage-vdisk-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/protos/events.proto ) +target_sources(blobstorage-vdisk-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/blobstorage/vdisk/protos/events.pb.h +) target_proto_addincls(blobstorage-vdisk-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/blobstorage/vdisk/protos/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/protos/CMakeLists.linux-x86_64.txt index 5a4de11188f5..b6f8ae32958f 100644 --- a/ydb/core/blobstorage/vdisk/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/protos/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(blobstorage-vdisk-protos PUBLIC target_proto_messages(blobstorage-vdisk-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/protos/events.proto ) +target_sources(blobstorage-vdisk-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/blobstorage/vdisk/protos/events.pb.h +) target_proto_addincls(blobstorage-vdisk-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/blobstorage/vdisk/protos/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/protos/CMakeLists.windows-x86_64.txt index 83c328d60b8f..fac99e9a47f9 100644 --- a/ydb/core/blobstorage/vdisk/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/protos/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(blobstorage-vdisk-protos PUBLIC target_proto_messages(blobstorage-vdisk-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/protos/events.proto ) +target_sources(blobstorage-vdisk-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/blobstorage/vdisk/protos/events.pb.h +) target_proto_addincls(blobstorage-vdisk-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/blobstorage/vdisk/query/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/query/CMakeLists.darwin-arm64.txt index 6cb0244a1b5b..550fd8d86e82 100644 --- a/ydb/core/blobstorage/vdisk/query/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/query/CMakeLists.darwin-arm64.txt @@ -19,6 +19,19 @@ target_link_libraries(blobstorage-vdisk-query PUBLIC vdisk-hulldb-base ) target_sources(blobstorage-vdisk-query PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/assimilation.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_base.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_dumpdb.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_public.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_readactor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_readbatch.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_spacetracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_statalgo.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_statdb.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_stathuge.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_stattablet.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_stream.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/assimilation.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_barrier.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_extr.cpp diff --git a/ydb/core/blobstorage/vdisk/query/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/query/CMakeLists.darwin-x86_64.txt index 6cb0244a1b5b..550fd8d86e82 100644 --- a/ydb/core/blobstorage/vdisk/query/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/query/CMakeLists.darwin-x86_64.txt @@ -19,6 +19,19 @@ target_link_libraries(blobstorage-vdisk-query PUBLIC vdisk-hulldb-base ) target_sources(blobstorage-vdisk-query PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/assimilation.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_base.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_dumpdb.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_public.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_readactor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_readbatch.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_spacetracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_statalgo.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_statdb.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_stathuge.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_stattablet.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_stream.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/assimilation.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_barrier.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_extr.cpp diff --git a/ydb/core/blobstorage/vdisk/query/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/query/CMakeLists.linux-aarch64.txt index 18f93a637d50..970686c2a3e4 100644 --- a/ydb/core/blobstorage/vdisk/query/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/query/CMakeLists.linux-aarch64.txt @@ -20,6 +20,19 @@ target_link_libraries(blobstorage-vdisk-query PUBLIC vdisk-hulldb-base ) target_sources(blobstorage-vdisk-query PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/assimilation.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_base.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_dumpdb.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_public.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_readactor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_readbatch.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_spacetracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_statalgo.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_statdb.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_stathuge.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_stattablet.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_stream.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/assimilation.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_barrier.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_extr.cpp diff --git a/ydb/core/blobstorage/vdisk/query/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/query/CMakeLists.linux-x86_64.txt index 18f93a637d50..970686c2a3e4 100644 --- a/ydb/core/blobstorage/vdisk/query/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/query/CMakeLists.linux-x86_64.txt @@ -20,6 +20,19 @@ target_link_libraries(blobstorage-vdisk-query PUBLIC vdisk-hulldb-base ) target_sources(blobstorage-vdisk-query PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/assimilation.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_base.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_dumpdb.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_public.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_readactor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_readbatch.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_spacetracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_statalgo.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_statdb.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_stathuge.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_stattablet.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_stream.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/assimilation.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_barrier.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_extr.cpp diff --git a/ydb/core/blobstorage/vdisk/query/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/query/CMakeLists.windows-x86_64.txt index 6cb0244a1b5b..550fd8d86e82 100644 --- a/ydb/core/blobstorage/vdisk/query/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/query/CMakeLists.windows-x86_64.txt @@ -19,6 +19,19 @@ target_link_libraries(blobstorage-vdisk-query PUBLIC vdisk-hulldb-base ) target_sources(blobstorage-vdisk-query PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/assimilation.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_base.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_dumpdb.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_public.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_readactor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_readbatch.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_spacetracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_statalgo.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_statdb.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_stathuge.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_stattablet.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_stream.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/assimilation.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_barrier.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_extr.cpp diff --git a/ydb/core/blobstorage/vdisk/query/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/query/ut/CMakeLists.darwin-arm64.txt index 57057b8e8b5b..6392ba0b945d 100644 --- a/ydb/core/blobstorage/vdisk/query/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/query/ut/CMakeLists.darwin-arm64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-core-blobstorage-vdisk-query-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-query-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_spacetracker_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/query/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/query/ut/CMakeLists.darwin-x86_64.txt index 83f4895d610d..8707ac884d94 100644 --- a/ydb/core/blobstorage/vdisk/query/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/query/ut/CMakeLists.darwin-x86_64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-core-blobstorage-vdisk-query-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-query-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_spacetracker_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/query/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/query/ut/CMakeLists.linux-aarch64.txt index 1244deca81a0..6a94af0076eb 100644 --- a/ydb/core/blobstorage/vdisk/query/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/query/ut/CMakeLists.linux-aarch64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-core-blobstorage-vdisk-query-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-query-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_spacetracker_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/query/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/query/ut/CMakeLists.linux-x86_64.txt index ebfc18f10ea9..d44ec66e9d6d 100644 --- a/ydb/core/blobstorage/vdisk/query/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/query/ut/CMakeLists.linux-x86_64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-core-blobstorage-vdisk-query-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-query-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/query/query_spacetracker_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/query/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/query/ut/CMakeLists.windows-x86_64.txt index 8b57c4d6019d..99ac8fe1636c 100644 --- a/ydb/core/blobstorage/vdisk/query/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/query/ut/CMakeLists.windows-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/repl/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/repl/CMakeLists.darwin-arm64.txt index 56105e6bf738..c4f08c3fbd1e 100644 --- a/ydb/core/blobstorage/vdisk/repl/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/repl/CMakeLists.darwin-arm64.txt @@ -25,6 +25,16 @@ target_link_libraries(blobstorage-vdisk-repl PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-repl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_hullrepljob.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_hullreplwritesst.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replbroker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replctx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_repl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replproxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replrecoverymachine.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/query_donor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/repl_quoter.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_hullrepljob.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replbroker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_repl.cpp diff --git a/ydb/core/blobstorage/vdisk/repl/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/repl/CMakeLists.darwin-x86_64.txt index 56105e6bf738..c4f08c3fbd1e 100644 --- a/ydb/core/blobstorage/vdisk/repl/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/repl/CMakeLists.darwin-x86_64.txt @@ -25,6 +25,16 @@ target_link_libraries(blobstorage-vdisk-repl PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-repl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_hullrepljob.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_hullreplwritesst.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replbroker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replctx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_repl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replproxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replrecoverymachine.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/query_donor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/repl_quoter.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_hullrepljob.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replbroker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_repl.cpp diff --git a/ydb/core/blobstorage/vdisk/repl/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/repl/CMakeLists.linux-aarch64.txt index 2dbebb2c46d4..afb417f57161 100644 --- a/ydb/core/blobstorage/vdisk/repl/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/repl/CMakeLists.linux-aarch64.txt @@ -26,6 +26,16 @@ target_link_libraries(blobstorage-vdisk-repl PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-repl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_hullrepljob.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_hullreplwritesst.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replbroker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replctx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_repl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replproxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replrecoverymachine.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/query_donor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/repl_quoter.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_hullrepljob.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replbroker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_repl.cpp diff --git a/ydb/core/blobstorage/vdisk/repl/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/repl/CMakeLists.linux-x86_64.txt index 2dbebb2c46d4..afb417f57161 100644 --- a/ydb/core/blobstorage/vdisk/repl/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/repl/CMakeLists.linux-x86_64.txt @@ -26,6 +26,16 @@ target_link_libraries(blobstorage-vdisk-repl PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-repl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_hullrepljob.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_hullreplwritesst.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replbroker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replctx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_repl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replproxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replrecoverymachine.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/query_donor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/repl_quoter.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_hullrepljob.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replbroker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_repl.cpp diff --git a/ydb/core/blobstorage/vdisk/repl/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/repl/CMakeLists.windows-x86_64.txt index 56105e6bf738..c4f08c3fbd1e 100644 --- a/ydb/core/blobstorage/vdisk/repl/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/repl/CMakeLists.windows-x86_64.txt @@ -25,6 +25,16 @@ target_link_libraries(blobstorage-vdisk-repl PUBLIC ydb-core-protos ) target_sources(blobstorage-vdisk-repl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_hullrepljob.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_hullreplwritesst.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replbroker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replctx.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_repl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replproxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replrecoverymachine.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/query_donor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/repl_quoter.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_hullrepljob.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_replbroker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_repl.cpp diff --git a/ydb/core/blobstorage/vdisk/repl/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/repl/ut/CMakeLists.darwin-arm64.txt index 16023ad1b64d..6fa5e625e484 100644 --- a/ydb/core/blobstorage/vdisk/repl/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/repl/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-blobstorage-vdisk-repl-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-repl-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_hullreplwritesst_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/repl/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/repl/ut/CMakeLists.darwin-x86_64.txt index cd42f2129ebe..8d30e7ec4e19 100644 --- a/ydb/core/blobstorage/vdisk/repl/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/repl/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-blobstorage-vdisk-repl-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-repl-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_hullreplwritesst_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/repl/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/repl/ut/CMakeLists.linux-aarch64.txt index 530395ef98d1..e78ea5b4ef49 100644 --- a/ydb/core/blobstorage/vdisk/repl/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/repl/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-blobstorage-vdisk-repl-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-repl-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_hullreplwritesst_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/repl/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/repl/ut/CMakeLists.linux-x86_64.txt index fd4c6c13e391..0248e8355efd 100644 --- a/ydb/core/blobstorage/vdisk/repl/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/repl/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-blobstorage-vdisk-repl-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-repl-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/repl/blobstorage_hullreplwritesst_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/repl/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/repl/ut/CMakeLists.windows-x86_64.txt index 83564a2c8fb5..3dcfe29217cc 100644 --- a/ydb/core/blobstorage/vdisk/repl/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/repl/ut/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/scrub/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/scrub/CMakeLists.darwin-arm64.txt index c8c2529e7ba3..79d4ffe3ae9f 100644 --- a/ydb/core/blobstorage/vdisk/scrub/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/scrub/CMakeLists.darwin-arm64.txt @@ -16,6 +16,13 @@ target_link_libraries(blobstorage-vdisk-scrub PUBLIC blobstorage-vdisk-skeleton ) target_sources(blobstorage-vdisk-scrub PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/blob_recovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/restore_corrupted_blob_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/scrub_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/scrub_actor_huge_blob_merger.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/scrub_actor_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/scrub_actor_sst_blob_merger.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/blob_recovery.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/blob_recovery_process.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/blob_recovery_queue.cpp diff --git a/ydb/core/blobstorage/vdisk/scrub/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/scrub/CMakeLists.darwin-x86_64.txt index c8c2529e7ba3..79d4ffe3ae9f 100644 --- a/ydb/core/blobstorage/vdisk/scrub/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/scrub/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,13 @@ target_link_libraries(blobstorage-vdisk-scrub PUBLIC blobstorage-vdisk-skeleton ) target_sources(blobstorage-vdisk-scrub PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/blob_recovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/restore_corrupted_blob_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/scrub_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/scrub_actor_huge_blob_merger.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/scrub_actor_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/scrub_actor_sst_blob_merger.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/blob_recovery.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/blob_recovery_process.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/blob_recovery_queue.cpp diff --git a/ydb/core/blobstorage/vdisk/scrub/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/scrub/CMakeLists.linux-aarch64.txt index af30c5651509..833db226c4dc 100644 --- a/ydb/core/blobstorage/vdisk/scrub/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/scrub/CMakeLists.linux-aarch64.txt @@ -17,6 +17,13 @@ target_link_libraries(blobstorage-vdisk-scrub PUBLIC blobstorage-vdisk-skeleton ) target_sources(blobstorage-vdisk-scrub PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/blob_recovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/restore_corrupted_blob_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/scrub_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/scrub_actor_huge_blob_merger.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/scrub_actor_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/scrub_actor_sst_blob_merger.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/blob_recovery.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/blob_recovery_process.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/blob_recovery_queue.cpp diff --git a/ydb/core/blobstorage/vdisk/scrub/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/scrub/CMakeLists.linux-x86_64.txt index af30c5651509..833db226c4dc 100644 --- a/ydb/core/blobstorage/vdisk/scrub/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/scrub/CMakeLists.linux-x86_64.txt @@ -17,6 +17,13 @@ target_link_libraries(blobstorage-vdisk-scrub PUBLIC blobstorage-vdisk-skeleton ) target_sources(blobstorage-vdisk-scrub PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/blob_recovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/restore_corrupted_blob_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/scrub_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/scrub_actor_huge_blob_merger.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/scrub_actor_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/scrub_actor_sst_blob_merger.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/blob_recovery.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/blob_recovery_process.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/blob_recovery_queue.cpp diff --git a/ydb/core/blobstorage/vdisk/scrub/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/scrub/CMakeLists.windows-x86_64.txt index c8c2529e7ba3..79d4ffe3ae9f 100644 --- a/ydb/core/blobstorage/vdisk/scrub/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/scrub/CMakeLists.windows-x86_64.txt @@ -16,6 +16,13 @@ target_link_libraries(blobstorage-vdisk-scrub PUBLIC blobstorage-vdisk-skeleton ) target_sources(blobstorage-vdisk-scrub PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/blob_recovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/restore_corrupted_blob_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/scrub_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/scrub_actor_huge_blob_merger.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/scrub_actor_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/scrub_actor_sst_blob_merger.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/blob_recovery.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/blob_recovery_process.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/scrub/blob_recovery_queue.cpp diff --git a/ydb/core/blobstorage/vdisk/skeleton/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/skeleton/CMakeLists.darwin-arm64.txt index e06a3623235d..d1a7ae94d46c 100644 --- a/ydb/core/blobstorage/vdisk/skeleton/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/skeleton/CMakeLists.darwin-arm64.txt @@ -13,12 +13,35 @@ target_link_libraries(blobstorage-vdisk-skeleton PUBLIC contrib-libs-cxxsupp yutil ydb-core-base + blobstorage-vdisk-balance vdisk-hulldb-base vdisk-hulldb-bulksst_add blobstorage-vdisk-synclog ydb-core-protos ) target_sources(blobstorage-vdisk-skeleton PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_monactors.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeleton.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeletonerr.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeletonfront.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_syncfull.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_syncfullhandler.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_takedbsnap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_block_and_get.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_capturevdisklayout.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_compactionstate.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_loggedrec.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_mon_dbmainpage.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_mon_util.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_oos_logic.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_oos_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_overload_handler.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_vmultiput_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_vmovedpatch_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_vpatch_actor.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_db.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_monactors.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeleton.cpp diff --git a/ydb/core/blobstorage/vdisk/skeleton/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/skeleton/CMakeLists.darwin-x86_64.txt index e06a3623235d..d1a7ae94d46c 100644 --- a/ydb/core/blobstorage/vdisk/skeleton/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/skeleton/CMakeLists.darwin-x86_64.txt @@ -13,12 +13,35 @@ target_link_libraries(blobstorage-vdisk-skeleton PUBLIC contrib-libs-cxxsupp yutil ydb-core-base + blobstorage-vdisk-balance vdisk-hulldb-base vdisk-hulldb-bulksst_add blobstorage-vdisk-synclog ydb-core-protos ) target_sources(blobstorage-vdisk-skeleton PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_monactors.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeleton.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeletonerr.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeletonfront.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_syncfull.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_syncfullhandler.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_takedbsnap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_block_and_get.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_capturevdisklayout.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_compactionstate.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_loggedrec.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_mon_dbmainpage.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_mon_util.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_oos_logic.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_oos_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_overload_handler.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_vmultiput_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_vmovedpatch_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_vpatch_actor.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_db.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_monactors.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeleton.cpp diff --git a/ydb/core/blobstorage/vdisk/skeleton/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/skeleton/CMakeLists.linux-aarch64.txt index bc6836ca5f8f..c572d7f1940d 100644 --- a/ydb/core/blobstorage/vdisk/skeleton/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/skeleton/CMakeLists.linux-aarch64.txt @@ -14,12 +14,35 @@ target_link_libraries(blobstorage-vdisk-skeleton PUBLIC contrib-libs-cxxsupp yutil ydb-core-base + blobstorage-vdisk-balance vdisk-hulldb-base vdisk-hulldb-bulksst_add blobstorage-vdisk-synclog ydb-core-protos ) target_sources(blobstorage-vdisk-skeleton PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_monactors.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeleton.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeletonerr.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeletonfront.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_syncfull.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_syncfullhandler.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_takedbsnap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_block_and_get.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_capturevdisklayout.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_compactionstate.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_loggedrec.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_mon_dbmainpage.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_mon_util.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_oos_logic.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_oos_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_overload_handler.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_vmultiput_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_vmovedpatch_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_vpatch_actor.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_db.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_monactors.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeleton.cpp diff --git a/ydb/core/blobstorage/vdisk/skeleton/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/skeleton/CMakeLists.linux-x86_64.txt index bc6836ca5f8f..c572d7f1940d 100644 --- a/ydb/core/blobstorage/vdisk/skeleton/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/skeleton/CMakeLists.linux-x86_64.txt @@ -14,12 +14,35 @@ target_link_libraries(blobstorage-vdisk-skeleton PUBLIC contrib-libs-cxxsupp yutil ydb-core-base + blobstorage-vdisk-balance vdisk-hulldb-base vdisk-hulldb-bulksst_add blobstorage-vdisk-synclog ydb-core-protos ) target_sources(blobstorage-vdisk-skeleton PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_monactors.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeleton.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeletonerr.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeletonfront.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_syncfull.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_syncfullhandler.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_takedbsnap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_block_and_get.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_capturevdisklayout.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_compactionstate.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_loggedrec.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_mon_dbmainpage.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_mon_util.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_oos_logic.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_oos_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_overload_handler.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_vmultiput_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_vmovedpatch_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_vpatch_actor.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_db.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_monactors.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeleton.cpp diff --git a/ydb/core/blobstorage/vdisk/skeleton/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/skeleton/CMakeLists.windows-x86_64.txt index e06a3623235d..d1a7ae94d46c 100644 --- a/ydb/core/blobstorage/vdisk/skeleton/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/skeleton/CMakeLists.windows-x86_64.txt @@ -13,12 +13,35 @@ target_link_libraries(blobstorage-vdisk-skeleton PUBLIC contrib-libs-cxxsupp yutil ydb-core-base + blobstorage-vdisk-balance vdisk-hulldb-base vdisk-hulldb-bulksst_add blobstorage-vdisk-synclog ydb-core-protos ) target_sources(blobstorage-vdisk-skeleton PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_monactors.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeleton.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeletonerr.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeletonfront.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_syncfull.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_syncfullhandler.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_takedbsnap.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_block_and_get.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_capturevdisklayout.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_compactionstate.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_loggedrec.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_mon_dbmainpage.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_mon_util.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_oos_logic.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_oos_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_overload_handler.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_vmultiput_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_vmovedpatch_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_vpatch_actor.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_db.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_monactors.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/blobstorage_skeleton.cpp diff --git a/ydb/core/blobstorage/vdisk/skeleton/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/skeleton/ut/CMakeLists.darwin-arm64.txt index b898b908bb44..fa7a6c269001 100644 --- a/ydb/core/blobstorage/vdisk/skeleton/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/skeleton/ut/CMakeLists.darwin-arm64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-blobstorage-vdisk-skeleton-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-skeleton-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_oos_logic_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/skeleton/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/skeleton/ut/CMakeLists.darwin-x86_64.txt index 819db2d04ef3..48ddc0d0ca89 100644 --- a/ydb/core/blobstorage/vdisk/skeleton/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/skeleton/ut/CMakeLists.darwin-x86_64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-blobstorage-vdisk-skeleton-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-skeleton-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_oos_logic_ut.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/skeleton/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/skeleton/ut/CMakeLists.linux-aarch64.txt index e79e549815c7..7159e147e23f 100644 --- a/ydb/core/blobstorage/vdisk/skeleton/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/skeleton/ut/CMakeLists.linux-aarch64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-blobstorage-vdisk-skeleton-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-skeleton-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_oos_logic_ut.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/skeleton/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/skeleton/ut/CMakeLists.linux-x86_64.txt index 764a1a2346e4..23d26289d63b 100644 --- a/ydb/core/blobstorage/vdisk/skeleton/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/skeleton/ut/CMakeLists.linux-x86_64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-blobstorage-vdisk-skeleton-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-skeleton-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/skeleton/skeleton_oos_logic_ut.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/skeleton/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/skeleton/ut/CMakeLists.windows-x86_64.txt index 404e8ceac676..a3051c2c4c2f 100644 --- a/ydb/core/blobstorage/vdisk/skeleton/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/skeleton/ut/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/syncer/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/syncer/CMakeLists.darwin-arm64.txt index 9051a00f6610..c15438701b90 100644 --- a/ydb/core/blobstorage/vdisk/syncer/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/syncer/CMakeLists.darwin-arm64.txt @@ -24,6 +24,25 @@ target_link_libraries(blobstorage-vdisk-syncer PUBLIC version ) target_sources(blobstorage-vdisk-syncer PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_committer.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_dataserdes.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_localwriter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_recoverlostdata.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_recoverlostdata_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_scheduler.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_firstrun.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_propagator.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_proxybase.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_proxyobtain.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_proxywrite.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_recovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/syncer_context.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/syncer_job_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/syncer_job_task.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_committer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_data.cpp diff --git a/ydb/core/blobstorage/vdisk/syncer/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/syncer/CMakeLists.darwin-x86_64.txt index 9051a00f6610..c15438701b90 100644 --- a/ydb/core/blobstorage/vdisk/syncer/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/syncer/CMakeLists.darwin-x86_64.txt @@ -24,6 +24,25 @@ target_link_libraries(blobstorage-vdisk-syncer PUBLIC version ) target_sources(blobstorage-vdisk-syncer PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_committer.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_dataserdes.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_localwriter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_recoverlostdata.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_recoverlostdata_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_scheduler.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_firstrun.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_propagator.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_proxybase.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_proxyobtain.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_proxywrite.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_recovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/syncer_context.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/syncer_job_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/syncer_job_task.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_committer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_data.cpp diff --git a/ydb/core/blobstorage/vdisk/syncer/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/syncer/CMakeLists.linux-aarch64.txt index 29dcf5244278..fa88c4ae00af 100644 --- a/ydb/core/blobstorage/vdisk/syncer/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/syncer/CMakeLists.linux-aarch64.txt @@ -25,6 +25,25 @@ target_link_libraries(blobstorage-vdisk-syncer PUBLIC version ) target_sources(blobstorage-vdisk-syncer PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_committer.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_dataserdes.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_localwriter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_recoverlostdata.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_recoverlostdata_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_scheduler.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_firstrun.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_propagator.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_proxybase.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_proxyobtain.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_proxywrite.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_recovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/syncer_context.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/syncer_job_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/syncer_job_task.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_committer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_data.cpp diff --git a/ydb/core/blobstorage/vdisk/syncer/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/syncer/CMakeLists.linux-x86_64.txt index 29dcf5244278..fa88c4ae00af 100644 --- a/ydb/core/blobstorage/vdisk/syncer/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/syncer/CMakeLists.linux-x86_64.txt @@ -25,6 +25,25 @@ target_link_libraries(blobstorage-vdisk-syncer PUBLIC version ) target_sources(blobstorage-vdisk-syncer PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_committer.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_dataserdes.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_localwriter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_recoverlostdata.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_recoverlostdata_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_scheduler.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_firstrun.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_propagator.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_proxybase.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_proxyobtain.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_proxywrite.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_recovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/syncer_context.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/syncer_job_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/syncer_job_task.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_committer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_data.cpp diff --git a/ydb/core/blobstorage/vdisk/syncer/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/syncer/CMakeLists.windows-x86_64.txt index 9051a00f6610..c15438701b90 100644 --- a/ydb/core/blobstorage/vdisk/syncer/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/syncer/CMakeLists.windows-x86_64.txt @@ -24,6 +24,25 @@ target_link_libraries(blobstorage-vdisk-syncer PUBLIC version ) target_sources(blobstorage-vdisk-syncer PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_committer.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_dataserdes.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_localwriter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_recoverlostdata.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_recoverlostdata_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_scheduler.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_firstrun.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_propagator.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_proxybase.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_proxyobtain.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_proxywrite.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/guid_recovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/syncer_context.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/syncer_job_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/syncer_job_task.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_committer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_data.cpp diff --git a/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.darwin-arm64.txt index 9eada578661b..7c716b4a5553 100644 --- a/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-blobstorage-vdisk-syncer-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-syncer-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_data_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.darwin-x86_64.txt index 47e586bf7467..75256f3af926 100644 --- a/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-blobstorage-vdisk-syncer-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-syncer-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_data_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.linux-aarch64.txt index b6de287e21fd..f4f1ee69f448 100644 --- a/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-blobstorage-vdisk-syncer-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-syncer-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_data_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.linux-x86_64.txt index 15bf4f809a7f..996ac0bd9406 100644 --- a/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-blobstorage-vdisk-syncer-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-syncer-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/syncer/blobstorage_syncer_data_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.windows-x86_64.txt index 24fa651f9538..657e7e41f3c3 100644 --- a/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/synclog/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/synclog/CMakeLists.darwin-arm64.txt index 0e7a1ace7f35..381f0d77c9ce 100644 --- a/ydb/core/blobstorage/vdisk/synclog/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/synclog/CMakeLists.darwin-arm64.txt @@ -28,6 +28,26 @@ target_link_libraries(blobstorage-vdisk-synclog PUBLIC ydb-core-util ) target_sources(blobstorage-vdisk-synclog PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog_private_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog_public_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogdata.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogdsk.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogformat.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_syncloghttp.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogkeeper.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogkeeper_committer.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogkeeper_state.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogmem.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogmsgimpl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogmsgreader.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogmsgwriter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogneighbors.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogreader.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogrecovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogwriteparts.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/codecs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog_private_events.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogdata.cpp diff --git a/ydb/core/blobstorage/vdisk/synclog/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/synclog/CMakeLists.darwin-x86_64.txt index 0e7a1ace7f35..381f0d77c9ce 100644 --- a/ydb/core/blobstorage/vdisk/synclog/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/synclog/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,26 @@ target_link_libraries(blobstorage-vdisk-synclog PUBLIC ydb-core-util ) target_sources(blobstorage-vdisk-synclog PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog_private_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog_public_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogdata.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogdsk.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogformat.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_syncloghttp.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogkeeper.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogkeeper_committer.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogkeeper_state.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogmem.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogmsgimpl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogmsgreader.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogmsgwriter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogneighbors.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogreader.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogrecovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogwriteparts.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/codecs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog_private_events.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogdata.cpp diff --git a/ydb/core/blobstorage/vdisk/synclog/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/synclog/CMakeLists.linux-aarch64.txt index 39f5e6a6ee5f..66bd938e7ecd 100644 --- a/ydb/core/blobstorage/vdisk/synclog/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/synclog/CMakeLists.linux-aarch64.txt @@ -29,6 +29,26 @@ target_link_libraries(blobstorage-vdisk-synclog PUBLIC ydb-core-util ) target_sources(blobstorage-vdisk-synclog PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog_private_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog_public_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogdata.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogdsk.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogformat.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_syncloghttp.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogkeeper.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogkeeper_committer.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogkeeper_state.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogmem.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogmsgimpl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogmsgreader.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogmsgwriter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogneighbors.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogreader.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogrecovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogwriteparts.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/codecs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog_private_events.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogdata.cpp diff --git a/ydb/core/blobstorage/vdisk/synclog/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/synclog/CMakeLists.linux-x86_64.txt index 39f5e6a6ee5f..66bd938e7ecd 100644 --- a/ydb/core/blobstorage/vdisk/synclog/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/synclog/CMakeLists.linux-x86_64.txt @@ -29,6 +29,26 @@ target_link_libraries(blobstorage-vdisk-synclog PUBLIC ydb-core-util ) target_sources(blobstorage-vdisk-synclog PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog_private_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog_public_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogdata.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogdsk.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogformat.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_syncloghttp.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogkeeper.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogkeeper_committer.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogkeeper_state.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogmem.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogmsgimpl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogmsgreader.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogmsgwriter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogneighbors.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogreader.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogrecovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogwriteparts.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/codecs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog_private_events.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogdata.cpp diff --git a/ydb/core/blobstorage/vdisk/synclog/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/synclog/CMakeLists.windows-x86_64.txt index 0e7a1ace7f35..381f0d77c9ce 100644 --- a/ydb/core/blobstorage/vdisk/synclog/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/synclog/CMakeLists.windows-x86_64.txt @@ -28,6 +28,26 @@ target_link_libraries(blobstorage-vdisk-synclog PUBLIC ydb-core-util ) target_sources(blobstorage-vdisk-synclog PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog_private_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog_public_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogdata.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogdsk.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogformat.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_syncloghttp.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogkeeper.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogkeeper_committer.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogkeeper_state.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogmem.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogmsgimpl.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogmsgreader.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogmsgwriter.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogneighbors.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogreader.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogrecovery.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogwriteparts.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/codecs.h ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclog_private_events.cpp ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogdata.cpp diff --git a/ydb/core/blobstorage/vdisk/synclog/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/synclog/ut/CMakeLists.darwin-arm64.txt index 0294becc64e2..9438729f6ffd 100644 --- a/ydb/core/blobstorage/vdisk/synclog/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/synclog/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-blobstorage-vdisk-synclog-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-synclog-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogdata_ut.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/synclog/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/synclog/ut/CMakeLists.darwin-x86_64.txt index 0608ca46b5aa..ed54370f49a1 100644 --- a/ydb/core/blobstorage/vdisk/synclog/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/synclog/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-blobstorage-vdisk-synclog-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-blobstorage-vdisk-synclog-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogdata_ut.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/synclog/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/synclog/ut/CMakeLists.linux-aarch64.txt index b388342bad56..0d8bf369f9b8 100644 --- a/ydb/core/blobstorage/vdisk/synclog/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/synclog/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-blobstorage-vdisk-synclog-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-synclog-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogdata_ut.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/synclog/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/synclog/ut/CMakeLists.linux-x86_64.txt index 33d9f1e445fa..45f55b9f8e31 100644 --- a/ydb/core/blobstorage/vdisk/synclog/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/synclog/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-blobstorage-vdisk-synclog-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-blobstorage-vdisk-synclog-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/blobstorage/vdisk/synclog/blobstorage_synclogdata_ut.cpp @@ -68,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/blobstorage/vdisk/synclog/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/synclog/ut/CMakeLists.windows-x86_64.txt index b65db6b2924b..aadd0798c115 100644 --- a/ydb/core/blobstorage/vdisk/synclog/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/synclog/ut/CMakeLists.windows-x86_64.txt @@ -57,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/change_exchange/CMakeLists.darwin-arm64.txt b/ydb/core/change_exchange/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..006168ed4df6 --- /dev/null +++ b/ydb/core/change_exchange/CMakeLists.darwin-arm64.txt @@ -0,0 +1,40 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) + +add_library(ydb-core-change_exchange) +target_compile_options(ydb-core-change_exchange PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-core-change_exchange PUBLIC + contrib-libs-cxxsupp + yutil + tools-enum_parser-enum_serialization_runtime + ydb-core-base + ydb-core-scheme + library-actors-core + ydb-library-yverify_stream + monlib-service-pages +) +target_sources(ydb-core-change_exchange PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_exchange.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_record.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_sender_common_ops.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_sender_monitoring.cpp +) +generate_enum_serilization(ydb-core-change_exchange + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_record.h + INCLUDE_HEADERS + ydb/core/change_exchange/change_record.h +) diff --git a/ydb/core/change_exchange/CMakeLists.darwin-x86_64.txt b/ydb/core/change_exchange/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..006168ed4df6 --- /dev/null +++ b/ydb/core/change_exchange/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,40 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) + +add_library(ydb-core-change_exchange) +target_compile_options(ydb-core-change_exchange PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-core-change_exchange PUBLIC + contrib-libs-cxxsupp + yutil + tools-enum_parser-enum_serialization_runtime + ydb-core-base + ydb-core-scheme + library-actors-core + ydb-library-yverify_stream + monlib-service-pages +) +target_sources(ydb-core-change_exchange PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_exchange.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_record.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_sender_common_ops.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_sender_monitoring.cpp +) +generate_enum_serilization(ydb-core-change_exchange + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_record.h + INCLUDE_HEADERS + ydb/core/change_exchange/change_record.h +) diff --git a/ydb/core/change_exchange/CMakeLists.linux-aarch64.txt b/ydb/core/change_exchange/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..c1c22233b26f --- /dev/null +++ b/ydb/core/change_exchange/CMakeLists.linux-aarch64.txt @@ -0,0 +1,41 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) + +add_library(ydb-core-change_exchange) +target_compile_options(ydb-core-change_exchange PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-core-change_exchange PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + tools-enum_parser-enum_serialization_runtime + ydb-core-base + ydb-core-scheme + library-actors-core + ydb-library-yverify_stream + monlib-service-pages +) +target_sources(ydb-core-change_exchange PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_exchange.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_record.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_sender_common_ops.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_sender_monitoring.cpp +) +generate_enum_serilization(ydb-core-change_exchange + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_record.h + INCLUDE_HEADERS + ydb/core/change_exchange/change_record.h +) diff --git a/ydb/core/change_exchange/CMakeLists.linux-x86_64.txt b/ydb/core/change_exchange/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..c1c22233b26f --- /dev/null +++ b/ydb/core/change_exchange/CMakeLists.linux-x86_64.txt @@ -0,0 +1,41 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) + +add_library(ydb-core-change_exchange) +target_compile_options(ydb-core-change_exchange PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-core-change_exchange PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + tools-enum_parser-enum_serialization_runtime + ydb-core-base + ydb-core-scheme + library-actors-core + ydb-library-yverify_stream + monlib-service-pages +) +target_sources(ydb-core-change_exchange PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_exchange.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_record.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_sender_common_ops.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_sender_monitoring.cpp +) +generate_enum_serilization(ydb-core-change_exchange + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_record.h + INCLUDE_HEADERS + ydb/core/change_exchange/change_record.h +) diff --git a/ydb/core/change_exchange/CMakeLists.txt b/ydb/core/change_exchange/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/change_exchange/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/change_exchange/CMakeLists.windows-x86_64.txt b/ydb/core/change_exchange/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..006168ed4df6 --- /dev/null +++ b/ydb/core/change_exchange/CMakeLists.windows-x86_64.txt @@ -0,0 +1,40 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) + +add_library(ydb-core-change_exchange) +target_compile_options(ydb-core-change_exchange PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-core-change_exchange PUBLIC + contrib-libs-cxxsupp + yutil + tools-enum_parser-enum_serialization_runtime + ydb-core-base + ydb-core-scheme + library-actors-core + ydb-library-yverify_stream + monlib-service-pages +) +target_sources(ydb-core-change_exchange PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_exchange.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_record.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_sender_common_ops.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_sender_monitoring.cpp +) +generate_enum_serilization(ydb-core-change_exchange + ${CMAKE_SOURCE_DIR}/ydb/core/change_exchange/change_record.h + INCLUDE_HEADERS + ydb/core/change_exchange/change_record.h +) diff --git a/ydb/core/client/metadata/CMakeLists.darwin-arm64.txt b/ydb/core/client/metadata/CMakeLists.darwin-arm64.txt index cfe7195d8579..d7e337d69317 100644 --- a/ydb/core/client/metadata/CMakeLists.darwin-arm64.txt +++ b/ydb/core/client/metadata/CMakeLists.darwin-arm64.txt @@ -17,7 +17,7 @@ target_link_libraries(core-client-metadata PUBLIC yutil ydb-core-protos ydb-core-scheme_types - minikql-invoke_builtins-llvm + library-yql-minikql ) target_sources(core-client-metadata PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/metadata/types_metadata.cpp diff --git a/ydb/core/client/metadata/CMakeLists.darwin-x86_64.txt b/ydb/core/client/metadata/CMakeLists.darwin-x86_64.txt index cfe7195d8579..d7e337d69317 100644 --- a/ydb/core/client/metadata/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/client/metadata/CMakeLists.darwin-x86_64.txt @@ -17,7 +17,7 @@ target_link_libraries(core-client-metadata PUBLIC yutil ydb-core-protos ydb-core-scheme_types - minikql-invoke_builtins-llvm + library-yql-minikql ) target_sources(core-client-metadata PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/metadata/types_metadata.cpp diff --git a/ydb/core/client/metadata/CMakeLists.linux-aarch64.txt b/ydb/core/client/metadata/CMakeLists.linux-aarch64.txt index 5969a9ece27c..3806a43b170b 100644 --- a/ydb/core/client/metadata/CMakeLists.linux-aarch64.txt +++ b/ydb/core/client/metadata/CMakeLists.linux-aarch64.txt @@ -18,7 +18,7 @@ target_link_libraries(core-client-metadata PUBLIC yutil ydb-core-protos ydb-core-scheme_types - minikql-invoke_builtins-llvm + library-yql-minikql ) target_sources(core-client-metadata PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/metadata/types_metadata.cpp diff --git a/ydb/core/client/metadata/CMakeLists.linux-x86_64.txt b/ydb/core/client/metadata/CMakeLists.linux-x86_64.txt index 5969a9ece27c..3806a43b170b 100644 --- a/ydb/core/client/metadata/CMakeLists.linux-x86_64.txt +++ b/ydb/core/client/metadata/CMakeLists.linux-x86_64.txt @@ -18,7 +18,7 @@ target_link_libraries(core-client-metadata PUBLIC yutil ydb-core-protos ydb-core-scheme_types - minikql-invoke_builtins-llvm + library-yql-minikql ) target_sources(core-client-metadata PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/metadata/types_metadata.cpp diff --git a/ydb/core/client/metadata/CMakeLists.windows-x86_64.txt b/ydb/core/client/metadata/CMakeLists.windows-x86_64.txt index cfe7195d8579..d7e337d69317 100644 --- a/ydb/core/client/metadata/CMakeLists.windows-x86_64.txt +++ b/ydb/core/client/metadata/CMakeLists.windows-x86_64.txt @@ -17,7 +17,7 @@ target_link_libraries(core-client-metadata PUBLIC yutil ydb-core-protos ydb-core-scheme_types - minikql-invoke_builtins-llvm + library-yql-minikql ) target_sources(core-client-metadata PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/metadata/types_metadata.cpp diff --git a/ydb/core/client/metadata/ut/CMakeLists.darwin-arm64.txt b/ydb/core/client/metadata/ut/CMakeLists.darwin-arm64.txt index 4630637c5ae5..7b485a8c32af 100644 --- a/ydb/core/client/metadata/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/client/metadata/ut/CMakeLists.darwin-arm64.txt @@ -19,6 +19,7 @@ target_link_libraries(ydb-core-client-metadata-ut PUBLIC yutil cpp-testing-unittest_main core-client-metadata + minikql-invoke_builtins-llvm14 udf-service-stub yql-sql-pg_dummy ) @@ -26,8 +27,6 @@ target_link_options(ydb-core-client-metadata-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-client-metadata-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/metadata/ut/functions_metadata_ut.cpp @@ -57,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/metadata/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/client/metadata/ut/CMakeLists.darwin-x86_64.txt index 711d57cbeac7..dbba7f1d7ea7 100644 --- a/ydb/core/client/metadata/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/client/metadata/ut/CMakeLists.darwin-x86_64.txt @@ -20,6 +20,7 @@ target_link_libraries(ydb-core-client-metadata-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main core-client-metadata + minikql-invoke_builtins-llvm14 udf-service-stub yql-sql-pg_dummy ) @@ -27,8 +28,6 @@ target_link_options(ydb-core-client-metadata-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-client-metadata-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/metadata/ut/functions_metadata_ut.cpp @@ -58,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/metadata/ut/CMakeLists.linux-aarch64.txt b/ydb/core/client/metadata/ut/CMakeLists.linux-aarch64.txt index 4f26a42ee3f4..6659c374a289 100644 --- a/ydb/core/client/metadata/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/client/metadata/ut/CMakeLists.linux-aarch64.txt @@ -20,6 +20,7 @@ target_link_libraries(ydb-core-client-metadata-ut PUBLIC yutil cpp-testing-unittest_main core-client-metadata + minikql-invoke_builtins-llvm14 udf-service-stub yql-sql-pg_dummy ) @@ -29,9 +30,6 @@ target_link_options(ydb-core-client-metadata-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-client-metadata-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/metadata/ut/functions_metadata_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/metadata/ut/CMakeLists.linux-x86_64.txt b/ydb/core/client/metadata/ut/CMakeLists.linux-x86_64.txt index 8d96ad302619..00f0255b187d 100644 --- a/ydb/core/client/metadata/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/client/metadata/ut/CMakeLists.linux-x86_64.txt @@ -21,6 +21,7 @@ target_link_libraries(ydb-core-client-metadata-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main core-client-metadata + minikql-invoke_builtins-llvm14 udf-service-stub yql-sql-pg_dummy ) @@ -30,9 +31,6 @@ target_link_options(ydb-core-client-metadata-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-client-metadata-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/metadata/ut/functions_metadata_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/metadata/ut/CMakeLists.windows-x86_64.txt b/ydb/core/client/metadata/ut/CMakeLists.windows-x86_64.txt index c57de3851fad..449f32b9253f 100644 --- a/ydb/core/client/metadata/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/client/metadata/ut/CMakeLists.windows-x86_64.txt @@ -20,6 +20,7 @@ target_link_libraries(ydb-core-client-metadata-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main core-client-metadata + minikql-invoke_builtins-llvm14 udf-service-stub yql-sql-pg_dummy ) @@ -51,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/minikql_compile/CMakeLists.darwin-arm64.txt b/ydb/core/client/minikql_compile/CMakeLists.darwin-arm64.txt index 97acc3e7d874..64fa4f9b6ab8 100644 --- a/ydb/core/client/minikql_compile/CMakeLists.darwin-arm64.txt +++ b/ydb/core/client/minikql_compile/CMakeLists.darwin-arm64.txt @@ -27,6 +27,10 @@ target_link_libraries(core-client-minikql_compile PUBLIC providers-common-mkql ) target_sources(core-client-minikql_compile PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/compile_context.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/compile_result.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/db_key_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/yql_expr_minikql.h ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/compile_context.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/compile_result.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/db_key_resolver.cpp diff --git a/ydb/core/client/minikql_compile/CMakeLists.darwin-x86_64.txt b/ydb/core/client/minikql_compile/CMakeLists.darwin-x86_64.txt index 97acc3e7d874..64fa4f9b6ab8 100644 --- a/ydb/core/client/minikql_compile/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/client/minikql_compile/CMakeLists.darwin-x86_64.txt @@ -27,6 +27,10 @@ target_link_libraries(core-client-minikql_compile PUBLIC providers-common-mkql ) target_sources(core-client-minikql_compile PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/compile_context.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/compile_result.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/db_key_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/yql_expr_minikql.h ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/compile_context.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/compile_result.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/db_key_resolver.cpp diff --git a/ydb/core/client/minikql_compile/CMakeLists.linux-aarch64.txt b/ydb/core/client/minikql_compile/CMakeLists.linux-aarch64.txt index 79ab31524614..f9c986e0e2f6 100644 --- a/ydb/core/client/minikql_compile/CMakeLists.linux-aarch64.txt +++ b/ydb/core/client/minikql_compile/CMakeLists.linux-aarch64.txt @@ -28,6 +28,10 @@ target_link_libraries(core-client-minikql_compile PUBLIC providers-common-mkql ) target_sources(core-client-minikql_compile PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/compile_context.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/compile_result.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/db_key_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/yql_expr_minikql.h ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/compile_context.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/compile_result.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/db_key_resolver.cpp diff --git a/ydb/core/client/minikql_compile/CMakeLists.linux-x86_64.txt b/ydb/core/client/minikql_compile/CMakeLists.linux-x86_64.txt index 79ab31524614..f9c986e0e2f6 100644 --- a/ydb/core/client/minikql_compile/CMakeLists.linux-x86_64.txt +++ b/ydb/core/client/minikql_compile/CMakeLists.linux-x86_64.txt @@ -28,6 +28,10 @@ target_link_libraries(core-client-minikql_compile PUBLIC providers-common-mkql ) target_sources(core-client-minikql_compile PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/compile_context.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/compile_result.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/db_key_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/yql_expr_minikql.h ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/compile_context.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/compile_result.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/db_key_resolver.cpp diff --git a/ydb/core/client/minikql_compile/CMakeLists.windows-x86_64.txt b/ydb/core/client/minikql_compile/CMakeLists.windows-x86_64.txt index 97acc3e7d874..64fa4f9b6ab8 100644 --- a/ydb/core/client/minikql_compile/CMakeLists.windows-x86_64.txt +++ b/ydb/core/client/minikql_compile/CMakeLists.windows-x86_64.txt @@ -27,6 +27,10 @@ target_link_libraries(core-client-minikql_compile PUBLIC providers-common-mkql ) target_sources(core-client-minikql_compile PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/compile_context.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/compile_result.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/db_key_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/yql_expr_minikql.h ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/compile_context.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/compile_result.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/db_key_resolver.cpp diff --git a/ydb/core/client/minikql_compile/ut/CMakeLists.darwin-arm64.txt b/ydb/core/client/minikql_compile/ut/CMakeLists.darwin-arm64.txt index ebfc048068a4..d704ff41f11f 100644 --- a/ydb/core/client/minikql_compile/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/client/minikql_compile/ut/CMakeLists.darwin-arm64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-client-minikql_compile-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-client-minikql_compile-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/yql_expr_minikql_compile_ut.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/minikql_compile/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/client/minikql_compile/ut/CMakeLists.darwin-x86_64.txt index a0c0fda01361..00b84854c9cd 100644 --- a/ydb/core/client/minikql_compile/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/client/minikql_compile/ut/CMakeLists.darwin-x86_64.txt @@ -33,8 +33,6 @@ target_link_options(ydb-core-client-minikql_compile-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-client-minikql_compile-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/yql_expr_minikql_compile_ut.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/minikql_compile/ut/CMakeLists.linux-aarch64.txt b/ydb/core/client/minikql_compile/ut/CMakeLists.linux-aarch64.txt index 4e1f9ed74747..39c8a032b76b 100644 --- a/ydb/core/client/minikql_compile/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/client/minikql_compile/ut/CMakeLists.linux-aarch64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-client-minikql_compile-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-client-minikql_compile-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/yql_expr_minikql_compile_ut.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/minikql_compile/ut/CMakeLists.linux-x86_64.txt b/ydb/core/client/minikql_compile/ut/CMakeLists.linux-x86_64.txt index a138e888ea04..3ee05f1d9307 100644 --- a/ydb/core/client/minikql_compile/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/client/minikql_compile/ut/CMakeLists.linux-x86_64.txt @@ -36,9 +36,6 @@ target_link_options(ydb-core-client-minikql_compile-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-client-minikql_compile-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_compile/yql_expr_minikql_compile_ut.cpp @@ -68,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/minikql_compile/ut/CMakeLists.windows-x86_64.txt b/ydb/core/client/minikql_compile/ut/CMakeLists.windows-x86_64.txt index f910632f5cee..37f93a7a754e 100644 --- a/ydb/core/client/minikql_compile/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/client/minikql_compile/ut/CMakeLists.windows-x86_64.txt @@ -57,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/minikql_result_lib/CMakeLists.darwin-arm64.txt b/ydb/core/client/minikql_result_lib/CMakeLists.darwin-arm64.txt index d66fdd861bb9..e31cb1c19e79 100644 --- a/ydb/core/client/minikql_result_lib/CMakeLists.darwin-arm64.txt +++ b/ydb/core/client/minikql_result_lib/CMakeLists.darwin-arm64.txt @@ -19,6 +19,8 @@ target_link_libraries(core-client-minikql_result_lib PUBLIC lib-deprecated-kicli ) target_sources(core-client-minikql_result_lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/objects.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/converter.h ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/objects.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/converter.cpp ) diff --git a/ydb/core/client/minikql_result_lib/CMakeLists.darwin-x86_64.txt b/ydb/core/client/minikql_result_lib/CMakeLists.darwin-x86_64.txt index d66fdd861bb9..e31cb1c19e79 100644 --- a/ydb/core/client/minikql_result_lib/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/client/minikql_result_lib/CMakeLists.darwin-x86_64.txt @@ -19,6 +19,8 @@ target_link_libraries(core-client-minikql_result_lib PUBLIC lib-deprecated-kicli ) target_sources(core-client-minikql_result_lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/objects.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/converter.h ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/objects.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/converter.cpp ) diff --git a/ydb/core/client/minikql_result_lib/CMakeLists.linux-aarch64.txt b/ydb/core/client/minikql_result_lib/CMakeLists.linux-aarch64.txt index 58ffd370d261..746f49665791 100644 --- a/ydb/core/client/minikql_result_lib/CMakeLists.linux-aarch64.txt +++ b/ydb/core/client/minikql_result_lib/CMakeLists.linux-aarch64.txt @@ -20,6 +20,8 @@ target_link_libraries(core-client-minikql_result_lib PUBLIC lib-deprecated-kicli ) target_sources(core-client-minikql_result_lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/objects.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/converter.h ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/objects.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/converter.cpp ) diff --git a/ydb/core/client/minikql_result_lib/CMakeLists.linux-x86_64.txt b/ydb/core/client/minikql_result_lib/CMakeLists.linux-x86_64.txt index 58ffd370d261..746f49665791 100644 --- a/ydb/core/client/minikql_result_lib/CMakeLists.linux-x86_64.txt +++ b/ydb/core/client/minikql_result_lib/CMakeLists.linux-x86_64.txt @@ -20,6 +20,8 @@ target_link_libraries(core-client-minikql_result_lib PUBLIC lib-deprecated-kicli ) target_sources(core-client-minikql_result_lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/objects.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/converter.h ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/objects.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/converter.cpp ) diff --git a/ydb/core/client/minikql_result_lib/CMakeLists.windows-x86_64.txt b/ydb/core/client/minikql_result_lib/CMakeLists.windows-x86_64.txt index d66fdd861bb9..e31cb1c19e79 100644 --- a/ydb/core/client/minikql_result_lib/CMakeLists.windows-x86_64.txt +++ b/ydb/core/client/minikql_result_lib/CMakeLists.windows-x86_64.txt @@ -19,6 +19,8 @@ target_link_libraries(core-client-minikql_result_lib PUBLIC lib-deprecated-kicli ) target_sources(core-client-minikql_result_lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/objects.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/converter.h ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/objects.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/converter.cpp ) diff --git a/ydb/core/client/minikql_result_lib/ut/CMakeLists.darwin-arm64.txt b/ydb/core/client/minikql_result_lib/ut/CMakeLists.darwin-arm64.txt index b0dd4768e755..399e6246ff86 100644 --- a/ydb/core/client/minikql_result_lib/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/client/minikql_result_lib/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-client-minikql_result_lib-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-client-minikql_result_lib-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/converter_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/minikql_result_lib/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/client/minikql_result_lib/ut/CMakeLists.darwin-x86_64.txt index 8920736a1016..28cc1a9c6608 100644 --- a/ydb/core/client/minikql_result_lib/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/client/minikql_result_lib/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-client-minikql_result_lib-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-client-minikql_result_lib-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/converter_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/minikql_result_lib/ut/CMakeLists.linux-aarch64.txt b/ydb/core/client/minikql_result_lib/ut/CMakeLists.linux-aarch64.txt index 692f1f1816d9..8bc3b939a8c1 100644 --- a/ydb/core/client/minikql_result_lib/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/client/minikql_result_lib/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-client-minikql_result_lib-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-client-minikql_result_lib-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/converter_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/minikql_result_lib/ut/CMakeLists.linux-x86_64.txt b/ydb/core/client/minikql_result_lib/ut/CMakeLists.linux-x86_64.txt index 37f6c488acb8..a0741ae40fe0 100644 --- a/ydb/core/client/minikql_result_lib/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/client/minikql_result_lib/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-client-minikql_result_lib-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-client-minikql_result_lib-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/minikql_result_lib/converter_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/minikql_result_lib/ut/CMakeLists.windows-x86_64.txt b/ydb/core/client/minikql_result_lib/ut/CMakeLists.windows-x86_64.txt index dfa6015200c2..9d7257bbbbce 100644 --- a/ydb/core/client/minikql_result_lib/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/client/minikql_result_lib/ut/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/scheme_cache_lib/CMakeLists.darwin-arm64.txt b/ydb/core/client/scheme_cache_lib/CMakeLists.darwin-arm64.txt index eb0967cc3f3b..68d282d7bfea 100644 --- a/ydb/core/client/scheme_cache_lib/CMakeLists.darwin-arm64.txt +++ b/ydb/core/client/scheme_cache_lib/CMakeLists.darwin-arm64.txt @@ -26,5 +26,6 @@ target_link_libraries(core-client-scheme_cache_lib PUBLIC ydb-core-tx ) target_sources(core-client-scheme_cache_lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/client/scheme_cache_lib/yql_db_scheme_resolver.h ${CMAKE_SOURCE_DIR}/ydb/core/client/scheme_cache_lib/yql_db_scheme_resolver.cpp ) diff --git a/ydb/core/client/scheme_cache_lib/CMakeLists.darwin-x86_64.txt b/ydb/core/client/scheme_cache_lib/CMakeLists.darwin-x86_64.txt index eb0967cc3f3b..68d282d7bfea 100644 --- a/ydb/core/client/scheme_cache_lib/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/client/scheme_cache_lib/CMakeLists.darwin-x86_64.txt @@ -26,5 +26,6 @@ target_link_libraries(core-client-scheme_cache_lib PUBLIC ydb-core-tx ) target_sources(core-client-scheme_cache_lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/client/scheme_cache_lib/yql_db_scheme_resolver.h ${CMAKE_SOURCE_DIR}/ydb/core/client/scheme_cache_lib/yql_db_scheme_resolver.cpp ) diff --git a/ydb/core/client/scheme_cache_lib/CMakeLists.linux-aarch64.txt b/ydb/core/client/scheme_cache_lib/CMakeLists.linux-aarch64.txt index 3fa2bcdf019d..98147eba1d93 100644 --- a/ydb/core/client/scheme_cache_lib/CMakeLists.linux-aarch64.txt +++ b/ydb/core/client/scheme_cache_lib/CMakeLists.linux-aarch64.txt @@ -27,5 +27,6 @@ target_link_libraries(core-client-scheme_cache_lib PUBLIC ydb-core-tx ) target_sources(core-client-scheme_cache_lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/client/scheme_cache_lib/yql_db_scheme_resolver.h ${CMAKE_SOURCE_DIR}/ydb/core/client/scheme_cache_lib/yql_db_scheme_resolver.cpp ) diff --git a/ydb/core/client/scheme_cache_lib/CMakeLists.linux-x86_64.txt b/ydb/core/client/scheme_cache_lib/CMakeLists.linux-x86_64.txt index 3fa2bcdf019d..98147eba1d93 100644 --- a/ydb/core/client/scheme_cache_lib/CMakeLists.linux-x86_64.txt +++ b/ydb/core/client/scheme_cache_lib/CMakeLists.linux-x86_64.txt @@ -27,5 +27,6 @@ target_link_libraries(core-client-scheme_cache_lib PUBLIC ydb-core-tx ) target_sources(core-client-scheme_cache_lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/client/scheme_cache_lib/yql_db_scheme_resolver.h ${CMAKE_SOURCE_DIR}/ydb/core/client/scheme_cache_lib/yql_db_scheme_resolver.cpp ) diff --git a/ydb/core/client/scheme_cache_lib/CMakeLists.windows-x86_64.txt b/ydb/core/client/scheme_cache_lib/CMakeLists.windows-x86_64.txt index eb0967cc3f3b..68d282d7bfea 100644 --- a/ydb/core/client/scheme_cache_lib/CMakeLists.windows-x86_64.txt +++ b/ydb/core/client/scheme_cache_lib/CMakeLists.windows-x86_64.txt @@ -26,5 +26,6 @@ target_link_libraries(core-client-scheme_cache_lib PUBLIC ydb-core-tx ) target_sources(core-client-scheme_cache_lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/client/scheme_cache_lib/yql_db_scheme_resolver.h ${CMAKE_SOURCE_DIR}/ydb/core/client/scheme_cache_lib/yql_db_scheme_resolver.cpp ) diff --git a/ydb/core/client/server/CMakeLists.darwin-arm64.txt b/ydb/core/client/server/CMakeLists.darwin-arm64.txt index 723e569c9b00..2a2beb561348 100644 --- a/ydb/core/client/server/CMakeLists.darwin-arm64.txt +++ b/ydb/core/client/server/CMakeLists.darwin-arm64.txt @@ -54,6 +54,19 @@ target_link_libraries(core-client-server PUBLIC cpp-deprecated-atomic ) target_sources(core-client-server PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/document_conversion.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/http_ping.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_http_server.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_persqueue.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_pq_metacache.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_pq_metarequest.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_request.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_servicereq.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_tabletreq.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/grpc_server.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/grpc_proxy_status.h ${CMAKE_SOURCE_DIR}/ydb/core/client/server/http_ping.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_blobstorage_config.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_bsadm.cpp diff --git a/ydb/core/client/server/CMakeLists.darwin-x86_64.txt b/ydb/core/client/server/CMakeLists.darwin-x86_64.txt index 723e569c9b00..2a2beb561348 100644 --- a/ydb/core/client/server/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/client/server/CMakeLists.darwin-x86_64.txt @@ -54,6 +54,19 @@ target_link_libraries(core-client-server PUBLIC cpp-deprecated-atomic ) target_sources(core-client-server PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/document_conversion.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/http_ping.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_http_server.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_persqueue.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_pq_metacache.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_pq_metarequest.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_request.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_servicereq.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_tabletreq.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/grpc_server.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/grpc_proxy_status.h ${CMAKE_SOURCE_DIR}/ydb/core/client/server/http_ping.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_blobstorage_config.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_bsadm.cpp diff --git a/ydb/core/client/server/CMakeLists.linux-aarch64.txt b/ydb/core/client/server/CMakeLists.linux-aarch64.txt index 45108117f248..a91ff927b33e 100644 --- a/ydb/core/client/server/CMakeLists.linux-aarch64.txt +++ b/ydb/core/client/server/CMakeLists.linux-aarch64.txt @@ -55,6 +55,19 @@ target_link_libraries(core-client-server PUBLIC cpp-deprecated-atomic ) target_sources(core-client-server PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/document_conversion.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/http_ping.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_http_server.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_persqueue.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_pq_metacache.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_pq_metarequest.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_request.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_servicereq.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_tabletreq.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/grpc_server.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/grpc_proxy_status.h ${CMAKE_SOURCE_DIR}/ydb/core/client/server/http_ping.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_blobstorage_config.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_bsadm.cpp diff --git a/ydb/core/client/server/CMakeLists.linux-x86_64.txt b/ydb/core/client/server/CMakeLists.linux-x86_64.txt index 45108117f248..a91ff927b33e 100644 --- a/ydb/core/client/server/CMakeLists.linux-x86_64.txt +++ b/ydb/core/client/server/CMakeLists.linux-x86_64.txt @@ -55,6 +55,19 @@ target_link_libraries(core-client-server PUBLIC cpp-deprecated-atomic ) target_sources(core-client-server PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/document_conversion.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/http_ping.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_http_server.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_persqueue.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_pq_metacache.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_pq_metarequest.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_request.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_servicereq.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_tabletreq.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/grpc_server.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/grpc_proxy_status.h ${CMAKE_SOURCE_DIR}/ydb/core/client/server/http_ping.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_blobstorage_config.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_bsadm.cpp diff --git a/ydb/core/client/server/CMakeLists.windows-x86_64.txt b/ydb/core/client/server/CMakeLists.windows-x86_64.txt index 723e569c9b00..2a2beb561348 100644 --- a/ydb/core/client/server/CMakeLists.windows-x86_64.txt +++ b/ydb/core/client/server/CMakeLists.windows-x86_64.txt @@ -54,6 +54,19 @@ target_link_libraries(core-client-server PUBLIC cpp-deprecated-atomic ) target_sources(core-client-server PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/document_conversion.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/http_ping.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_http_server.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_persqueue.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_pq_metacache.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_pq_metarequest.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_request.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_servicereq.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_tabletreq.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/grpc_server.h + ${CMAKE_SOURCE_DIR}/ydb/core/client/server/grpc_proxy_status.h ${CMAKE_SOURCE_DIR}/ydb/core/client/server/http_ping.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_blobstorage_config.cpp ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_bsadm.cpp diff --git a/ydb/core/client/server/ut/CMakeLists.darwin-arm64.txt b/ydb/core/client/server/ut/CMakeLists.darwin-arm64.txt index 7d553634a45e..81bf62b171f4 100644 --- a/ydb/core/client/server/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/client/server/ut/CMakeLists.darwin-arm64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-core-client-server-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-client-server-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_pq_metarequest_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/server/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/client/server/ut/CMakeLists.darwin-x86_64.txt index 06537c3a75cc..5fa77004029b 100644 --- a/ydb/core/client/server/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/client/server/ut/CMakeLists.darwin-x86_64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-client-server-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-client-server-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_pq_metarequest_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/server/ut/CMakeLists.linux-aarch64.txt b/ydb/core/client/server/ut/CMakeLists.linux-aarch64.txt index 095647ab92dc..3b1d25cfdec3 100644 --- a/ydb/core/client/server/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/client/server/ut/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-core-client-server-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-client-server-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_pq_metarequest_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/server/ut/CMakeLists.linux-x86_64.txt b/ydb/core/client/server/ut/CMakeLists.linux-x86_64.txt index 3f26224c6190..61366a5b462b 100644 --- a/ydb/core/client/server/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/client/server/ut/CMakeLists.linux-x86_64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-client-server-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-client-server-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/server/msgbus_server_pq_metarequest_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/server/ut/CMakeLists.windows-x86_64.txt b/ydb/core/client/server/ut/CMakeLists.windows-x86_64.txt index 88057798e880..32d6bfbc3999 100644 --- a/ydb/core/client/server/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/client/server/ut/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/ut/CMakeLists.darwin-arm64.txt b/ydb/core/client/ut/CMakeLists.darwin-arm64.txt index fe31a10e0858..25ef41702978 100644 --- a/ydb/core/client/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/client/ut/CMakeLists.darwin-arm64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-client-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-client-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/cancel_tx_ut.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/client/ut/CMakeLists.darwin-x86_64.txt index 27a8521cb1f9..712768c2ba51 100644 --- a/ydb/core/client/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/client/ut/CMakeLists.darwin-x86_64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-client-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-client-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/cancel_tx_ut.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/ut/CMakeLists.linux-aarch64.txt b/ydb/core/client/ut/CMakeLists.linux-aarch64.txt index 9cef71b7b902..9bdcad37a170 100644 --- a/ydb/core/client/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/client/ut/CMakeLists.linux-aarch64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-client-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-client-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/cancel_tx_ut.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/ut/CMakeLists.linux-x86_64.txt b/ydb/core/client/ut/CMakeLists.linux-x86_64.txt index e804d63cb7c0..3592ad21b561 100644 --- a/ydb/core/client/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/client/ut/CMakeLists.linux-x86_64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-client-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-client-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/client/cancel_tx_ut.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/client/ut/CMakeLists.windows-x86_64.txt b/ydb/core/client/ut/CMakeLists.windows-x86_64.txt index 0cd389cdf235..0451dcf0a19a 100644 --- a/ydb/core/client/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/client/ut/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/cms/CMakeLists.darwin-arm64.txt b/ydb/core/cms/CMakeLists.darwin-arm64.txt index 672177e0f3e4..c3a38b99234e 100644 --- a/ydb/core/cms/CMakeLists.darwin-arm64.txt +++ b/ydb/core/cms/CMakeLists.darwin-arm64.txt @@ -52,6 +52,32 @@ target_link_libraries(ydb-core-cms PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(ydb-core-cms PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/base_handler.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cluster_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_state.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/downtime.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/erasure_checkers.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/http.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/info_collector.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_config_items.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_config_updates.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_config_validators.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_console_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_operations.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_proto.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_sentinel.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_toggle_config_validator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/logger.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/node_checkers.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/log_formatter.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/pdiskid.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/walle.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/api_adapters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/audit_log.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/cluster_info.cpp diff --git a/ydb/core/cms/CMakeLists.darwin-x86_64.txt b/ydb/core/cms/CMakeLists.darwin-x86_64.txt index 672177e0f3e4..c3a38b99234e 100644 --- a/ydb/core/cms/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/cms/CMakeLists.darwin-x86_64.txt @@ -52,6 +52,32 @@ target_link_libraries(ydb-core-cms PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(ydb-core-cms PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/base_handler.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cluster_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_state.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/downtime.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/erasure_checkers.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/http.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/info_collector.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_config_items.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_config_updates.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_config_validators.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_console_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_operations.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_proto.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_sentinel.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_toggle_config_validator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/logger.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/node_checkers.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/log_formatter.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/pdiskid.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/walle.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/api_adapters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/audit_log.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/cluster_info.cpp diff --git a/ydb/core/cms/CMakeLists.linux-aarch64.txt b/ydb/core/cms/CMakeLists.linux-aarch64.txt index 700de3c15b92..b255aecdb037 100644 --- a/ydb/core/cms/CMakeLists.linux-aarch64.txt +++ b/ydb/core/cms/CMakeLists.linux-aarch64.txt @@ -53,6 +53,32 @@ target_link_libraries(ydb-core-cms PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(ydb-core-cms PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/base_handler.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cluster_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_state.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/downtime.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/erasure_checkers.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/http.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/info_collector.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_config_items.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_config_updates.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_config_validators.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_console_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_operations.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_proto.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_sentinel.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_toggle_config_validator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/logger.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/node_checkers.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/log_formatter.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/pdiskid.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/walle.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/api_adapters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/audit_log.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/cluster_info.cpp diff --git a/ydb/core/cms/CMakeLists.linux-x86_64.txt b/ydb/core/cms/CMakeLists.linux-x86_64.txt index 700de3c15b92..b255aecdb037 100644 --- a/ydb/core/cms/CMakeLists.linux-x86_64.txt +++ b/ydb/core/cms/CMakeLists.linux-x86_64.txt @@ -53,6 +53,32 @@ target_link_libraries(ydb-core-cms PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(ydb-core-cms PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/base_handler.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cluster_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_state.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/downtime.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/erasure_checkers.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/http.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/info_collector.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_config_items.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_config_updates.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_config_validators.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_console_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_operations.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_proto.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_sentinel.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_toggle_config_validator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/logger.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/node_checkers.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/log_formatter.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/pdiskid.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/walle.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/api_adapters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/audit_log.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/cluster_info.cpp diff --git a/ydb/core/cms/CMakeLists.windows-x86_64.txt b/ydb/core/cms/CMakeLists.windows-x86_64.txt index 672177e0f3e4..c3a38b99234e 100644 --- a/ydb/core/cms/CMakeLists.windows-x86_64.txt +++ b/ydb/core/cms/CMakeLists.windows-x86_64.txt @@ -52,6 +52,32 @@ target_link_libraries(ydb-core-cms PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(ydb-core-cms PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/base_handler.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cluster_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_state.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/downtime.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/erasure_checkers.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/http.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/info_collector.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_config_items.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_config_updates.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_config_validators.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_console_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_operations.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_proto.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_sentinel.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/json_proxy_toggle_config_validator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/logger.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/node_checkers.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/log_formatter.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/pdiskid.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/walle.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/api_adapters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/audit_log.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/cluster_info.cpp diff --git a/ydb/core/cms/console/CMakeLists.darwin-arm64.txt b/ydb/core/cms/console/CMakeLists.darwin-arm64.txt index 589b75be3d99..b37ecdf577b7 100644 --- a/ydb/core/cms/console/CMakeLists.darwin-arm64.txt +++ b/ydb/core/cms/console/CMakeLists.darwin-arm64.txt @@ -43,6 +43,26 @@ target_link_libraries(core-cms-console PUBLIC public-lib-operation_id ) target_sources(core-cms-console PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/config_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_dispatcher.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_configs_manager.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_configs_provider.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_configs_subscriber.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_tenants_manager.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console__scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/http.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/immediate_controls_configurator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/log_settings_configurator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/logger.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/modifications_validator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/shared_cache_configurator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/tx_processor.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/util.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/config_helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_cache.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_config.cpp diff --git a/ydb/core/cms/console/CMakeLists.darwin-x86_64.txt b/ydb/core/cms/console/CMakeLists.darwin-x86_64.txt index 589b75be3d99..b37ecdf577b7 100644 --- a/ydb/core/cms/console/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/cms/console/CMakeLists.darwin-x86_64.txt @@ -43,6 +43,26 @@ target_link_libraries(core-cms-console PUBLIC public-lib-operation_id ) target_sources(core-cms-console PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/config_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_dispatcher.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_configs_manager.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_configs_provider.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_configs_subscriber.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_tenants_manager.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console__scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/http.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/immediate_controls_configurator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/log_settings_configurator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/logger.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/modifications_validator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/shared_cache_configurator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/tx_processor.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/util.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/config_helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_cache.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_config.cpp diff --git a/ydb/core/cms/console/CMakeLists.linux-aarch64.txt b/ydb/core/cms/console/CMakeLists.linux-aarch64.txt index 6d6b88064ffe..7a14cc28b5ee 100644 --- a/ydb/core/cms/console/CMakeLists.linux-aarch64.txt +++ b/ydb/core/cms/console/CMakeLists.linux-aarch64.txt @@ -44,6 +44,26 @@ target_link_libraries(core-cms-console PUBLIC public-lib-operation_id ) target_sources(core-cms-console PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/config_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_dispatcher.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_configs_manager.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_configs_provider.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_configs_subscriber.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_tenants_manager.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console__scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/http.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/immediate_controls_configurator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/log_settings_configurator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/logger.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/modifications_validator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/shared_cache_configurator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/tx_processor.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/util.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/config_helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_cache.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_config.cpp diff --git a/ydb/core/cms/console/CMakeLists.linux-x86_64.txt b/ydb/core/cms/console/CMakeLists.linux-x86_64.txt index 6d6b88064ffe..7a14cc28b5ee 100644 --- a/ydb/core/cms/console/CMakeLists.linux-x86_64.txt +++ b/ydb/core/cms/console/CMakeLists.linux-x86_64.txt @@ -44,6 +44,26 @@ target_link_libraries(core-cms-console PUBLIC public-lib-operation_id ) target_sources(core-cms-console PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/config_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_dispatcher.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_configs_manager.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_configs_provider.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_configs_subscriber.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_tenants_manager.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console__scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/http.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/immediate_controls_configurator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/log_settings_configurator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/logger.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/modifications_validator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/shared_cache_configurator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/tx_processor.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/util.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/config_helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_cache.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_config.cpp diff --git a/ydb/core/cms/console/CMakeLists.windows-x86_64.txt b/ydb/core/cms/console/CMakeLists.windows-x86_64.txt index 589b75be3d99..b37ecdf577b7 100644 --- a/ydb/core/cms/console/CMakeLists.windows-x86_64.txt +++ b/ydb/core/cms/console/CMakeLists.windows-x86_64.txt @@ -43,6 +43,26 @@ target_link_libraries(core-cms-console PUBLIC public-lib-operation_id ) target_sources(core-cms-console PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/config_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_dispatcher.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_configs_manager.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_configs_provider.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_configs_subscriber.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console_tenants_manager.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/console__scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/http.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/immediate_controls_configurator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/log_settings_configurator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/logger.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/modifications_validator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/shared_cache_configurator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/tx_processor.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/util.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/config_helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_cache.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_config.cpp diff --git a/ydb/core/cms/console/ut/CMakeLists.darwin-arm64.txt b/ydb/core/cms/console/ut/CMakeLists.darwin-arm64.txt index c86287b46dcc..bb7d210d886b 100644 --- a/ydb/core/cms/console/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/cms/console/ut/CMakeLists.darwin-arm64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-core-cms-console-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-cms-console-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_cache_ut.cpp @@ -67,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/cms/console/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/cms/console/ut/CMakeLists.darwin-x86_64.txt index 966bdb80a6a7..e9c72f840aa3 100644 --- a/ydb/core/cms/console/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/cms/console/ut/CMakeLists.darwin-x86_64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-cms-console-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-cms-console-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_cache_ut.cpp @@ -68,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/cms/console/ut/CMakeLists.linux-aarch64.txt b/ydb/core/cms/console/ut/CMakeLists.linux-aarch64.txt index 8478050b90ce..454cdf140859 100644 --- a/ydb/core/cms/console/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/cms/console/ut/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-core-cms-console-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-cms-console-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_cache_ut.cpp @@ -71,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/cms/console/ut/CMakeLists.linux-x86_64.txt b/ydb/core/cms/console/ut/CMakeLists.linux-x86_64.txt index e3ab82d09c3a..c755a3632f4e 100644 --- a/ydb/core/cms/console/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/cms/console/ut/CMakeLists.linux-x86_64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-cms-console-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-cms-console-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/configs_cache_ut.cpp @@ -72,6 +69,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/cms/console/ut/CMakeLists.windows-x86_64.txt b/ydb/core/cms/console/ut/CMakeLists.windows-x86_64.txt index 05c7ccd4f3cc..6e5d9f285db3 100644 --- a/ydb/core/cms/console/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/cms/console/ut/CMakeLists.windows-x86_64.txt @@ -61,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/cms/console/util/CMakeLists.darwin-arm64.txt b/ydb/core/cms/console/util/CMakeLists.darwin-arm64.txt index 2a8aa60113a6..4a1e202f1aaf 100644 --- a/ydb/core/cms/console/util/CMakeLists.darwin-arm64.txt +++ b/ydb/core/cms/console/util/CMakeLists.darwin-arm64.txt @@ -15,5 +15,7 @@ target_link_libraries(cms-console-util PUBLIC ydb-core-protos ) target_sources(cms-console-util PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/util/config_index.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/util/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/util/config_index.cpp ) diff --git a/ydb/core/cms/console/util/CMakeLists.darwin-x86_64.txt b/ydb/core/cms/console/util/CMakeLists.darwin-x86_64.txt index 2a8aa60113a6..4a1e202f1aaf 100644 --- a/ydb/core/cms/console/util/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/cms/console/util/CMakeLists.darwin-x86_64.txt @@ -15,5 +15,7 @@ target_link_libraries(cms-console-util PUBLIC ydb-core-protos ) target_sources(cms-console-util PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/util/config_index.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/util/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/util/config_index.cpp ) diff --git a/ydb/core/cms/console/util/CMakeLists.linux-aarch64.txt b/ydb/core/cms/console/util/CMakeLists.linux-aarch64.txt index 4793dbe9ea17..89d845bc8569 100644 --- a/ydb/core/cms/console/util/CMakeLists.linux-aarch64.txt +++ b/ydb/core/cms/console/util/CMakeLists.linux-aarch64.txt @@ -16,5 +16,7 @@ target_link_libraries(cms-console-util PUBLIC ydb-core-protos ) target_sources(cms-console-util PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/util/config_index.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/util/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/util/config_index.cpp ) diff --git a/ydb/core/cms/console/util/CMakeLists.linux-x86_64.txt b/ydb/core/cms/console/util/CMakeLists.linux-x86_64.txt index 4793dbe9ea17..89d845bc8569 100644 --- a/ydb/core/cms/console/util/CMakeLists.linux-x86_64.txt +++ b/ydb/core/cms/console/util/CMakeLists.linux-x86_64.txt @@ -16,5 +16,7 @@ target_link_libraries(cms-console-util PUBLIC ydb-core-protos ) target_sources(cms-console-util PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/util/config_index.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/util/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/util/config_index.cpp ) diff --git a/ydb/core/cms/console/util/CMakeLists.windows-x86_64.txt b/ydb/core/cms/console/util/CMakeLists.windows-x86_64.txt index 2a8aa60113a6..4a1e202f1aaf 100644 --- a/ydb/core/cms/console/util/CMakeLists.windows-x86_64.txt +++ b/ydb/core/cms/console/util/CMakeLists.windows-x86_64.txt @@ -15,5 +15,7 @@ target_link_libraries(cms-console-util PUBLIC ydb-core-protos ) target_sources(cms-console-util PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/util/config_index.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/util/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/util/config_index.cpp ) diff --git a/ydb/core/cms/console/validators/CMakeLists.darwin-arm64.txt b/ydb/core/cms/console/validators/CMakeLists.darwin-arm64.txt index ae6ae3abc0e0..1db13cff1818 100644 --- a/ydb/core/cms/console/validators/CMakeLists.darwin-arm64.txt +++ b/ydb/core/cms/console/validators/CMakeLists.darwin-arm64.txt @@ -19,6 +19,11 @@ target_link_libraries(cms-console-validators PUBLIC cpp-deprecated-atomic ) target_sources(cms-console-validators PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/core_validators.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/registry.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_bootstrap.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_nameservice.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/core_validators.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/registry.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator.cpp diff --git a/ydb/core/cms/console/validators/CMakeLists.darwin-x86_64.txt b/ydb/core/cms/console/validators/CMakeLists.darwin-x86_64.txt index ae6ae3abc0e0..1db13cff1818 100644 --- a/ydb/core/cms/console/validators/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/cms/console/validators/CMakeLists.darwin-x86_64.txt @@ -19,6 +19,11 @@ target_link_libraries(cms-console-validators PUBLIC cpp-deprecated-atomic ) target_sources(cms-console-validators PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/core_validators.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/registry.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_bootstrap.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_nameservice.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/core_validators.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/registry.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator.cpp diff --git a/ydb/core/cms/console/validators/CMakeLists.linux-aarch64.txt b/ydb/core/cms/console/validators/CMakeLists.linux-aarch64.txt index 11d91e59fc08..40fa3a8cba17 100644 --- a/ydb/core/cms/console/validators/CMakeLists.linux-aarch64.txt +++ b/ydb/core/cms/console/validators/CMakeLists.linux-aarch64.txt @@ -20,6 +20,11 @@ target_link_libraries(cms-console-validators PUBLIC cpp-deprecated-atomic ) target_sources(cms-console-validators PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/core_validators.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/registry.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_bootstrap.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_nameservice.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/core_validators.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/registry.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator.cpp diff --git a/ydb/core/cms/console/validators/CMakeLists.linux-x86_64.txt b/ydb/core/cms/console/validators/CMakeLists.linux-x86_64.txt index 11d91e59fc08..40fa3a8cba17 100644 --- a/ydb/core/cms/console/validators/CMakeLists.linux-x86_64.txt +++ b/ydb/core/cms/console/validators/CMakeLists.linux-x86_64.txt @@ -20,6 +20,11 @@ target_link_libraries(cms-console-validators PUBLIC cpp-deprecated-atomic ) target_sources(cms-console-validators PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/core_validators.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/registry.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_bootstrap.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_nameservice.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/core_validators.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/registry.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator.cpp diff --git a/ydb/core/cms/console/validators/CMakeLists.windows-x86_64.txt b/ydb/core/cms/console/validators/CMakeLists.windows-x86_64.txt index ae6ae3abc0e0..1db13cff1818 100644 --- a/ydb/core/cms/console/validators/CMakeLists.windows-x86_64.txt +++ b/ydb/core/cms/console/validators/CMakeLists.windows-x86_64.txt @@ -19,6 +19,11 @@ target_link_libraries(cms-console-validators PUBLIC cpp-deprecated-atomic ) target_sources(cms-console-validators PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/core_validators.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/registry.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_bootstrap.h + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_nameservice.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/core_validators.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/registry.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator.cpp diff --git a/ydb/core/cms/console/validators/ut/CMakeLists.darwin-arm64.txt b/ydb/core/cms/console/validators/ut/CMakeLists.darwin-arm64.txt index 38926d6d6379..deb391abee2e 100644 --- a/ydb/core/cms/console/validators/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/cms/console/validators/ut/CMakeLists.darwin-arm64.txt @@ -22,10 +22,9 @@ target_link_options(ydb-core-cms-console-validators-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-cms-console-validators-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/registry_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_bootstrap_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_nameservice_ut.cpp @@ -55,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/cms/console/validators/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/cms/console/validators/ut/CMakeLists.darwin-x86_64.txt index 773ed4c1cc79..1cd85f647947 100644 --- a/ydb/core/cms/console/validators/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/cms/console/validators/ut/CMakeLists.darwin-x86_64.txt @@ -23,10 +23,9 @@ target_link_options(ydb-core-cms-console-validators-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-cms-console-validators-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/registry_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_bootstrap_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_nameservice_ut.cpp @@ -56,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/cms/console/validators/ut/CMakeLists.linux-aarch64.txt b/ydb/core/cms/console/validators/ut/CMakeLists.linux-aarch64.txt index 31fc2fe9a664..098728a47348 100644 --- a/ydb/core/cms/console/validators/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/cms/console/validators/ut/CMakeLists.linux-aarch64.txt @@ -25,11 +25,9 @@ target_link_options(ydb-core-cms-console-validators-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-cms-console-validators-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/registry_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_bootstrap_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_nameservice_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/cms/console/validators/ut/CMakeLists.linux-x86_64.txt b/ydb/core/cms/console/validators/ut/CMakeLists.linux-x86_64.txt index a6cd6cef9919..2641e4f29452 100644 --- a/ydb/core/cms/console/validators/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/cms/console/validators/ut/CMakeLists.linux-x86_64.txt @@ -26,11 +26,9 @@ target_link_options(ydb-core-cms-console-validators-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-cms-console-validators-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/registry_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_bootstrap_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_nameservice_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/cms/console/validators/ut/CMakeLists.windows-x86_64.txt b/ydb/core/cms/console/validators/ut/CMakeLists.windows-x86_64.txt index f53d17188ff3..1249a14f430e 100644 --- a/ydb/core/cms/console/validators/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/cms/console/validators/ut/CMakeLists.windows-x86_64.txt @@ -20,6 +20,7 @@ target_link_libraries(ydb-core-cms-console-validators-ut PUBLIC cpp-testing-unittest ) target_sources(ydb-core-cms-console-validators-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/registry_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_bootstrap_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/console/validators/validator_nameservice_ut.cpp @@ -49,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/cms/ut/CMakeLists.darwin-arm64.txt b/ydb/core/cms/ut/CMakeLists.darwin-arm64.txt index 8ebcb62a6937..9d444cb58ee9 100644 --- a/ydb/core/cms/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/cms/ut/CMakeLists.darwin-arm64.txt @@ -27,10 +27,9 @@ target_link_options(ydb-core-cms-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-cms-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/cluster_info_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_tenants_ut.cpp @@ -63,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/cms/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/cms/ut/CMakeLists.darwin-x86_64.txt index 922dc62a7b99..4281ce100f50 100644 --- a/ydb/core/cms/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/cms/ut/CMakeLists.darwin-x86_64.txt @@ -28,10 +28,9 @@ target_link_options(ydb-core-cms-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-cms-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/cluster_info_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_tenants_ut.cpp @@ -64,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/cms/ut/CMakeLists.linux-aarch64.txt b/ydb/core/cms/ut/CMakeLists.linux-aarch64.txt index 64ee05e59311..bbb7ed408a7c 100644 --- a/ydb/core/cms/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/cms/ut/CMakeLists.linux-aarch64.txt @@ -30,11 +30,9 @@ target_link_options(ydb-core-cms-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-cms-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/cluster_info_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_tenants_ut.cpp @@ -67,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/cms/ut/CMakeLists.linux-x86_64.txt b/ydb/core/cms/ut/CMakeLists.linux-x86_64.txt index ede8d036c2ad..b4bcc6476c07 100644 --- a/ydb/core/cms/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/cms/ut/CMakeLists.linux-x86_64.txt @@ -31,11 +31,9 @@ target_link_options(ydb-core-cms-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-cms-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/cluster_info_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_tenants_ut.cpp @@ -68,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/cms/ut/CMakeLists.windows-x86_64.txt b/ydb/core/cms/ut/CMakeLists.windows-x86_64.txt index 1dbbee1959ad..92273ea5095e 100644 --- a/ydb/core/cms/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/cms/ut/CMakeLists.windows-x86_64.txt @@ -25,6 +25,7 @@ target_link_libraries(ydb-core-cms-ut PUBLIC core-testlib-default ) target_sources(ydb-core-cms-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/cluster_info_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_tenants_ut.cpp @@ -57,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/cms/ut_sentinel/CMakeLists.darwin-arm64.txt b/ydb/core/cms/ut_sentinel/CMakeLists.darwin-arm64.txt index 32f82e1f42b6..6622d1e34152 100644 --- a/ydb/core/cms/ut_sentinel/CMakeLists.darwin-arm64.txt +++ b/ydb/core/cms/ut_sentinel/CMakeLists.darwin-arm64.txt @@ -27,10 +27,9 @@ target_link_options(ydb-core-cms-ut_sentinel PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-cms-ut_sentinel PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_ut_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/sentinel_ut.cpp ) @@ -59,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/cms/ut_sentinel/CMakeLists.darwin-x86_64.txt b/ydb/core/cms/ut_sentinel/CMakeLists.darwin-x86_64.txt index 21090b142de2..52d13fbc1ad1 100644 --- a/ydb/core/cms/ut_sentinel/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/cms/ut_sentinel/CMakeLists.darwin-x86_64.txt @@ -28,10 +28,9 @@ target_link_options(ydb-core-cms-ut_sentinel PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-cms-ut_sentinel PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_ut_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/sentinel_ut.cpp ) @@ -60,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/cms/ut_sentinel/CMakeLists.linux-aarch64.txt b/ydb/core/cms/ut_sentinel/CMakeLists.linux-aarch64.txt index b467fc19dcbc..99f98c0f8a5a 100644 --- a/ydb/core/cms/ut_sentinel/CMakeLists.linux-aarch64.txt +++ b/ydb/core/cms/ut_sentinel/CMakeLists.linux-aarch64.txt @@ -30,11 +30,9 @@ target_link_options(ydb-core-cms-ut_sentinel PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-cms-ut_sentinel PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_ut_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/sentinel_ut.cpp ) @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/cms/ut_sentinel/CMakeLists.linux-x86_64.txt b/ydb/core/cms/ut_sentinel/CMakeLists.linux-x86_64.txt index 804549a8abe0..f98006fbe60b 100644 --- a/ydb/core/cms/ut_sentinel/CMakeLists.linux-x86_64.txt +++ b/ydb/core/cms/ut_sentinel/CMakeLists.linux-x86_64.txt @@ -31,11 +31,9 @@ target_link_options(ydb-core-cms-ut_sentinel PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-cms-ut_sentinel PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_ut_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/sentinel_ut.cpp ) @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/cms/ut_sentinel/CMakeLists.windows-x86_64.txt b/ydb/core/cms/ut_sentinel/CMakeLists.windows-x86_64.txt index 70f1faf287f1..b3f47a8721ff 100644 --- a/ydb/core/cms/ut_sentinel/CMakeLists.windows-x86_64.txt +++ b/ydb/core/cms/ut_sentinel/CMakeLists.windows-x86_64.txt @@ -25,6 +25,7 @@ target_link_libraries(ydb-core-cms-ut_sentinel PUBLIC core-testlib-default ) target_sources(ydb-core-cms-ut_sentinel PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/cms/cms_ut_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/cms/sentinel_ut.cpp ) @@ -53,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/control/CMakeLists.darwin-arm64.txt b/ydb/core/control/CMakeLists.darwin-arm64.txt index 8f45b8eaa490..3d24b9460a59 100644 --- a/ydb/core/control/CMakeLists.darwin-arm64.txt +++ b/ydb/core/control/CMakeLists.darwin-arm64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(common_controls) add_subdirectory(ut) add_library(ydb-core-control) @@ -20,6 +21,13 @@ target_link_libraries(ydb-core-control PUBLIC cpp-deprecated-atomic ) target_sources(ydb-core-control PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/control/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_control.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_wrapper.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_throttler.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_sampler.h ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_control.cpp ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_impl.cpp diff --git a/ydb/core/control/CMakeLists.darwin-x86_64.txt b/ydb/core/control/CMakeLists.darwin-x86_64.txt index 8f45b8eaa490..3d24b9460a59 100644 --- a/ydb/core/control/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/control/CMakeLists.darwin-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(common_controls) add_subdirectory(ut) add_library(ydb-core-control) @@ -20,6 +21,13 @@ target_link_libraries(ydb-core-control PUBLIC cpp-deprecated-atomic ) target_sources(ydb-core-control PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/control/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_control.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_wrapper.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_throttler.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_sampler.h ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_control.cpp ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_impl.cpp diff --git a/ydb/core/control/CMakeLists.linux-aarch64.txt b/ydb/core/control/CMakeLists.linux-aarch64.txt index 9fb8392e6e79..5f4cceef8df0 100644 --- a/ydb/core/control/CMakeLists.linux-aarch64.txt +++ b/ydb/core/control/CMakeLists.linux-aarch64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(common_controls) add_subdirectory(ut) add_library(ydb-core-control) @@ -21,6 +22,13 @@ target_link_libraries(ydb-core-control PUBLIC cpp-deprecated-atomic ) target_sources(ydb-core-control PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/control/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_control.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_wrapper.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_throttler.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_sampler.h ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_control.cpp ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_impl.cpp diff --git a/ydb/core/control/CMakeLists.linux-x86_64.txt b/ydb/core/control/CMakeLists.linux-x86_64.txt index 9fb8392e6e79..5f4cceef8df0 100644 --- a/ydb/core/control/CMakeLists.linux-x86_64.txt +++ b/ydb/core/control/CMakeLists.linux-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(common_controls) add_subdirectory(ut) add_library(ydb-core-control) @@ -21,6 +22,13 @@ target_link_libraries(ydb-core-control PUBLIC cpp-deprecated-atomic ) target_sources(ydb-core-control PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/control/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_control.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_wrapper.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_throttler.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_sampler.h ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_control.cpp ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_impl.cpp diff --git a/ydb/core/control/CMakeLists.windows-x86_64.txt b/ydb/core/control/CMakeLists.windows-x86_64.txt index 8f45b8eaa490..3d24b9460a59 100644 --- a/ydb/core/control/CMakeLists.windows-x86_64.txt +++ b/ydb/core/control/CMakeLists.windows-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(common_controls) add_subdirectory(ut) add_library(ydb-core-control) @@ -20,6 +21,13 @@ target_link_libraries(ydb-core-control PUBLIC cpp-deprecated-atomic ) target_sources(ydb-core-control PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/control/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_control.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_wrapper.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_throttler.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_sampler.h ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_control.cpp ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_impl.cpp diff --git a/ydb/core/control/common_controls/CMakeLists.darwin-arm64.txt b/ydb/core/control/common_controls/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..4788eae0c69c --- /dev/null +++ b/ydb/core/control/common_controls/CMakeLists.darwin-arm64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(core-control-common_controls) +target_link_libraries(core-control-common_controls PUBLIC + contrib-libs-cxxsupp + yutil + library-actors-wilson + ydb-core-protos +) +target_sources(core-control-common_controls PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/control/common_controls/tracing_control.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/common_controls/tracing_control.cpp +) diff --git a/ydb/core/control/common_controls/CMakeLists.darwin-x86_64.txt b/ydb/core/control/common_controls/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..4788eae0c69c --- /dev/null +++ b/ydb/core/control/common_controls/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(core-control-common_controls) +target_link_libraries(core-control-common_controls PUBLIC + contrib-libs-cxxsupp + yutil + library-actors-wilson + ydb-core-protos +) +target_sources(core-control-common_controls PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/control/common_controls/tracing_control.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/common_controls/tracing_control.cpp +) diff --git a/ydb/core/control/common_controls/CMakeLists.linux-aarch64.txt b/ydb/core/control/common_controls/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..d50d2eec75f5 --- /dev/null +++ b/ydb/core/control/common_controls/CMakeLists.linux-aarch64.txt @@ -0,0 +1,21 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(core-control-common_controls) +target_link_libraries(core-control-common_controls PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-actors-wilson + ydb-core-protos +) +target_sources(core-control-common_controls PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/control/common_controls/tracing_control.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/common_controls/tracing_control.cpp +) diff --git a/ydb/core/control/common_controls/CMakeLists.linux-x86_64.txt b/ydb/core/control/common_controls/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..d50d2eec75f5 --- /dev/null +++ b/ydb/core/control/common_controls/CMakeLists.linux-x86_64.txt @@ -0,0 +1,21 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(core-control-common_controls) +target_link_libraries(core-control-common_controls PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-actors-wilson + ydb-core-protos +) +target_sources(core-control-common_controls PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/control/common_controls/tracing_control.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/common_controls/tracing_control.cpp +) diff --git a/ydb/core/control/common_controls/CMakeLists.txt b/ydb/core/control/common_controls/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/control/common_controls/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/control/common_controls/CMakeLists.windows-x86_64.txt b/ydb/core/control/common_controls/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..4788eae0c69c --- /dev/null +++ b/ydb/core/control/common_controls/CMakeLists.windows-x86_64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(core-control-common_controls) +target_link_libraries(core-control-common_controls PUBLIC + contrib-libs-cxxsupp + yutil + library-actors-wilson + ydb-core-protos +) +target_sources(core-control-common_controls PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/control/common_controls/tracing_control.h + ${CMAKE_SOURCE_DIR}/ydb/core/control/common_controls/tracing_control.cpp +) diff --git a/ydb/core/control/ut/CMakeLists.darwin-arm64.txt b/ydb/core/control/ut/CMakeLists.darwin-arm64.txt index 9e35db8ab972..499db870a927 100644 --- a/ydb/core/control/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/control/ut/CMakeLists.darwin-arm64.txt @@ -30,12 +30,12 @@ target_link_options(ydb-core-control-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-control-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_actor_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_sampler_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_throttler_ut.cpp ) set_property( TARGET @@ -62,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/control/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/control/ut/CMakeLists.darwin-x86_64.txt index 01234b59939b..26029c5bd91b 100644 --- a/ydb/core/control/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/control/ut/CMakeLists.darwin-x86_64.txt @@ -31,12 +31,12 @@ target_link_options(ydb-core-control-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-control-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_actor_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_sampler_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_throttler_ut.cpp ) set_property( TARGET @@ -63,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/control/ut/CMakeLists.linux-aarch64.txt b/ydb/core/control/ut/CMakeLists.linux-aarch64.txt index 4b7923fa481f..c31203d4e7e8 100644 --- a/ydb/core/control/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/control/ut/CMakeLists.linux-aarch64.txt @@ -33,13 +33,12 @@ target_link_options(ydb-core-control-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-control-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_actor_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_sampler_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_throttler_ut.cpp ) set_property( TARGET @@ -66,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/control/ut/CMakeLists.linux-x86_64.txt b/ydb/core/control/ut/CMakeLists.linux-x86_64.txt index 271bcf375831..866b30a3d21d 100644 --- a/ydb/core/control/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/control/ut/CMakeLists.linux-x86_64.txt @@ -34,13 +34,12 @@ target_link_options(ydb-core-control-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-control-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_actor_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_sampler_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_throttler_ut.cpp ) set_property( TARGET @@ -67,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/control/ut/CMakeLists.windows-x86_64.txt b/ydb/core/control/ut/CMakeLists.windows-x86_64.txt index 2640c1175b47..bef999eab2bd 100644 --- a/ydb/core/control/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/control/ut/CMakeLists.windows-x86_64.txt @@ -30,6 +30,8 @@ target_link_libraries(ydb-core-control-ut PUBLIC target_sources(ydb-core-control-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_actor_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_sampler_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/control/immediate_control_board_throttler_ut.cpp ) set_property( TARGET @@ -56,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/debug/CMakeLists.darwin-arm64.txt b/ydb/core/debug/CMakeLists.darwin-arm64.txt index ebb5e769c71a..3b08af1d3949 100644 --- a/ydb/core/debug/CMakeLists.darwin-arm64.txt +++ b/ydb/core/debug/CMakeLists.darwin-arm64.txt @@ -13,5 +13,6 @@ target_link_libraries(ydb-core-debug PUBLIC yutil ) target_sources(ydb-core-debug PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/debug/valgrind_check.h ${CMAKE_SOURCE_DIR}/ydb/core/debug/valgrind_check.cpp ) diff --git a/ydb/core/debug/CMakeLists.darwin-x86_64.txt b/ydb/core/debug/CMakeLists.darwin-x86_64.txt index ebb5e769c71a..3b08af1d3949 100644 --- a/ydb/core/debug/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/debug/CMakeLists.darwin-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(ydb-core-debug PUBLIC yutil ) target_sources(ydb-core-debug PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/debug/valgrind_check.h ${CMAKE_SOURCE_DIR}/ydb/core/debug/valgrind_check.cpp ) diff --git a/ydb/core/debug/CMakeLists.linux-aarch64.txt b/ydb/core/debug/CMakeLists.linux-aarch64.txt index d5b228940e6c..e7a4350f9086 100644 --- a/ydb/core/debug/CMakeLists.linux-aarch64.txt +++ b/ydb/core/debug/CMakeLists.linux-aarch64.txt @@ -14,5 +14,6 @@ target_link_libraries(ydb-core-debug PUBLIC yutil ) target_sources(ydb-core-debug PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/debug/valgrind_check.h ${CMAKE_SOURCE_DIR}/ydb/core/debug/valgrind_check.cpp ) diff --git a/ydb/core/debug/CMakeLists.linux-x86_64.txt b/ydb/core/debug/CMakeLists.linux-x86_64.txt index d5b228940e6c..e7a4350f9086 100644 --- a/ydb/core/debug/CMakeLists.linux-x86_64.txt +++ b/ydb/core/debug/CMakeLists.linux-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(ydb-core-debug PUBLIC yutil ) target_sources(ydb-core-debug PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/debug/valgrind_check.h ${CMAKE_SOURCE_DIR}/ydb/core/debug/valgrind_check.cpp ) diff --git a/ydb/core/debug/CMakeLists.windows-x86_64.txt b/ydb/core/debug/CMakeLists.windows-x86_64.txt index ebb5e769c71a..3b08af1d3949 100644 --- a/ydb/core/debug/CMakeLists.windows-x86_64.txt +++ b/ydb/core/debug/CMakeLists.windows-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(ydb-core-debug PUBLIC yutil ) target_sources(ydb-core-debug PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/debug/valgrind_check.h ${CMAKE_SOURCE_DIR}/ydb/core/debug/valgrind_check.cpp ) diff --git a/ydb/core/debug_tools/ut/CMakeLists.darwin-arm64.txt b/ydb/core/debug_tools/ut/CMakeLists.darwin-arm64.txt index 8d1200f4a223..980fec4c4ff7 100644 --- a/ydb/core/debug_tools/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/debug_tools/ut/CMakeLists.darwin-arm64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/debug_tools/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/debug_tools/ut/CMakeLists.darwin-x86_64.txt index c7b7447ddb93..c5a3a49cf635 100644 --- a/ydb/core/debug_tools/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/debug_tools/ut/CMakeLists.darwin-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/debug_tools/ut/CMakeLists.linux-aarch64.txt b/ydb/core/debug_tools/ut/CMakeLists.linux-aarch64.txt index e9317040b5c8..fa19065997e9 100644 --- a/ydb/core/debug_tools/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/debug_tools/ut/CMakeLists.linux-aarch64.txt @@ -21,9 +21,6 @@ target_link_options(ydb-core-debug_tools-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-debug_tools-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/debug_tools/ut/main.cpp @@ -53,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/debug_tools/ut/CMakeLists.linux-x86_64.txt b/ydb/core/debug_tools/ut/CMakeLists.linux-x86_64.txt index b7fd30e9f7d0..cc23d7f401f1 100644 --- a/ydb/core/debug_tools/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/debug_tools/ut/CMakeLists.linux-x86_64.txt @@ -22,9 +22,6 @@ target_link_options(ydb-core-debug_tools-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-debug_tools-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/debug_tools/ut/main.cpp @@ -54,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/debug_tools/ut/CMakeLists.windows-x86_64.txt b/ydb/core/debug_tools/ut/CMakeLists.windows-x86_64.txt index ed56e5468611..21fd862581c7 100644 --- a/ydb/core/debug_tools/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/debug_tools/ut/CMakeLists.windows-x86_64.txt @@ -43,6 +43,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/driver_lib/base_utils/CMakeLists.darwin-arm64.txt b/ydb/core/driver_lib/base_utils/CMakeLists.darwin-arm64.txt index d04bba414857..f63fcdb3fd04 100644 --- a/ydb/core/driver_lib/base_utils/CMakeLists.darwin-arm64.txt +++ b/ydb/core/driver_lib/base_utils/CMakeLists.darwin-arm64.txt @@ -23,6 +23,10 @@ target_link_libraries(base_utils PUBLIC lib-deprecated-client ) target_sources(base_utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/base_utils.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/format_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/format_util.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/node_by_host.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/format_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/format_util.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/node_by_host.cpp diff --git a/ydb/core/driver_lib/base_utils/CMakeLists.darwin-x86_64.txt b/ydb/core/driver_lib/base_utils/CMakeLists.darwin-x86_64.txt index d04bba414857..f63fcdb3fd04 100644 --- a/ydb/core/driver_lib/base_utils/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/driver_lib/base_utils/CMakeLists.darwin-x86_64.txt @@ -23,6 +23,10 @@ target_link_libraries(base_utils PUBLIC lib-deprecated-client ) target_sources(base_utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/base_utils.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/format_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/format_util.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/node_by_host.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/format_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/format_util.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/node_by_host.cpp diff --git a/ydb/core/driver_lib/base_utils/CMakeLists.linux-aarch64.txt b/ydb/core/driver_lib/base_utils/CMakeLists.linux-aarch64.txt index fc2d0020a2c4..ed1df30b5638 100644 --- a/ydb/core/driver_lib/base_utils/CMakeLists.linux-aarch64.txt +++ b/ydb/core/driver_lib/base_utils/CMakeLists.linux-aarch64.txt @@ -24,6 +24,10 @@ target_link_libraries(base_utils PUBLIC lib-deprecated-client ) target_sources(base_utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/base_utils.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/format_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/format_util.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/node_by_host.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/format_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/format_util.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/node_by_host.cpp diff --git a/ydb/core/driver_lib/base_utils/CMakeLists.linux-x86_64.txt b/ydb/core/driver_lib/base_utils/CMakeLists.linux-x86_64.txt index fc2d0020a2c4..ed1df30b5638 100644 --- a/ydb/core/driver_lib/base_utils/CMakeLists.linux-x86_64.txt +++ b/ydb/core/driver_lib/base_utils/CMakeLists.linux-x86_64.txt @@ -24,6 +24,10 @@ target_link_libraries(base_utils PUBLIC lib-deprecated-client ) target_sources(base_utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/base_utils.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/format_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/format_util.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/node_by_host.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/format_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/format_util.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/node_by_host.cpp diff --git a/ydb/core/driver_lib/base_utils/CMakeLists.windows-x86_64.txt b/ydb/core/driver_lib/base_utils/CMakeLists.windows-x86_64.txt index d04bba414857..f63fcdb3fd04 100644 --- a/ydb/core/driver_lib/base_utils/CMakeLists.windows-x86_64.txt +++ b/ydb/core/driver_lib/base_utils/CMakeLists.windows-x86_64.txt @@ -23,6 +23,10 @@ target_link_libraries(base_utils PUBLIC lib-deprecated-client ) target_sources(base_utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/base_utils.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/format_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/format_util.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/node_by_host.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/format_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/format_util.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/base_utils/node_by_host.cpp diff --git a/ydb/core/driver_lib/cli_config_base/CMakeLists.darwin-arm64.txt b/ydb/core/driver_lib/cli_config_base/CMakeLists.darwin-arm64.txt index 55f3c886ac72..9c98d7518960 100644 --- a/ydb/core/driver_lib/cli_config_base/CMakeLists.darwin-arm64.txt +++ b/ydb/core/driver_lib/cli_config_base/CMakeLists.darwin-arm64.txt @@ -20,5 +20,6 @@ target_link_libraries(core-driver_lib-cli_config_base PUBLIC library-yql-minikql ) target_sources(core-driver_lib-cli_config_base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_config_base/config_base.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_config_base/config_base.cpp ) diff --git a/ydb/core/driver_lib/cli_config_base/CMakeLists.darwin-x86_64.txt b/ydb/core/driver_lib/cli_config_base/CMakeLists.darwin-x86_64.txt index 55f3c886ac72..9c98d7518960 100644 --- a/ydb/core/driver_lib/cli_config_base/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/driver_lib/cli_config_base/CMakeLists.darwin-x86_64.txt @@ -20,5 +20,6 @@ target_link_libraries(core-driver_lib-cli_config_base PUBLIC library-yql-minikql ) target_sources(core-driver_lib-cli_config_base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_config_base/config_base.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_config_base/config_base.cpp ) diff --git a/ydb/core/driver_lib/cli_config_base/CMakeLists.linux-aarch64.txt b/ydb/core/driver_lib/cli_config_base/CMakeLists.linux-aarch64.txt index 60de3239637d..536b08e8b15b 100644 --- a/ydb/core/driver_lib/cli_config_base/CMakeLists.linux-aarch64.txt +++ b/ydb/core/driver_lib/cli_config_base/CMakeLists.linux-aarch64.txt @@ -21,5 +21,6 @@ target_link_libraries(core-driver_lib-cli_config_base PUBLIC library-yql-minikql ) target_sources(core-driver_lib-cli_config_base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_config_base/config_base.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_config_base/config_base.cpp ) diff --git a/ydb/core/driver_lib/cli_config_base/CMakeLists.linux-x86_64.txt b/ydb/core/driver_lib/cli_config_base/CMakeLists.linux-x86_64.txt index 60de3239637d..536b08e8b15b 100644 --- a/ydb/core/driver_lib/cli_config_base/CMakeLists.linux-x86_64.txt +++ b/ydb/core/driver_lib/cli_config_base/CMakeLists.linux-x86_64.txt @@ -21,5 +21,6 @@ target_link_libraries(core-driver_lib-cli_config_base PUBLIC library-yql-minikql ) target_sources(core-driver_lib-cli_config_base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_config_base/config_base.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_config_base/config_base.cpp ) diff --git a/ydb/core/driver_lib/cli_config_base/CMakeLists.windows-x86_64.txt b/ydb/core/driver_lib/cli_config_base/CMakeLists.windows-x86_64.txt index 55f3c886ac72..9c98d7518960 100644 --- a/ydb/core/driver_lib/cli_config_base/CMakeLists.windows-x86_64.txt +++ b/ydb/core/driver_lib/cli_config_base/CMakeLists.windows-x86_64.txt @@ -20,5 +20,6 @@ target_link_libraries(core-driver_lib-cli_config_base PUBLIC library-yql-minikql ) target_sources(core-driver_lib-cli_config_base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_config_base/config_base.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_config_base/config_base.cpp ) diff --git a/ydb/core/driver_lib/cli_utils/CMakeLists.darwin-arm64.txt b/ydb/core/driver_lib/cli_utils/CMakeLists.darwin-arm64.txt index a6fa732a27cd..9b0aef0e4ca9 100644 --- a/ydb/core/driver_lib/cli_utils/CMakeLists.darwin-arm64.txt +++ b/ydb/core/driver_lib/cli_utils/CMakeLists.darwin-arm64.txt @@ -40,6 +40,9 @@ target_link_libraries(cli_utils PUBLIC cpp-client-ydb_driver ) target_sources(cli_utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli_cmd_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli_cmds.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli_actorsystem_perftest.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli_cmd_config.cpp diff --git a/ydb/core/driver_lib/cli_utils/CMakeLists.darwin-x86_64.txt b/ydb/core/driver_lib/cli_utils/CMakeLists.darwin-x86_64.txt index a6fa732a27cd..9b0aef0e4ca9 100644 --- a/ydb/core/driver_lib/cli_utils/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/driver_lib/cli_utils/CMakeLists.darwin-x86_64.txt @@ -40,6 +40,9 @@ target_link_libraries(cli_utils PUBLIC cpp-client-ydb_driver ) target_sources(cli_utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli_cmd_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli_cmds.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli_actorsystem_perftest.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli_cmd_config.cpp diff --git a/ydb/core/driver_lib/cli_utils/CMakeLists.linux-aarch64.txt b/ydb/core/driver_lib/cli_utils/CMakeLists.linux-aarch64.txt index 65eb5ba00592..f622ee31dc5e 100644 --- a/ydb/core/driver_lib/cli_utils/CMakeLists.linux-aarch64.txt +++ b/ydb/core/driver_lib/cli_utils/CMakeLists.linux-aarch64.txt @@ -41,6 +41,9 @@ target_link_libraries(cli_utils PUBLIC cpp-client-ydb_driver ) target_sources(cli_utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli_cmd_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli_cmds.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli_actorsystem_perftest.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli_cmd_config.cpp diff --git a/ydb/core/driver_lib/cli_utils/CMakeLists.linux-x86_64.txt b/ydb/core/driver_lib/cli_utils/CMakeLists.linux-x86_64.txt index 65eb5ba00592..f622ee31dc5e 100644 --- a/ydb/core/driver_lib/cli_utils/CMakeLists.linux-x86_64.txt +++ b/ydb/core/driver_lib/cli_utils/CMakeLists.linux-x86_64.txt @@ -41,6 +41,9 @@ target_link_libraries(cli_utils PUBLIC cpp-client-ydb_driver ) target_sources(cli_utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli_cmd_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli_cmds.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli_actorsystem_perftest.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli_cmd_config.cpp diff --git a/ydb/core/driver_lib/cli_utils/CMakeLists.windows-x86_64.txt b/ydb/core/driver_lib/cli_utils/CMakeLists.windows-x86_64.txt index a6fa732a27cd..9b0aef0e4ca9 100644 --- a/ydb/core/driver_lib/cli_utils/CMakeLists.windows-x86_64.txt +++ b/ydb/core/driver_lib/cli_utils/CMakeLists.windows-x86_64.txt @@ -40,6 +40,9 @@ target_link_libraries(cli_utils PUBLIC cpp-client-ydb_driver ) target_sources(cli_utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli_cmd_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli_cmds.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli_actorsystem_perftest.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/cli_utils/cli_cmd_config.cpp diff --git a/ydb/core/driver_lib/run/CMakeLists.darwin-arm64.txt b/ydb/core/driver_lib/run/CMakeLists.darwin-arm64.txt index a3aa7ffb29f8..cb6369bf8a72 100644 --- a/ydb/core/driver_lib/run/CMakeLists.darwin-arm64.txt +++ b/ydb/core/driver_lib/run/CMakeLists.darwin-arm64.txt @@ -58,6 +58,8 @@ target_link_libraries(run PUBLIC ydb-core-formats fq-libs-init fq-libs-logs + core-graph-service + core-graph-shard ydb-core-grpc_services core-grpc_services-base core-grpc_services-auth_processor @@ -122,7 +124,7 @@ target_link_libraries(run PUBLIC library-folder_service-proto ydb-library-pdisk_io ydb-library-security - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 providers-pq-cm_client udf-service-exception_policy public-lib-base @@ -151,6 +153,16 @@ target_link_libraries(run PUBLIC ydb-services-ydb ) target_sources(run PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/config.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/config_parser.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/driver.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/dummy.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/factories.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/kikimr_services_initializers.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/main.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/run.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/service_initializer.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/cert_auth_props.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/auto_config_initializer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/config.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/config_parser.cpp diff --git a/ydb/core/driver_lib/run/CMakeLists.darwin-x86_64.txt b/ydb/core/driver_lib/run/CMakeLists.darwin-x86_64.txt index a3aa7ffb29f8..cb6369bf8a72 100644 --- a/ydb/core/driver_lib/run/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/driver_lib/run/CMakeLists.darwin-x86_64.txt @@ -58,6 +58,8 @@ target_link_libraries(run PUBLIC ydb-core-formats fq-libs-init fq-libs-logs + core-graph-service + core-graph-shard ydb-core-grpc_services core-grpc_services-base core-grpc_services-auth_processor @@ -122,7 +124,7 @@ target_link_libraries(run PUBLIC library-folder_service-proto ydb-library-pdisk_io ydb-library-security - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 providers-pq-cm_client udf-service-exception_policy public-lib-base @@ -151,6 +153,16 @@ target_link_libraries(run PUBLIC ydb-services-ydb ) target_sources(run PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/config.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/config_parser.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/driver.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/dummy.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/factories.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/kikimr_services_initializers.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/main.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/run.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/service_initializer.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/cert_auth_props.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/auto_config_initializer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/config.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/config_parser.cpp diff --git a/ydb/core/driver_lib/run/CMakeLists.linux-aarch64.txt b/ydb/core/driver_lib/run/CMakeLists.linux-aarch64.txt index 5d041be3895d..3558a2cdc1cb 100644 --- a/ydb/core/driver_lib/run/CMakeLists.linux-aarch64.txt +++ b/ydb/core/driver_lib/run/CMakeLists.linux-aarch64.txt @@ -59,6 +59,8 @@ target_link_libraries(run PUBLIC ydb-core-formats fq-libs-init fq-libs-logs + core-graph-service + core-graph-shard ydb-core-grpc_services core-grpc_services-base core-grpc_services-auth_processor @@ -123,7 +125,7 @@ target_link_libraries(run PUBLIC library-folder_service-proto ydb-library-pdisk_io ydb-library-security - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 providers-pq-cm_client udf-service-exception_policy public-lib-base @@ -152,6 +154,16 @@ target_link_libraries(run PUBLIC ydb-services-ydb ) target_sources(run PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/config.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/config_parser.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/driver.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/dummy.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/factories.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/kikimr_services_initializers.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/main.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/run.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/service_initializer.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/cert_auth_props.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/auto_config_initializer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/config.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/config_parser.cpp diff --git a/ydb/core/driver_lib/run/CMakeLists.linux-x86_64.txt b/ydb/core/driver_lib/run/CMakeLists.linux-x86_64.txt index 5d041be3895d..3558a2cdc1cb 100644 --- a/ydb/core/driver_lib/run/CMakeLists.linux-x86_64.txt +++ b/ydb/core/driver_lib/run/CMakeLists.linux-x86_64.txt @@ -59,6 +59,8 @@ target_link_libraries(run PUBLIC ydb-core-formats fq-libs-init fq-libs-logs + core-graph-service + core-graph-shard ydb-core-grpc_services core-grpc_services-base core-grpc_services-auth_processor @@ -123,7 +125,7 @@ target_link_libraries(run PUBLIC library-folder_service-proto ydb-library-pdisk_io ydb-library-security - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 providers-pq-cm_client udf-service-exception_policy public-lib-base @@ -152,6 +154,16 @@ target_link_libraries(run PUBLIC ydb-services-ydb ) target_sources(run PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/config.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/config_parser.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/driver.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/dummy.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/factories.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/kikimr_services_initializers.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/main.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/run.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/service_initializer.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/cert_auth_props.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/auto_config_initializer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/config.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/config_parser.cpp diff --git a/ydb/core/driver_lib/run/CMakeLists.windows-x86_64.txt b/ydb/core/driver_lib/run/CMakeLists.windows-x86_64.txt index a3aa7ffb29f8..cb6369bf8a72 100644 --- a/ydb/core/driver_lib/run/CMakeLists.windows-x86_64.txt +++ b/ydb/core/driver_lib/run/CMakeLists.windows-x86_64.txt @@ -58,6 +58,8 @@ target_link_libraries(run PUBLIC ydb-core-formats fq-libs-init fq-libs-logs + core-graph-service + core-graph-shard ydb-core-grpc_services core-grpc_services-base core-grpc_services-auth_processor @@ -122,7 +124,7 @@ target_link_libraries(run PUBLIC library-folder_service-proto ydb-library-pdisk_io ydb-library-security - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 providers-pq-cm_client udf-service-exception_policy public-lib-base @@ -151,6 +153,16 @@ target_link_libraries(run PUBLIC ydb-services-ydb ) target_sources(run PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/config.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/config_parser.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/driver.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/dummy.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/factories.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/kikimr_services_initializers.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/main.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/run.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/service_initializer.h + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/cert_auth_props.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/auto_config_initializer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/config.cpp ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/config_parser.cpp diff --git a/ydb/core/driver_lib/run/ut/CMakeLists.darwin-arm64.txt b/ydb/core/driver_lib/run/ut/CMakeLists.darwin-arm64.txt index 892768c8c49b..1da1bb546635 100644 --- a/ydb/core/driver_lib/run/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/driver_lib/run/ut/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-driver_lib-run-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-driver_lib-run-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/auto_config_initializer_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/driver_lib/run/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/driver_lib/run/ut/CMakeLists.darwin-x86_64.txt index efd77ad094cd..6889623691fb 100644 --- a/ydb/core/driver_lib/run/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/driver_lib/run/ut/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-driver_lib-run-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-driver_lib-run-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/auto_config_initializer_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/driver_lib/run/ut/CMakeLists.linux-aarch64.txt b/ydb/core/driver_lib/run/ut/CMakeLists.linux-aarch64.txt index 096613ddb59e..98ae15ff5be1 100644 --- a/ydb/core/driver_lib/run/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/driver_lib/run/ut/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-driver_lib-run-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-driver_lib-run-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/auto_config_initializer_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/driver_lib/run/ut/CMakeLists.linux-x86_64.txt b/ydb/core/driver_lib/run/ut/CMakeLists.linux-x86_64.txt index 272f212f575e..f4b3cd1e2c39 100644 --- a/ydb/core/driver_lib/run/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/driver_lib/run/ut/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-driver_lib-run-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-driver_lib-run-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/run/auto_config_initializer_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/driver_lib/run/ut/CMakeLists.windows-x86_64.txt b/ydb/core/driver_lib/run/ut/CMakeLists.windows-x86_64.txt index cbb124fc9e41..66f69e8e562a 100644 --- a/ydb/core/driver_lib/run/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/driver_lib/run/ut/CMakeLists.windows-x86_64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/driver_lib/version/CMakeLists.darwin-arm64.txt b/ydb/core/driver_lib/version/CMakeLists.darwin-arm64.txt index 122d3326b3bf..328f804c830f 100644 --- a/ydb/core/driver_lib/version/CMakeLists.darwin-arm64.txt +++ b/ydb/core/driver_lib/version/CMakeLists.darwin-arm64.txt @@ -20,5 +20,6 @@ target_link_libraries(version PUBLIC core-viewer-json ) target_sources(version PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/version/version.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/version/version.cpp ) diff --git a/ydb/core/driver_lib/version/CMakeLists.darwin-x86_64.txt b/ydb/core/driver_lib/version/CMakeLists.darwin-x86_64.txt index 122d3326b3bf..328f804c830f 100644 --- a/ydb/core/driver_lib/version/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/driver_lib/version/CMakeLists.darwin-x86_64.txt @@ -20,5 +20,6 @@ target_link_libraries(version PUBLIC core-viewer-json ) target_sources(version PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/version/version.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/version/version.cpp ) diff --git a/ydb/core/driver_lib/version/CMakeLists.linux-aarch64.txt b/ydb/core/driver_lib/version/CMakeLists.linux-aarch64.txt index 475f443e9685..8d91cfefea6f 100644 --- a/ydb/core/driver_lib/version/CMakeLists.linux-aarch64.txt +++ b/ydb/core/driver_lib/version/CMakeLists.linux-aarch64.txt @@ -21,5 +21,6 @@ target_link_libraries(version PUBLIC core-viewer-json ) target_sources(version PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/version/version.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/version/version.cpp ) diff --git a/ydb/core/driver_lib/version/CMakeLists.linux-x86_64.txt b/ydb/core/driver_lib/version/CMakeLists.linux-x86_64.txt index 475f443e9685..8d91cfefea6f 100644 --- a/ydb/core/driver_lib/version/CMakeLists.linux-x86_64.txt +++ b/ydb/core/driver_lib/version/CMakeLists.linux-x86_64.txt @@ -21,5 +21,6 @@ target_link_libraries(version PUBLIC core-viewer-json ) target_sources(version PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/version/version.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/version/version.cpp ) diff --git a/ydb/core/driver_lib/version/CMakeLists.windows-x86_64.txt b/ydb/core/driver_lib/version/CMakeLists.windows-x86_64.txt index 122d3326b3bf..328f804c830f 100644 --- a/ydb/core/driver_lib/version/CMakeLists.windows-x86_64.txt +++ b/ydb/core/driver_lib/version/CMakeLists.windows-x86_64.txt @@ -20,5 +20,6 @@ target_link_libraries(version PUBLIC core-viewer-json ) target_sources(version PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/version/version.h ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/version/version.cpp ) diff --git a/ydb/core/driver_lib/version/ut/CMakeLists.darwin-arm64.txt b/ydb/core/driver_lib/version/ut/CMakeLists.darwin-arm64.txt index 8f1886e8debb..923cb8c2f35a 100644 --- a/ydb/core/driver_lib/version/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/driver_lib/version/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-core-driver_lib-version-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-driver_lib-version-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/version/ut/version_ut.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/driver_lib/version/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/driver_lib/version/ut/CMakeLists.darwin-x86_64.txt index e0a3ec19bc8b..ff98a9080641 100644 --- a/ydb/core/driver_lib/version/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/driver_lib/version/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-core-driver_lib-version-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-driver_lib-version-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/version/ut/version_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/driver_lib/version/ut/CMakeLists.linux-aarch64.txt b/ydb/core/driver_lib/version/ut/CMakeLists.linux-aarch64.txt index 0905a7b00a6f..3ecb12cd4036 100644 --- a/ydb/core/driver_lib/version/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/driver_lib/version/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-core-driver_lib-version-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-driver_lib-version-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/version/ut/version_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/driver_lib/version/ut/CMakeLists.linux-x86_64.txt b/ydb/core/driver_lib/version/ut/CMakeLists.linux-x86_64.txt index 7e32e2defdf3..999ad8804d32 100644 --- a/ydb/core/driver_lib/version/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/driver_lib/version/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-core-driver_lib-version-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-driver_lib-version-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/version/ut/version_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/driver_lib/version/ut/CMakeLists.windows-x86_64.txt b/ydb/core/driver_lib/version/ut/CMakeLists.windows-x86_64.txt index 811a5dda44d3..f611bebb0fcc 100644 --- a/ydb/core/driver_lib/version/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/driver_lib/version/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/engine/CMakeLists.darwin-arm64.txt b/ydb/core/engine/CMakeLists.darwin-arm64.txt index e424e4640f26..026972831831 100644 --- a/ydb/core/engine/CMakeLists.darwin-arm64.txt +++ b/ydb/core/engine/CMakeLists.darwin-arm64.txt @@ -26,11 +26,12 @@ target_link_libraries(ydb-core-engine PUBLIC ydb-library-mkql_proto library-mkql_proto-protos api-protos - minikql-comp_nodes-llvm + yql-minikql-comp_nodes parser-pg_wrapper-interface yql-public-decimal ) target_sources(ydb-core-engine PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/engine/mkql_proto.h ${CMAKE_SOURCE_DIR}/ydb/core/engine/kikimr_program_builder.cpp ${CMAKE_SOURCE_DIR}/ydb/core/engine/mkql_engine_flat.cpp ${CMAKE_SOURCE_DIR}/ydb/core/engine/mkql_engine_flat_extfunc.cpp diff --git a/ydb/core/engine/CMakeLists.darwin-x86_64.txt b/ydb/core/engine/CMakeLists.darwin-x86_64.txt index e424e4640f26..026972831831 100644 --- a/ydb/core/engine/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/engine/CMakeLists.darwin-x86_64.txt @@ -26,11 +26,12 @@ target_link_libraries(ydb-core-engine PUBLIC ydb-library-mkql_proto library-mkql_proto-protos api-protos - minikql-comp_nodes-llvm + yql-minikql-comp_nodes parser-pg_wrapper-interface yql-public-decimal ) target_sources(ydb-core-engine PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/engine/mkql_proto.h ${CMAKE_SOURCE_DIR}/ydb/core/engine/kikimr_program_builder.cpp ${CMAKE_SOURCE_DIR}/ydb/core/engine/mkql_engine_flat.cpp ${CMAKE_SOURCE_DIR}/ydb/core/engine/mkql_engine_flat_extfunc.cpp diff --git a/ydb/core/engine/CMakeLists.linux-aarch64.txt b/ydb/core/engine/CMakeLists.linux-aarch64.txt index 4650f2e89a16..1b38ba2411e2 100644 --- a/ydb/core/engine/CMakeLists.linux-aarch64.txt +++ b/ydb/core/engine/CMakeLists.linux-aarch64.txt @@ -27,11 +27,12 @@ target_link_libraries(ydb-core-engine PUBLIC ydb-library-mkql_proto library-mkql_proto-protos api-protos - minikql-comp_nodes-llvm + yql-minikql-comp_nodes parser-pg_wrapper-interface yql-public-decimal ) target_sources(ydb-core-engine PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/engine/mkql_proto.h ${CMAKE_SOURCE_DIR}/ydb/core/engine/kikimr_program_builder.cpp ${CMAKE_SOURCE_DIR}/ydb/core/engine/mkql_engine_flat.cpp ${CMAKE_SOURCE_DIR}/ydb/core/engine/mkql_engine_flat_extfunc.cpp diff --git a/ydb/core/engine/CMakeLists.linux-x86_64.txt b/ydb/core/engine/CMakeLists.linux-x86_64.txt index 4650f2e89a16..1b38ba2411e2 100644 --- a/ydb/core/engine/CMakeLists.linux-x86_64.txt +++ b/ydb/core/engine/CMakeLists.linux-x86_64.txt @@ -27,11 +27,12 @@ target_link_libraries(ydb-core-engine PUBLIC ydb-library-mkql_proto library-mkql_proto-protos api-protos - minikql-comp_nodes-llvm + yql-minikql-comp_nodes parser-pg_wrapper-interface yql-public-decimal ) target_sources(ydb-core-engine PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/engine/mkql_proto.h ${CMAKE_SOURCE_DIR}/ydb/core/engine/kikimr_program_builder.cpp ${CMAKE_SOURCE_DIR}/ydb/core/engine/mkql_engine_flat.cpp ${CMAKE_SOURCE_DIR}/ydb/core/engine/mkql_engine_flat_extfunc.cpp diff --git a/ydb/core/engine/CMakeLists.windows-x86_64.txt b/ydb/core/engine/CMakeLists.windows-x86_64.txt index e424e4640f26..026972831831 100644 --- a/ydb/core/engine/CMakeLists.windows-x86_64.txt +++ b/ydb/core/engine/CMakeLists.windows-x86_64.txt @@ -26,11 +26,12 @@ target_link_libraries(ydb-core-engine PUBLIC ydb-library-mkql_proto library-mkql_proto-protos api-protos - minikql-comp_nodes-llvm + yql-minikql-comp_nodes parser-pg_wrapper-interface yql-public-decimal ) target_sources(ydb-core-engine PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/engine/mkql_proto.h ${CMAKE_SOURCE_DIR}/ydb/core/engine/kikimr_program_builder.cpp ${CMAKE_SOURCE_DIR}/ydb/core/engine/mkql_engine_flat.cpp ${CMAKE_SOURCE_DIR}/ydb/core/engine/mkql_engine_flat_extfunc.cpp diff --git a/ydb/core/engine/minikql/CMakeLists.darwin-arm64.txt b/ydb/core/engine/minikql/CMakeLists.darwin-arm64.txt index 924d66edc5bf..a87666e19b47 100644 --- a/ydb/core/engine/minikql/CMakeLists.darwin-arm64.txt +++ b/ydb/core/engine/minikql/CMakeLists.darwin-arm64.txt @@ -22,6 +22,8 @@ target_link_libraries(core-engine-minikql PUBLIC parser-pg_wrapper-interface ) target_sources(core-engine-minikql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/engine/minikql/flat_local_minikql_host.h + ${CMAKE_SOURCE_DIR}/ydb/core/engine/minikql/minikql_engine_host.h ${CMAKE_SOURCE_DIR}/ydb/core/engine/minikql/flat_local_tx_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/core/engine/minikql/minikql_engine_host.cpp ) diff --git a/ydb/core/engine/minikql/CMakeLists.darwin-x86_64.txt b/ydb/core/engine/minikql/CMakeLists.darwin-x86_64.txt index 924d66edc5bf..a87666e19b47 100644 --- a/ydb/core/engine/minikql/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/engine/minikql/CMakeLists.darwin-x86_64.txt @@ -22,6 +22,8 @@ target_link_libraries(core-engine-minikql PUBLIC parser-pg_wrapper-interface ) target_sources(core-engine-minikql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/engine/minikql/flat_local_minikql_host.h + ${CMAKE_SOURCE_DIR}/ydb/core/engine/minikql/minikql_engine_host.h ${CMAKE_SOURCE_DIR}/ydb/core/engine/minikql/flat_local_tx_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/core/engine/minikql/minikql_engine_host.cpp ) diff --git a/ydb/core/engine/minikql/CMakeLists.linux-aarch64.txt b/ydb/core/engine/minikql/CMakeLists.linux-aarch64.txt index 2189242369ab..639aaefe3f81 100644 --- a/ydb/core/engine/minikql/CMakeLists.linux-aarch64.txt +++ b/ydb/core/engine/minikql/CMakeLists.linux-aarch64.txt @@ -23,6 +23,8 @@ target_link_libraries(core-engine-minikql PUBLIC parser-pg_wrapper-interface ) target_sources(core-engine-minikql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/engine/minikql/flat_local_minikql_host.h + ${CMAKE_SOURCE_DIR}/ydb/core/engine/minikql/minikql_engine_host.h ${CMAKE_SOURCE_DIR}/ydb/core/engine/minikql/flat_local_tx_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/core/engine/minikql/minikql_engine_host.cpp ) diff --git a/ydb/core/engine/minikql/CMakeLists.linux-x86_64.txt b/ydb/core/engine/minikql/CMakeLists.linux-x86_64.txt index 2189242369ab..639aaefe3f81 100644 --- a/ydb/core/engine/minikql/CMakeLists.linux-x86_64.txt +++ b/ydb/core/engine/minikql/CMakeLists.linux-x86_64.txt @@ -23,6 +23,8 @@ target_link_libraries(core-engine-minikql PUBLIC parser-pg_wrapper-interface ) target_sources(core-engine-minikql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/engine/minikql/flat_local_minikql_host.h + ${CMAKE_SOURCE_DIR}/ydb/core/engine/minikql/minikql_engine_host.h ${CMAKE_SOURCE_DIR}/ydb/core/engine/minikql/flat_local_tx_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/core/engine/minikql/minikql_engine_host.cpp ) diff --git a/ydb/core/engine/minikql/CMakeLists.windows-x86_64.txt b/ydb/core/engine/minikql/CMakeLists.windows-x86_64.txt index 924d66edc5bf..a87666e19b47 100644 --- a/ydb/core/engine/minikql/CMakeLists.windows-x86_64.txt +++ b/ydb/core/engine/minikql/CMakeLists.windows-x86_64.txt @@ -22,6 +22,8 @@ target_link_libraries(core-engine-minikql PUBLIC parser-pg_wrapper-interface ) target_sources(core-engine-minikql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/engine/minikql/flat_local_minikql_host.h + ${CMAKE_SOURCE_DIR}/ydb/core/engine/minikql/minikql_engine_host.h ${CMAKE_SOURCE_DIR}/ydb/core/engine/minikql/flat_local_tx_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/core/engine/minikql/minikql_engine_host.cpp ) diff --git a/ydb/core/engine/ut/CMakeLists.darwin-arm64.txt b/ydb/core/engine/ut/CMakeLists.darwin-arm64.txt index fc6a0f5a05da..9dfe0f7e9b39 100644 --- a/ydb/core/engine/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/engine/ut/CMakeLists.darwin-arm64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-engine-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-engine-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/engine/mkql_engine_flat_host_ut.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/engine/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/engine/ut/CMakeLists.darwin-x86_64.txt index 77157af6b6f9..ee369a3e16ae 100644 --- a/ydb/core/engine/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/engine/ut/CMakeLists.darwin-x86_64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-engine-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-engine-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/engine/mkql_engine_flat_host_ut.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/engine/ut/CMakeLists.linux-aarch64.txt b/ydb/core/engine/ut/CMakeLists.linux-aarch64.txt index f8f1f84e4903..36fc34aa6490 100644 --- a/ydb/core/engine/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/engine/ut/CMakeLists.linux-aarch64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-engine-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-engine-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/engine/mkql_engine_flat_host_ut.cpp @@ -68,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/engine/ut/CMakeLists.linux-x86_64.txt b/ydb/core/engine/ut/CMakeLists.linux-x86_64.txt index caa1af7aa60b..f9f848b5043b 100644 --- a/ydb/core/engine/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/engine/ut/CMakeLists.linux-x86_64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-engine-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-engine-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/engine/mkql_engine_flat_host_ut.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/engine/ut/CMakeLists.windows-x86_64.txt b/ydb/core/engine/ut/CMakeLists.windows-x86_64.txt index e846ff614d7d..3c1c869716d9 100644 --- a/ydb/core/engine/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/engine/ut/CMakeLists.windows-x86_64.txt @@ -58,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/erasure/CMakeLists.darwin-arm64.txt b/ydb/core/erasure/CMakeLists.darwin-arm64.txt index 068a0bb37ac0..e88fc798e5ef 100644 --- a/ydb/core/erasure/CMakeLists.darwin-arm64.txt +++ b/ydb/core/erasure/CMakeLists.darwin-arm64.txt @@ -21,6 +21,8 @@ target_link_libraries(ydb-core-erasure PUBLIC ydb-core-debug ) target_sources(ydb-core-erasure PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure.h + ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_rope.h ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure.cpp ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_rope.cpp ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_perf_test.cpp diff --git a/ydb/core/erasure/CMakeLists.darwin-x86_64.txt b/ydb/core/erasure/CMakeLists.darwin-x86_64.txt index 068a0bb37ac0..e88fc798e5ef 100644 --- a/ydb/core/erasure/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/erasure/CMakeLists.darwin-x86_64.txt @@ -21,6 +21,8 @@ target_link_libraries(ydb-core-erasure PUBLIC ydb-core-debug ) target_sources(ydb-core-erasure PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure.h + ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_rope.h ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure.cpp ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_rope.cpp ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_perf_test.cpp diff --git a/ydb/core/erasure/CMakeLists.linux-aarch64.txt b/ydb/core/erasure/CMakeLists.linux-aarch64.txt index ffd9912bb95e..bc37231d6225 100644 --- a/ydb/core/erasure/CMakeLists.linux-aarch64.txt +++ b/ydb/core/erasure/CMakeLists.linux-aarch64.txt @@ -22,6 +22,8 @@ target_link_libraries(ydb-core-erasure PUBLIC ydb-core-debug ) target_sources(ydb-core-erasure PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure.h + ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_rope.h ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure.cpp ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_rope.cpp ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_perf_test.cpp diff --git a/ydb/core/erasure/CMakeLists.linux-x86_64.txt b/ydb/core/erasure/CMakeLists.linux-x86_64.txt index ffd9912bb95e..bc37231d6225 100644 --- a/ydb/core/erasure/CMakeLists.linux-x86_64.txt +++ b/ydb/core/erasure/CMakeLists.linux-x86_64.txt @@ -22,6 +22,8 @@ target_link_libraries(ydb-core-erasure PUBLIC ydb-core-debug ) target_sources(ydb-core-erasure PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure.h + ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_rope.h ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure.cpp ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_rope.cpp ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_perf_test.cpp diff --git a/ydb/core/erasure/CMakeLists.windows-x86_64.txt b/ydb/core/erasure/CMakeLists.windows-x86_64.txt index 71aec8b22643..fe2e5a32528a 100644 --- a/ydb/core/erasure/CMakeLists.windows-x86_64.txt +++ b/ydb/core/erasure/CMakeLists.windows-x86_64.txt @@ -24,6 +24,8 @@ target_link_libraries(ydb-core-erasure PUBLIC ydb-core-debug ) target_sources(ydb-core-erasure PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure.h + ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_rope.h ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure.cpp ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_rope.cpp ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_perf_test.cpp diff --git a/ydb/core/erasure/ut/CMakeLists.darwin-arm64.txt b/ydb/core/erasure/ut/CMakeLists.darwin-arm64.txt index fe867c1d46f8..c2bf1145834f 100644 --- a/ydb/core/erasure/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/erasure/ut/CMakeLists.darwin-arm64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-core-erasure-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-erasure-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/erasure/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/erasure/ut/CMakeLists.darwin-x86_64.txt index ff15eec7e550..ba77c9d20c87 100644 --- a/ydb/core/erasure/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/erasure/ut/CMakeLists.darwin-x86_64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-core-erasure-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-erasure-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/erasure/ut/CMakeLists.linux-aarch64.txt b/ydb/core/erasure/ut/CMakeLists.linux-aarch64.txt index 2282138caa05..162b123f722c 100644 --- a/ydb/core/erasure/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/erasure/ut/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-core-erasure-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-erasure-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/erasure/ut/CMakeLists.linux-x86_64.txt b/ydb/core/erasure/ut/CMakeLists.linux-x86_64.txt index fb817d461ff9..a2fbe6582226 100644 --- a/ydb/core/erasure/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/erasure/ut/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-core-erasure-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-erasure-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/erasure/ut/CMakeLists.windows-x86_64.txt b/ydb/core/erasure/ut/CMakeLists.windows-x86_64.txt index 1dc16fe51f6a..01fcc7bcd0d5 100644 --- a/ydb/core/erasure/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/erasure/ut/CMakeLists.windows-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/erasure/ut_perf/CMakeLists.darwin-arm64.txt b/ydb/core/erasure/ut_perf/CMakeLists.darwin-arm64.txt index 19e7454b5fb0..53e65c0f7f88 100644 --- a/ydb/core/erasure/ut_perf/CMakeLists.darwin-arm64.txt +++ b/ydb/core/erasure/ut_perf/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-core-erasure-ut_perf PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-erasure-ut_perf PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_perf_test.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/erasure/ut_perf/CMakeLists.darwin-x86_64.txt b/ydb/core/erasure/ut_perf/CMakeLists.darwin-x86_64.txt index 82951db456ff..6586d72db955 100644 --- a/ydb/core/erasure/ut_perf/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/erasure/ut_perf/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-core-erasure-ut_perf PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-erasure-ut_perf PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_perf_test.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/erasure/ut_perf/CMakeLists.linux-aarch64.txt b/ydb/core/erasure/ut_perf/CMakeLists.linux-aarch64.txt index 9084a377ad9c..a41bc735badd 100644 --- a/ydb/core/erasure/ut_perf/CMakeLists.linux-aarch64.txt +++ b/ydb/core/erasure/ut_perf/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-core-erasure-ut_perf PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-erasure-ut_perf PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_perf_test.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/erasure/ut_perf/CMakeLists.linux-x86_64.txt b/ydb/core/erasure/ut_perf/CMakeLists.linux-x86_64.txt index 4ff939bb432a..54fc31d8fe96 100644 --- a/ydb/core/erasure/ut_perf/CMakeLists.linux-x86_64.txt +++ b/ydb/core/erasure/ut_perf/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-core-erasure-ut_perf PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-erasure-ut_perf PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_perf_test.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/erasure/ut_perf/CMakeLists.windows-x86_64.txt b/ydb/core/erasure/ut_perf/CMakeLists.windows-x86_64.txt index af7c68bbe07f..1a9822e31957 100644 --- a/ydb/core/erasure/ut_perf/CMakeLists.windows-x86_64.txt +++ b/ydb/core/erasure/ut_perf/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/erasure/ut_rope/CMakeLists.darwin-arm64.txt b/ydb/core/erasure/ut_rope/CMakeLists.darwin-arm64.txt index 480656c7c6b4..f213db6ebbd6 100644 --- a/ydb/core/erasure/ut_rope/CMakeLists.darwin-arm64.txt +++ b/ydb/core/erasure/ut_rope/CMakeLists.darwin-arm64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-core-erasure-ut_rope PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-erasure-ut_rope PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_rope_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/erasure/ut_rope/CMakeLists.darwin-x86_64.txt b/ydb/core/erasure/ut_rope/CMakeLists.darwin-x86_64.txt index f07378583d3c..b7b1269a1760 100644 --- a/ydb/core/erasure/ut_rope/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/erasure/ut_rope/CMakeLists.darwin-x86_64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-core-erasure-ut_rope PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-erasure-ut_rope PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_rope_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/erasure/ut_rope/CMakeLists.linux-aarch64.txt b/ydb/core/erasure/ut_rope/CMakeLists.linux-aarch64.txt index bf91fac5d78a..cebc58d48775 100644 --- a/ydb/core/erasure/ut_rope/CMakeLists.linux-aarch64.txt +++ b/ydb/core/erasure/ut_rope/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-core-erasure-ut_rope PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-erasure-ut_rope PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_rope_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/erasure/ut_rope/CMakeLists.linux-x86_64.txt b/ydb/core/erasure/ut_rope/CMakeLists.linux-x86_64.txt index 5ceba48e1ed6..1d11fb6337bd 100644 --- a/ydb/core/erasure/ut_rope/CMakeLists.linux-x86_64.txt +++ b/ydb/core/erasure/ut_rope/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-core-erasure-ut_rope PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-erasure-ut_rope PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/erasure/erasure_rope_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/erasure/ut_rope/CMakeLists.windows-x86_64.txt b/ydb/core/erasure/ut_rope/CMakeLists.windows-x86_64.txt index 817347b30741..f2afbf4c4c8a 100644 --- a/ydb/core/erasure/ut_rope/CMakeLists.windows-x86_64.txt +++ b/ydb/core/erasure/ut_rope/CMakeLists.windows-x86_64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/external_sources/ut/CMakeLists.darwin-arm64.txt b/ydb/core/external_sources/ut/CMakeLists.darwin-arm64.txt index 1b138ada4702..6152d8ac5b52 100644 --- a/ydb/core/external_sources/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/external_sources/ut/CMakeLists.darwin-arm64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-core-external_sources-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-external_sources-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/external_sources/object_storage_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/external_sources/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/external_sources/ut/CMakeLists.darwin-x86_64.txt index 608d02c37e92..2ccc1091a751 100644 --- a/ydb/core/external_sources/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/external_sources/ut/CMakeLists.darwin-x86_64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-core-external_sources-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-external_sources-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/external_sources/object_storage_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/external_sources/ut/CMakeLists.linux-aarch64.txt b/ydb/core/external_sources/ut/CMakeLists.linux-aarch64.txt index 60647ffd9dbc..830b2eececcb 100644 --- a/ydb/core/external_sources/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/external_sources/ut/CMakeLists.linux-aarch64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-core-external_sources-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-external_sources-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/external_sources/object_storage_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/external_sources/ut/CMakeLists.linux-x86_64.txt b/ydb/core/external_sources/ut/CMakeLists.linux-x86_64.txt index 3b617e428312..38259a6fba6b 100644 --- a/ydb/core/external_sources/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/external_sources/ut/CMakeLists.linux-x86_64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-core-external_sources-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-external_sources-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/external_sources/object_storage_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/external_sources/ut/CMakeLists.windows-x86_64.txt b/ydb/core/external_sources/ut/CMakeLists.windows-x86_64.txt index 8679bf77c692..f9378fda1ba8 100644 --- a/ydb/core/external_sources/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/external_sources/ut/CMakeLists.windows-x86_64.txt @@ -49,6 +49,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/formats/CMakeLists.darwin-arm64.txt b/ydb/core/formats/CMakeLists.darwin-arm64.txt index f1230dd58c11..0dc3d23c5805 100644 --- a/ydb/core/formats/CMakeLists.darwin-arm64.txt +++ b/ydb/core/formats/CMakeLists.darwin-arm64.txt @@ -18,5 +18,7 @@ target_link_libraries(ydb-core-formats PUBLIC ydb-core-scheme ) target_sources(ydb-core-formats PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/formats/clickhouse_block.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/factory.h ${CMAKE_SOURCE_DIR}/ydb/core/formats/clickhouse_block.cpp ) diff --git a/ydb/core/formats/CMakeLists.darwin-x86_64.txt b/ydb/core/formats/CMakeLists.darwin-x86_64.txt index f1230dd58c11..0dc3d23c5805 100644 --- a/ydb/core/formats/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/formats/CMakeLists.darwin-x86_64.txt @@ -18,5 +18,7 @@ target_link_libraries(ydb-core-formats PUBLIC ydb-core-scheme ) target_sources(ydb-core-formats PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/formats/clickhouse_block.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/factory.h ${CMAKE_SOURCE_DIR}/ydb/core/formats/clickhouse_block.cpp ) diff --git a/ydb/core/formats/CMakeLists.linux-aarch64.txt b/ydb/core/formats/CMakeLists.linux-aarch64.txt index 0c1fd44e5f26..4e6274ea56f1 100644 --- a/ydb/core/formats/CMakeLists.linux-aarch64.txt +++ b/ydb/core/formats/CMakeLists.linux-aarch64.txt @@ -19,5 +19,7 @@ target_link_libraries(ydb-core-formats PUBLIC ydb-core-scheme ) target_sources(ydb-core-formats PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/formats/clickhouse_block.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/factory.h ${CMAKE_SOURCE_DIR}/ydb/core/formats/clickhouse_block.cpp ) diff --git a/ydb/core/formats/CMakeLists.linux-x86_64.txt b/ydb/core/formats/CMakeLists.linux-x86_64.txt index 0c1fd44e5f26..4e6274ea56f1 100644 --- a/ydb/core/formats/CMakeLists.linux-x86_64.txt +++ b/ydb/core/formats/CMakeLists.linux-x86_64.txt @@ -19,5 +19,7 @@ target_link_libraries(ydb-core-formats PUBLIC ydb-core-scheme ) target_sources(ydb-core-formats PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/formats/clickhouse_block.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/factory.h ${CMAKE_SOURCE_DIR}/ydb/core/formats/clickhouse_block.cpp ) diff --git a/ydb/core/formats/CMakeLists.windows-x86_64.txt b/ydb/core/formats/CMakeLists.windows-x86_64.txt index f1230dd58c11..0dc3d23c5805 100644 --- a/ydb/core/formats/CMakeLists.windows-x86_64.txt +++ b/ydb/core/formats/CMakeLists.windows-x86_64.txt @@ -18,5 +18,7 @@ target_link_libraries(ydb-core-formats PUBLIC ydb-core-scheme ) target_sources(ydb-core-formats PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/formats/clickhouse_block.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/factory.h ${CMAKE_SOURCE_DIR}/ydb/core/formats/clickhouse_block.cpp ) diff --git a/ydb/core/formats/arrow/CMakeLists.darwin-arm64.txt b/ydb/core/formats/arrow/CMakeLists.darwin-arm64.txt index e6f485e74179..96ab2157e829 100644 --- a/ydb/core/formats/arrow/CMakeLists.darwin-arm64.txt +++ b/ydb/core/formats/arrow/CMakeLists.darwin-arm64.txt @@ -40,9 +40,15 @@ target_link_libraries(core-formats-arrow PUBLIC ydb-library-binary_json ydb-library-dynumber ydb-library-services + core-arrow_kernels-request ydb-library-arrow_clickhouse ) target_sources(core-formats-arrow PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/converter.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/input_stream.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/merging_sorted_input_stream.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/one_batch_input_stream.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/sort_cursor.h ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/arrow_batch_builder.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/arrow_filter.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/arrow_helpers.cpp diff --git a/ydb/core/formats/arrow/CMakeLists.darwin-x86_64.txt b/ydb/core/formats/arrow/CMakeLists.darwin-x86_64.txt index e6f485e74179..96ab2157e829 100644 --- a/ydb/core/formats/arrow/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/formats/arrow/CMakeLists.darwin-x86_64.txt @@ -40,9 +40,15 @@ target_link_libraries(core-formats-arrow PUBLIC ydb-library-binary_json ydb-library-dynumber ydb-library-services + core-arrow_kernels-request ydb-library-arrow_clickhouse ) target_sources(core-formats-arrow PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/converter.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/input_stream.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/merging_sorted_input_stream.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/one_batch_input_stream.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/sort_cursor.h ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/arrow_batch_builder.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/arrow_filter.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/arrow_helpers.cpp diff --git a/ydb/core/formats/arrow/CMakeLists.linux-aarch64.txt b/ydb/core/formats/arrow/CMakeLists.linux-aarch64.txt index 92b2cb86a557..bee6ba5a47fe 100644 --- a/ydb/core/formats/arrow/CMakeLists.linux-aarch64.txt +++ b/ydb/core/formats/arrow/CMakeLists.linux-aarch64.txt @@ -41,9 +41,15 @@ target_link_libraries(core-formats-arrow PUBLIC ydb-library-binary_json ydb-library-dynumber ydb-library-services + core-arrow_kernels-request ydb-library-arrow_clickhouse ) target_sources(core-formats-arrow PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/converter.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/input_stream.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/merging_sorted_input_stream.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/one_batch_input_stream.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/sort_cursor.h ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/arrow_batch_builder.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/arrow_filter.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/arrow_helpers.cpp diff --git a/ydb/core/formats/arrow/CMakeLists.linux-x86_64.txt b/ydb/core/formats/arrow/CMakeLists.linux-x86_64.txt index 92b2cb86a557..bee6ba5a47fe 100644 --- a/ydb/core/formats/arrow/CMakeLists.linux-x86_64.txt +++ b/ydb/core/formats/arrow/CMakeLists.linux-x86_64.txt @@ -41,9 +41,15 @@ target_link_libraries(core-formats-arrow PUBLIC ydb-library-binary_json ydb-library-dynumber ydb-library-services + core-arrow_kernels-request ydb-library-arrow_clickhouse ) target_sources(core-formats-arrow PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/converter.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/input_stream.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/merging_sorted_input_stream.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/one_batch_input_stream.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/sort_cursor.h ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/arrow_batch_builder.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/arrow_filter.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/arrow_helpers.cpp diff --git a/ydb/core/formats/arrow/CMakeLists.windows-x86_64.txt b/ydb/core/formats/arrow/CMakeLists.windows-x86_64.txt index 66ab0217c244..17376b66d573 100644 --- a/ydb/core/formats/arrow/CMakeLists.windows-x86_64.txt +++ b/ydb/core/formats/arrow/CMakeLists.windows-x86_64.txt @@ -41,8 +41,14 @@ target_link_libraries(core-formats-arrow PUBLIC ydb-library-binary_json ydb-library-dynumber ydb-library-services + core-arrow_kernels-request ) target_sources(core-formats-arrow PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/converter.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/input_stream.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/merging_sorted_input_stream.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/one_batch_input_stream.h + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/sort_cursor.h ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/arrow_batch_builder.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/arrow_filter.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/arrow_helpers.cpp diff --git a/ydb/core/formats/arrow/ut/CMakeLists.darwin-arm64.txt b/ydb/core/formats/arrow/ut/CMakeLists.darwin-arm64.txt index b493df8561ee..d837867bd67f 100644 --- a/ydb/core/formats/arrow/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/formats/arrow/ut/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-formats-arrow-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-formats-arrow-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut_arrow.cpp @@ -40,6 +38,7 @@ target_sources(ydb-core-formats-arrow-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut/ut_dictionary.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut/ut_size_calcer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut/ut_column_filter.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut/ut_hash.cpp ) set_property( TARGET @@ -66,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/formats/arrow/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/formats/arrow/ut/CMakeLists.darwin-x86_64.txt index 6e15f878a41b..8b56367fa02a 100644 --- a/ydb/core/formats/arrow/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/formats/arrow/ut/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-formats-arrow-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-formats-arrow-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut_arrow.cpp @@ -41,6 +39,7 @@ target_sources(ydb-core-formats-arrow-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut/ut_dictionary.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut/ut_size_calcer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut/ut_column_filter.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut/ut_hash.cpp ) set_property( TARGET @@ -67,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/formats/arrow/ut/CMakeLists.linux-aarch64.txt b/ydb/core/formats/arrow/ut/CMakeLists.linux-aarch64.txt index 86633fb881d3..e0db7c1dbc9c 100644 --- a/ydb/core/formats/arrow/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/formats/arrow/ut/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-formats-arrow-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-formats-arrow-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut_arrow.cpp @@ -44,6 +41,7 @@ target_sources(ydb-core-formats-arrow-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut/ut_dictionary.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut/ut_size_calcer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut/ut_column_filter.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut/ut_hash.cpp ) set_property( TARGET @@ -70,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/formats/arrow/ut/CMakeLists.linux-x86_64.txt b/ydb/core/formats/arrow/ut/CMakeLists.linux-x86_64.txt index 1cdada418ddd..5cd06dbcab6b 100644 --- a/ydb/core/formats/arrow/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/formats/arrow/ut/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-formats-arrow-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-formats-arrow-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut_arrow.cpp @@ -45,6 +42,7 @@ target_sources(ydb-core-formats-arrow-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut/ut_dictionary.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut/ut_size_calcer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut/ut_column_filter.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut/ut_hash.cpp ) set_property( TARGET @@ -71,6 +69,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/formats/arrow/ut/CMakeLists.windows-x86_64.txt b/ydb/core/formats/arrow/ut/CMakeLists.windows-x86_64.txt index 81d16205ae45..47cd1cd804c7 100644 --- a/ydb/core/formats/arrow/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/formats/arrow/ut/CMakeLists.windows-x86_64.txt @@ -34,6 +34,7 @@ target_sources(ydb-core-formats-arrow-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut/ut_dictionary.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut/ut_size_calcer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut/ut_column_filter.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/ut/ut_hash.cpp ) set_property( TARGET @@ -60,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/actors/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/actors/CMakeLists.darwin-arm64.txt index b4306c62f894..9912e950ebf2 100644 --- a/ydb/core/fq/libs/actors/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/actors/CMakeLists.darwin-arm64.txt @@ -54,7 +54,7 @@ target_link_libraries(fq-libs-actors PUBLIC yql-core-facade core-services-mounts dq-integration-transform - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-codec providers-common-comp_nodes providers-common-db_id_async_resolver diff --git a/ydb/core/fq/libs/actors/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/actors/CMakeLists.darwin-x86_64.txt index b4306c62f894..9912e950ebf2 100644 --- a/ydb/core/fq/libs/actors/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/actors/CMakeLists.darwin-x86_64.txt @@ -54,7 +54,7 @@ target_link_libraries(fq-libs-actors PUBLIC yql-core-facade core-services-mounts dq-integration-transform - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-codec providers-common-comp_nodes providers-common-db_id_async_resolver diff --git a/ydb/core/fq/libs/actors/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/actors/CMakeLists.linux-aarch64.txt index 31d7e557ca88..d60053d12b56 100644 --- a/ydb/core/fq/libs/actors/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/actors/CMakeLists.linux-aarch64.txt @@ -55,7 +55,7 @@ target_link_libraries(fq-libs-actors PUBLIC yql-core-facade core-services-mounts dq-integration-transform - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-codec providers-common-comp_nodes providers-common-db_id_async_resolver diff --git a/ydb/core/fq/libs/actors/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/actors/CMakeLists.linux-x86_64.txt index 31d7e557ca88..d60053d12b56 100644 --- a/ydb/core/fq/libs/actors/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/actors/CMakeLists.linux-x86_64.txt @@ -55,7 +55,7 @@ target_link_libraries(fq-libs-actors PUBLIC yql-core-facade core-services-mounts dq-integration-transform - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-codec providers-common-comp_nodes providers-common-db_id_async_resolver diff --git a/ydb/core/fq/libs/actors/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/actors/CMakeLists.windows-x86_64.txt index b4306c62f894..9912e950ebf2 100644 --- a/ydb/core/fq/libs/actors/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/actors/CMakeLists.windows-x86_64.txt @@ -54,7 +54,7 @@ target_link_libraries(fq-libs-actors PUBLIC yql-core-facade core-services-mounts dq-integration-transform - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-codec providers-common-comp_nodes providers-common-db_id_async_resolver diff --git a/ydb/core/fq/libs/actors/logging/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/actors/logging/CMakeLists.darwin-arm64.txt index 54ca068fe90e..ad8c2c1040f1 100644 --- a/ydb/core/fq/libs/actors/logging/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/actors/logging/CMakeLists.darwin-arm64.txt @@ -14,3 +14,6 @@ target_link_libraries(libs-actors-logging INTERFACE library-actors-core ydb-core-protos ) +target_sources(libs-actors-logging INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/actors/logging/log.h +) diff --git a/ydb/core/fq/libs/actors/logging/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/actors/logging/CMakeLists.darwin-x86_64.txt index 54ca068fe90e..ad8c2c1040f1 100644 --- a/ydb/core/fq/libs/actors/logging/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/actors/logging/CMakeLists.darwin-x86_64.txt @@ -14,3 +14,6 @@ target_link_libraries(libs-actors-logging INTERFACE library-actors-core ydb-core-protos ) +target_sources(libs-actors-logging INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/actors/logging/log.h +) diff --git a/ydb/core/fq/libs/actors/logging/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/actors/logging/CMakeLists.linux-aarch64.txt index 562d8c1637b2..05344586d623 100644 --- a/ydb/core/fq/libs/actors/logging/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/actors/logging/CMakeLists.linux-aarch64.txt @@ -15,3 +15,6 @@ target_link_libraries(libs-actors-logging INTERFACE library-actors-core ydb-core-protos ) +target_sources(libs-actors-logging INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/actors/logging/log.h +) diff --git a/ydb/core/fq/libs/actors/logging/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/actors/logging/CMakeLists.linux-x86_64.txt index 562d8c1637b2..05344586d623 100644 --- a/ydb/core/fq/libs/actors/logging/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/actors/logging/CMakeLists.linux-x86_64.txt @@ -15,3 +15,6 @@ target_link_libraries(libs-actors-logging INTERFACE library-actors-core ydb-core-protos ) +target_sources(libs-actors-logging INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/actors/logging/log.h +) diff --git a/ydb/core/fq/libs/actors/logging/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/actors/logging/CMakeLists.windows-x86_64.txt index 54ca068fe90e..ad8c2c1040f1 100644 --- a/ydb/core/fq/libs/actors/logging/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/actors/logging/CMakeLists.windows-x86_64.txt @@ -14,3 +14,6 @@ target_link_libraries(libs-actors-logging INTERFACE library-actors-core ydb-core-protos ) +target_sources(libs-actors-logging INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/actors/logging/log.h +) diff --git a/ydb/core/fq/libs/actors/ut/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/actors/ut/CMakeLists.darwin-arm64.txt index 72c3b166f618..4c0b53124cf0 100644 --- a/ydb/core/fq/libs/actors/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/actors/ut/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-fq-libs-actors-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-fq-libs-actors-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/actors/ut/database_resolver_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/actors/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/actors/ut/CMakeLists.darwin-x86_64.txt index ae525b4d8cb1..faabc0915f44 100644 --- a/ydb/core/fq/libs/actors/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/actors/ut/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-fq-libs-actors-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-fq-libs-actors-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/actors/ut/database_resolver_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/actors/ut/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/actors/ut/CMakeLists.linux-aarch64.txt index ea0437ff4f0d..c6290ed93bee 100644 --- a/ydb/core/fq/libs/actors/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/actors/ut/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-fq-libs-actors-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-fq-libs-actors-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/actors/ut/database_resolver_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/actors/ut/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/actors/ut/CMakeLists.linux-x86_64.txt index f9a7e0bdc2b9..ff0f4c390361 100644 --- a/ydb/core/fq/libs/actors/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/actors/ut/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-fq-libs-actors-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-fq-libs-actors-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/actors/ut/database_resolver_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/actors/ut/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/actors/ut/CMakeLists.windows-x86_64.txt index 54271f5e5128..a4d5c413b131 100644 --- a/ydb/core/fq/libs/actors/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/actors/ut/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/checkpoint_storage/proto/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/checkpoint_storage/proto/CMakeLists.darwin-arm64.txt index b2ae1bcd7663..b83aa27e6a78 100644 --- a/ydb/core/fq/libs/checkpoint_storage/proto/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/checkpoint_storage/proto/CMakeLists.darwin-arm64.txt @@ -29,6 +29,9 @@ target_link_libraries(libs-checkpoint_storage-proto PUBLIC target_proto_messages(libs-checkpoint_storage-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpoint_storage/proto/graph_description.proto ) +target_sources(libs-checkpoint_storage-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/checkpoint_storage/proto/graph_description.pb.h +) target_proto_addincls(libs-checkpoint_storage-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/checkpoint_storage/proto/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/checkpoint_storage/proto/CMakeLists.darwin-x86_64.txt index b2ae1bcd7663..b83aa27e6a78 100644 --- a/ydb/core/fq/libs/checkpoint_storage/proto/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/checkpoint_storage/proto/CMakeLists.darwin-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(libs-checkpoint_storage-proto PUBLIC target_proto_messages(libs-checkpoint_storage-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpoint_storage/proto/graph_description.proto ) +target_sources(libs-checkpoint_storage-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/checkpoint_storage/proto/graph_description.pb.h +) target_proto_addincls(libs-checkpoint_storage-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/checkpoint_storage/proto/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/checkpoint_storage/proto/CMakeLists.linux-aarch64.txt index 568b2ed66f62..dc94745c6571 100644 --- a/ydb/core/fq/libs/checkpoint_storage/proto/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/checkpoint_storage/proto/CMakeLists.linux-aarch64.txt @@ -30,6 +30,9 @@ target_link_libraries(libs-checkpoint_storage-proto PUBLIC target_proto_messages(libs-checkpoint_storage-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpoint_storage/proto/graph_description.proto ) +target_sources(libs-checkpoint_storage-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/checkpoint_storage/proto/graph_description.pb.h +) target_proto_addincls(libs-checkpoint_storage-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/checkpoint_storage/proto/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/checkpoint_storage/proto/CMakeLists.linux-x86_64.txt index 568b2ed66f62..dc94745c6571 100644 --- a/ydb/core/fq/libs/checkpoint_storage/proto/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/checkpoint_storage/proto/CMakeLists.linux-x86_64.txt @@ -30,6 +30,9 @@ target_link_libraries(libs-checkpoint_storage-proto PUBLIC target_proto_messages(libs-checkpoint_storage-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpoint_storage/proto/graph_description.proto ) +target_sources(libs-checkpoint_storage-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/checkpoint_storage/proto/graph_description.pb.h +) target_proto_addincls(libs-checkpoint_storage-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/checkpoint_storage/proto/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/checkpoint_storage/proto/CMakeLists.windows-x86_64.txt index b2ae1bcd7663..b83aa27e6a78 100644 --- a/ydb/core/fq/libs/checkpoint_storage/proto/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/checkpoint_storage/proto/CMakeLists.windows-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(libs-checkpoint_storage-proto PUBLIC target_proto_messages(libs-checkpoint_storage-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpoint_storage/proto/graph_description.proto ) +target_sources(libs-checkpoint_storage-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/checkpoint_storage/proto/graph_description.pb.h +) target_proto_addincls(libs-checkpoint_storage-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/checkpoint_storage/ut/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/checkpoint_storage/ut/CMakeLists.darwin-arm64.txt index 4f58e8923b92..26f53e4c1462 100644 --- a/ydb/core/fq/libs/checkpoint_storage/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/checkpoint_storage/ut/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-fq-libs-checkpoint_storage-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-fq-libs-checkpoint_storage-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpoint_storage/ut/gc_ut.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/checkpoint_storage/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/checkpoint_storage/ut/CMakeLists.darwin-x86_64.txt index c1bca4ee9751..041c632291e5 100644 --- a/ydb/core/fq/libs/checkpoint_storage/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/checkpoint_storage/ut/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-fq-libs-checkpoint_storage-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-fq-libs-checkpoint_storage-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpoint_storage/ut/gc_ut.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/checkpoint_storage/ut/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/checkpoint_storage/ut/CMakeLists.linux-aarch64.txt index d498b8f82bf5..6f4a3a7edb63 100644 --- a/ydb/core/fq/libs/checkpoint_storage/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/checkpoint_storage/ut/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-fq-libs-checkpoint_storage-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-fq-libs-checkpoint_storage-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpoint_storage/ut/gc_ut.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/checkpoint_storage/ut/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/checkpoint_storage/ut/CMakeLists.linux-x86_64.txt index 8881dbebf17a..a51d37224ddd 100644 --- a/ydb/core/fq/libs/checkpoint_storage/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/checkpoint_storage/ut/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-fq-libs-checkpoint_storage-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-fq-libs-checkpoint_storage-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpoint_storage/ut/gc_ut.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/checkpoint_storage/ut/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/checkpoint_storage/ut/CMakeLists.windows-x86_64.txt index b384b0f5d99f..4cf1ded81a8b 100644 --- a/ydb/core/fq/libs/checkpoint_storage/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/checkpoint_storage/ut/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/checkpointing/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/checkpointing/CMakeLists.darwin-arm64.txt index e2e4a2e77b77..0f62f3be509e 100644 --- a/ydb/core/fq/libs/checkpointing/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/checkpointing/CMakeLists.darwin-arm64.txt @@ -26,6 +26,10 @@ target_link_libraries(fq-libs-checkpointing PUBLIC dq-api-protos ) target_sources(fq-libs-checkpointing PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/checkpoint_coordinator.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/checkpoint_id_generator.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/pending_checkpoint.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/utils.h ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/checkpoint_coordinator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/checkpoint_id_generator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/pending_checkpoint.cpp diff --git a/ydb/core/fq/libs/checkpointing/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/checkpointing/CMakeLists.darwin-x86_64.txt index e2e4a2e77b77..0f62f3be509e 100644 --- a/ydb/core/fq/libs/checkpointing/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/checkpointing/CMakeLists.darwin-x86_64.txt @@ -26,6 +26,10 @@ target_link_libraries(fq-libs-checkpointing PUBLIC dq-api-protos ) target_sources(fq-libs-checkpointing PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/checkpoint_coordinator.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/checkpoint_id_generator.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/pending_checkpoint.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/utils.h ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/checkpoint_coordinator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/checkpoint_id_generator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/pending_checkpoint.cpp diff --git a/ydb/core/fq/libs/checkpointing/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/checkpointing/CMakeLists.linux-aarch64.txt index 5353b351c754..3ba7575f88d9 100644 --- a/ydb/core/fq/libs/checkpointing/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/checkpointing/CMakeLists.linux-aarch64.txt @@ -27,6 +27,10 @@ target_link_libraries(fq-libs-checkpointing PUBLIC dq-api-protos ) target_sources(fq-libs-checkpointing PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/checkpoint_coordinator.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/checkpoint_id_generator.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/pending_checkpoint.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/utils.h ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/checkpoint_coordinator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/checkpoint_id_generator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/pending_checkpoint.cpp diff --git a/ydb/core/fq/libs/checkpointing/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/checkpointing/CMakeLists.linux-x86_64.txt index 5353b351c754..3ba7575f88d9 100644 --- a/ydb/core/fq/libs/checkpointing/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/checkpointing/CMakeLists.linux-x86_64.txt @@ -27,6 +27,10 @@ target_link_libraries(fq-libs-checkpointing PUBLIC dq-api-protos ) target_sources(fq-libs-checkpointing PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/checkpoint_coordinator.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/checkpoint_id_generator.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/pending_checkpoint.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/utils.h ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/checkpoint_coordinator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/checkpoint_id_generator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/pending_checkpoint.cpp diff --git a/ydb/core/fq/libs/checkpointing/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/checkpointing/CMakeLists.windows-x86_64.txt index e2e4a2e77b77..0f62f3be509e 100644 --- a/ydb/core/fq/libs/checkpointing/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/checkpointing/CMakeLists.windows-x86_64.txt @@ -26,6 +26,10 @@ target_link_libraries(fq-libs-checkpointing PUBLIC dq-api-protos ) target_sources(fq-libs-checkpointing PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/checkpoint_coordinator.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/checkpoint_id_generator.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/pending_checkpoint.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/utils.h ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/checkpoint_coordinator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/checkpoint_id_generator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/pending_checkpoint.cpp diff --git a/ydb/core/fq/libs/checkpointing/ut/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/checkpointing/ut/CMakeLists.darwin-arm64.txt index bf8ee490c33a..8da1322129ad 100644 --- a/ydb/core/fq/libs/checkpointing/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/checkpointing/ut/CMakeLists.darwin-arm64.txt @@ -22,13 +22,12 @@ target_link_libraries(ydb-core-fq-libs-checkpointing-ut PUBLIC cpp-testing-unittest core-testlib-actors testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-core-fq-libs-checkpointing-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-fq-libs-checkpointing-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/ut/checkpoint_coordinator_ut.cpp @@ -58,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/checkpointing/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/checkpointing/ut/CMakeLists.darwin-x86_64.txt index f680e0bab507..ce11c6b10b27 100644 --- a/ydb/core/fq/libs/checkpointing/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/checkpointing/ut/CMakeLists.darwin-x86_64.txt @@ -23,13 +23,12 @@ target_link_libraries(ydb-core-fq-libs-checkpointing-ut PUBLIC cpp-testing-unittest core-testlib-actors testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-core-fq-libs-checkpointing-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-fq-libs-checkpointing-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/ut/checkpoint_coordinator_ut.cpp @@ -59,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/checkpointing/ut/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/checkpointing/ut/CMakeLists.linux-aarch64.txt index 4e06e6e2fc00..a9c1d7d00fd5 100644 --- a/ydb/core/fq/libs/checkpointing/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/checkpointing/ut/CMakeLists.linux-aarch64.txt @@ -23,6 +23,7 @@ target_link_libraries(ydb-core-fq-libs-checkpointing-ut PUBLIC cpp-testing-unittest core-testlib-actors testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-core-fq-libs-checkpointing-ut PRIVATE -ldl @@ -30,9 +31,6 @@ target_link_options(ydb-core-fq-libs-checkpointing-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-fq-libs-checkpointing-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/ut/checkpoint_coordinator_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/checkpointing/ut/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/checkpointing/ut/CMakeLists.linux-x86_64.txt index 9d64108808c6..6b22a8ca6894 100644 --- a/ydb/core/fq/libs/checkpointing/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/checkpointing/ut/CMakeLists.linux-x86_64.txt @@ -24,6 +24,7 @@ target_link_libraries(ydb-core-fq-libs-checkpointing-ut PUBLIC cpp-testing-unittest core-testlib-actors testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-core-fq-libs-checkpointing-ut PRIVATE -ldl @@ -31,9 +32,6 @@ target_link_options(ydb-core-fq-libs-checkpointing-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-fq-libs-checkpointing-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/ut/checkpoint_coordinator_ut.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/checkpointing/ut/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/checkpointing/ut/CMakeLists.windows-x86_64.txt index 3b0fceb7c6ef..e3cb7b126792 100644 --- a/ydb/core/fq/libs/checkpointing/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/checkpointing/ut/CMakeLists.windows-x86_64.txt @@ -23,6 +23,7 @@ target_link_libraries(ydb-core-fq-libs-checkpointing-ut PUBLIC cpp-testing-unittest core-testlib-actors testlib-basics-default + minikql-comp_nodes-llvm14 ) target_sources(ydb-core-fq-libs-checkpointing-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/checkpointing/ut/checkpoint_coordinator_ut.cpp @@ -52,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/common/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/common/CMakeLists.darwin-arm64.txt index 3f433561b010..9f2bc5e93896 100644 --- a/ydb/core/fq/libs/common/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/common/CMakeLists.darwin-arm64.txt @@ -30,6 +30,10 @@ target_link_libraries(fq-libs-common PUBLIC api-protos ) target_sources(fq-libs-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/compression.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/entity_id.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/rows_proto_splitter.h ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/compression.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/debug_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/entity_id.cpp diff --git a/ydb/core/fq/libs/common/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/common/CMakeLists.darwin-x86_64.txt index 3f433561b010..9f2bc5e93896 100644 --- a/ydb/core/fq/libs/common/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/common/CMakeLists.darwin-x86_64.txt @@ -30,6 +30,10 @@ target_link_libraries(fq-libs-common PUBLIC api-protos ) target_sources(fq-libs-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/compression.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/entity_id.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/rows_proto_splitter.h ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/compression.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/debug_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/entity_id.cpp diff --git a/ydb/core/fq/libs/common/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/common/CMakeLists.linux-aarch64.txt index 008f49085bcf..180c0b5585bb 100644 --- a/ydb/core/fq/libs/common/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/common/CMakeLists.linux-aarch64.txt @@ -31,6 +31,10 @@ target_link_libraries(fq-libs-common PUBLIC api-protos ) target_sources(fq-libs-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/compression.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/entity_id.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/rows_proto_splitter.h ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/compression.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/debug_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/entity_id.cpp diff --git a/ydb/core/fq/libs/common/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/common/CMakeLists.linux-x86_64.txt index 008f49085bcf..180c0b5585bb 100644 --- a/ydb/core/fq/libs/common/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/common/CMakeLists.linux-x86_64.txt @@ -31,6 +31,10 @@ target_link_libraries(fq-libs-common PUBLIC api-protos ) target_sources(fq-libs-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/compression.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/entity_id.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/rows_proto_splitter.h ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/compression.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/debug_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/entity_id.cpp diff --git a/ydb/core/fq/libs/common/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/common/CMakeLists.windows-x86_64.txt index 3f433561b010..9f2bc5e93896 100644 --- a/ydb/core/fq/libs/common/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/common/CMakeLists.windows-x86_64.txt @@ -30,6 +30,10 @@ target_link_libraries(fq-libs-common PUBLIC api-protos ) target_sources(fq-libs-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/compression.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/entity_id.h + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/rows_proto_splitter.h ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/compression.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/debug_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/entity_id.cpp diff --git a/ydb/core/fq/libs/common/ut/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/common/ut/CMakeLists.darwin-arm64.txt index 0bae2a0e64c9..1e7d228ec20a 100644 --- a/ydb/core/fq/libs/common/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/common/ut/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-fq-libs-common-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-fq-libs-common-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/cache_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/common/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/common/ut/CMakeLists.darwin-x86_64.txt index caf6cbb853c6..e70e53b30b60 100644 --- a/ydb/core/fq/libs/common/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/common/ut/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-fq-libs-common-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-fq-libs-common-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/cache_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/common/ut/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/common/ut/CMakeLists.linux-aarch64.txt index 6fa8cbdffe49..f36f47acf609 100644 --- a/ydb/core/fq/libs/common/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/common/ut/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-fq-libs-common-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-fq-libs-common-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/cache_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/common/ut/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/common/ut/CMakeLists.linux-x86_64.txt index b8e15f89df3e..06884b157d56 100644 --- a/ydb/core/fq/libs/common/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/common/ut/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-fq-libs-common-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-fq-libs-common-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/common/cache_ut.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/common/ut/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/common/ut/CMakeLists.windows-x86_64.txt index 1f681d45effb..368c906303c8 100644 --- a/ydb/core/fq/libs/common/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/common/ut/CMakeLists.windows-x86_64.txt @@ -55,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/compute/common/ut/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/compute/common/ut/CMakeLists.darwin-arm64.txt index a0d043868710..dccf426e2476 100644 --- a/ydb/core/fq/libs/compute/common/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/compute/common/ut/CMakeLists.darwin-arm64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-core-fq-libs-compute-common-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-fq-libs-compute-common-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/common/ut/config_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/compute/common/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/compute/common/ut/CMakeLists.darwin-x86_64.txt index 9971099bf195..6e4ea6c151b0 100644 --- a/ydb/core/fq/libs/compute/common/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/compute/common/ut/CMakeLists.darwin-x86_64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-fq-libs-compute-common-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-fq-libs-compute-common-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/common/ut/config_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/compute/common/ut/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/compute/common/ut/CMakeLists.linux-aarch64.txt index 71085a1b10f7..071af7528a3c 100644 --- a/ydb/core/fq/libs/compute/common/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/compute/common/ut/CMakeLists.linux-aarch64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-core-fq-libs-compute-common-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-fq-libs-compute-common-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/common/ut/config_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/compute/common/ut/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/compute/common/ut/CMakeLists.linux-x86_64.txt index 41bb55c7ba29..39efea058f95 100644 --- a/ydb/core/fq/libs/compute/common/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/compute/common/ut/CMakeLists.linux-x86_64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-fq-libs-compute-common-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-fq-libs-compute-common-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/common/ut/config_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/compute/common/ut/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/compute/common/ut/CMakeLists.windows-x86_64.txt index 587644432083..da4957865be2 100644 --- a/ydb/core/fq/libs/compute/common/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/compute/common/ut/CMakeLists.windows-x86_64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/compute/ydb/control_plane/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/compute/ydb/control_plane/CMakeLists.darwin-arm64.txt index ff859935b9b1..20a3643fc91d 100644 --- a/ydb/core/fq/libs/compute/ydb/control_plane/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/compute/ydb/control_plane/CMakeLists.darwin-arm64.txt @@ -30,5 +30,7 @@ target_sources(compute-ydb-control_plane PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/cms_grpc_client_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/compute_database_control_plane_service.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/compute_databases_cache.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/database_monitoring.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/monitoring_grpc_client_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/ydbcp_grpc_client_actor.cpp ) diff --git a/ydb/core/fq/libs/compute/ydb/control_plane/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/compute/ydb/control_plane/CMakeLists.darwin-x86_64.txt index ff859935b9b1..20a3643fc91d 100644 --- a/ydb/core/fq/libs/compute/ydb/control_plane/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/compute/ydb/control_plane/CMakeLists.darwin-x86_64.txt @@ -30,5 +30,7 @@ target_sources(compute-ydb-control_plane PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/cms_grpc_client_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/compute_database_control_plane_service.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/compute_databases_cache.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/database_monitoring.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/monitoring_grpc_client_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/ydbcp_grpc_client_actor.cpp ) diff --git a/ydb/core/fq/libs/compute/ydb/control_plane/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/compute/ydb/control_plane/CMakeLists.linux-aarch64.txt index e57ea9e9ab52..1e7e69d75c02 100644 --- a/ydb/core/fq/libs/compute/ydb/control_plane/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/compute/ydb/control_plane/CMakeLists.linux-aarch64.txt @@ -31,5 +31,7 @@ target_sources(compute-ydb-control_plane PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/cms_grpc_client_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/compute_database_control_plane_service.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/compute_databases_cache.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/database_monitoring.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/monitoring_grpc_client_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/ydbcp_grpc_client_actor.cpp ) diff --git a/ydb/core/fq/libs/compute/ydb/control_plane/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/compute/ydb/control_plane/CMakeLists.linux-x86_64.txt index e57ea9e9ab52..1e7e69d75c02 100644 --- a/ydb/core/fq/libs/compute/ydb/control_plane/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/compute/ydb/control_plane/CMakeLists.linux-x86_64.txt @@ -31,5 +31,7 @@ target_sources(compute-ydb-control_plane PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/cms_grpc_client_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/compute_database_control_plane_service.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/compute_databases_cache.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/database_monitoring.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/monitoring_grpc_client_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/ydbcp_grpc_client_actor.cpp ) diff --git a/ydb/core/fq/libs/compute/ydb/control_plane/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/compute/ydb/control_plane/CMakeLists.windows-x86_64.txt index ff859935b9b1..20a3643fc91d 100644 --- a/ydb/core/fq/libs/compute/ydb/control_plane/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/compute/ydb/control_plane/CMakeLists.windows-x86_64.txt @@ -30,5 +30,7 @@ target_sources(compute-ydb-control_plane PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/cms_grpc_client_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/compute_database_control_plane_service.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/compute_databases_cache.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/database_monitoring.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/monitoring_grpc_client_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/compute/ydb/control_plane/ydbcp_grpc_client_actor.cpp ) diff --git a/ydb/core/fq/libs/config/protos/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/config/protos/CMakeLists.darwin-arm64.txt index af844d5199ba..59b1451c88ee 100644 --- a/ydb/core/fq/libs/config/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/config/protos/CMakeLists.darwin-arm64.txt @@ -331,6 +331,32 @@ target_proto_messages(libs-config-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/config/protos/test_connection.proto ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/config/protos/token_accessor.proto ) +target_sources(libs-config-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/activation.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/audit.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/checkpoint_coordinator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/common.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/compute.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/control_plane_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/control_plane_storage.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/db_pool.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/fq_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/gateways.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/health_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/issue_id.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/nodes_manager.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/pending_fetcher.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/pinger.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/private_api.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/private_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/quotas_manager.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/rate_limiter.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/read_actors_factory.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/resource_manager.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/storage.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/test_connection.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/token_accessor.pb.h +) target_proto_addincls(libs-config-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/config/protos/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/config/protos/CMakeLists.darwin-x86_64.txt index af844d5199ba..59b1451c88ee 100644 --- a/ydb/core/fq/libs/config/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/config/protos/CMakeLists.darwin-x86_64.txt @@ -331,6 +331,32 @@ target_proto_messages(libs-config-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/config/protos/test_connection.proto ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/config/protos/token_accessor.proto ) +target_sources(libs-config-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/activation.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/audit.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/checkpoint_coordinator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/common.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/compute.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/control_plane_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/control_plane_storage.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/db_pool.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/fq_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/gateways.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/health_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/issue_id.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/nodes_manager.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/pending_fetcher.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/pinger.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/private_api.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/private_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/quotas_manager.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/rate_limiter.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/read_actors_factory.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/resource_manager.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/storage.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/test_connection.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/token_accessor.pb.h +) target_proto_addincls(libs-config-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/config/protos/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/config/protos/CMakeLists.linux-aarch64.txt index 494977cd87e1..9f31747030b2 100644 --- a/ydb/core/fq/libs/config/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/config/protos/CMakeLists.linux-aarch64.txt @@ -332,6 +332,32 @@ target_proto_messages(libs-config-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/config/protos/test_connection.proto ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/config/protos/token_accessor.proto ) +target_sources(libs-config-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/activation.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/audit.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/checkpoint_coordinator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/common.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/compute.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/control_plane_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/control_plane_storage.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/db_pool.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/fq_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/gateways.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/health_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/issue_id.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/nodes_manager.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/pending_fetcher.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/pinger.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/private_api.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/private_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/quotas_manager.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/rate_limiter.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/read_actors_factory.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/resource_manager.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/storage.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/test_connection.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/token_accessor.pb.h +) target_proto_addincls(libs-config-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/config/protos/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/config/protos/CMakeLists.linux-x86_64.txt index 494977cd87e1..9f31747030b2 100644 --- a/ydb/core/fq/libs/config/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/config/protos/CMakeLists.linux-x86_64.txt @@ -332,6 +332,32 @@ target_proto_messages(libs-config-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/config/protos/test_connection.proto ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/config/protos/token_accessor.proto ) +target_sources(libs-config-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/activation.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/audit.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/checkpoint_coordinator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/common.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/compute.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/control_plane_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/control_plane_storage.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/db_pool.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/fq_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/gateways.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/health_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/issue_id.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/nodes_manager.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/pending_fetcher.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/pinger.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/private_api.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/private_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/quotas_manager.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/rate_limiter.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/read_actors_factory.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/resource_manager.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/storage.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/test_connection.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/token_accessor.pb.h +) target_proto_addincls(libs-config-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/config/protos/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/config/protos/CMakeLists.windows-x86_64.txt index af844d5199ba..59b1451c88ee 100644 --- a/ydb/core/fq/libs/config/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/config/protos/CMakeLists.windows-x86_64.txt @@ -331,6 +331,32 @@ target_proto_messages(libs-config-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/config/protos/test_connection.proto ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/config/protos/token_accessor.proto ) +target_sources(libs-config-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/activation.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/audit.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/checkpoint_coordinator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/common.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/compute.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/control_plane_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/control_plane_storage.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/db_pool.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/fq_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/gateways.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/health_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/issue_id.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/nodes_manager.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/pending_fetcher.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/pinger.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/private_api.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/private_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/quotas_manager.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/rate_limiter.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/read_actors_factory.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/resource_manager.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/storage.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/test_connection.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/config/protos/token_accessor.pb.h +) target_proto_addincls(libs-config-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/control_plane_proxy/ut/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/control_plane_proxy/ut/CMakeLists.darwin-arm64.txt index 2d8f5b7c89bd..ce7cd24281a4 100644 --- a/ydb/core/fq/libs/control_plane_proxy/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/control_plane_proxy/ut/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-fq-libs-control_plane_proxy-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-fq-libs-control_plane_proxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_proxy/ut/control_plane_proxy_ut.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/control_plane_proxy/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/control_plane_proxy/ut/CMakeLists.darwin-x86_64.txt index f0233522fe2e..6fced308b4c4 100644 --- a/ydb/core/fq/libs/control_plane_proxy/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/control_plane_proxy/ut/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-fq-libs-control_plane_proxy-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-fq-libs-control_plane_proxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_proxy/ut/control_plane_proxy_ut.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/control_plane_proxy/ut/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/control_plane_proxy/ut/CMakeLists.linux-aarch64.txt index 7cf6780bc847..9735ff8f34ea 100644 --- a/ydb/core/fq/libs/control_plane_proxy/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/control_plane_proxy/ut/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-fq-libs-control_plane_proxy-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-fq-libs-control_plane_proxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_proxy/ut/control_plane_proxy_ut.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/control_plane_proxy/ut/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/control_plane_proxy/ut/CMakeLists.linux-x86_64.txt index e59c8cbdb52b..cbf9e6f81096 100644 --- a/ydb/core/fq/libs/control_plane_proxy/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/control_plane_proxy/ut/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-fq-libs-control_plane_proxy-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-fq-libs-control_plane_proxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_proxy/ut/control_plane_proxy_ut.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/control_plane_proxy/ut/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/control_plane_proxy/ut/CMakeLists.windows-x86_64.txt index fdc1a06c29da..9b49b658db48 100644 --- a/ydb/core/fq/libs/control_plane_proxy/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/control_plane_proxy/ut/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/control_plane_storage/internal/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/control_plane_storage/internal/CMakeLists.darwin-arm64.txt index 713689d16d38..b7f978579da8 100644 --- a/ydb/core/fq/libs/control_plane_storage/internal/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/control_plane_storage/internal/CMakeLists.darwin-arm64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(ut) add_library(libs-control_plane_storage-internal) target_compile_options(libs-control_plane_storage-internal PRIVATE @@ -14,6 +15,7 @@ target_compile_options(libs-control_plane_storage-internal PRIVATE target_link_libraries(libs-control_plane_storage-internal PUBLIC contrib-libs-cxxsupp yutil + contrib-libs-fmt library-actors-core cpp-lwtrace-mon monlib-service-pages diff --git a/ydb/core/fq/libs/control_plane_storage/internal/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/control_plane_storage/internal/CMakeLists.darwin-x86_64.txt index 713689d16d38..b7f978579da8 100644 --- a/ydb/core/fq/libs/control_plane_storage/internal/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/control_plane_storage/internal/CMakeLists.darwin-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(ut) add_library(libs-control_plane_storage-internal) target_compile_options(libs-control_plane_storage-internal PRIVATE @@ -14,6 +15,7 @@ target_compile_options(libs-control_plane_storage-internal PRIVATE target_link_libraries(libs-control_plane_storage-internal PUBLIC contrib-libs-cxxsupp yutil + contrib-libs-fmt library-actors-core cpp-lwtrace-mon monlib-service-pages diff --git a/ydb/core/fq/libs/control_plane_storage/internal/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/control_plane_storage/internal/CMakeLists.linux-aarch64.txt index a583ef2667b3..326139f8cde5 100644 --- a/ydb/core/fq/libs/control_plane_storage/internal/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/control_plane_storage/internal/CMakeLists.linux-aarch64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(ut) add_library(libs-control_plane_storage-internal) target_compile_options(libs-control_plane_storage-internal PRIVATE @@ -15,6 +16,7 @@ target_link_libraries(libs-control_plane_storage-internal PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + contrib-libs-fmt library-actors-core cpp-lwtrace-mon monlib-service-pages diff --git a/ydb/core/fq/libs/control_plane_storage/internal/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/control_plane_storage/internal/CMakeLists.linux-x86_64.txt index a583ef2667b3..326139f8cde5 100644 --- a/ydb/core/fq/libs/control_plane_storage/internal/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/control_plane_storage/internal/CMakeLists.linux-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(ut) add_library(libs-control_plane_storage-internal) target_compile_options(libs-control_plane_storage-internal PRIVATE @@ -15,6 +16,7 @@ target_link_libraries(libs-control_plane_storage-internal PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + contrib-libs-fmt library-actors-core cpp-lwtrace-mon monlib-service-pages diff --git a/ydb/core/fq/libs/control_plane_storage/internal/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/control_plane_storage/internal/CMakeLists.windows-x86_64.txt index 713689d16d38..b7f978579da8 100644 --- a/ydb/core/fq/libs/control_plane_storage/internal/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/control_plane_storage/internal/CMakeLists.windows-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(ut) add_library(libs-control_plane_storage-internal) target_compile_options(libs-control_plane_storage-internal PRIVATE @@ -14,6 +15,7 @@ target_compile_options(libs-control_plane_storage-internal PRIVATE target_link_libraries(libs-control_plane_storage-internal PUBLIC contrib-libs-cxxsupp yutil + contrib-libs-fmt library-actors-core cpp-lwtrace-mon monlib-service-pages diff --git a/ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..9b10f9f1e926 --- /dev/null +++ b/ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.darwin-arm64.txt @@ -0,0 +1,96 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_rescompiler_bin + TOOL_rescompiler_dependency + tools/rescompiler/bin + rescompiler +) + +add_executable(core-fq-libs-control_plane_storage-internal-ut) +target_compile_options(core-fq-libs-control_plane_storage-internal-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(core-fq-libs-control_plane_storage-internal-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal +) +target_link_libraries(core-fq-libs-control_plane_storage-internal-ut PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + libs-control_plane_storage-internal + cpp-testing-unittest + cpp-json-yson + udf-service-stub + library-cpp-resource +) +target_link_options(core-fq-libs-control_plane_storage-internal-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(core-fq-libs-control_plane_storage-internal-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/utils_ut.cpp + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/047a4c3f0575d8af7f0dc67f808daaba.cpp +) +set_property( + TARGET + core-fq-libs-control_plane_storage-internal-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + core-fq-libs-control_plane_storage-internal-ut + TEST_TARGET + core-fq-libs-control_plane_storage-internal-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + core-fq-libs-control_plane_storage-internal-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + core-fq-libs-control_plane_storage-internal-ut + PROPERTY + PROCESSORS + 1 +) +resources(core-fq-libs-control_plane_storage-internal-ut + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/047a4c3f0575d8af7f0dc67f808daaba.cpp + INPUTS + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v1_output.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v2_output.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v1_s3source.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v2_s3source.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v1_two_results.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v2_two_results.json + KEYS + v1_output.json + v2_output.json + v1_s3source.json + v2_s3source.json + v1_two_results.json + v2_two_results.json +) +target_allocator(core-fq-libs-control_plane_storage-internal-ut + system_allocator +) +vcs_info(core-fq-libs-control_plane_storage-internal-ut) diff --git a/ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..298873f4cc0f --- /dev/null +++ b/ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,97 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_rescompiler_bin + TOOL_rescompiler_dependency + tools/rescompiler/bin + rescompiler +) + +add_executable(core-fq-libs-control_plane_storage-internal-ut) +target_compile_options(core-fq-libs-control_plane_storage-internal-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(core-fq-libs-control_plane_storage-internal-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal +) +target_link_libraries(core-fq-libs-control_plane_storage-internal-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + libs-control_plane_storage-internal + cpp-testing-unittest + cpp-json-yson + udf-service-stub + library-cpp-resource +) +target_link_options(core-fq-libs-control_plane_storage-internal-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(core-fq-libs-control_plane_storage-internal-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/utils_ut.cpp + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/047a4c3f0575d8af7f0dc67f808daaba.cpp +) +set_property( + TARGET + core-fq-libs-control_plane_storage-internal-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + core-fq-libs-control_plane_storage-internal-ut + TEST_TARGET + core-fq-libs-control_plane_storage-internal-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + core-fq-libs-control_plane_storage-internal-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + core-fq-libs-control_plane_storage-internal-ut + PROPERTY + PROCESSORS + 1 +) +resources(core-fq-libs-control_plane_storage-internal-ut + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/047a4c3f0575d8af7f0dc67f808daaba.cpp + INPUTS + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v1_output.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v2_output.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v1_s3source.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v2_s3source.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v1_two_results.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v2_two_results.json + KEYS + v1_output.json + v2_output.json + v1_s3source.json + v2_s3source.json + v1_two_results.json + v2_two_results.json +) +target_allocator(core-fq-libs-control_plane_storage-internal-ut + system_allocator +) +vcs_info(core-fq-libs-control_plane_storage-internal-ut) diff --git a/ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..13de4e657a12 --- /dev/null +++ b/ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.linux-aarch64.txt @@ -0,0 +1,99 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_rescompiler_bin + TOOL_rescompiler_dependency + tools/rescompiler/bin + rescompiler +) + +add_executable(core-fq-libs-control_plane_storage-internal-ut) +target_compile_options(core-fq-libs-control_plane_storage-internal-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(core-fq-libs-control_plane_storage-internal-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal +) +target_link_libraries(core-fq-libs-control_plane_storage-internal-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + libs-control_plane_storage-internal + cpp-testing-unittest + cpp-json-yson + udf-service-stub + library-cpp-resource +) +target_link_options(core-fq-libs-control_plane_storage-internal-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(core-fq-libs-control_plane_storage-internal-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/utils_ut.cpp + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/047a4c3f0575d8af7f0dc67f808daaba.cpp +) +set_property( + TARGET + core-fq-libs-control_plane_storage-internal-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + core-fq-libs-control_plane_storage-internal-ut + TEST_TARGET + core-fq-libs-control_plane_storage-internal-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + core-fq-libs-control_plane_storage-internal-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + core-fq-libs-control_plane_storage-internal-ut + PROPERTY + PROCESSORS + 1 +) +resources(core-fq-libs-control_plane_storage-internal-ut + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/047a4c3f0575d8af7f0dc67f808daaba.cpp + INPUTS + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v1_output.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v2_output.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v1_s3source.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v2_s3source.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v1_two_results.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v2_two_results.json + KEYS + v1_output.json + v2_output.json + v1_s3source.json + v2_s3source.json + v1_two_results.json + v2_two_results.json +) +target_allocator(core-fq-libs-control_plane_storage-internal-ut + cpp-malloc-jemalloc +) +vcs_info(core-fq-libs-control_plane_storage-internal-ut) diff --git a/ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..7d4256f0de43 --- /dev/null +++ b/ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.linux-x86_64.txt @@ -0,0 +1,101 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_rescompiler_bin + TOOL_rescompiler_dependency + tools/rescompiler/bin + rescompiler +) + +add_executable(core-fq-libs-control_plane_storage-internal-ut) +target_compile_options(core-fq-libs-control_plane_storage-internal-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(core-fq-libs-control_plane_storage-internal-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal +) +target_link_libraries(core-fq-libs-control_plane_storage-internal-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + libs-control_plane_storage-internal + cpp-testing-unittest + cpp-json-yson + udf-service-stub + library-cpp-resource +) +target_link_options(core-fq-libs-control_plane_storage-internal-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(core-fq-libs-control_plane_storage-internal-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/utils_ut.cpp + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/047a4c3f0575d8af7f0dc67f808daaba.cpp +) +set_property( + TARGET + core-fq-libs-control_plane_storage-internal-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + core-fq-libs-control_plane_storage-internal-ut + TEST_TARGET + core-fq-libs-control_plane_storage-internal-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + core-fq-libs-control_plane_storage-internal-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + core-fq-libs-control_plane_storage-internal-ut + PROPERTY + PROCESSORS + 1 +) +resources(core-fq-libs-control_plane_storage-internal-ut + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/047a4c3f0575d8af7f0dc67f808daaba.cpp + INPUTS + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v1_output.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v2_output.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v1_s3source.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v2_s3source.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v1_two_results.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v2_two_results.json + KEYS + v1_output.json + v2_output.json + v1_s3source.json + v2_s3source.json + v1_two_results.json + v2_two_results.json +) +target_allocator(core-fq-libs-control_plane_storage-internal-ut + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(core-fq-libs-control_plane_storage-internal-ut) diff --git a/ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.txt b/ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..4142e4d8ad32 --- /dev/null +++ b/ydb/core/fq/libs/control_plane_storage/internal/ut/CMakeLists.windows-x86_64.txt @@ -0,0 +1,92 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_rescompiler_bin + TOOL_rescompiler_dependency + tools/rescompiler/bin + rescompiler +) + +add_executable(core-fq-libs-control_plane_storage-internal-ut) +target_compile_options(core-fq-libs-control_plane_storage-internal-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(core-fq-libs-control_plane_storage-internal-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal +) +target_link_libraries(core-fq-libs-control_plane_storage-internal-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + libs-control_plane_storage-internal + cpp-testing-unittest + cpp-json-yson + udf-service-stub + library-cpp-resource +) +target_sources(core-fq-libs-control_plane_storage-internal-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/utils_ut.cpp + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/047a4c3f0575d8af7f0dc67f808daaba.cpp +) +set_property( + TARGET + core-fq-libs-control_plane_storage-internal-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + core-fq-libs-control_plane_storage-internal-ut + TEST_TARGET + core-fq-libs-control_plane_storage-internal-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + core-fq-libs-control_plane_storage-internal-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + core-fq-libs-control_plane_storage-internal-ut + PROPERTY + PROCESSORS + 1 +) +resources(core-fq-libs-control_plane_storage-internal-ut + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/047a4c3f0575d8af7f0dc67f808daaba.cpp + INPUTS + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v1_output.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v2_output.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v1_s3source.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v2_s3source.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v1_two_results.json + ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/internal/ut/resources/v2_two_results.json + KEYS + v1_output.json + v2_output.json + v1_s3source.json + v2_s3source.json + v1_two_results.json + v2_two_results.json +) +target_allocator(core-fq-libs-control_plane_storage-internal-ut + system_allocator +) +vcs_info(core-fq-libs-control_plane_storage-internal-ut) diff --git a/ydb/core/fq/libs/control_plane_storage/proto/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/control_plane_storage/proto/CMakeLists.darwin-arm64.txt index 5a1066883e27..ea6d1586403a 100644 --- a/ydb/core/fq/libs/control_plane_storage/proto/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/control_plane_storage/proto/CMakeLists.darwin-arm64.txt @@ -32,6 +32,9 @@ target_link_libraries(libs-control_plane_storage-proto PUBLIC target_proto_messages(libs-control_plane_storage-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/proto/yq_internal.proto ) +target_sources(libs-control_plane_storage-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/control_plane_storage/proto/yq_internal.pb.h +) target_proto_addincls(libs-control_plane_storage-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/control_plane_storage/proto/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/control_plane_storage/proto/CMakeLists.darwin-x86_64.txt index 5a1066883e27..ea6d1586403a 100644 --- a/ydb/core/fq/libs/control_plane_storage/proto/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/control_plane_storage/proto/CMakeLists.darwin-x86_64.txt @@ -32,6 +32,9 @@ target_link_libraries(libs-control_plane_storage-proto PUBLIC target_proto_messages(libs-control_plane_storage-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/proto/yq_internal.proto ) +target_sources(libs-control_plane_storage-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/control_plane_storage/proto/yq_internal.pb.h +) target_proto_addincls(libs-control_plane_storage-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/control_plane_storage/proto/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/control_plane_storage/proto/CMakeLists.linux-aarch64.txt index bb39142ed7de..6bd25c8dad11 100644 --- a/ydb/core/fq/libs/control_plane_storage/proto/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/control_plane_storage/proto/CMakeLists.linux-aarch64.txt @@ -33,6 +33,9 @@ target_link_libraries(libs-control_plane_storage-proto PUBLIC target_proto_messages(libs-control_plane_storage-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/proto/yq_internal.proto ) +target_sources(libs-control_plane_storage-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/control_plane_storage/proto/yq_internal.pb.h +) target_proto_addincls(libs-control_plane_storage-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/control_plane_storage/proto/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/control_plane_storage/proto/CMakeLists.linux-x86_64.txt index bb39142ed7de..6bd25c8dad11 100644 --- a/ydb/core/fq/libs/control_plane_storage/proto/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/control_plane_storage/proto/CMakeLists.linux-x86_64.txt @@ -33,6 +33,9 @@ target_link_libraries(libs-control_plane_storage-proto PUBLIC target_proto_messages(libs-control_plane_storage-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/proto/yq_internal.proto ) +target_sources(libs-control_plane_storage-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/control_plane_storage/proto/yq_internal.pb.h +) target_proto_addincls(libs-control_plane_storage-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/control_plane_storage/proto/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/control_plane_storage/proto/CMakeLists.windows-x86_64.txt index 5a1066883e27..ea6d1586403a 100644 --- a/ydb/core/fq/libs/control_plane_storage/proto/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/control_plane_storage/proto/CMakeLists.windows-x86_64.txt @@ -32,6 +32,9 @@ target_link_libraries(libs-control_plane_storage-proto PUBLIC target_proto_messages(libs-control_plane_storage-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/control_plane_storage/proto/yq_internal.proto ) +target_sources(libs-control_plane_storage-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/control_plane_storage/proto/yq_internal.pb.h +) target_proto_addincls(libs-control_plane_storage-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/db_id_async_resolver_impl/ut/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/db_id_async_resolver_impl/ut/CMakeLists.darwin-arm64.txt index d7bb6bfd911c..6e00631ff5b0 100644 --- a/ydb/core/fq/libs/db_id_async_resolver_impl/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/db_id_async_resolver_impl/ut/CMakeLists.darwin-arm64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-core-fq-libs-db_id_async_resolver_impl-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-fq-libs-db_id_async_resolver_impl-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/db_id_async_resolver_impl/ut/mdb_endpoint_generator_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/db_id_async_resolver_impl/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/db_id_async_resolver_impl/ut/CMakeLists.darwin-x86_64.txt index d125d17a9f07..b18c983cad47 100644 --- a/ydb/core/fq/libs/db_id_async_resolver_impl/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/db_id_async_resolver_impl/ut/CMakeLists.darwin-x86_64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-core-fq-libs-db_id_async_resolver_impl-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-fq-libs-db_id_async_resolver_impl-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/db_id_async_resolver_impl/ut/mdb_endpoint_generator_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/db_id_async_resolver_impl/ut/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/db_id_async_resolver_impl/ut/CMakeLists.linux-aarch64.txt index d62845533b7b..eba4b7bd83b6 100644 --- a/ydb/core/fq/libs/db_id_async_resolver_impl/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/db_id_async_resolver_impl/ut/CMakeLists.linux-aarch64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-core-fq-libs-db_id_async_resolver_impl-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-fq-libs-db_id_async_resolver_impl-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/db_id_async_resolver_impl/ut/mdb_endpoint_generator_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/db_id_async_resolver_impl/ut/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/db_id_async_resolver_impl/ut/CMakeLists.linux-x86_64.txt index 6b2a81ddaab0..86e4d25185f6 100644 --- a/ydb/core/fq/libs/db_id_async_resolver_impl/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/db_id_async_resolver_impl/ut/CMakeLists.linux-x86_64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-core-fq-libs-db_id_async_resolver_impl-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-fq-libs-db_id_async_resolver_impl-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/db_id_async_resolver_impl/ut/mdb_endpoint_generator_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/db_id_async_resolver_impl/ut/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/db_id_async_resolver_impl/ut/CMakeLists.windows-x86_64.txt index 81eee6368f96..654f6acc8c5f 100644 --- a/ydb/core/fq/libs/db_id_async_resolver_impl/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/db_id_async_resolver_impl/ut/CMakeLists.windows-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/graph_params/proto/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/graph_params/proto/CMakeLists.darwin-arm64.txt index cef8ac1b3867..30fc69724b19 100644 --- a/ydb/core/fq/libs/graph_params/proto/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/graph_params/proto/CMakeLists.darwin-arm64.txt @@ -30,6 +30,9 @@ target_link_libraries(libs-graph_params-proto PUBLIC target_proto_messages(libs-graph_params-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/graph_params/proto/graph_params.proto ) +target_sources(libs-graph_params-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/graph_params/proto/graph_params.pb.h +) target_proto_addincls(libs-graph_params-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/graph_params/proto/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/graph_params/proto/CMakeLists.darwin-x86_64.txt index cef8ac1b3867..30fc69724b19 100644 --- a/ydb/core/fq/libs/graph_params/proto/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/graph_params/proto/CMakeLists.darwin-x86_64.txt @@ -30,6 +30,9 @@ target_link_libraries(libs-graph_params-proto PUBLIC target_proto_messages(libs-graph_params-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/graph_params/proto/graph_params.proto ) +target_sources(libs-graph_params-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/graph_params/proto/graph_params.pb.h +) target_proto_addincls(libs-graph_params-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/graph_params/proto/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/graph_params/proto/CMakeLists.linux-aarch64.txt index e171a7e6f026..c1630844705a 100644 --- a/ydb/core/fq/libs/graph_params/proto/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/graph_params/proto/CMakeLists.linux-aarch64.txt @@ -31,6 +31,9 @@ target_link_libraries(libs-graph_params-proto PUBLIC target_proto_messages(libs-graph_params-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/graph_params/proto/graph_params.proto ) +target_sources(libs-graph_params-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/graph_params/proto/graph_params.pb.h +) target_proto_addincls(libs-graph_params-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/graph_params/proto/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/graph_params/proto/CMakeLists.linux-x86_64.txt index e171a7e6f026..c1630844705a 100644 --- a/ydb/core/fq/libs/graph_params/proto/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/graph_params/proto/CMakeLists.linux-x86_64.txt @@ -31,6 +31,9 @@ target_link_libraries(libs-graph_params-proto PUBLIC target_proto_messages(libs-graph_params-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/graph_params/proto/graph_params.proto ) +target_sources(libs-graph_params-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/graph_params/proto/graph_params.pb.h +) target_proto_addincls(libs-graph_params-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/graph_params/proto/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/graph_params/proto/CMakeLists.windows-x86_64.txt index cef8ac1b3867..30fc69724b19 100644 --- a/ydb/core/fq/libs/graph_params/proto/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/graph_params/proto/CMakeLists.windows-x86_64.txt @@ -30,6 +30,9 @@ target_link_libraries(libs-graph_params-proto PUBLIC target_proto_messages(libs-graph_params-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/graph_params/proto/graph_params.proto ) +target_sources(libs-graph_params-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/graph_params/proto/graph_params.pb.h +) target_proto_addincls(libs-graph_params-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/grpc/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/grpc/CMakeLists.darwin-arm64.txt index 7c8a43428f86..d28cd3607496 100644 --- a/ydb/core/fq/libs/grpc/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/grpc/CMakeLists.darwin-arm64.txt @@ -40,6 +40,10 @@ target_link_libraries(fq-libs-grpc PUBLIC target_proto_messages(fq-libs-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/grpc/fq_private_v1.proto ) +target_sources(fq-libs-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/grpc/fq_private_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/grpc/fq_private_v1.grpc.pb.h +) target_proto_addincls(fq-libs-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/grpc/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/grpc/CMakeLists.darwin-x86_64.txt index 7c8a43428f86..d28cd3607496 100644 --- a/ydb/core/fq/libs/grpc/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/grpc/CMakeLists.darwin-x86_64.txt @@ -40,6 +40,10 @@ target_link_libraries(fq-libs-grpc PUBLIC target_proto_messages(fq-libs-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/grpc/fq_private_v1.proto ) +target_sources(fq-libs-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/grpc/fq_private_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/grpc/fq_private_v1.grpc.pb.h +) target_proto_addincls(fq-libs-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/grpc/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/grpc/CMakeLists.linux-aarch64.txt index 4d879be523eb..0faca62ff1b6 100644 --- a/ydb/core/fq/libs/grpc/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/grpc/CMakeLists.linux-aarch64.txt @@ -41,6 +41,10 @@ target_link_libraries(fq-libs-grpc PUBLIC target_proto_messages(fq-libs-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/grpc/fq_private_v1.proto ) +target_sources(fq-libs-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/grpc/fq_private_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/grpc/fq_private_v1.grpc.pb.h +) target_proto_addincls(fq-libs-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/grpc/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/grpc/CMakeLists.linux-x86_64.txt index 4d879be523eb..0faca62ff1b6 100644 --- a/ydb/core/fq/libs/grpc/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/grpc/CMakeLists.linux-x86_64.txt @@ -41,6 +41,10 @@ target_link_libraries(fq-libs-grpc PUBLIC target_proto_messages(fq-libs-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/grpc/fq_private_v1.proto ) +target_sources(fq-libs-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/grpc/fq_private_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/grpc/fq_private_v1.grpc.pb.h +) target_proto_addincls(fq-libs-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/grpc/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/grpc/CMakeLists.windows-x86_64.txt index 7c8a43428f86..d28cd3607496 100644 --- a/ydb/core/fq/libs/grpc/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/grpc/CMakeLists.windows-x86_64.txt @@ -40,6 +40,10 @@ target_link_libraries(fq-libs-grpc PUBLIC target_proto_messages(fq-libs-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/grpc/fq_private_v1.proto ) +target_sources(fq-libs-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/grpc/fq_private_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/grpc/fq_private_v1.grpc.pb.h +) target_proto_addincls(fq-libs-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/hmac/ut/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/hmac/ut/CMakeLists.darwin-arm64.txt index 1e3adcf67e35..3bca9a23d552 100644 --- a/ydb/core/fq/libs/hmac/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/hmac/ut/CMakeLists.darwin-arm64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/hmac/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/hmac/ut/CMakeLists.darwin-x86_64.txt index 16986de71998..b2e90c72e0fd 100644 --- a/ydb/core/fq/libs/hmac/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/hmac/ut/CMakeLists.darwin-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/hmac/ut/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/hmac/ut/CMakeLists.linux-aarch64.txt index 6e5db5855c4c..d8f7165b3c24 100644 --- a/ydb/core/fq/libs/hmac/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/hmac/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-core-fq-libs-hmac-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-fq-libs-hmac-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/hmac/ut/hmac_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/hmac/ut/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/hmac/ut/CMakeLists.linux-x86_64.txt index e48cc51a1f9e..3d5661d748a0 100644 --- a/ydb/core/fq/libs/hmac/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/hmac/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-core-fq-libs-hmac-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-fq-libs-hmac-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/hmac/ut/hmac_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/hmac/ut/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/hmac/ut/CMakeLists.windows-x86_64.txt index 90eaf618f48c..ae64989c61c3 100644 --- a/ydb/core/fq/libs/hmac/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/hmac/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/init/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/init/CMakeLists.darwin-arm64.txt index a2a9c2082b84..a96f9e28bf94 100644 --- a/ydb/core/fq/libs/init/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/init/CMakeLists.darwin-arm64.txt @@ -39,7 +39,7 @@ target_link_libraries(fq-libs-init PUBLIC ydb-library-folder_service library-folder_service-proto ydb-library-security - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-utils-actor_log dq-actors-compute yql-dq-comp_nodes diff --git a/ydb/core/fq/libs/init/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/init/CMakeLists.darwin-x86_64.txt index a2a9c2082b84..a96f9e28bf94 100644 --- a/ydb/core/fq/libs/init/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/init/CMakeLists.darwin-x86_64.txt @@ -39,7 +39,7 @@ target_link_libraries(fq-libs-init PUBLIC ydb-library-folder_service library-folder_service-proto ydb-library-security - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-utils-actor_log dq-actors-compute yql-dq-comp_nodes diff --git a/ydb/core/fq/libs/init/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/init/CMakeLists.linux-aarch64.txt index 3fcb18a6f620..9ab5ed646d3b 100644 --- a/ydb/core/fq/libs/init/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/init/CMakeLists.linux-aarch64.txt @@ -40,7 +40,7 @@ target_link_libraries(fq-libs-init PUBLIC ydb-library-folder_service library-folder_service-proto ydb-library-security - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-utils-actor_log dq-actors-compute yql-dq-comp_nodes diff --git a/ydb/core/fq/libs/init/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/init/CMakeLists.linux-x86_64.txt index 3fcb18a6f620..9ab5ed646d3b 100644 --- a/ydb/core/fq/libs/init/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/init/CMakeLists.linux-x86_64.txt @@ -40,7 +40,7 @@ target_link_libraries(fq-libs-init PUBLIC ydb-library-folder_service library-folder_service-proto ydb-library-security - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-utils-actor_log dq-actors-compute yql-dq-comp_nodes diff --git a/ydb/core/fq/libs/init/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/init/CMakeLists.windows-x86_64.txt index a2a9c2082b84..a96f9e28bf94 100644 --- a/ydb/core/fq/libs/init/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/init/CMakeLists.windows-x86_64.txt @@ -39,7 +39,7 @@ target_link_libraries(fq-libs-init PUBLIC ydb-library-folder_service library-folder_service-proto ydb-library-security - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-utils-actor_log dq-actors-compute yql-dq-comp_nodes diff --git a/ydb/core/fq/libs/mock/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/mock/CMakeLists.darwin-arm64.txt index 81bafdb5dde0..24204667af2e 100644 --- a/ydb/core/fq/libs/mock/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/mock/CMakeLists.darwin-arm64.txt @@ -32,7 +32,7 @@ target_link_libraries(fq-libs-mock PUBLIC yql-core-facade core-services-mounts dq-integration-transform - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-clickhouse-provider providers-common-codec providers-common-comp_nodes diff --git a/ydb/core/fq/libs/mock/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/mock/CMakeLists.darwin-x86_64.txt index 81bafdb5dde0..24204667af2e 100644 --- a/ydb/core/fq/libs/mock/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/mock/CMakeLists.darwin-x86_64.txt @@ -32,7 +32,7 @@ target_link_libraries(fq-libs-mock PUBLIC yql-core-facade core-services-mounts dq-integration-transform - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-clickhouse-provider providers-common-codec providers-common-comp_nodes diff --git a/ydb/core/fq/libs/mock/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/mock/CMakeLists.linux-aarch64.txt index 927b79c875ae..5df8c803bdc4 100644 --- a/ydb/core/fq/libs/mock/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/mock/CMakeLists.linux-aarch64.txt @@ -33,7 +33,7 @@ target_link_libraries(fq-libs-mock PUBLIC yql-core-facade core-services-mounts dq-integration-transform - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-clickhouse-provider providers-common-codec providers-common-comp_nodes diff --git a/ydb/core/fq/libs/mock/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/mock/CMakeLists.linux-x86_64.txt index 927b79c875ae..5df8c803bdc4 100644 --- a/ydb/core/fq/libs/mock/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/mock/CMakeLists.linux-x86_64.txt @@ -33,7 +33,7 @@ target_link_libraries(fq-libs-mock PUBLIC yql-core-facade core-services-mounts dq-integration-transform - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-clickhouse-provider providers-common-codec providers-common-comp_nodes diff --git a/ydb/core/fq/libs/mock/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/mock/CMakeLists.windows-x86_64.txt index 81bafdb5dde0..24204667af2e 100644 --- a/ydb/core/fq/libs/mock/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/mock/CMakeLists.windows-x86_64.txt @@ -32,7 +32,7 @@ target_link_libraries(fq-libs-mock PUBLIC yql-core-facade core-services-mounts dq-integration-transform - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-clickhouse-provider providers-common-codec providers-common-comp_nodes diff --git a/ydb/core/fq/libs/protos/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/protos/CMakeLists.darwin-arm64.txt index 7e39a3f60b17..7804d00dfba6 100644 --- a/ydb/core/fq/libs/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/protos/CMakeLists.darwin-arm64.txt @@ -44,6 +44,10 @@ target_proto_messages(fq-libs-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/protos/dq_effects.proto ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/protos/fq_private.proto ) +target_sources(fq-libs-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/protos/dq_effects.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/protos/fq_private.pb.h +) target_proto_addincls(fq-libs-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/protos/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/protos/CMakeLists.darwin-x86_64.txt index 7e39a3f60b17..7804d00dfba6 100644 --- a/ydb/core/fq/libs/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/protos/CMakeLists.darwin-x86_64.txt @@ -44,6 +44,10 @@ target_proto_messages(fq-libs-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/protos/dq_effects.proto ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/protos/fq_private.proto ) +target_sources(fq-libs-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/protos/dq_effects.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/protos/fq_private.pb.h +) target_proto_addincls(fq-libs-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/protos/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/protos/CMakeLists.linux-aarch64.txt index 4ebf71e37649..a20c0dde710c 100644 --- a/ydb/core/fq/libs/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/protos/CMakeLists.linux-aarch64.txt @@ -45,6 +45,10 @@ target_proto_messages(fq-libs-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/protos/dq_effects.proto ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/protos/fq_private.proto ) +target_sources(fq-libs-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/protos/dq_effects.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/protos/fq_private.pb.h +) target_proto_addincls(fq-libs-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/protos/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/protos/CMakeLists.linux-x86_64.txt index 4ebf71e37649..a20c0dde710c 100644 --- a/ydb/core/fq/libs/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/protos/CMakeLists.linux-x86_64.txt @@ -45,6 +45,10 @@ target_proto_messages(fq-libs-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/protos/dq_effects.proto ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/protos/fq_private.proto ) +target_sources(fq-libs-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/protos/dq_effects.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/protos/fq_private.pb.h +) target_proto_addincls(fq-libs-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/protos/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/protos/CMakeLists.windows-x86_64.txt index 7e39a3f60b17..7804d00dfba6 100644 --- a/ydb/core/fq/libs/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/protos/CMakeLists.windows-x86_64.txt @@ -44,6 +44,10 @@ target_proto_messages(fq-libs-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/protos/dq_effects.proto ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/protos/fq_private.proto ) +target_sources(fq-libs-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/protos/dq_effects.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/protos/fq_private.pb.h +) target_proto_addincls(fq-libs-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/quota_manager/proto/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/quota_manager/proto/CMakeLists.darwin-arm64.txt index baf535c0076a..21a513976d8c 100644 --- a/ydb/core/fq/libs/quota_manager/proto/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/quota_manager/proto/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(libs-quota_manager-proto PUBLIC target_proto_messages(libs-quota_manager-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/quota_manager/proto/quota_internal.proto ) +target_sources(libs-quota_manager-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/quota_manager/proto/quota_internal.pb.h +) target_proto_addincls(libs-quota_manager-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/quota_manager/proto/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/quota_manager/proto/CMakeLists.darwin-x86_64.txt index baf535c0076a..21a513976d8c 100644 --- a/ydb/core/fq/libs/quota_manager/proto/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/quota_manager/proto/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(libs-quota_manager-proto PUBLIC target_proto_messages(libs-quota_manager-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/quota_manager/proto/quota_internal.proto ) +target_sources(libs-quota_manager-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/quota_manager/proto/quota_internal.pb.h +) target_proto_addincls(libs-quota_manager-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/quota_manager/proto/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/quota_manager/proto/CMakeLists.linux-aarch64.txt index 377733cb08d6..9e26cecbfd94 100644 --- a/ydb/core/fq/libs/quota_manager/proto/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/quota_manager/proto/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(libs-quota_manager-proto PUBLIC target_proto_messages(libs-quota_manager-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/quota_manager/proto/quota_internal.proto ) +target_sources(libs-quota_manager-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/quota_manager/proto/quota_internal.pb.h +) target_proto_addincls(libs-quota_manager-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/quota_manager/proto/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/quota_manager/proto/CMakeLists.linux-x86_64.txt index 377733cb08d6..9e26cecbfd94 100644 --- a/ydb/core/fq/libs/quota_manager/proto/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/quota_manager/proto/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(libs-quota_manager-proto PUBLIC target_proto_messages(libs-quota_manager-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/quota_manager/proto/quota_internal.proto ) +target_sources(libs-quota_manager-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/quota_manager/proto/quota_internal.pb.h +) target_proto_addincls(libs-quota_manager-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/quota_manager/proto/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/quota_manager/proto/CMakeLists.windows-x86_64.txt index baf535c0076a..21a513976d8c 100644 --- a/ydb/core/fq/libs/quota_manager/proto/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/quota_manager/proto/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(libs-quota_manager-proto PUBLIC target_proto_messages(libs-quota_manager-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/quota_manager/proto/quota_internal.proto ) +target_sources(libs-quota_manager-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/fq/libs/quota_manager/proto/quota_internal.pb.h +) target_proto_addincls(libs-quota_manager-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/fq/libs/result_formatter/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/result_formatter/CMakeLists.darwin-arm64.txt index 37994c7c359a..bd419bb83793 100644 --- a/ydb/core/fq/libs/result_formatter/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/result_formatter/CMakeLists.darwin-arm64.txt @@ -19,7 +19,7 @@ target_link_libraries(fq-libs-result_formatter PUBLIC cpp-json-yson ydb-library-mkql_proto library-yql-ast - minikql-computation-llvm + yql-minikql-computation yql-public-udf api-protos cpp-client-ydb_proto diff --git a/ydb/core/fq/libs/result_formatter/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/result_formatter/CMakeLists.darwin-x86_64.txt index 37994c7c359a..bd419bb83793 100644 --- a/ydb/core/fq/libs/result_formatter/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/result_formatter/CMakeLists.darwin-x86_64.txt @@ -19,7 +19,7 @@ target_link_libraries(fq-libs-result_formatter PUBLIC cpp-json-yson ydb-library-mkql_proto library-yql-ast - minikql-computation-llvm + yql-minikql-computation yql-public-udf api-protos cpp-client-ydb_proto diff --git a/ydb/core/fq/libs/result_formatter/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/result_formatter/CMakeLists.linux-aarch64.txt index d62b3106e87d..67c4b0397472 100644 --- a/ydb/core/fq/libs/result_formatter/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/result_formatter/CMakeLists.linux-aarch64.txt @@ -20,7 +20,7 @@ target_link_libraries(fq-libs-result_formatter PUBLIC cpp-json-yson ydb-library-mkql_proto library-yql-ast - minikql-computation-llvm + yql-minikql-computation yql-public-udf api-protos cpp-client-ydb_proto diff --git a/ydb/core/fq/libs/result_formatter/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/result_formatter/CMakeLists.linux-x86_64.txt index d62b3106e87d..67c4b0397472 100644 --- a/ydb/core/fq/libs/result_formatter/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/result_formatter/CMakeLists.linux-x86_64.txt @@ -20,7 +20,7 @@ target_link_libraries(fq-libs-result_formatter PUBLIC cpp-json-yson ydb-library-mkql_proto library-yql-ast - minikql-computation-llvm + yql-minikql-computation yql-public-udf api-protos cpp-client-ydb_proto diff --git a/ydb/core/fq/libs/result_formatter/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/result_formatter/CMakeLists.windows-x86_64.txt index 37994c7c359a..bd419bb83793 100644 --- a/ydb/core/fq/libs/result_formatter/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/result_formatter/CMakeLists.windows-x86_64.txt @@ -19,7 +19,7 @@ target_link_libraries(fq-libs-result_formatter PUBLIC cpp-json-yson ydb-library-mkql_proto library-yql-ast - minikql-computation-llvm + yql-minikql-computation yql-public-udf api-protos cpp-client-ydb_proto diff --git a/ydb/core/fq/libs/result_formatter/ut/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/result_formatter/ut/CMakeLists.darwin-arm64.txt index 8bedad0c0792..3e273eb2f877 100644 --- a/ydb/core/fq/libs/result_formatter/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/result_formatter/ut/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-fq-libs-result_formatter-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-fq-libs-result_formatter-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/result_formatter/result_formatter_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/result_formatter/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/result_formatter/ut/CMakeLists.darwin-x86_64.txt index 1ce2a2fce663..e68d97fece6c 100644 --- a/ydb/core/fq/libs/result_formatter/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/result_formatter/ut/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-fq-libs-result_formatter-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-fq-libs-result_formatter-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/result_formatter/result_formatter_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/result_formatter/ut/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/result_formatter/ut/CMakeLists.linux-aarch64.txt index 4ac24a2f312c..f5de5e728cdf 100644 --- a/ydb/core/fq/libs/result_formatter/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/result_formatter/ut/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-fq-libs-result_formatter-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-fq-libs-result_formatter-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/result_formatter/result_formatter_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/result_formatter/ut/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/result_formatter/ut/CMakeLists.linux-x86_64.txt index db67a782fafa..8226d7b9f694 100644 --- a/ydb/core/fq/libs/result_formatter/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/result_formatter/ut/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-fq-libs-result_formatter-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-fq-libs-result_formatter-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/result_formatter/result_formatter_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/result_formatter/ut/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/result_formatter/ut/CMakeLists.windows-x86_64.txt index ddb8ba569b09..04fa67380d5a 100644 --- a/ydb/core/fq/libs/result_formatter/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/result_formatter/ut/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/shared_resources/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/shared_resources/CMakeLists.darwin-arm64.txt index 4854ca09d529..5d9a5bec9465 100644 --- a/ydb/core/fq/libs/shared_resources/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/shared_resources/CMakeLists.darwin-arm64.txt @@ -30,6 +30,7 @@ target_link_libraries(fq-libs-shared_resources PUBLIC ydb-library-logger ydb-library-security cpp-client-ydb_driver + cpp-client-ydb_extension cpp-client-ydb_table ) target_sources(fq-libs-shared_resources PRIVATE diff --git a/ydb/core/fq/libs/shared_resources/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/shared_resources/CMakeLists.darwin-x86_64.txt index 4854ca09d529..5d9a5bec9465 100644 --- a/ydb/core/fq/libs/shared_resources/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/shared_resources/CMakeLists.darwin-x86_64.txt @@ -30,6 +30,7 @@ target_link_libraries(fq-libs-shared_resources PUBLIC ydb-library-logger ydb-library-security cpp-client-ydb_driver + cpp-client-ydb_extension cpp-client-ydb_table ) target_sources(fq-libs-shared_resources PRIVATE diff --git a/ydb/core/fq/libs/shared_resources/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/shared_resources/CMakeLists.linux-aarch64.txt index 11101194d535..044b606a6c3a 100644 --- a/ydb/core/fq/libs/shared_resources/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/shared_resources/CMakeLists.linux-aarch64.txt @@ -31,6 +31,7 @@ target_link_libraries(fq-libs-shared_resources PUBLIC ydb-library-logger ydb-library-security cpp-client-ydb_driver + cpp-client-ydb_extension cpp-client-ydb_table ) target_sources(fq-libs-shared_resources PRIVATE diff --git a/ydb/core/fq/libs/shared_resources/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/shared_resources/CMakeLists.linux-x86_64.txt index 11101194d535..044b606a6c3a 100644 --- a/ydb/core/fq/libs/shared_resources/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/shared_resources/CMakeLists.linux-x86_64.txt @@ -31,6 +31,7 @@ target_link_libraries(fq-libs-shared_resources PUBLIC ydb-library-logger ydb-library-security cpp-client-ydb_driver + cpp-client-ydb_extension cpp-client-ydb_table ) target_sources(fq-libs-shared_resources PRIVATE diff --git a/ydb/core/fq/libs/shared_resources/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/shared_resources/CMakeLists.windows-x86_64.txt index 4854ca09d529..5d9a5bec9465 100644 --- a/ydb/core/fq/libs/shared_resources/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/shared_resources/CMakeLists.windows-x86_64.txt @@ -30,6 +30,7 @@ target_link_libraries(fq-libs-shared_resources PUBLIC ydb-library-logger ydb-library-security cpp-client-ydb_driver + cpp-client-ydb_extension cpp-client-ydb_table ) target_sources(fq-libs-shared_resources PRIVATE diff --git a/ydb/core/fq/libs/signer/ut/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/signer/ut/CMakeLists.darwin-arm64.txt index 87e6dcefeb1f..af96f35c4b34 100644 --- a/ydb/core/fq/libs/signer/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/signer/ut/CMakeLists.darwin-arm64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/signer/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/signer/ut/CMakeLists.darwin-x86_64.txt index e1b19c75d000..671c4919060c 100644 --- a/ydb/core/fq/libs/signer/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/signer/ut/CMakeLists.darwin-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/signer/ut/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/signer/ut/CMakeLists.linux-aarch64.txt index bed7849db4b4..b32073cb7fa3 100644 --- a/ydb/core/fq/libs/signer/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/signer/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-core-fq-libs-signer-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-fq-libs-signer-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/signer/ut/signer_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/signer/ut/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/signer/ut/CMakeLists.linux-x86_64.txt index 35a77d9b181e..86d81745635b 100644 --- a/ydb/core/fq/libs/signer/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/signer/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-core-fq-libs-signer-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-fq-libs-signer-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/signer/ut/signer_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/signer/ut/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/signer/ut/CMakeLists.windows-x86_64.txt index dd9ed5220869..6bcc23424f62 100644 --- a/ydb/core/fq/libs/signer/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/signer/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/test_connection/ut/CMakeLists.darwin-arm64.txt b/ydb/core/fq/libs/test_connection/ut/CMakeLists.darwin-arm64.txt index b57738d9be9b..b7263de7d5d2 100644 --- a/ydb/core/fq/libs/test_connection/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/fq/libs/test_connection/ut/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-fq-libs-test_connection-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-fq-libs-test_connection-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/test_connection/ut/test_connection_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/test_connection/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/fq/libs/test_connection/ut/CMakeLists.darwin-x86_64.txt index 43cc39a38d90..2b8789dcdc7f 100644 --- a/ydb/core/fq/libs/test_connection/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/fq/libs/test_connection/ut/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-fq-libs-test_connection-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-fq-libs-test_connection-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/test_connection/ut/test_connection_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/test_connection/ut/CMakeLists.linux-aarch64.txt b/ydb/core/fq/libs/test_connection/ut/CMakeLists.linux-aarch64.txt index cfe6a23037b1..4614992788cf 100644 --- a/ydb/core/fq/libs/test_connection/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/fq/libs/test_connection/ut/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-fq-libs-test_connection-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-fq-libs-test_connection-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/test_connection/ut/test_connection_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/test_connection/ut/CMakeLists.linux-x86_64.txt b/ydb/core/fq/libs/test_connection/ut/CMakeLists.linux-x86_64.txt index 31176de85108..aba46fa5cf12 100644 --- a/ydb/core/fq/libs/test_connection/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/fq/libs/test_connection/ut/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-fq-libs-test_connection-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-fq-libs-test_connection-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/fq/libs/test_connection/ut/test_connection_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/fq/libs/test_connection/ut/CMakeLists.windows-x86_64.txt b/ydb/core/fq/libs/test_connection/ut/CMakeLists.windows-x86_64.txt index 662e6ce1490f..20ace4f6a8fc 100644 --- a/ydb/core/fq/libs/test_connection/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/fq/libs/test_connection/ut/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/graph/CMakeLists.txt b/ydb/core/graph/CMakeLists.txt new file mode 100644 index 000000000000..ea2252c31a2a --- /dev/null +++ b/ydb/core/graph/CMakeLists.txt @@ -0,0 +1,13 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(api) +add_subdirectory(protos) +add_subdirectory(service) +add_subdirectory(shard) +add_subdirectory(ut) diff --git a/ydb/core/graph/api/CMakeLists.darwin-arm64.txt b/ydb/core/graph/api/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..a8f2ab00e789 --- /dev/null +++ b/ydb/core/graph/api/CMakeLists.darwin-arm64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(core-graph-api INTERFACE) +target_link_libraries(core-graph-api INTERFACE + contrib-libs-cxxsupp + yutil + core-graph-protos +) +target_sources(core-graph-api INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/api/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/api/service.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/api/shard.h +) diff --git a/ydb/core/graph/api/CMakeLists.darwin-x86_64.txt b/ydb/core/graph/api/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..a8f2ab00e789 --- /dev/null +++ b/ydb/core/graph/api/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(core-graph-api INTERFACE) +target_link_libraries(core-graph-api INTERFACE + contrib-libs-cxxsupp + yutil + core-graph-protos +) +target_sources(core-graph-api INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/api/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/api/service.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/api/shard.h +) diff --git a/ydb/core/graph/api/CMakeLists.linux-aarch64.txt b/ydb/core/graph/api/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..aa398f50fe21 --- /dev/null +++ b/ydb/core/graph/api/CMakeLists.linux-aarch64.txt @@ -0,0 +1,21 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(core-graph-api INTERFACE) +target_link_libraries(core-graph-api INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + core-graph-protos +) +target_sources(core-graph-api INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/api/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/api/service.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/api/shard.h +) diff --git a/ydb/core/graph/api/CMakeLists.linux-x86_64.txt b/ydb/core/graph/api/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..aa398f50fe21 --- /dev/null +++ b/ydb/core/graph/api/CMakeLists.linux-x86_64.txt @@ -0,0 +1,21 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(core-graph-api INTERFACE) +target_link_libraries(core-graph-api INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + core-graph-protos +) +target_sources(core-graph-api INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/api/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/api/service.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/api/shard.h +) diff --git a/ydb/core/graph/api/CMakeLists.txt b/ydb/core/graph/api/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/graph/api/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/graph/api/CMakeLists.windows-x86_64.txt b/ydb/core/graph/api/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..a8f2ab00e789 --- /dev/null +++ b/ydb/core/graph/api/CMakeLists.windows-x86_64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(core-graph-api INTERFACE) +target_link_libraries(core-graph-api INTERFACE + contrib-libs-cxxsupp + yutil + core-graph-protos +) +target_sources(core-graph-api INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/api/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/api/service.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/api/shard.h +) diff --git a/ydb/core/graph/protos/CMakeLists.darwin-arm64.txt b/ydb/core/graph/protos/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..06b6fef2b12d --- /dev/null +++ b/ydb/core/graph/protos/CMakeLists.darwin-arm64.txt @@ -0,0 +1,46 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) + +add_library(core-graph-protos) +target_link_libraries(core-graph-protos PUBLIC + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf +) +target_proto_messages(core-graph-protos PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/protos/graph.proto +) +target_sources(core-graph-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/graph/protos/graph.pb.h +) +target_proto_addincls(core-graph-protos + ./ + ${CMAKE_SOURCE_DIR}/ + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src +) +target_proto_outs(core-graph-protos + --cpp_out=${CMAKE_BINARY_DIR}/ + --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ +) diff --git a/ydb/core/graph/protos/CMakeLists.darwin-x86_64.txt b/ydb/core/graph/protos/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..06b6fef2b12d --- /dev/null +++ b/ydb/core/graph/protos/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,46 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) + +add_library(core-graph-protos) +target_link_libraries(core-graph-protos PUBLIC + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf +) +target_proto_messages(core-graph-protos PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/protos/graph.proto +) +target_sources(core-graph-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/graph/protos/graph.pb.h +) +target_proto_addincls(core-graph-protos + ./ + ${CMAKE_SOURCE_DIR}/ + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src +) +target_proto_outs(core-graph-protos + --cpp_out=${CMAKE_BINARY_DIR}/ + --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ +) diff --git a/ydb/core/graph/protos/CMakeLists.linux-aarch64.txt b/ydb/core/graph/protos/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..21288f0678e7 --- /dev/null +++ b/ydb/core/graph/protos/CMakeLists.linux-aarch64.txt @@ -0,0 +1,47 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) + +add_library(core-graph-protos) +target_link_libraries(core-graph-protos PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf +) +target_proto_messages(core-graph-protos PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/protos/graph.proto +) +target_sources(core-graph-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/graph/protos/graph.pb.h +) +target_proto_addincls(core-graph-protos + ./ + ${CMAKE_SOURCE_DIR}/ + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src +) +target_proto_outs(core-graph-protos + --cpp_out=${CMAKE_BINARY_DIR}/ + --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ +) diff --git a/ydb/core/graph/protos/CMakeLists.linux-x86_64.txt b/ydb/core/graph/protos/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..21288f0678e7 --- /dev/null +++ b/ydb/core/graph/protos/CMakeLists.linux-x86_64.txt @@ -0,0 +1,47 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) + +add_library(core-graph-protos) +target_link_libraries(core-graph-protos PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf +) +target_proto_messages(core-graph-protos PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/protos/graph.proto +) +target_sources(core-graph-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/graph/protos/graph.pb.h +) +target_proto_addincls(core-graph-protos + ./ + ${CMAKE_SOURCE_DIR}/ + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src +) +target_proto_outs(core-graph-protos + --cpp_out=${CMAKE_BINARY_DIR}/ + --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ +) diff --git a/ydb/core/graph/protos/CMakeLists.txt b/ydb/core/graph/protos/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/graph/protos/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/graph/protos/CMakeLists.windows-x86_64.txt b/ydb/core/graph/protos/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..06b6fef2b12d --- /dev/null +++ b/ydb/core/graph/protos/CMakeLists.windows-x86_64.txt @@ -0,0 +1,46 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) + +add_library(core-graph-protos) +target_link_libraries(core-graph-protos PUBLIC + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf +) +target_proto_messages(core-graph-protos PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/protos/graph.proto +) +target_sources(core-graph-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/graph/protos/graph.pb.h +) +target_proto_addincls(core-graph-protos + ./ + ${CMAKE_SOURCE_DIR}/ + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src +) +target_proto_outs(core-graph-protos + --cpp_out=${CMAKE_BINARY_DIR}/ + --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ +) diff --git a/ydb/core/graph/service/CMakeLists.darwin-arm64.txt b/ydb/core/graph/service/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..0ff1742a994e --- /dev/null +++ b/ydb/core/graph/service/CMakeLists.darwin-arm64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(core-graph-service) +target_link_libraries(core-graph-service PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-base + core-graph-api +) +target_sources(core-graph-service PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/service/log.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/service/service_impl.cpp +) diff --git a/ydb/core/graph/service/CMakeLists.darwin-x86_64.txt b/ydb/core/graph/service/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..0ff1742a994e --- /dev/null +++ b/ydb/core/graph/service/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(core-graph-service) +target_link_libraries(core-graph-service PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-base + core-graph-api +) +target_sources(core-graph-service PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/service/log.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/service/service_impl.cpp +) diff --git a/ydb/core/graph/service/CMakeLists.linux-aarch64.txt b/ydb/core/graph/service/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..f5111421c79f --- /dev/null +++ b/ydb/core/graph/service/CMakeLists.linux-aarch64.txt @@ -0,0 +1,21 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(core-graph-service) +target_link_libraries(core-graph-service PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-base + core-graph-api +) +target_sources(core-graph-service PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/service/log.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/service/service_impl.cpp +) diff --git a/ydb/core/graph/service/CMakeLists.linux-x86_64.txt b/ydb/core/graph/service/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..f5111421c79f --- /dev/null +++ b/ydb/core/graph/service/CMakeLists.linux-x86_64.txt @@ -0,0 +1,21 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(core-graph-service) +target_link_libraries(core-graph-service PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-base + core-graph-api +) +target_sources(core-graph-service PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/service/log.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/service/service_impl.cpp +) diff --git a/ydb/core/graph/service/CMakeLists.txt b/ydb/core/graph/service/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/graph/service/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/graph/service/CMakeLists.windows-x86_64.txt b/ydb/core/graph/service/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..0ff1742a994e --- /dev/null +++ b/ydb/core/graph/service/CMakeLists.windows-x86_64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(core-graph-service) +target_link_libraries(core-graph-service PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-base + core-graph-api +) +target_sources(core-graph-service PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/service/log.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/service/service_impl.cpp +) diff --git a/ydb/core/graph/shard/CMakeLists.darwin-arm64.txt b/ydb/core/graph/shard/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..34d35ae3c556 --- /dev/null +++ b/ydb/core/graph/shard/CMakeLists.darwin-arm64.txt @@ -0,0 +1,37 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(protos) +add_subdirectory(ut) + +add_library(core-graph-shard) +target_link_libraries(core-graph-shard PUBLIC + contrib-libs-cxxsupp + yutil + library-actors-core + ydb-core-base + ydb-core-tablet + ydb-core-tablet_flat + core-graph-api + graph-shard-protos +) +target_sources(core-graph-shard PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/backends.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/log.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/shard_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/backends.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/shard_impl.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_change_backend.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_clear_data.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_get_metrics.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_init_schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_monitoring.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_startup.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_store_metrics.cpp +) diff --git a/ydb/core/graph/shard/CMakeLists.darwin-x86_64.txt b/ydb/core/graph/shard/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..34d35ae3c556 --- /dev/null +++ b/ydb/core/graph/shard/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,37 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(protos) +add_subdirectory(ut) + +add_library(core-graph-shard) +target_link_libraries(core-graph-shard PUBLIC + contrib-libs-cxxsupp + yutil + library-actors-core + ydb-core-base + ydb-core-tablet + ydb-core-tablet_flat + core-graph-api + graph-shard-protos +) +target_sources(core-graph-shard PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/backends.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/log.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/shard_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/backends.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/shard_impl.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_change_backend.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_clear_data.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_get_metrics.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_init_schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_monitoring.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_startup.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_store_metrics.cpp +) diff --git a/ydb/core/graph/shard/CMakeLists.linux-aarch64.txt b/ydb/core/graph/shard/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..f66548999b06 --- /dev/null +++ b/ydb/core/graph/shard/CMakeLists.linux-aarch64.txt @@ -0,0 +1,38 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(protos) +add_subdirectory(ut) + +add_library(core-graph-shard) +target_link_libraries(core-graph-shard PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-actors-core + ydb-core-base + ydb-core-tablet + ydb-core-tablet_flat + core-graph-api + graph-shard-protos +) +target_sources(core-graph-shard PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/backends.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/log.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/shard_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/backends.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/shard_impl.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_change_backend.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_clear_data.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_get_metrics.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_init_schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_monitoring.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_startup.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_store_metrics.cpp +) diff --git a/ydb/core/graph/shard/CMakeLists.linux-x86_64.txt b/ydb/core/graph/shard/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..f66548999b06 --- /dev/null +++ b/ydb/core/graph/shard/CMakeLists.linux-x86_64.txt @@ -0,0 +1,38 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(protos) +add_subdirectory(ut) + +add_library(core-graph-shard) +target_link_libraries(core-graph-shard PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-actors-core + ydb-core-base + ydb-core-tablet + ydb-core-tablet_flat + core-graph-api + graph-shard-protos +) +target_sources(core-graph-shard PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/backends.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/log.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/shard_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/backends.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/shard_impl.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_change_backend.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_clear_data.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_get_metrics.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_init_schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_monitoring.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_startup.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_store_metrics.cpp +) diff --git a/ydb/core/graph/shard/CMakeLists.txt b/ydb/core/graph/shard/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/graph/shard/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/graph/shard/CMakeLists.windows-x86_64.txt b/ydb/core/graph/shard/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..34d35ae3c556 --- /dev/null +++ b/ydb/core/graph/shard/CMakeLists.windows-x86_64.txt @@ -0,0 +1,37 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(protos) +add_subdirectory(ut) + +add_library(core-graph-shard) +target_link_libraries(core-graph-shard PUBLIC + contrib-libs-cxxsupp + yutil + library-actors-core + ydb-core-base + ydb-core-tablet + ydb-core-tablet_flat + core-graph-api + graph-shard-protos +) +target_sources(core-graph-shard PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/backends.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/log.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/shard_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/backends.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/shard_impl.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_change_backend.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_clear_data.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_get_metrics.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_init_schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_monitoring.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_startup.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/tx_store_metrics.cpp +) diff --git a/ydb/core/graph/shard/protos/CMakeLists.darwin-arm64.txt b/ydb/core/graph/shard/protos/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..2cc8be1c24fd --- /dev/null +++ b/ydb/core/graph/shard/protos/CMakeLists.darwin-arm64.txt @@ -0,0 +1,47 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) + +add_library(graph-shard-protos) +target_link_libraries(graph-shard-protos PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-protos + contrib-libs-protobuf +) +target_proto_messages(graph-shard-protos PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/protos/counters_shard.proto +) +target_sources(graph-shard-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/graph/shard/protos/counters_shard.pb.h +) +target_proto_addincls(graph-shard-protos + ./ + ${CMAKE_SOURCE_DIR}/ + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src +) +target_proto_outs(graph-shard-protos + --cpp_out=${CMAKE_BINARY_DIR}/ + --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ +) diff --git a/ydb/core/graph/shard/protos/CMakeLists.darwin-x86_64.txt b/ydb/core/graph/shard/protos/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..2cc8be1c24fd --- /dev/null +++ b/ydb/core/graph/shard/protos/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,47 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) + +add_library(graph-shard-protos) +target_link_libraries(graph-shard-protos PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-protos + contrib-libs-protobuf +) +target_proto_messages(graph-shard-protos PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/protos/counters_shard.proto +) +target_sources(graph-shard-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/graph/shard/protos/counters_shard.pb.h +) +target_proto_addincls(graph-shard-protos + ./ + ${CMAKE_SOURCE_DIR}/ + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src +) +target_proto_outs(graph-shard-protos + --cpp_out=${CMAKE_BINARY_DIR}/ + --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ +) diff --git a/ydb/core/graph/shard/protos/CMakeLists.linux-aarch64.txt b/ydb/core/graph/shard/protos/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..cda356e1e288 --- /dev/null +++ b/ydb/core/graph/shard/protos/CMakeLists.linux-aarch64.txt @@ -0,0 +1,48 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) + +add_library(graph-shard-protos) +target_link_libraries(graph-shard-protos PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-protos + contrib-libs-protobuf +) +target_proto_messages(graph-shard-protos PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/protos/counters_shard.proto +) +target_sources(graph-shard-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/graph/shard/protos/counters_shard.pb.h +) +target_proto_addincls(graph-shard-protos + ./ + ${CMAKE_SOURCE_DIR}/ + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src +) +target_proto_outs(graph-shard-protos + --cpp_out=${CMAKE_BINARY_DIR}/ + --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ +) diff --git a/ydb/core/graph/shard/protos/CMakeLists.linux-x86_64.txt b/ydb/core/graph/shard/protos/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..cda356e1e288 --- /dev/null +++ b/ydb/core/graph/shard/protos/CMakeLists.linux-x86_64.txt @@ -0,0 +1,48 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) + +add_library(graph-shard-protos) +target_link_libraries(graph-shard-protos PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-protos + contrib-libs-protobuf +) +target_proto_messages(graph-shard-protos PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/protos/counters_shard.proto +) +target_sources(graph-shard-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/graph/shard/protos/counters_shard.pb.h +) +target_proto_addincls(graph-shard-protos + ./ + ${CMAKE_SOURCE_DIR}/ + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src +) +target_proto_outs(graph-shard-protos + --cpp_out=${CMAKE_BINARY_DIR}/ + --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ +) diff --git a/ydb/core/graph/shard/protos/CMakeLists.txt b/ydb/core/graph/shard/protos/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/graph/shard/protos/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/graph/shard/protos/CMakeLists.windows-x86_64.txt b/ydb/core/graph/shard/protos/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..2cc8be1c24fd --- /dev/null +++ b/ydb/core/graph/shard/protos/CMakeLists.windows-x86_64.txt @@ -0,0 +1,47 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) + +add_library(graph-shard-protos) +target_link_libraries(graph-shard-protos PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-protos + contrib-libs-protobuf +) +target_proto_messages(graph-shard-protos PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/protos/counters_shard.proto +) +target_sources(graph-shard-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/graph/shard/protos/counters_shard.pb.h +) +target_proto_addincls(graph-shard-protos + ./ + ${CMAKE_SOURCE_DIR}/ + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src +) +target_proto_outs(graph-shard-protos + --cpp_out=${CMAKE_BINARY_DIR}/ + --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ +) diff --git a/ydb/core/graph/shard/ut/CMakeLists.darwin-arm64.txt b/ydb/core/graph/shard/ut/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..8d09fd9adc73 --- /dev/null +++ b/ydb/core/graph/shard/ut/CMakeLists.darwin-arm64.txt @@ -0,0 +1,71 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-graph-shard-ut) +target_compile_options(ydb-core-graph-shard-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-graph-shard-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard +) +target_link_libraries(ydb-core-graph-shard-ut PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + core-graph-shard + library-actors-helpers + tx-schemeshard-ut_helpers + core-testlib-default +) +target_link_options(ydb-core-graph-shard-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-core-graph-shard-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/ut/shard_ut.cpp +) +set_property( + TARGET + ydb-core-graph-shard-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-graph-shard-ut + TEST_TARGET + ydb-core-graph-shard-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-graph-shard-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-graph-shard-ut + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-core-graph-shard-ut + system_allocator +) +vcs_info(ydb-core-graph-shard-ut) diff --git a/ydb/core/graph/shard/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/graph/shard/ut/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..658949c6c757 --- /dev/null +++ b/ydb/core/graph/shard/ut/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,72 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-graph-shard-ut) +target_compile_options(ydb-core-graph-shard-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-graph-shard-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard +) +target_link_libraries(ydb-core-graph-shard-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + core-graph-shard + library-actors-helpers + tx-schemeshard-ut_helpers + core-testlib-default +) +target_link_options(ydb-core-graph-shard-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-core-graph-shard-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/ut/shard_ut.cpp +) +set_property( + TARGET + ydb-core-graph-shard-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-graph-shard-ut + TEST_TARGET + ydb-core-graph-shard-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-graph-shard-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-graph-shard-ut + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-core-graph-shard-ut + system_allocator +) +vcs_info(ydb-core-graph-shard-ut) diff --git a/ydb/core/graph/shard/ut/CMakeLists.linux-aarch64.txt b/ydb/core/graph/shard/ut/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..94c63a88a604 --- /dev/null +++ b/ydb/core/graph/shard/ut/CMakeLists.linux-aarch64.txt @@ -0,0 +1,74 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-graph-shard-ut) +target_compile_options(ydb-core-graph-shard-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-graph-shard-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard +) +target_link_libraries(ydb-core-graph-shard-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + core-graph-shard + library-actors-helpers + tx-schemeshard-ut_helpers + core-testlib-default +) +target_link_options(ydb-core-graph-shard-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-core-graph-shard-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/ut/shard_ut.cpp +) +set_property( + TARGET + ydb-core-graph-shard-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-graph-shard-ut + TEST_TARGET + ydb-core-graph-shard-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-graph-shard-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-graph-shard-ut + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-core-graph-shard-ut + cpp-malloc-jemalloc +) +vcs_info(ydb-core-graph-shard-ut) diff --git a/ydb/core/graph/shard/ut/CMakeLists.linux-x86_64.txt b/ydb/core/graph/shard/ut/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..02b2e29294c4 --- /dev/null +++ b/ydb/core/graph/shard/ut/CMakeLists.linux-x86_64.txt @@ -0,0 +1,76 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-graph-shard-ut) +target_compile_options(ydb-core-graph-shard-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-graph-shard-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard +) +target_link_libraries(ydb-core-graph-shard-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + core-graph-shard + library-actors-helpers + tx-schemeshard-ut_helpers + core-testlib-default +) +target_link_options(ydb-core-graph-shard-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-core-graph-shard-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/ut/shard_ut.cpp +) +set_property( + TARGET + ydb-core-graph-shard-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-graph-shard-ut + TEST_TARGET + ydb-core-graph-shard-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-graph-shard-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-graph-shard-ut + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-core-graph-shard-ut + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(ydb-core-graph-shard-ut) diff --git a/ydb/core/graph/shard/ut/CMakeLists.txt b/ydb/core/graph/shard/ut/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/graph/shard/ut/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/graph/shard/ut/CMakeLists.windows-x86_64.txt b/ydb/core/graph/shard/ut/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..0a232c3a4320 --- /dev/null +++ b/ydb/core/graph/shard/ut/CMakeLists.windows-x86_64.txt @@ -0,0 +1,67 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-graph-shard-ut) +target_compile_options(ydb-core-graph-shard-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-graph-shard-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard +) +target_link_libraries(ydb-core-graph-shard-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + core-graph-shard + library-actors-helpers + tx-schemeshard-ut_helpers + core-testlib-default +) +target_sources(ydb-core-graph-shard-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/shard/ut/shard_ut.cpp +) +set_property( + TARGET + ydb-core-graph-shard-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-graph-shard-ut + TEST_TARGET + ydb-core-graph-shard-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-graph-shard-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-graph-shard-ut + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-core-graph-shard-ut + system_allocator +) +vcs_info(ydb-core-graph-shard-ut) diff --git a/ydb/core/graph/ut/CMakeLists.darwin-arm64.txt b/ydb/core/graph/ut/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..304f86876790 --- /dev/null +++ b/ydb/core/graph/ut/CMakeLists.darwin-arm64.txt @@ -0,0 +1,72 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-graph-ut) +target_compile_options(ydb-core-graph-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-graph-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph +) +target_link_libraries(ydb-core-graph-ut PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + library-actors-helpers + tx-schemeshard-ut_helpers + core-testlib-default + core-graph-shard + core-graph-service +) +target_link_options(ydb-core-graph-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-core-graph-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/ut/graph_ut.cpp +) +set_property( + TARGET + ydb-core-graph-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-graph-ut + TEST_TARGET + ydb-core-graph-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-graph-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-graph-ut + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-core-graph-ut + system_allocator +) +vcs_info(ydb-core-graph-ut) diff --git a/ydb/core/graph/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/graph/ut/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..3608a015823e --- /dev/null +++ b/ydb/core/graph/ut/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,73 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-graph-ut) +target_compile_options(ydb-core-graph-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-graph-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph +) +target_link_libraries(ydb-core-graph-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + library-actors-helpers + tx-schemeshard-ut_helpers + core-testlib-default + core-graph-shard + core-graph-service +) +target_link_options(ydb-core-graph-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-core-graph-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/ut/graph_ut.cpp +) +set_property( + TARGET + ydb-core-graph-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-graph-ut + TEST_TARGET + ydb-core-graph-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-graph-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-graph-ut + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-core-graph-ut + system_allocator +) +vcs_info(ydb-core-graph-ut) diff --git a/ydb/core/graph/ut/CMakeLists.linux-aarch64.txt b/ydb/core/graph/ut/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..fa83e0c4c2a4 --- /dev/null +++ b/ydb/core/graph/ut/CMakeLists.linux-aarch64.txt @@ -0,0 +1,75 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-graph-ut) +target_compile_options(ydb-core-graph-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-graph-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph +) +target_link_libraries(ydb-core-graph-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + library-actors-helpers + tx-schemeshard-ut_helpers + core-testlib-default + core-graph-shard + core-graph-service +) +target_link_options(ydb-core-graph-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-core-graph-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/ut/graph_ut.cpp +) +set_property( + TARGET + ydb-core-graph-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-graph-ut + TEST_TARGET + ydb-core-graph-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-graph-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-graph-ut + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-core-graph-ut + cpp-malloc-jemalloc +) +vcs_info(ydb-core-graph-ut) diff --git a/ydb/core/graph/ut/CMakeLists.linux-x86_64.txt b/ydb/core/graph/ut/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..4f6b102d9610 --- /dev/null +++ b/ydb/core/graph/ut/CMakeLists.linux-x86_64.txt @@ -0,0 +1,77 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-graph-ut) +target_compile_options(ydb-core-graph-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-graph-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph +) +target_link_libraries(ydb-core-graph-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + library-actors-helpers + tx-schemeshard-ut_helpers + core-testlib-default + core-graph-shard + core-graph-service +) +target_link_options(ydb-core-graph-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-core-graph-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/ut/graph_ut.cpp +) +set_property( + TARGET + ydb-core-graph-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-graph-ut + TEST_TARGET + ydb-core-graph-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-graph-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-graph-ut + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-core-graph-ut + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(ydb-core-graph-ut) diff --git a/ydb/core/graph/ut/CMakeLists.txt b/ydb/core/graph/ut/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/graph/ut/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/graph/ut/CMakeLists.windows-x86_64.txt b/ydb/core/graph/ut/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..ae97d99cf917 --- /dev/null +++ b/ydb/core/graph/ut/CMakeLists.windows-x86_64.txt @@ -0,0 +1,68 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-graph-ut) +target_compile_options(ydb-core-graph-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-graph-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph +) +target_link_libraries(ydb-core-graph-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + library-actors-helpers + tx-schemeshard-ut_helpers + core-testlib-default + core-graph-shard + core-graph-service +) +target_sources(ydb-core-graph-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/graph/ut/graph_ut.cpp +) +set_property( + TARGET + ydb-core-graph-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-graph-ut + TEST_TARGET + ydb-core-graph-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-graph-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-graph-ut + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-core-graph-ut + system_allocator +) +vcs_info(ydb-core-graph-ut) diff --git a/ydb/core/grpc_services/CMakeLists.darwin-arm64.txt b/ydb/core/grpc_services/CMakeLists.darwin-arm64.txt index 42e3c2e08c4f..0a054a07e78f 100644 --- a/ydb/core/grpc_services/CMakeLists.darwin-arm64.txt +++ b/ydb/core/grpc_services/CMakeLists.darwin-arm64.txt @@ -39,7 +39,7 @@ target_link_libraries(ydb-core-grpc_services PUBLIC core-grpc_services-cancelation core-grpc_services-auth_processor ydb-core-health_check - ydb-core-io_formats + core-io_formats-ydb_dump core-kesus-tablet core-kqp-common ydb-core-protos @@ -69,6 +69,8 @@ target_link_libraries(ydb-core-grpc_services PUBLIC services-ext_index-common ) target_sources(ydb-core-grpc_services PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/db_metadata_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/query/service_query.h ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/audit_log.cpp ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/audit_dml_operations.cpp ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/grpc_endpoint_publish_actor.cpp diff --git a/ydb/core/grpc_services/CMakeLists.darwin-x86_64.txt b/ydb/core/grpc_services/CMakeLists.darwin-x86_64.txt index 42e3c2e08c4f..0a054a07e78f 100644 --- a/ydb/core/grpc_services/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/grpc_services/CMakeLists.darwin-x86_64.txt @@ -39,7 +39,7 @@ target_link_libraries(ydb-core-grpc_services PUBLIC core-grpc_services-cancelation core-grpc_services-auth_processor ydb-core-health_check - ydb-core-io_formats + core-io_formats-ydb_dump core-kesus-tablet core-kqp-common ydb-core-protos @@ -69,6 +69,8 @@ target_link_libraries(ydb-core-grpc_services PUBLIC services-ext_index-common ) target_sources(ydb-core-grpc_services PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/db_metadata_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/query/service_query.h ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/audit_log.cpp ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/audit_dml_operations.cpp ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/grpc_endpoint_publish_actor.cpp diff --git a/ydb/core/grpc_services/CMakeLists.linux-aarch64.txt b/ydb/core/grpc_services/CMakeLists.linux-aarch64.txt index eabc5819db48..6b5f5cea2874 100644 --- a/ydb/core/grpc_services/CMakeLists.linux-aarch64.txt +++ b/ydb/core/grpc_services/CMakeLists.linux-aarch64.txt @@ -40,7 +40,7 @@ target_link_libraries(ydb-core-grpc_services PUBLIC core-grpc_services-cancelation core-grpc_services-auth_processor ydb-core-health_check - ydb-core-io_formats + core-io_formats-ydb_dump core-kesus-tablet core-kqp-common ydb-core-protos @@ -70,6 +70,8 @@ target_link_libraries(ydb-core-grpc_services PUBLIC services-ext_index-common ) target_sources(ydb-core-grpc_services PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/db_metadata_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/query/service_query.h ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/audit_log.cpp ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/audit_dml_operations.cpp ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/grpc_endpoint_publish_actor.cpp diff --git a/ydb/core/grpc_services/CMakeLists.linux-x86_64.txt b/ydb/core/grpc_services/CMakeLists.linux-x86_64.txt index eabc5819db48..6b5f5cea2874 100644 --- a/ydb/core/grpc_services/CMakeLists.linux-x86_64.txt +++ b/ydb/core/grpc_services/CMakeLists.linux-x86_64.txt @@ -40,7 +40,7 @@ target_link_libraries(ydb-core-grpc_services PUBLIC core-grpc_services-cancelation core-grpc_services-auth_processor ydb-core-health_check - ydb-core-io_formats + core-io_formats-ydb_dump core-kesus-tablet core-kqp-common ydb-core-protos @@ -70,6 +70,8 @@ target_link_libraries(ydb-core-grpc_services PUBLIC services-ext_index-common ) target_sources(ydb-core-grpc_services PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/db_metadata_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/query/service_query.h ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/audit_log.cpp ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/audit_dml_operations.cpp ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/grpc_endpoint_publish_actor.cpp diff --git a/ydb/core/grpc_services/CMakeLists.windows-x86_64.txt b/ydb/core/grpc_services/CMakeLists.windows-x86_64.txt index 42e3c2e08c4f..0a054a07e78f 100644 --- a/ydb/core/grpc_services/CMakeLists.windows-x86_64.txt +++ b/ydb/core/grpc_services/CMakeLists.windows-x86_64.txt @@ -39,7 +39,7 @@ target_link_libraries(ydb-core-grpc_services PUBLIC core-grpc_services-cancelation core-grpc_services-auth_processor ydb-core-health_check - ydb-core-io_formats + core-io_formats-ydb_dump core-kesus-tablet core-kqp-common ydb-core-protos @@ -69,6 +69,8 @@ target_link_libraries(ydb-core-grpc_services PUBLIC services-ext_index-common ) target_sources(ydb-core-grpc_services PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/db_metadata_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/query/service_query.h ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/audit_log.cpp ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/audit_dml_operations.cpp ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/grpc_endpoint_publish_actor.cpp diff --git a/ydb/core/grpc_services/base/CMakeLists.darwin-arm64.txt b/ydb/core/grpc_services/base/CMakeLists.darwin-arm64.txt index 25d885cac0cf..adb4bedfe5ff 100644 --- a/ydb/core/grpc_services/base/CMakeLists.darwin-arm64.txt +++ b/ydb/core/grpc_services/base/CMakeLists.darwin-arm64.txt @@ -20,3 +20,7 @@ target_link_libraries(core-grpc_services-base INTERFACE cpp-client-resources yql-public-issue ) +target_sources(core-grpc_services-base INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/base/base_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/base/base.h +) diff --git a/ydb/core/grpc_services/base/CMakeLists.darwin-x86_64.txt b/ydb/core/grpc_services/base/CMakeLists.darwin-x86_64.txt index 25d885cac0cf..adb4bedfe5ff 100644 --- a/ydb/core/grpc_services/base/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/grpc_services/base/CMakeLists.darwin-x86_64.txt @@ -20,3 +20,7 @@ target_link_libraries(core-grpc_services-base INTERFACE cpp-client-resources yql-public-issue ) +target_sources(core-grpc_services-base INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/base/base_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/base/base.h +) diff --git a/ydb/core/grpc_services/base/CMakeLists.linux-aarch64.txt b/ydb/core/grpc_services/base/CMakeLists.linux-aarch64.txt index 386b4dba850f..dc6647953c50 100644 --- a/ydb/core/grpc_services/base/CMakeLists.linux-aarch64.txt +++ b/ydb/core/grpc_services/base/CMakeLists.linux-aarch64.txt @@ -21,3 +21,7 @@ target_link_libraries(core-grpc_services-base INTERFACE cpp-client-resources yql-public-issue ) +target_sources(core-grpc_services-base INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/base/base_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/base/base.h +) diff --git a/ydb/core/grpc_services/base/CMakeLists.linux-x86_64.txt b/ydb/core/grpc_services/base/CMakeLists.linux-x86_64.txt index 386b4dba850f..dc6647953c50 100644 --- a/ydb/core/grpc_services/base/CMakeLists.linux-x86_64.txt +++ b/ydb/core/grpc_services/base/CMakeLists.linux-x86_64.txt @@ -21,3 +21,7 @@ target_link_libraries(core-grpc_services-base INTERFACE cpp-client-resources yql-public-issue ) +target_sources(core-grpc_services-base INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/base/base_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/base/base.h +) diff --git a/ydb/core/grpc_services/base/CMakeLists.windows-x86_64.txt b/ydb/core/grpc_services/base/CMakeLists.windows-x86_64.txt index 25d885cac0cf..adb4bedfe5ff 100644 --- a/ydb/core/grpc_services/base/CMakeLists.windows-x86_64.txt +++ b/ydb/core/grpc_services/base/CMakeLists.windows-x86_64.txt @@ -20,3 +20,7 @@ target_link_libraries(core-grpc_services-base INTERFACE cpp-client-resources yql-public-issue ) +target_sources(core-grpc_services-base INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/base/base_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/base/base.h +) diff --git a/ydb/core/grpc_services/cancelation/protos/CMakeLists.darwin-arm64.txt b/ydb/core/grpc_services/cancelation/protos/CMakeLists.darwin-arm64.txt index e12075948358..f910f456f370 100644 --- a/ydb/core/grpc_services/cancelation/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/core/grpc_services/cancelation/protos/CMakeLists.darwin-arm64.txt @@ -29,6 +29,9 @@ target_link_libraries(grpc_services-cancelation-protos PUBLIC target_proto_messages(grpc_services-cancelation-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/cancelation/protos/event.proto ) +target_sources(grpc_services-cancelation-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/grpc_services/cancelation/protos/event.pb.h +) target_proto_addincls(grpc_services-cancelation-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/grpc_services/cancelation/protos/CMakeLists.darwin-x86_64.txt b/ydb/core/grpc_services/cancelation/protos/CMakeLists.darwin-x86_64.txt index e12075948358..f910f456f370 100644 --- a/ydb/core/grpc_services/cancelation/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/grpc_services/cancelation/protos/CMakeLists.darwin-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(grpc_services-cancelation-protos PUBLIC target_proto_messages(grpc_services-cancelation-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/cancelation/protos/event.proto ) +target_sources(grpc_services-cancelation-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/grpc_services/cancelation/protos/event.pb.h +) target_proto_addincls(grpc_services-cancelation-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/grpc_services/cancelation/protos/CMakeLists.linux-aarch64.txt b/ydb/core/grpc_services/cancelation/protos/CMakeLists.linux-aarch64.txt index 836c5d515b14..3f5c3fc8621a 100644 --- a/ydb/core/grpc_services/cancelation/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/core/grpc_services/cancelation/protos/CMakeLists.linux-aarch64.txt @@ -30,6 +30,9 @@ target_link_libraries(grpc_services-cancelation-protos PUBLIC target_proto_messages(grpc_services-cancelation-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/cancelation/protos/event.proto ) +target_sources(grpc_services-cancelation-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/grpc_services/cancelation/protos/event.pb.h +) target_proto_addincls(grpc_services-cancelation-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/grpc_services/cancelation/protos/CMakeLists.linux-x86_64.txt b/ydb/core/grpc_services/cancelation/protos/CMakeLists.linux-x86_64.txt index 836c5d515b14..3f5c3fc8621a 100644 --- a/ydb/core/grpc_services/cancelation/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/core/grpc_services/cancelation/protos/CMakeLists.linux-x86_64.txt @@ -30,6 +30,9 @@ target_link_libraries(grpc_services-cancelation-protos PUBLIC target_proto_messages(grpc_services-cancelation-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/cancelation/protos/event.proto ) +target_sources(grpc_services-cancelation-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/grpc_services/cancelation/protos/event.pb.h +) target_proto_addincls(grpc_services-cancelation-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/grpc_services/cancelation/protos/CMakeLists.windows-x86_64.txt b/ydb/core/grpc_services/cancelation/protos/CMakeLists.windows-x86_64.txt index e12075948358..f910f456f370 100644 --- a/ydb/core/grpc_services/cancelation/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/core/grpc_services/cancelation/protos/CMakeLists.windows-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(grpc_services-cancelation-protos PUBLIC target_proto_messages(grpc_services-cancelation-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/cancelation/protos/event.proto ) +target_sources(grpc_services-cancelation-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/grpc_services/cancelation/protos/event.pb.h +) target_proto_addincls(grpc_services-cancelation-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/grpc_services/counters/CMakeLists.darwin-arm64.txt b/ydb/core/grpc_services/counters/CMakeLists.darwin-arm64.txt index 9738ee1e46a4..c5246c9363fa 100644 --- a/ydb/core/grpc_services/counters/CMakeLists.darwin-arm64.txt +++ b/ydb/core/grpc_services/counters/CMakeLists.darwin-arm64.txt @@ -19,6 +19,8 @@ target_link_libraries(core-grpc_services-counters PUBLIC core-sys_view-service ) target_sources(core-grpc_services-counters PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/counters/counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/counters/proxy_counters.h ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/counters/counters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/counters/proxy_counters.cpp ) diff --git a/ydb/core/grpc_services/counters/CMakeLists.darwin-x86_64.txt b/ydb/core/grpc_services/counters/CMakeLists.darwin-x86_64.txt index 9738ee1e46a4..c5246c9363fa 100644 --- a/ydb/core/grpc_services/counters/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/grpc_services/counters/CMakeLists.darwin-x86_64.txt @@ -19,6 +19,8 @@ target_link_libraries(core-grpc_services-counters PUBLIC core-sys_view-service ) target_sources(core-grpc_services-counters PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/counters/counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/counters/proxy_counters.h ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/counters/counters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/counters/proxy_counters.cpp ) diff --git a/ydb/core/grpc_services/counters/CMakeLists.linux-aarch64.txt b/ydb/core/grpc_services/counters/CMakeLists.linux-aarch64.txt index 2c1e1761e725..b86ee7ae74ae 100644 --- a/ydb/core/grpc_services/counters/CMakeLists.linux-aarch64.txt +++ b/ydb/core/grpc_services/counters/CMakeLists.linux-aarch64.txt @@ -20,6 +20,8 @@ target_link_libraries(core-grpc_services-counters PUBLIC core-sys_view-service ) target_sources(core-grpc_services-counters PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/counters/counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/counters/proxy_counters.h ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/counters/counters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/counters/proxy_counters.cpp ) diff --git a/ydb/core/grpc_services/counters/CMakeLists.linux-x86_64.txt b/ydb/core/grpc_services/counters/CMakeLists.linux-x86_64.txt index 2c1e1761e725..b86ee7ae74ae 100644 --- a/ydb/core/grpc_services/counters/CMakeLists.linux-x86_64.txt +++ b/ydb/core/grpc_services/counters/CMakeLists.linux-x86_64.txt @@ -20,6 +20,8 @@ target_link_libraries(core-grpc_services-counters PUBLIC core-sys_view-service ) target_sources(core-grpc_services-counters PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/counters/counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/counters/proxy_counters.h ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/counters/counters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/counters/proxy_counters.cpp ) diff --git a/ydb/core/grpc_services/counters/CMakeLists.windows-x86_64.txt b/ydb/core/grpc_services/counters/CMakeLists.windows-x86_64.txt index 9738ee1e46a4..c5246c9363fa 100644 --- a/ydb/core/grpc_services/counters/CMakeLists.windows-x86_64.txt +++ b/ydb/core/grpc_services/counters/CMakeLists.windows-x86_64.txt @@ -19,6 +19,8 @@ target_link_libraries(core-grpc_services-counters PUBLIC core-sys_view-service ) target_sources(core-grpc_services-counters PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/counters/counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/counters/proxy_counters.h ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/counters/counters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/counters/proxy_counters.cpp ) diff --git a/ydb/core/grpc_services/local_rpc/CMakeLists.darwin-arm64.txt b/ydb/core/grpc_services/local_rpc/CMakeLists.darwin-arm64.txt index f446f6684628..9d944032cd8b 100644 --- a/ydb/core/grpc_services/local_rpc/CMakeLists.darwin-arm64.txt +++ b/ydb/core/grpc_services/local_rpc/CMakeLists.darwin-arm64.txt @@ -14,3 +14,6 @@ target_link_libraries(core-grpc_services-local_rpc INTERFACE ydb-core-base core-grpc_services-base ) +target_sources(core-grpc_services-local_rpc INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/local_rpc/local_rpc.h +) diff --git a/ydb/core/grpc_services/local_rpc/CMakeLists.darwin-x86_64.txt b/ydb/core/grpc_services/local_rpc/CMakeLists.darwin-x86_64.txt index f446f6684628..9d944032cd8b 100644 --- a/ydb/core/grpc_services/local_rpc/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/grpc_services/local_rpc/CMakeLists.darwin-x86_64.txt @@ -14,3 +14,6 @@ target_link_libraries(core-grpc_services-local_rpc INTERFACE ydb-core-base core-grpc_services-base ) +target_sources(core-grpc_services-local_rpc INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/local_rpc/local_rpc.h +) diff --git a/ydb/core/grpc_services/local_rpc/CMakeLists.linux-aarch64.txt b/ydb/core/grpc_services/local_rpc/CMakeLists.linux-aarch64.txt index e93f011dede3..fa768d8997cb 100644 --- a/ydb/core/grpc_services/local_rpc/CMakeLists.linux-aarch64.txt +++ b/ydb/core/grpc_services/local_rpc/CMakeLists.linux-aarch64.txt @@ -15,3 +15,6 @@ target_link_libraries(core-grpc_services-local_rpc INTERFACE ydb-core-base core-grpc_services-base ) +target_sources(core-grpc_services-local_rpc INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/local_rpc/local_rpc.h +) diff --git a/ydb/core/grpc_services/local_rpc/CMakeLists.linux-x86_64.txt b/ydb/core/grpc_services/local_rpc/CMakeLists.linux-x86_64.txt index e93f011dede3..fa768d8997cb 100644 --- a/ydb/core/grpc_services/local_rpc/CMakeLists.linux-x86_64.txt +++ b/ydb/core/grpc_services/local_rpc/CMakeLists.linux-x86_64.txt @@ -15,3 +15,6 @@ target_link_libraries(core-grpc_services-local_rpc INTERFACE ydb-core-base core-grpc_services-base ) +target_sources(core-grpc_services-local_rpc INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/local_rpc/local_rpc.h +) diff --git a/ydb/core/grpc_services/local_rpc/CMakeLists.windows-x86_64.txt b/ydb/core/grpc_services/local_rpc/CMakeLists.windows-x86_64.txt index f446f6684628..9d944032cd8b 100644 --- a/ydb/core/grpc_services/local_rpc/CMakeLists.windows-x86_64.txt +++ b/ydb/core/grpc_services/local_rpc/CMakeLists.windows-x86_64.txt @@ -14,3 +14,6 @@ target_link_libraries(core-grpc_services-local_rpc INTERFACE ydb-core-base core-grpc_services-base ) +target_sources(core-grpc_services-local_rpc INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/local_rpc/local_rpc.h +) diff --git a/ydb/core/grpc_services/ut/CMakeLists.darwin-arm64.txt b/ydb/core/grpc_services/ut/CMakeLists.darwin-arm64.txt index 1515ac312f35..27323524c014 100644 --- a/ydb/core/grpc_services/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/grpc_services/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-grpc_services-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-grpc_services-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/rpc_calls_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/grpc_services/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/grpc_services/ut/CMakeLists.darwin-x86_64.txt index cbc84c0328f9..1aa2c9e81ee9 100644 --- a/ydb/core/grpc_services/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/grpc_services/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-grpc_services-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-grpc_services-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/rpc_calls_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/grpc_services/ut/CMakeLists.linux-aarch64.txt b/ydb/core/grpc_services/ut/CMakeLists.linux-aarch64.txt index 1ec3b7478c27..de8a9d5dccab 100644 --- a/ydb/core/grpc_services/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/grpc_services/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-grpc_services-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-grpc_services-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/rpc_calls_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/grpc_services/ut/CMakeLists.linux-x86_64.txt b/ydb/core/grpc_services/ut/CMakeLists.linux-x86_64.txt index 748191faf97d..c49370404d94 100644 --- a/ydb/core/grpc_services/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/grpc_services/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-grpc_services-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-grpc_services-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/grpc_services/rpc_calls_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/grpc_services/ut/CMakeLists.windows-x86_64.txt b/ydb/core/grpc_services/ut/CMakeLists.windows-x86_64.txt index e5e58ab7a4b5..8e7e8e42abe4 100644 --- a/ydb/core/grpc_services/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/grpc_services/ut/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/grpc_streaming/ut/CMakeLists.darwin-arm64.txt b/ydb/core/grpc_streaming/ut/CMakeLists.darwin-arm64.txt index d97d42c34ed8..2d73bd059729 100644 --- a/ydb/core/grpc_streaming/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/grpc_streaming/ut/CMakeLists.darwin-arm64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-grpc_streaming-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-grpc_streaming-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/grpc_streaming/grpc_streaming_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/grpc_streaming/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/grpc_streaming/ut/CMakeLists.darwin-x86_64.txt index e695b814279b..80fd847d4542 100644 --- a/ydb/core/grpc_streaming/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/grpc_streaming/ut/CMakeLists.darwin-x86_64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-core-grpc_streaming-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-grpc_streaming-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/grpc_streaming/grpc_streaming_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/grpc_streaming/ut/CMakeLists.linux-aarch64.txt b/ydb/core/grpc_streaming/ut/CMakeLists.linux-aarch64.txt index e80dd5314aa8..a74f96e0444d 100644 --- a/ydb/core/grpc_streaming/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/grpc_streaming/ut/CMakeLists.linux-aarch64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-grpc_streaming-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-grpc_streaming-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/grpc_streaming/grpc_streaming_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/grpc_streaming/ut/CMakeLists.linux-x86_64.txt b/ydb/core/grpc_streaming/ut/CMakeLists.linux-x86_64.txt index e53c9e864d1f..4814cd92c9f4 100644 --- a/ydb/core/grpc_streaming/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/grpc_streaming/ut/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-core-grpc_streaming-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-grpc_streaming-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/grpc_streaming/grpc_streaming_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/grpc_streaming/ut/CMakeLists.windows-x86_64.txt b/ydb/core/grpc_streaming/ut/CMakeLists.windows-x86_64.txt index bc9ea30e4f52..1caefd88517e 100644 --- a/ydb/core/grpc_streaming/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/grpc_streaming/ut/CMakeLists.windows-x86_64.txt @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/grpc_streaming/ut/grpc/CMakeLists.darwin-arm64.txt b/ydb/core/grpc_streaming/ut/grpc/CMakeLists.darwin-arm64.txt index cf5d7ddabfb9..8e5070146635 100644 --- a/ydb/core/grpc_streaming/ut/grpc/CMakeLists.darwin-arm64.txt +++ b/ydb/core/grpc_streaming/ut/grpc/CMakeLists.darwin-arm64.txt @@ -38,6 +38,10 @@ target_link_libraries(grpc_streaming-ut-grpc PUBLIC target_proto_messages(grpc_streaming-ut-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/grpc_streaming/ut/grpc/streaming_service.proto ) +target_sources(grpc_streaming-ut-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/grpc_streaming/ut/grpc/streaming_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/grpc_streaming/ut/grpc/streaming_service.grpc.pb.h +) target_proto_addincls(grpc_streaming-ut-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/grpc_streaming/ut/grpc/CMakeLists.darwin-x86_64.txt b/ydb/core/grpc_streaming/ut/grpc/CMakeLists.darwin-x86_64.txt index cf5d7ddabfb9..8e5070146635 100644 --- a/ydb/core/grpc_streaming/ut/grpc/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/grpc_streaming/ut/grpc/CMakeLists.darwin-x86_64.txt @@ -38,6 +38,10 @@ target_link_libraries(grpc_streaming-ut-grpc PUBLIC target_proto_messages(grpc_streaming-ut-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/grpc_streaming/ut/grpc/streaming_service.proto ) +target_sources(grpc_streaming-ut-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/grpc_streaming/ut/grpc/streaming_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/grpc_streaming/ut/grpc/streaming_service.grpc.pb.h +) target_proto_addincls(grpc_streaming-ut-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/grpc_streaming/ut/grpc/CMakeLists.linux-aarch64.txt b/ydb/core/grpc_streaming/ut/grpc/CMakeLists.linux-aarch64.txt index 414016cadb4c..bf92d144ee30 100644 --- a/ydb/core/grpc_streaming/ut/grpc/CMakeLists.linux-aarch64.txt +++ b/ydb/core/grpc_streaming/ut/grpc/CMakeLists.linux-aarch64.txt @@ -39,6 +39,10 @@ target_link_libraries(grpc_streaming-ut-grpc PUBLIC target_proto_messages(grpc_streaming-ut-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/grpc_streaming/ut/grpc/streaming_service.proto ) +target_sources(grpc_streaming-ut-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/grpc_streaming/ut/grpc/streaming_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/grpc_streaming/ut/grpc/streaming_service.grpc.pb.h +) target_proto_addincls(grpc_streaming-ut-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/grpc_streaming/ut/grpc/CMakeLists.linux-x86_64.txt b/ydb/core/grpc_streaming/ut/grpc/CMakeLists.linux-x86_64.txt index 414016cadb4c..bf92d144ee30 100644 --- a/ydb/core/grpc_streaming/ut/grpc/CMakeLists.linux-x86_64.txt +++ b/ydb/core/grpc_streaming/ut/grpc/CMakeLists.linux-x86_64.txt @@ -39,6 +39,10 @@ target_link_libraries(grpc_streaming-ut-grpc PUBLIC target_proto_messages(grpc_streaming-ut-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/grpc_streaming/ut/grpc/streaming_service.proto ) +target_sources(grpc_streaming-ut-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/grpc_streaming/ut/grpc/streaming_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/grpc_streaming/ut/grpc/streaming_service.grpc.pb.h +) target_proto_addincls(grpc_streaming-ut-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/grpc_streaming/ut/grpc/CMakeLists.windows-x86_64.txt b/ydb/core/grpc_streaming/ut/grpc/CMakeLists.windows-x86_64.txt index cf5d7ddabfb9..8e5070146635 100644 --- a/ydb/core/grpc_streaming/ut/grpc/CMakeLists.windows-x86_64.txt +++ b/ydb/core/grpc_streaming/ut/grpc/CMakeLists.windows-x86_64.txt @@ -38,6 +38,10 @@ target_link_libraries(grpc_streaming-ut-grpc PUBLIC target_proto_messages(grpc_streaming-ut-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/grpc_streaming/ut/grpc/streaming_service.proto ) +target_sources(grpc_streaming-ut-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/grpc_streaming/ut/grpc/streaming_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/grpc_streaming/ut/grpc/streaming_service.grpc.pb.h +) target_proto_addincls(grpc_streaming-ut-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/health_check/CMakeLists.darwin-arm64.txt b/ydb/core/health_check/CMakeLists.darwin-arm64.txt index f55659260cde..87050e3cea5e 100644 --- a/ydb/core/health_check/CMakeLists.darwin-arm64.txt +++ b/ydb/core/health_check/CMakeLists.darwin-arm64.txt @@ -21,5 +21,6 @@ target_link_libraries(ydb-core-health_check PUBLIC public-issue-protos ) target_sources(ydb-core-health_check PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/health_check/health_check.h ${CMAKE_SOURCE_DIR}/ydb/core/health_check/health_check.cpp ) diff --git a/ydb/core/health_check/CMakeLists.darwin-x86_64.txt b/ydb/core/health_check/CMakeLists.darwin-x86_64.txt index f55659260cde..87050e3cea5e 100644 --- a/ydb/core/health_check/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/health_check/CMakeLists.darwin-x86_64.txt @@ -21,5 +21,6 @@ target_link_libraries(ydb-core-health_check PUBLIC public-issue-protos ) target_sources(ydb-core-health_check PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/health_check/health_check.h ${CMAKE_SOURCE_DIR}/ydb/core/health_check/health_check.cpp ) diff --git a/ydb/core/health_check/CMakeLists.linux-aarch64.txt b/ydb/core/health_check/CMakeLists.linux-aarch64.txt index a5c42268c66d..9fd33bf30cce 100644 --- a/ydb/core/health_check/CMakeLists.linux-aarch64.txt +++ b/ydb/core/health_check/CMakeLists.linux-aarch64.txt @@ -22,5 +22,6 @@ target_link_libraries(ydb-core-health_check PUBLIC public-issue-protos ) target_sources(ydb-core-health_check PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/health_check/health_check.h ${CMAKE_SOURCE_DIR}/ydb/core/health_check/health_check.cpp ) diff --git a/ydb/core/health_check/CMakeLists.linux-x86_64.txt b/ydb/core/health_check/CMakeLists.linux-x86_64.txt index a5c42268c66d..9fd33bf30cce 100644 --- a/ydb/core/health_check/CMakeLists.linux-x86_64.txt +++ b/ydb/core/health_check/CMakeLists.linux-x86_64.txt @@ -22,5 +22,6 @@ target_link_libraries(ydb-core-health_check PUBLIC public-issue-protos ) target_sources(ydb-core-health_check PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/health_check/health_check.h ${CMAKE_SOURCE_DIR}/ydb/core/health_check/health_check.cpp ) diff --git a/ydb/core/health_check/CMakeLists.windows-x86_64.txt b/ydb/core/health_check/CMakeLists.windows-x86_64.txt index f55659260cde..87050e3cea5e 100644 --- a/ydb/core/health_check/CMakeLists.windows-x86_64.txt +++ b/ydb/core/health_check/CMakeLists.windows-x86_64.txt @@ -21,5 +21,6 @@ target_link_libraries(ydb-core-health_check PUBLIC public-issue-protos ) target_sources(ydb-core-health_check PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/health_check/health_check.h ${CMAKE_SOURCE_DIR}/ydb/core/health_check/health_check.cpp ) diff --git a/ydb/core/health_check/ut/CMakeLists.darwin-arm64.txt b/ydb/core/health_check/ut/CMakeLists.darwin-arm64.txt index e16d9760ab75..7f32f6ed25b4 100644 --- a/ydb/core/health_check/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/health_check/ut/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-health_check-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-health_check-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/health_check/health_check_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/health_check/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/health_check/ut/CMakeLists.darwin-x86_64.txt index 0a7cae7e00fb..be11f1d18a28 100644 --- a/ydb/core/health_check/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/health_check/ut/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-health_check-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-health_check-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/health_check/health_check_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/health_check/ut/CMakeLists.linux-aarch64.txt b/ydb/core/health_check/ut/CMakeLists.linux-aarch64.txt index f60933001491..c1146423901c 100644 --- a/ydb/core/health_check/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/health_check/ut/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-health_check-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-health_check-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/health_check/health_check_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/health_check/ut/CMakeLists.linux-x86_64.txt b/ydb/core/health_check/ut/CMakeLists.linux-x86_64.txt index a79f990b26b6..b866aa9b8ccc 100644 --- a/ydb/core/health_check/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/health_check/ut/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-health_check-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-health_check-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/health_check/health_check_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/health_check/ut/CMakeLists.windows-x86_64.txt b/ydb/core/health_check/ut/CMakeLists.windows-x86_64.txt index 444a227e1cc0..cc35b596d3d2 100644 --- a/ydb/core/health_check/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/health_check/ut/CMakeLists.windows-x86_64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/http_proxy/CMakeLists.darwin-arm64.txt b/ydb/core/http_proxy/CMakeLists.darwin-arm64.txt index 773de1780320..98913aeebc38 100644 --- a/ydb/core/http_proxy/CMakeLists.darwin-arm64.txt +++ b/ydb/core/http_proxy/CMakeLists.darwin-arm64.txt @@ -38,6 +38,16 @@ target_link_libraries(ydb-core-http_proxy PUBLIC api-protos ) target_sources(ydb-core-http_proxy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/auth_factory.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/custom_metrics.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/discovery_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/exceptions_mapping.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/grpc_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/http_req.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/http_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/json_proto_conversion.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/metrics_actor.h ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/auth_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/discovery_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/exceptions_mapping.cpp diff --git a/ydb/core/http_proxy/CMakeLists.darwin-x86_64.txt b/ydb/core/http_proxy/CMakeLists.darwin-x86_64.txt index 773de1780320..98913aeebc38 100644 --- a/ydb/core/http_proxy/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/http_proxy/CMakeLists.darwin-x86_64.txt @@ -38,6 +38,16 @@ target_link_libraries(ydb-core-http_proxy PUBLIC api-protos ) target_sources(ydb-core-http_proxy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/auth_factory.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/custom_metrics.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/discovery_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/exceptions_mapping.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/grpc_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/http_req.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/http_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/json_proto_conversion.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/metrics_actor.h ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/auth_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/discovery_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/exceptions_mapping.cpp diff --git a/ydb/core/http_proxy/CMakeLists.linux-aarch64.txt b/ydb/core/http_proxy/CMakeLists.linux-aarch64.txt index 7cbdad430428..1393a4cb096f 100644 --- a/ydb/core/http_proxy/CMakeLists.linux-aarch64.txt +++ b/ydb/core/http_proxy/CMakeLists.linux-aarch64.txt @@ -39,6 +39,16 @@ target_link_libraries(ydb-core-http_proxy PUBLIC api-protos ) target_sources(ydb-core-http_proxy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/auth_factory.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/custom_metrics.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/discovery_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/exceptions_mapping.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/grpc_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/http_req.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/http_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/json_proto_conversion.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/metrics_actor.h ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/auth_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/discovery_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/exceptions_mapping.cpp diff --git a/ydb/core/http_proxy/CMakeLists.linux-x86_64.txt b/ydb/core/http_proxy/CMakeLists.linux-x86_64.txt index 7cbdad430428..1393a4cb096f 100644 --- a/ydb/core/http_proxy/CMakeLists.linux-x86_64.txt +++ b/ydb/core/http_proxy/CMakeLists.linux-x86_64.txt @@ -39,6 +39,16 @@ target_link_libraries(ydb-core-http_proxy PUBLIC api-protos ) target_sources(ydb-core-http_proxy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/auth_factory.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/custom_metrics.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/discovery_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/exceptions_mapping.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/grpc_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/http_req.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/http_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/json_proto_conversion.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/metrics_actor.h ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/auth_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/discovery_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/exceptions_mapping.cpp diff --git a/ydb/core/http_proxy/CMakeLists.windows-x86_64.txt b/ydb/core/http_proxy/CMakeLists.windows-x86_64.txt index 773de1780320..98913aeebc38 100644 --- a/ydb/core/http_proxy/CMakeLists.windows-x86_64.txt +++ b/ydb/core/http_proxy/CMakeLists.windows-x86_64.txt @@ -38,6 +38,16 @@ target_link_libraries(ydb-core-http_proxy PUBLIC api-protos ) target_sources(ydb-core-http_proxy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/auth_factory.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/custom_metrics.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/discovery_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/exceptions_mapping.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/grpc_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/http_req.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/http_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/json_proto_conversion.h + ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/metrics_actor.h ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/auth_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/discovery_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/exceptions_mapping.cpp diff --git a/ydb/core/http_proxy/ut/CMakeLists.darwin-arm64.txt b/ydb/core/http_proxy/ut/CMakeLists.darwin-arm64.txt index 94cc11f30a4e..1487ddfc8a4c 100644 --- a/ydb/core/http_proxy/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/http_proxy/ut/CMakeLists.darwin-arm64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-core-http_proxy-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-http_proxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/ut/json_proto_conversion_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/http_proxy/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/http_proxy/ut/CMakeLists.darwin-x86_64.txt index a58d83dc9c3f..153b398d9019 100644 --- a/ydb/core/http_proxy/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/http_proxy/ut/CMakeLists.darwin-x86_64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-http_proxy-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-http_proxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/ut/json_proto_conversion_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/http_proxy/ut/CMakeLists.linux-aarch64.txt b/ydb/core/http_proxy/ut/CMakeLists.linux-aarch64.txt index 4c2a361df4bd..c0846aecac0a 100644 --- a/ydb/core/http_proxy/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/http_proxy/ut/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-core-http_proxy-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-http_proxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/ut/json_proto_conversion_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/http_proxy/ut/CMakeLists.linux-x86_64.txt b/ydb/core/http_proxy/ut/CMakeLists.linux-x86_64.txt index 32dd275dd13a..5b864b8e0acd 100644 --- a/ydb/core/http_proxy/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/http_proxy/ut/CMakeLists.linux-x86_64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-http_proxy-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-http_proxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/http_proxy/ut/json_proto_conversion_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/http_proxy/ut/CMakeLists.windows-x86_64.txt b/ydb/core/http_proxy/ut/CMakeLists.windows-x86_64.txt index 0ff2ea5eeae5..bdee9ec08eab 100644 --- a/ydb/core/http_proxy/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/http_proxy/ut/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/io_formats/CMakeLists.txt b/ydb/core/io_formats/CMakeLists.txt index d863ebd18067..85bd72492bf7 100644 --- a/ydb/core/io_formats/CMakeLists.txt +++ b/ydb/core/io_formats/CMakeLists.txt @@ -6,14 +6,6 @@ # original buildsystem will not be accepted. -if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) - include(CMakeLists.linux-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) - include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) -endif() +add_subdirectory(arrow) +add_subdirectory(cell_maker) +add_subdirectory(ydb_dump) diff --git a/ydb/core/io_formats/arrow/CMakeLists.darwin-arm64.txt b/ydb/core/io_formats/arrow/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..104809697adc --- /dev/null +++ b/ydb/core/io_formats/arrow/CMakeLists.darwin-arm64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(core-io_formats-arrow) +target_compile_options(core-io_formats-arrow PRIVATE + -Wno-unused-parameter + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(core-io_formats-arrow PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-scheme_types + core-formats-arrow +) +target_sources(core-io_formats-arrow PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/arrow/csv_arrow.cpp +) diff --git a/ydb/core/io_formats/arrow/CMakeLists.darwin-x86_64.txt b/ydb/core/io_formats/arrow/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..104809697adc --- /dev/null +++ b/ydb/core/io_formats/arrow/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(core-io_formats-arrow) +target_compile_options(core-io_formats-arrow PRIVATE + -Wno-unused-parameter + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(core-io_formats-arrow PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-scheme_types + core-formats-arrow +) +target_sources(core-io_formats-arrow PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/arrow/csv_arrow.cpp +) diff --git a/ydb/core/io_formats/arrow/CMakeLists.linux-aarch64.txt b/ydb/core/io_formats/arrow/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..e784f8726fb4 --- /dev/null +++ b/ydb/core/io_formats/arrow/CMakeLists.linux-aarch64.txt @@ -0,0 +1,25 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(core-io_formats-arrow) +target_compile_options(core-io_formats-arrow PRIVATE + -Wno-unused-parameter + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(core-io_formats-arrow PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-scheme_types + core-formats-arrow +) +target_sources(core-io_formats-arrow PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/arrow/csv_arrow.cpp +) diff --git a/ydb/core/io_formats/arrow/CMakeLists.linux-x86_64.txt b/ydb/core/io_formats/arrow/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..e784f8726fb4 --- /dev/null +++ b/ydb/core/io_formats/arrow/CMakeLists.linux-x86_64.txt @@ -0,0 +1,25 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(core-io_formats-arrow) +target_compile_options(core-io_formats-arrow PRIVATE + -Wno-unused-parameter + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(core-io_formats-arrow PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-scheme_types + core-formats-arrow +) +target_sources(core-io_formats-arrow PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/arrow/csv_arrow.cpp +) diff --git a/ydb/core/io_formats/arrow/CMakeLists.txt b/ydb/core/io_formats/arrow/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/io_formats/arrow/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/io_formats/arrow/CMakeLists.windows-x86_64.txt b/ydb/core/io_formats/arrow/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..104809697adc --- /dev/null +++ b/ydb/core/io_formats/arrow/CMakeLists.windows-x86_64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(core-io_formats-arrow) +target_compile_options(core-io_formats-arrow PRIVATE + -Wno-unused-parameter + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(core-io_formats-arrow PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-scheme_types + core-formats-arrow +) +target_sources(core-io_formats-arrow PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/arrow/csv_arrow.cpp +) diff --git a/ydb/core/io_formats/arrow/ut/CMakeLists.darwin-arm64.txt b/ydb/core/io_formats/arrow/ut/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..ffd154c2abad --- /dev/null +++ b/ydb/core/io_formats/arrow/ut/CMakeLists.darwin-arm64.txt @@ -0,0 +1,70 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-io_formats-arrow-ut) +target_compile_options(ydb-core-io_formats-arrow-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-io_formats-arrow-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/arrow +) +target_link_libraries(ydb-core-io_formats-arrow-ut PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + core-io_formats-arrow + udf-service-exception_policy + yql-sql-pg_dummy +) +target_link_options(ydb-core-io_formats-arrow-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-core-io_formats-arrow-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/arrow/csv_arrow_ut.cpp +) +set_property( + TARGET + ydb-core-io_formats-arrow-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-io_formats-arrow-ut + TEST_TARGET + ydb-core-io_formats-arrow-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-io_formats-arrow-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-io_formats-arrow-ut + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-core-io_formats-arrow-ut + system_allocator +) +vcs_info(ydb-core-io_formats-arrow-ut) diff --git a/ydb/core/io_formats/arrow/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/io_formats/arrow/ut/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..7c1ef02316ea --- /dev/null +++ b/ydb/core/io_formats/arrow/ut/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,71 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-io_formats-arrow-ut) +target_compile_options(ydb-core-io_formats-arrow-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-io_formats-arrow-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/arrow +) +target_link_libraries(ydb-core-io_formats-arrow-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + core-io_formats-arrow + udf-service-exception_policy + yql-sql-pg_dummy +) +target_link_options(ydb-core-io_formats-arrow-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-core-io_formats-arrow-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/arrow/csv_arrow_ut.cpp +) +set_property( + TARGET + ydb-core-io_formats-arrow-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-io_formats-arrow-ut + TEST_TARGET + ydb-core-io_formats-arrow-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-io_formats-arrow-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-io_formats-arrow-ut + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-core-io_formats-arrow-ut + system_allocator +) +vcs_info(ydb-core-io_formats-arrow-ut) diff --git a/ydb/core/io_formats/arrow/ut/CMakeLists.linux-aarch64.txt b/ydb/core/io_formats/arrow/ut/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..1fe31e513398 --- /dev/null +++ b/ydb/core/io_formats/arrow/ut/CMakeLists.linux-aarch64.txt @@ -0,0 +1,73 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-io_formats-arrow-ut) +target_compile_options(ydb-core-io_formats-arrow-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-io_formats-arrow-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/arrow +) +target_link_libraries(ydb-core-io_formats-arrow-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + core-io_formats-arrow + udf-service-exception_policy + yql-sql-pg_dummy +) +target_link_options(ydb-core-io_formats-arrow-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-core-io_formats-arrow-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/arrow/csv_arrow_ut.cpp +) +set_property( + TARGET + ydb-core-io_formats-arrow-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-io_formats-arrow-ut + TEST_TARGET + ydb-core-io_formats-arrow-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-io_formats-arrow-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-io_formats-arrow-ut + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-core-io_formats-arrow-ut + cpp-malloc-jemalloc +) +vcs_info(ydb-core-io_formats-arrow-ut) diff --git a/ydb/core/io_formats/arrow/ut/CMakeLists.linux-x86_64.txt b/ydb/core/io_formats/arrow/ut/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..27a70d4cf882 --- /dev/null +++ b/ydb/core/io_formats/arrow/ut/CMakeLists.linux-x86_64.txt @@ -0,0 +1,75 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-io_formats-arrow-ut) +target_compile_options(ydb-core-io_formats-arrow-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-io_formats-arrow-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/arrow +) +target_link_libraries(ydb-core-io_formats-arrow-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + core-io_formats-arrow + udf-service-exception_policy + yql-sql-pg_dummy +) +target_link_options(ydb-core-io_formats-arrow-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-core-io_formats-arrow-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/arrow/csv_arrow_ut.cpp +) +set_property( + TARGET + ydb-core-io_formats-arrow-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-io_formats-arrow-ut + TEST_TARGET + ydb-core-io_formats-arrow-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-io_formats-arrow-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-io_formats-arrow-ut + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-core-io_formats-arrow-ut + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(ydb-core-io_formats-arrow-ut) diff --git a/ydb/core/io_formats/arrow/ut/CMakeLists.txt b/ydb/core/io_formats/arrow/ut/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/io_formats/arrow/ut/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/io_formats/arrow/ut/CMakeLists.windows-x86_64.txt b/ydb/core/io_formats/arrow/ut/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..87c39d282746 --- /dev/null +++ b/ydb/core/io_formats/arrow/ut/CMakeLists.windows-x86_64.txt @@ -0,0 +1,66 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-io_formats-arrow-ut) +target_compile_options(ydb-core-io_formats-arrow-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-io_formats-arrow-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/arrow +) +target_link_libraries(ydb-core-io_formats-arrow-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + core-io_formats-arrow + udf-service-exception_policy + yql-sql-pg_dummy +) +target_sources(ydb-core-io_formats-arrow-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/arrow/csv_arrow_ut.cpp +) +set_property( + TARGET + ydb-core-io_formats-arrow-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-io_formats-arrow-ut + TEST_TARGET + ydb-core-io_formats-arrow-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-io_formats-arrow-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-io_formats-arrow-ut + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-core-io_formats-arrow-ut + system_allocator +) +vcs_info(ydb-core-io_formats-arrow-ut) diff --git a/ydb/core/io_formats/CMakeLists.darwin-arm64.txt b/ydb/core/io_formats/cell_maker/CMakeLists.darwin-arm64.txt similarity index 63% rename from ydb/core/io_formats/CMakeLists.darwin-arm64.txt rename to ydb/core/io_formats/cell_maker/CMakeLists.darwin-arm64.txt index 617ed8f31fd1..83af0bd12fa0 100644 --- a/ydb/core/io_formats/CMakeLists.darwin-arm64.txt +++ b/ydb/core/io_formats/cell_maker/CMakeLists.darwin-arm64.txt @@ -6,29 +6,28 @@ # original buildsystem will not be accepted. -add_subdirectory(ut) -add_library(ydb-core-io_formats) -target_compile_options(ydb-core-io_formats PRIVATE - -Wno-unused-parameter +add_library(core-io_formats-cell_maker) +target_compile_options(core-io_formats-cell_maker PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(ydb-core-io_formats PUBLIC +target_link_libraries(core-io_formats-cell_maker PUBLIC contrib-libs-cxxsupp yutil - contrib-libs-double-conversion - cpp-string_utils-quote - core-formats-arrow ydb-core-scheme + ydb-core-scheme_types ydb-library-binary_json ydb-library-dynumber yql-minikql-dom yql-public-decimal yql-public-udf library-yql-utils - public-lib-scheme_types + contrib-libs-double-conversion + library-cpp-json + cpp-json-yson + cpp-string_utils-base64 + cpp-string_utils-quote ) -target_sources(ydb-core-io_formats PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/csv_ydb_dump.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/csv_arrow.cpp +target_sources(core-io_formats-cell_maker PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/cell_maker/cell_maker.cpp ) diff --git a/ydb/core/io_formats/CMakeLists.darwin-x86_64.txt b/ydb/core/io_formats/cell_maker/CMakeLists.darwin-x86_64.txt similarity index 63% rename from ydb/core/io_formats/CMakeLists.darwin-x86_64.txt rename to ydb/core/io_formats/cell_maker/CMakeLists.darwin-x86_64.txt index 617ed8f31fd1..83af0bd12fa0 100644 --- a/ydb/core/io_formats/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/io_formats/cell_maker/CMakeLists.darwin-x86_64.txt @@ -6,29 +6,28 @@ # original buildsystem will not be accepted. -add_subdirectory(ut) -add_library(ydb-core-io_formats) -target_compile_options(ydb-core-io_formats PRIVATE - -Wno-unused-parameter +add_library(core-io_formats-cell_maker) +target_compile_options(core-io_formats-cell_maker PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(ydb-core-io_formats PUBLIC +target_link_libraries(core-io_formats-cell_maker PUBLIC contrib-libs-cxxsupp yutil - contrib-libs-double-conversion - cpp-string_utils-quote - core-formats-arrow ydb-core-scheme + ydb-core-scheme_types ydb-library-binary_json ydb-library-dynumber yql-minikql-dom yql-public-decimal yql-public-udf library-yql-utils - public-lib-scheme_types + contrib-libs-double-conversion + library-cpp-json + cpp-json-yson + cpp-string_utils-base64 + cpp-string_utils-quote ) -target_sources(ydb-core-io_formats PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/csv_ydb_dump.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/csv_arrow.cpp +target_sources(core-io_formats-cell_maker PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/cell_maker/cell_maker.cpp ) diff --git a/ydb/core/io_formats/CMakeLists.linux-aarch64.txt b/ydb/core/io_formats/cell_maker/CMakeLists.linux-aarch64.txt similarity index 64% rename from ydb/core/io_formats/CMakeLists.linux-aarch64.txt rename to ydb/core/io_formats/cell_maker/CMakeLists.linux-aarch64.txt index 6128891a22ae..d1f0f464296b 100644 --- a/ydb/core/io_formats/CMakeLists.linux-aarch64.txt +++ b/ydb/core/io_formats/cell_maker/CMakeLists.linux-aarch64.txt @@ -6,30 +6,29 @@ # original buildsystem will not be accepted. -add_subdirectory(ut) -add_library(ydb-core-io_formats) -target_compile_options(ydb-core-io_formats PRIVATE - -Wno-unused-parameter +add_library(core-io_formats-cell_maker) +target_compile_options(core-io_formats-cell_maker PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(ydb-core-io_formats PUBLIC +target_link_libraries(core-io_formats-cell_maker PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - contrib-libs-double-conversion - cpp-string_utils-quote - core-formats-arrow ydb-core-scheme + ydb-core-scheme_types ydb-library-binary_json ydb-library-dynumber yql-minikql-dom yql-public-decimal yql-public-udf library-yql-utils - public-lib-scheme_types + contrib-libs-double-conversion + library-cpp-json + cpp-json-yson + cpp-string_utils-base64 + cpp-string_utils-quote ) -target_sources(ydb-core-io_formats PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/csv_ydb_dump.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/csv_arrow.cpp +target_sources(core-io_formats-cell_maker PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/cell_maker/cell_maker.cpp ) diff --git a/ydb/core/io_formats/CMakeLists.linux-x86_64.txt b/ydb/core/io_formats/cell_maker/CMakeLists.linux-x86_64.txt similarity index 64% rename from ydb/core/io_formats/CMakeLists.linux-x86_64.txt rename to ydb/core/io_formats/cell_maker/CMakeLists.linux-x86_64.txt index 6128891a22ae..d1f0f464296b 100644 --- a/ydb/core/io_formats/CMakeLists.linux-x86_64.txt +++ b/ydb/core/io_formats/cell_maker/CMakeLists.linux-x86_64.txt @@ -6,30 +6,29 @@ # original buildsystem will not be accepted. -add_subdirectory(ut) -add_library(ydb-core-io_formats) -target_compile_options(ydb-core-io_formats PRIVATE - -Wno-unused-parameter +add_library(core-io_formats-cell_maker) +target_compile_options(core-io_formats-cell_maker PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(ydb-core-io_formats PUBLIC +target_link_libraries(core-io_formats-cell_maker PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - contrib-libs-double-conversion - cpp-string_utils-quote - core-formats-arrow ydb-core-scheme + ydb-core-scheme_types ydb-library-binary_json ydb-library-dynumber yql-minikql-dom yql-public-decimal yql-public-udf library-yql-utils - public-lib-scheme_types + contrib-libs-double-conversion + library-cpp-json + cpp-json-yson + cpp-string_utils-base64 + cpp-string_utils-quote ) -target_sources(ydb-core-io_formats PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/csv_ydb_dump.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/csv_arrow.cpp +target_sources(core-io_formats-cell_maker PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/cell_maker/cell_maker.cpp ) diff --git a/ydb/core/io_formats/cell_maker/CMakeLists.txt b/ydb/core/io_formats/cell_maker/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/io_formats/cell_maker/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/io_formats/CMakeLists.windows-x86_64.txt b/ydb/core/io_formats/cell_maker/CMakeLists.windows-x86_64.txt similarity index 63% rename from ydb/core/io_formats/CMakeLists.windows-x86_64.txt rename to ydb/core/io_formats/cell_maker/CMakeLists.windows-x86_64.txt index 617ed8f31fd1..83af0bd12fa0 100644 --- a/ydb/core/io_formats/CMakeLists.windows-x86_64.txt +++ b/ydb/core/io_formats/cell_maker/CMakeLists.windows-x86_64.txt @@ -6,29 +6,28 @@ # original buildsystem will not be accepted. -add_subdirectory(ut) -add_library(ydb-core-io_formats) -target_compile_options(ydb-core-io_formats PRIVATE - -Wno-unused-parameter +add_library(core-io_formats-cell_maker) +target_compile_options(core-io_formats-cell_maker PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(ydb-core-io_formats PUBLIC +target_link_libraries(core-io_formats-cell_maker PUBLIC contrib-libs-cxxsupp yutil - contrib-libs-double-conversion - cpp-string_utils-quote - core-formats-arrow ydb-core-scheme + ydb-core-scheme_types ydb-library-binary_json ydb-library-dynumber yql-minikql-dom yql-public-decimal yql-public-udf library-yql-utils - public-lib-scheme_types + contrib-libs-double-conversion + library-cpp-json + cpp-json-yson + cpp-string_utils-base64 + cpp-string_utils-quote ) -target_sources(ydb-core-io_formats PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/csv_ydb_dump.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/csv_arrow.cpp +target_sources(core-io_formats-cell_maker PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/cell_maker/cell_maker.cpp ) diff --git a/ydb/core/io_formats/ydb_dump/CMakeLists.darwin-arm64.txt b/ydb/core/io_formats/ydb_dump/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..eaf86b603a80 --- /dev/null +++ b/ydb/core/io_formats/ydb_dump/CMakeLists.darwin-arm64.txt @@ -0,0 +1,23 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(core-io_formats-ydb_dump) +target_compile_options(core-io_formats-ydb_dump PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(core-io_formats-ydb_dump PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-scheme + ydb-core-scheme_types + core-io_formats-cell_maker +) +target_sources(core-io_formats-ydb_dump PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/ydb_dump/csv_ydb_dump.cpp +) diff --git a/ydb/core/io_formats/ydb_dump/CMakeLists.darwin-x86_64.txt b/ydb/core/io_formats/ydb_dump/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..eaf86b603a80 --- /dev/null +++ b/ydb/core/io_formats/ydb_dump/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,23 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(core-io_formats-ydb_dump) +target_compile_options(core-io_formats-ydb_dump PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(core-io_formats-ydb_dump PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-scheme + ydb-core-scheme_types + core-io_formats-cell_maker +) +target_sources(core-io_formats-ydb_dump PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/ydb_dump/csv_ydb_dump.cpp +) diff --git a/ydb/core/io_formats/ydb_dump/CMakeLists.linux-aarch64.txt b/ydb/core/io_formats/ydb_dump/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..7d16f66ff36b --- /dev/null +++ b/ydb/core/io_formats/ydb_dump/CMakeLists.linux-aarch64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(core-io_formats-ydb_dump) +target_compile_options(core-io_formats-ydb_dump PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(core-io_formats-ydb_dump PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-scheme + ydb-core-scheme_types + core-io_formats-cell_maker +) +target_sources(core-io_formats-ydb_dump PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/ydb_dump/csv_ydb_dump.cpp +) diff --git a/ydb/core/io_formats/ydb_dump/CMakeLists.linux-x86_64.txt b/ydb/core/io_formats/ydb_dump/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..7d16f66ff36b --- /dev/null +++ b/ydb/core/io_formats/ydb_dump/CMakeLists.linux-x86_64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(core-io_formats-ydb_dump) +target_compile_options(core-io_formats-ydb_dump PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(core-io_formats-ydb_dump PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-scheme + ydb-core-scheme_types + core-io_formats-cell_maker +) +target_sources(core-io_formats-ydb_dump PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/ydb_dump/csv_ydb_dump.cpp +) diff --git a/ydb/core/io_formats/ydb_dump/CMakeLists.txt b/ydb/core/io_formats/ydb_dump/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/io_formats/ydb_dump/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/io_formats/ydb_dump/CMakeLists.windows-x86_64.txt b/ydb/core/io_formats/ydb_dump/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..eaf86b603a80 --- /dev/null +++ b/ydb/core/io_formats/ydb_dump/CMakeLists.windows-x86_64.txt @@ -0,0 +1,23 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(core-io_formats-ydb_dump) +target_compile_options(core-io_formats-ydb_dump PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(core-io_formats-ydb_dump PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-scheme + ydb-core-scheme_types + core-io_formats-cell_maker +) +target_sources(core-io_formats-ydb_dump PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/io_formats/ydb_dump/csv_ydb_dump.cpp +) diff --git a/ydb/core/kafka_proxy/CMakeLists.darwin-arm64.txt b/ydb/core/kafka_proxy/CMakeLists.darwin-arm64.txt index 14e450725360..98daa89b760a 100644 --- a/ydb/core/kafka_proxy/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kafka_proxy/CMakeLists.darwin-arm64.txt @@ -27,6 +27,15 @@ target_link_libraries(ydb-core-kafka_proxy PUBLIC ydb-services-persqueue_v1 ) target_sources(ydb-core-kafka_proxy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_connection.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_constants.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_listener.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_messages.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_messages_int.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_proxy.h ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_api_versions_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_init_producer_id_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_metadata_actor.cpp @@ -41,6 +50,8 @@ target_sources(ydb-core-kafka_proxy PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_read_session_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_offset_fetch_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_offset_commit_actor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_create_topics_actor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_create_partitions_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_connection.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_messages.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_messages_int.cpp diff --git a/ydb/core/kafka_proxy/CMakeLists.darwin-x86_64.txt b/ydb/core/kafka_proxy/CMakeLists.darwin-x86_64.txt index 14e450725360..98daa89b760a 100644 --- a/ydb/core/kafka_proxy/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kafka_proxy/CMakeLists.darwin-x86_64.txt @@ -27,6 +27,15 @@ target_link_libraries(ydb-core-kafka_proxy PUBLIC ydb-services-persqueue_v1 ) target_sources(ydb-core-kafka_proxy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_connection.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_constants.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_listener.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_messages.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_messages_int.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_proxy.h ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_api_versions_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_init_producer_id_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_metadata_actor.cpp @@ -41,6 +50,8 @@ target_sources(ydb-core-kafka_proxy PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_read_session_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_offset_fetch_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_offset_commit_actor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_create_topics_actor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_create_partitions_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_connection.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_messages.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_messages_int.cpp diff --git a/ydb/core/kafka_proxy/CMakeLists.linux-aarch64.txt b/ydb/core/kafka_proxy/CMakeLists.linux-aarch64.txt index df2ec8838fc6..f756f03c49a9 100644 --- a/ydb/core/kafka_proxy/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kafka_proxy/CMakeLists.linux-aarch64.txt @@ -28,6 +28,15 @@ target_link_libraries(ydb-core-kafka_proxy PUBLIC ydb-services-persqueue_v1 ) target_sources(ydb-core-kafka_proxy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_connection.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_constants.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_listener.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_messages.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_messages_int.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_proxy.h ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_api_versions_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_init_producer_id_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_metadata_actor.cpp @@ -42,6 +51,8 @@ target_sources(ydb-core-kafka_proxy PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_read_session_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_offset_fetch_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_offset_commit_actor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_create_topics_actor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_create_partitions_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_connection.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_messages.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_messages_int.cpp diff --git a/ydb/core/kafka_proxy/CMakeLists.linux-x86_64.txt b/ydb/core/kafka_proxy/CMakeLists.linux-x86_64.txt index df2ec8838fc6..f756f03c49a9 100644 --- a/ydb/core/kafka_proxy/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kafka_proxy/CMakeLists.linux-x86_64.txt @@ -28,6 +28,15 @@ target_link_libraries(ydb-core-kafka_proxy PUBLIC ydb-services-persqueue_v1 ) target_sources(ydb-core-kafka_proxy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_connection.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_constants.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_listener.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_messages.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_messages_int.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_proxy.h ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_api_versions_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_init_producer_id_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_metadata_actor.cpp @@ -42,6 +51,8 @@ target_sources(ydb-core-kafka_proxy PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_read_session_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_offset_fetch_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_offset_commit_actor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_create_topics_actor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_create_partitions_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_connection.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_messages.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_messages_int.cpp diff --git a/ydb/core/kafka_proxy/CMakeLists.windows-x86_64.txt b/ydb/core/kafka_proxy/CMakeLists.windows-x86_64.txt index 14e450725360..98daa89b760a 100644 --- a/ydb/core/kafka_proxy/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kafka_proxy/CMakeLists.windows-x86_64.txt @@ -27,6 +27,15 @@ target_link_libraries(ydb-core-kafka_proxy PUBLIC ydb-services-persqueue_v1 ) target_sources(ydb-core-kafka_proxy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_connection.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_constants.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_listener.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_messages.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_messages_int.h + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_proxy.h ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_api_versions_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_init_producer_id_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_metadata_actor.cpp @@ -41,6 +50,8 @@ target_sources(ydb-core-kafka_proxy PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_read_session_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_offset_fetch_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_offset_commit_actor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_create_topics_actor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/actors/kafka_create_partitions_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_connection.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_messages.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/kafka_messages_int.cpp diff --git a/ydb/core/kafka_proxy/ut/CMakeLists.darwin-arm64.txt b/ydb/core/kafka_proxy/ut/CMakeLists.darwin-arm64.txt index 5c5c404f6582..5c18285a27cf 100644 --- a/ydb/core/kafka_proxy/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kafka_proxy/ut/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-kafka_proxy-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kafka_proxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/ut/ut_kafka_functions.cpp @@ -60,7 +58,8 @@ set_yunittest_property( ydb-core-kafka_proxy-ut PROPERTY LABELS - SMALL + medium + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kafka_proxy/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/kafka_proxy/ut/CMakeLists.darwin-x86_64.txt index b8df216cda26..90114af3bdba 100644 --- a/ydb/core/kafka_proxy/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kafka_proxy/ut/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-kafka_proxy-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kafka_proxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/ut/ut_kafka_functions.cpp @@ -61,7 +59,8 @@ set_yunittest_property( ydb-core-kafka_proxy-ut PROPERTY LABELS - SMALL + medium + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kafka_proxy/ut/CMakeLists.linux-aarch64.txt b/ydb/core/kafka_proxy/ut/CMakeLists.linux-aarch64.txt index a4ad9bc7be67..81c7a0309b04 100644 --- a/ydb/core/kafka_proxy/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kafka_proxy/ut/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-kafka_proxy-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kafka_proxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/ut/ut_kafka_functions.cpp @@ -64,7 +61,8 @@ set_yunittest_property( ydb-core-kafka_proxy-ut PROPERTY LABELS - SMALL + medium + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kafka_proxy/ut/CMakeLists.linux-x86_64.txt b/ydb/core/kafka_proxy/ut/CMakeLists.linux-x86_64.txt index a7c8cc61723f..4cf3c17f6e42 100644 --- a/ydb/core/kafka_proxy/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kafka_proxy/ut/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-kafka_proxy-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kafka_proxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kafka_proxy/ut/ut_kafka_functions.cpp @@ -65,7 +62,8 @@ set_yunittest_property( ydb-core-kafka_proxy-ut PROPERTY LABELS - SMALL + medium + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kafka_proxy/ut/CMakeLists.windows-x86_64.txt b/ydb/core/kafka_proxy/ut/CMakeLists.windows-x86_64.txt index 38fe365d4f7d..4dd8dbee3726 100644 --- a/ydb/core/kafka_proxy/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kafka_proxy/ut/CMakeLists.windows-x86_64.txt @@ -54,7 +54,8 @@ set_yunittest_property( ydb-core-kafka_proxy-ut PROPERTY LABELS - SMALL + medium + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kesus/proxy/ut/CMakeLists.darwin-arm64.txt b/ydb/core/kesus/proxy/ut/CMakeLists.darwin-arm64.txt index af7950a656a9..306a715a5be1 100644 --- a/ydb/core/kesus/proxy/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kesus/proxy/ut/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-kesus-proxy-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kesus-proxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kesus/proxy/proxy_actor_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kesus/proxy/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/kesus/proxy/ut/CMakeLists.darwin-x86_64.txt index 9a06807d2326..691712fddef4 100644 --- a/ydb/core/kesus/proxy/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kesus/proxy/ut/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-kesus-proxy-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kesus-proxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kesus/proxy/proxy_actor_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kesus/proxy/ut/CMakeLists.linux-aarch64.txt b/ydb/core/kesus/proxy/ut/CMakeLists.linux-aarch64.txt index a2f3d894725b..e85728868480 100644 --- a/ydb/core/kesus/proxy/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kesus/proxy/ut/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-kesus-proxy-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kesus-proxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kesus/proxy/proxy_actor_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kesus/proxy/ut/CMakeLists.linux-x86_64.txt b/ydb/core/kesus/proxy/ut/CMakeLists.linux-x86_64.txt index 3940018f3a0a..8a82186bdd3e 100644 --- a/ydb/core/kesus/proxy/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kesus/proxy/ut/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-kesus-proxy-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kesus-proxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kesus/proxy/proxy_actor_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kesus/proxy/ut/CMakeLists.windows-x86_64.txt b/ydb/core/kesus/proxy/ut/CMakeLists.windows-x86_64.txt index 4ca11281b287..ddae307eb9ff 100644 --- a/ydb/core/kesus/proxy/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kesus/proxy/ut/CMakeLists.windows-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kesus/tablet/quoter_performance_test/CMakeLists.darwin-arm64.txt b/ydb/core/kesus/tablet/quoter_performance_test/CMakeLists.darwin-arm64.txt index 2c77321d191a..3fe68b0b9e29 100644 --- a/ydb/core/kesus/tablet/quoter_performance_test/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kesus/tablet/quoter_performance_test/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(quoter_performance_test PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(quoter_performance_test PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kesus/tablet/quoter_performance_test/main.cpp diff --git a/ydb/core/kesus/tablet/quoter_performance_test/CMakeLists.darwin-x86_64.txt b/ydb/core/kesus/tablet/quoter_performance_test/CMakeLists.darwin-x86_64.txt index 6a6077972bb9..2c5edc71121a 100644 --- a/ydb/core/kesus/tablet/quoter_performance_test/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kesus/tablet/quoter_performance_test/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(quoter_performance_test PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(quoter_performance_test PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kesus/tablet/quoter_performance_test/main.cpp diff --git a/ydb/core/kesus/tablet/quoter_performance_test/CMakeLists.linux-aarch64.txt b/ydb/core/kesus/tablet/quoter_performance_test/CMakeLists.linux-aarch64.txt index e90fa56c1e6a..f10daaf53a04 100644 --- a/ydb/core/kesus/tablet/quoter_performance_test/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kesus/tablet/quoter_performance_test/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(quoter_performance_test PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(quoter_performance_test PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kesus/tablet/quoter_performance_test/main.cpp diff --git a/ydb/core/kesus/tablet/quoter_performance_test/CMakeLists.linux-x86_64.txt b/ydb/core/kesus/tablet/quoter_performance_test/CMakeLists.linux-x86_64.txt index f57e7cf3eb6b..cfcb3c69b2aa 100644 --- a/ydb/core/kesus/tablet/quoter_performance_test/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kesus/tablet/quoter_performance_test/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(quoter_performance_test PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(quoter_performance_test PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kesus/tablet/quoter_performance_test/main.cpp diff --git a/ydb/core/kesus/tablet/ut/CMakeLists.darwin-arm64.txt b/ydb/core/kesus/tablet/ut/CMakeLists.darwin-arm64.txt index df909a96ecb1..e4f0c68f8270 100644 --- a/ydb/core/kesus/tablet/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kesus/tablet/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-kesus-tablet-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kesus-tablet-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kesus/tablet/tablet_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kesus/tablet/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/kesus/tablet/ut/CMakeLists.darwin-x86_64.txt index e7d8de9826f6..7e33f5888c54 100644 --- a/ydb/core/kesus/tablet/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kesus/tablet/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-kesus-tablet-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kesus-tablet-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kesus/tablet/tablet_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kesus/tablet/ut/CMakeLists.linux-aarch64.txt b/ydb/core/kesus/tablet/ut/CMakeLists.linux-aarch64.txt index 683c26b59d96..52d9c6f0ad2c 100644 --- a/ydb/core/kesus/tablet/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kesus/tablet/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-kesus-tablet-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kesus-tablet-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kesus/tablet/tablet_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kesus/tablet/ut/CMakeLists.linux-x86_64.txt b/ydb/core/kesus/tablet/ut/CMakeLists.linux-x86_64.txt index 4878dc0cc4bb..e991c877b8c5 100644 --- a/ydb/core/kesus/tablet/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kesus/tablet/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-kesus-tablet-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kesus-tablet-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kesus/tablet/tablet_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kesus/tablet/ut/CMakeLists.windows-x86_64.txt b/ydb/core/kesus/tablet/ut/CMakeLists.windows-x86_64.txt index 5bb666fcdc5a..113101d61db5 100644 --- a/ydb/core/kesus/tablet/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kesus/tablet/ut/CMakeLists.windows-x86_64.txt @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/keyvalue/CMakeLists.darwin-arm64.txt b/ydb/core/keyvalue/CMakeLists.darwin-arm64.txt index 895622c8c687..042b066356be 100644 --- a/ydb/core/keyvalue/CMakeLists.darwin-arm64.txt +++ b/ydb/core/keyvalue/CMakeLists.darwin-arm64.txt @@ -8,6 +8,7 @@ add_subdirectory(protos) add_subdirectory(ut) +add_subdirectory(ut_trace) add_library(ydb-core-keyvalue) target_link_libraries(ydb-core-keyvalue PUBLIC @@ -17,6 +18,7 @@ target_link_libraries(ydb-core-keyvalue PUBLIC library-actors-protos ydb-core-base core-blobstorage-base + core-control-common_controls core-engine-minikql core-keyvalue-protos ydb-core-protos @@ -26,6 +28,30 @@ target_link_libraries(ydb-core-keyvalue PUBLIC public-lib-base ) target_sources(ydb-core-keyvalue PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_collect_operation.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_collector.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_const.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_data_header.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_flat_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_index_record.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_intermediate.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_item_type.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_key_header.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_key_range.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_request_stat.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_request_type.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_scheme_flat.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_simple_db_flat.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_simple_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_state.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_storage_request.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_stored_state_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_trash_key_arbitrary.h ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_collect_operation.cpp ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_collector.cpp ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue.cpp diff --git a/ydb/core/keyvalue/CMakeLists.darwin-x86_64.txt b/ydb/core/keyvalue/CMakeLists.darwin-x86_64.txt index 895622c8c687..042b066356be 100644 --- a/ydb/core/keyvalue/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/keyvalue/CMakeLists.darwin-x86_64.txt @@ -8,6 +8,7 @@ add_subdirectory(protos) add_subdirectory(ut) +add_subdirectory(ut_trace) add_library(ydb-core-keyvalue) target_link_libraries(ydb-core-keyvalue PUBLIC @@ -17,6 +18,7 @@ target_link_libraries(ydb-core-keyvalue PUBLIC library-actors-protos ydb-core-base core-blobstorage-base + core-control-common_controls core-engine-minikql core-keyvalue-protos ydb-core-protos @@ -26,6 +28,30 @@ target_link_libraries(ydb-core-keyvalue PUBLIC public-lib-base ) target_sources(ydb-core-keyvalue PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_collect_operation.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_collector.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_const.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_data_header.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_flat_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_index_record.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_intermediate.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_item_type.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_key_header.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_key_range.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_request_stat.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_request_type.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_scheme_flat.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_simple_db_flat.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_simple_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_state.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_storage_request.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_stored_state_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_trash_key_arbitrary.h ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_collect_operation.cpp ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_collector.cpp ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue.cpp diff --git a/ydb/core/keyvalue/CMakeLists.linux-aarch64.txt b/ydb/core/keyvalue/CMakeLists.linux-aarch64.txt index ec8e271beaf3..a1bcab8ded2f 100644 --- a/ydb/core/keyvalue/CMakeLists.linux-aarch64.txt +++ b/ydb/core/keyvalue/CMakeLists.linux-aarch64.txt @@ -8,6 +8,7 @@ add_subdirectory(protos) add_subdirectory(ut) +add_subdirectory(ut_trace) add_library(ydb-core-keyvalue) target_link_libraries(ydb-core-keyvalue PUBLIC @@ -18,6 +19,7 @@ target_link_libraries(ydb-core-keyvalue PUBLIC library-actors-protos ydb-core-base core-blobstorage-base + core-control-common_controls core-engine-minikql core-keyvalue-protos ydb-core-protos @@ -27,6 +29,30 @@ target_link_libraries(ydb-core-keyvalue PUBLIC public-lib-base ) target_sources(ydb-core-keyvalue PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_collect_operation.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_collector.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_const.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_data_header.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_flat_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_index_record.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_intermediate.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_item_type.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_key_header.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_key_range.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_request_stat.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_request_type.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_scheme_flat.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_simple_db_flat.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_simple_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_state.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_storage_request.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_stored_state_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_trash_key_arbitrary.h ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_collect_operation.cpp ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_collector.cpp ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue.cpp diff --git a/ydb/core/keyvalue/CMakeLists.linux-x86_64.txt b/ydb/core/keyvalue/CMakeLists.linux-x86_64.txt index ec8e271beaf3..a1bcab8ded2f 100644 --- a/ydb/core/keyvalue/CMakeLists.linux-x86_64.txt +++ b/ydb/core/keyvalue/CMakeLists.linux-x86_64.txt @@ -8,6 +8,7 @@ add_subdirectory(protos) add_subdirectory(ut) +add_subdirectory(ut_trace) add_library(ydb-core-keyvalue) target_link_libraries(ydb-core-keyvalue PUBLIC @@ -18,6 +19,7 @@ target_link_libraries(ydb-core-keyvalue PUBLIC library-actors-protos ydb-core-base core-blobstorage-base + core-control-common_controls core-engine-minikql core-keyvalue-protos ydb-core-protos @@ -27,6 +29,30 @@ target_link_libraries(ydb-core-keyvalue PUBLIC public-lib-base ) target_sources(ydb-core-keyvalue PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_collect_operation.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_collector.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_const.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_data_header.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_flat_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_index_record.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_intermediate.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_item_type.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_key_header.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_key_range.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_request_stat.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_request_type.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_scheme_flat.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_simple_db_flat.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_simple_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_state.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_storage_request.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_stored_state_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_trash_key_arbitrary.h ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_collect_operation.cpp ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_collector.cpp ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue.cpp diff --git a/ydb/core/keyvalue/CMakeLists.windows-x86_64.txt b/ydb/core/keyvalue/CMakeLists.windows-x86_64.txt index 895622c8c687..042b066356be 100644 --- a/ydb/core/keyvalue/CMakeLists.windows-x86_64.txt +++ b/ydb/core/keyvalue/CMakeLists.windows-x86_64.txt @@ -8,6 +8,7 @@ add_subdirectory(protos) add_subdirectory(ut) +add_subdirectory(ut_trace) add_library(ydb-core-keyvalue) target_link_libraries(ydb-core-keyvalue PUBLIC @@ -17,6 +18,7 @@ target_link_libraries(ydb-core-keyvalue PUBLIC library-actors-protos ydb-core-base core-blobstorage-base + core-control-common_controls core-engine-minikql core-keyvalue-protos ydb-core-protos @@ -26,6 +28,30 @@ target_link_libraries(ydb-core-keyvalue PUBLIC public-lib-base ) target_sources(ydb-core-keyvalue PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_collect_operation.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_collector.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_const.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_data_header.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_flat_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_index_record.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_intermediate.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_item_type.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_key_header.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_key_range.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_request_stat.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_request_type.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_scheme_flat.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_simple_db_flat.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_simple_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_state.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_storage_request.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_stored_state_data.h + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_trash_key_arbitrary.h ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_collect_operation.cpp ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_collector.cpp ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue.cpp diff --git a/ydb/core/keyvalue/protos/CMakeLists.darwin-arm64.txt b/ydb/core/keyvalue/protos/CMakeLists.darwin-arm64.txt index e533541cd43a..79a1f1bc5b78 100644 --- a/ydb/core/keyvalue/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/core/keyvalue/protos/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(core-keyvalue-protos PUBLIC target_proto_messages(core-keyvalue-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/protos/events.proto ) +target_sources(core-keyvalue-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/keyvalue/protos/events.pb.h +) target_proto_addincls(core-keyvalue-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/keyvalue/protos/CMakeLists.darwin-x86_64.txt b/ydb/core/keyvalue/protos/CMakeLists.darwin-x86_64.txt index e533541cd43a..79a1f1bc5b78 100644 --- a/ydb/core/keyvalue/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/keyvalue/protos/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(core-keyvalue-protos PUBLIC target_proto_messages(core-keyvalue-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/protos/events.proto ) +target_sources(core-keyvalue-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/keyvalue/protos/events.pb.h +) target_proto_addincls(core-keyvalue-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/keyvalue/protos/CMakeLists.linux-aarch64.txt b/ydb/core/keyvalue/protos/CMakeLists.linux-aarch64.txt index f82d9f019b7c..61d9782d6a05 100644 --- a/ydb/core/keyvalue/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/core/keyvalue/protos/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(core-keyvalue-protos PUBLIC target_proto_messages(core-keyvalue-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/protos/events.proto ) +target_sources(core-keyvalue-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/keyvalue/protos/events.pb.h +) target_proto_addincls(core-keyvalue-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/keyvalue/protos/CMakeLists.linux-x86_64.txt b/ydb/core/keyvalue/protos/CMakeLists.linux-x86_64.txt index f82d9f019b7c..61d9782d6a05 100644 --- a/ydb/core/keyvalue/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/core/keyvalue/protos/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(core-keyvalue-protos PUBLIC target_proto_messages(core-keyvalue-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/protos/events.proto ) +target_sources(core-keyvalue-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/keyvalue/protos/events.pb.h +) target_proto_addincls(core-keyvalue-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/keyvalue/protos/CMakeLists.windows-x86_64.txt b/ydb/core/keyvalue/protos/CMakeLists.windows-x86_64.txt index e533541cd43a..79a1f1bc5b78 100644 --- a/ydb/core/keyvalue/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/core/keyvalue/protos/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(core-keyvalue-protos PUBLIC target_proto_messages(core-keyvalue-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/protos/events.proto ) +target_sources(core-keyvalue-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/keyvalue/protos/events.pb.h +) target_proto_addincls(core-keyvalue-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/keyvalue/ut/CMakeLists.darwin-arm64.txt b/ydb/core/keyvalue/ut/CMakeLists.darwin-arm64.txt index 7b53f811efd5..a99327953ebd 100644 --- a/ydb/core/keyvalue/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/keyvalue/ut/CMakeLists.darwin-arm64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-keyvalue-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-keyvalue-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/keyvalue/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/keyvalue/ut/CMakeLists.darwin-x86_64.txt index 3bc04c094bda..90578ab67702 100644 --- a/ydb/core/keyvalue/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/keyvalue/ut/CMakeLists.darwin-x86_64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-core-keyvalue-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-keyvalue-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/keyvalue/ut/CMakeLists.linux-aarch64.txt b/ydb/core/keyvalue/ut/CMakeLists.linux-aarch64.txt index 8018b22bdc3c..c190e9f49959 100644 --- a/ydb/core/keyvalue/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/keyvalue/ut/CMakeLists.linux-aarch64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-keyvalue-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-keyvalue-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/keyvalue/ut/CMakeLists.linux-x86_64.txt b/ydb/core/keyvalue/ut/CMakeLists.linux-x86_64.txt index 39337c178a5a..cd1b8d6b290a 100644 --- a/ydb/core/keyvalue/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/keyvalue/ut/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-core-keyvalue-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-keyvalue-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_ut.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/keyvalue/ut/CMakeLists.windows-x86_64.txt b/ydb/core/keyvalue/ut/CMakeLists.windows-x86_64.txt index ad492e42c486..ebac92803742 100644 --- a/ydb/core/keyvalue/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/keyvalue/ut/CMakeLists.windows-x86_64.txt @@ -55,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/keyvalue/ut_trace/CMakeLists.darwin-arm64.txt b/ydb/core/keyvalue/ut_trace/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..a4f8dd1f8614 --- /dev/null +++ b/ydb/core/keyvalue/ut_trace/CMakeLists.darwin-arm64.txt @@ -0,0 +1,73 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-keyvalue-ut_trace) +target_include_directories(ydb-core-keyvalue-ut_trace PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue +) +target_link_libraries(ydb-core-keyvalue-ut_trace PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + ydb-core-keyvalue + core-testlib-default +) +target_link_options(ydb-core-keyvalue-ut_trace PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-core-keyvalue-ut_trace PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_ut_trace.cpp +) +set_property( + TARGET + ydb-core-keyvalue-ut_trace + PROPERTY + SPLIT_FACTOR + 5 +) +add_yunittest( + NAME + ydb-core-keyvalue-ut_trace + TEST_TARGET + ydb-core-keyvalue-ut_trace + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-keyvalue-ut_trace + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-keyvalue-ut_trace + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-keyvalue-ut_trace + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-keyvalue-ut_trace + system_allocator +) +vcs_info(ydb-core-keyvalue-ut_trace) diff --git a/ydb/core/keyvalue/ut_trace/CMakeLists.darwin-x86_64.txt b/ydb/core/keyvalue/ut_trace/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..1b48a4a8aee5 --- /dev/null +++ b/ydb/core/keyvalue/ut_trace/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,74 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-keyvalue-ut_trace) +target_include_directories(ydb-core-keyvalue-ut_trace PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue +) +target_link_libraries(ydb-core-keyvalue-ut_trace PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + ydb-core-keyvalue + core-testlib-default +) +target_link_options(ydb-core-keyvalue-ut_trace PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-core-keyvalue-ut_trace PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_ut_trace.cpp +) +set_property( + TARGET + ydb-core-keyvalue-ut_trace + PROPERTY + SPLIT_FACTOR + 5 +) +add_yunittest( + NAME + ydb-core-keyvalue-ut_trace + TEST_TARGET + ydb-core-keyvalue-ut_trace + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-keyvalue-ut_trace + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-keyvalue-ut_trace + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-keyvalue-ut_trace + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-keyvalue-ut_trace + system_allocator +) +vcs_info(ydb-core-keyvalue-ut_trace) diff --git a/ydb/core/keyvalue/ut_trace/CMakeLists.linux-aarch64.txt b/ydb/core/keyvalue/ut_trace/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..44862ade9b8e --- /dev/null +++ b/ydb/core/keyvalue/ut_trace/CMakeLists.linux-aarch64.txt @@ -0,0 +1,76 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-keyvalue-ut_trace) +target_include_directories(ydb-core-keyvalue-ut_trace PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue +) +target_link_libraries(ydb-core-keyvalue-ut_trace PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + ydb-core-keyvalue + core-testlib-default +) +target_link_options(ydb-core-keyvalue-ut_trace PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-core-keyvalue-ut_trace PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_ut_trace.cpp +) +set_property( + TARGET + ydb-core-keyvalue-ut_trace + PROPERTY + SPLIT_FACTOR + 5 +) +add_yunittest( + NAME + ydb-core-keyvalue-ut_trace + TEST_TARGET + ydb-core-keyvalue-ut_trace + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-keyvalue-ut_trace + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-keyvalue-ut_trace + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-keyvalue-ut_trace + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-keyvalue-ut_trace + cpp-malloc-jemalloc +) +vcs_info(ydb-core-keyvalue-ut_trace) diff --git a/ydb/core/keyvalue/ut_trace/CMakeLists.linux-x86_64.txt b/ydb/core/keyvalue/ut_trace/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..3fa7f8da969c --- /dev/null +++ b/ydb/core/keyvalue/ut_trace/CMakeLists.linux-x86_64.txt @@ -0,0 +1,78 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-keyvalue-ut_trace) +target_include_directories(ydb-core-keyvalue-ut_trace PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue +) +target_link_libraries(ydb-core-keyvalue-ut_trace PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + ydb-core-keyvalue + core-testlib-default +) +target_link_options(ydb-core-keyvalue-ut_trace PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-core-keyvalue-ut_trace PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_ut_trace.cpp +) +set_property( + TARGET + ydb-core-keyvalue-ut_trace + PROPERTY + SPLIT_FACTOR + 5 +) +add_yunittest( + NAME + ydb-core-keyvalue-ut_trace + TEST_TARGET + ydb-core-keyvalue-ut_trace + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-keyvalue-ut_trace + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-keyvalue-ut_trace + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-keyvalue-ut_trace + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-keyvalue-ut_trace + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(ydb-core-keyvalue-ut_trace) diff --git a/ydb/core/keyvalue/ut_trace/CMakeLists.txt b/ydb/core/keyvalue/ut_trace/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/keyvalue/ut_trace/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/keyvalue/ut_trace/CMakeLists.windows-x86_64.txt b/ydb/core/keyvalue/ut_trace/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..232c30f9b842 --- /dev/null +++ b/ydb/core/keyvalue/ut_trace/CMakeLists.windows-x86_64.txt @@ -0,0 +1,69 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-keyvalue-ut_trace) +target_include_directories(ydb-core-keyvalue-ut_trace PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue +) +target_link_libraries(ydb-core-keyvalue-ut_trace PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + ydb-core-keyvalue + core-testlib-default +) +target_sources(ydb-core-keyvalue-ut_trace PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/keyvalue/keyvalue_ut_trace.cpp +) +set_property( + TARGET + ydb-core-keyvalue-ut_trace + PROPERTY + SPLIT_FACTOR + 5 +) +add_yunittest( + NAME + ydb-core-keyvalue-ut_trace + TEST_TARGET + ydb-core-keyvalue-ut_trace + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-keyvalue-ut_trace + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-keyvalue-ut_trace + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-keyvalue-ut_trace + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-keyvalue-ut_trace + system_allocator +) +vcs_info(ydb-core-keyvalue-ut_trace) diff --git a/ydb/core/kqp/common/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/common/CMakeLists.darwin-arm64.txt index 5a5b9167f107..10326d230260 100644 --- a/ydb/core/kqp/common/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/common/CMakeLists.darwin-arm64.txt @@ -53,6 +53,14 @@ target_link_libraries(core-kqp-common PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(core-kqp-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_event_ids.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_resolve.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_yql.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_timeouts.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_lwtrace_probes.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_user_request_context.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_event_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_resolve.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_ru_calc.cpp diff --git a/ydb/core/kqp/common/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/common/CMakeLists.darwin-x86_64.txt index 5a5b9167f107..10326d230260 100644 --- a/ydb/core/kqp/common/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/common/CMakeLists.darwin-x86_64.txt @@ -53,6 +53,14 @@ target_link_libraries(core-kqp-common PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(core-kqp-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_event_ids.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_resolve.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_yql.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_timeouts.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_lwtrace_probes.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_user_request_context.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_event_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_resolve.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_ru_calc.cpp diff --git a/ydb/core/kqp/common/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/common/CMakeLists.linux-aarch64.txt index 11c2296e52f1..89a15ab7e5bd 100644 --- a/ydb/core/kqp/common/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/common/CMakeLists.linux-aarch64.txt @@ -54,6 +54,14 @@ target_link_libraries(core-kqp-common PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(core-kqp-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_event_ids.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_resolve.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_yql.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_timeouts.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_lwtrace_probes.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_user_request_context.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_event_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_resolve.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_ru_calc.cpp diff --git a/ydb/core/kqp/common/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/common/CMakeLists.linux-x86_64.txt index 11c2296e52f1..89a15ab7e5bd 100644 --- a/ydb/core/kqp/common/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/common/CMakeLists.linux-x86_64.txt @@ -54,6 +54,14 @@ target_link_libraries(core-kqp-common PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(core-kqp-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_event_ids.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_resolve.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_yql.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_timeouts.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_lwtrace_probes.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_user_request_context.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_event_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_resolve.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_ru_calc.cpp diff --git a/ydb/core/kqp/common/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/common/CMakeLists.windows-x86_64.txt index 5a5b9167f107..10326d230260 100644 --- a/ydb/core/kqp/common/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/common/CMakeLists.windows-x86_64.txt @@ -53,6 +53,14 @@ target_link_libraries(core-kqp-common PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(core-kqp-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_event_ids.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_resolve.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_yql.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_timeouts.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_lwtrace_probes.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_user_request_context.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_event_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_resolve.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/common/kqp_ru_calc.cpp diff --git a/ydb/core/kqp/counters/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/counters/CMakeLists.darwin-arm64.txt index b5a08b2bb1bd..2ff4afa4475d 100644 --- a/ydb/core/kqp/counters/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/counters/CMakeLists.darwin-arm64.txt @@ -18,5 +18,7 @@ target_link_libraries(core-kqp-counters PUBLIC library-yql-minikql ) target_sources(core-kqp-counters PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/counters/kqp_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/counters/kqp_db_counters.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/counters/kqp_counters.cpp ) diff --git a/ydb/core/kqp/counters/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/counters/CMakeLists.darwin-x86_64.txt index b5a08b2bb1bd..2ff4afa4475d 100644 --- a/ydb/core/kqp/counters/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/counters/CMakeLists.darwin-x86_64.txt @@ -18,5 +18,7 @@ target_link_libraries(core-kqp-counters PUBLIC library-yql-minikql ) target_sources(core-kqp-counters PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/counters/kqp_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/counters/kqp_db_counters.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/counters/kqp_counters.cpp ) diff --git a/ydb/core/kqp/counters/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/counters/CMakeLists.linux-aarch64.txt index 3a231a526138..69f04990e42c 100644 --- a/ydb/core/kqp/counters/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/counters/CMakeLists.linux-aarch64.txt @@ -19,5 +19,7 @@ target_link_libraries(core-kqp-counters PUBLIC library-yql-minikql ) target_sources(core-kqp-counters PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/counters/kqp_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/counters/kqp_db_counters.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/counters/kqp_counters.cpp ) diff --git a/ydb/core/kqp/counters/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/counters/CMakeLists.linux-x86_64.txt index 3a231a526138..69f04990e42c 100644 --- a/ydb/core/kqp/counters/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/counters/CMakeLists.linux-x86_64.txt @@ -19,5 +19,7 @@ target_link_libraries(core-kqp-counters PUBLIC library-yql-minikql ) target_sources(core-kqp-counters PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/counters/kqp_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/counters/kqp_db_counters.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/counters/kqp_counters.cpp ) diff --git a/ydb/core/kqp/counters/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/counters/CMakeLists.windows-x86_64.txt index b5a08b2bb1bd..2ff4afa4475d 100644 --- a/ydb/core/kqp/counters/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/counters/CMakeLists.windows-x86_64.txt @@ -18,5 +18,7 @@ target_link_libraries(core-kqp-counters PUBLIC library-yql-minikql ) target_sources(core-kqp-counters PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/counters/kqp_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/counters/kqp_db_counters.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/counters/kqp_counters.cpp ) diff --git a/ydb/core/kqp/executer_actor/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/executer_actor/CMakeLists.darwin-arm64.txt index b4e24b394f33..2fbf94276ed8 100644 --- a/ydb/core/kqp/executer_actor/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/executer_actor/CMakeLists.darwin-arm64.txt @@ -29,6 +29,7 @@ target_link_libraries(core-kqp-executer_actor PUBLIC ydb-core-protos tx-long_tx_service-public ydb-core-ydb_convert + services-metadata-abstract ydb-library-mkql_proto library-mkql_proto-protos dq-actors-compute diff --git a/ydb/core/kqp/executer_actor/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/executer_actor/CMakeLists.darwin-x86_64.txt index b4e24b394f33..2fbf94276ed8 100644 --- a/ydb/core/kqp/executer_actor/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/executer_actor/CMakeLists.darwin-x86_64.txt @@ -29,6 +29,7 @@ target_link_libraries(core-kqp-executer_actor PUBLIC ydb-core-protos tx-long_tx_service-public ydb-core-ydb_convert + services-metadata-abstract ydb-library-mkql_proto library-mkql_proto-protos dq-actors-compute diff --git a/ydb/core/kqp/executer_actor/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/executer_actor/CMakeLists.linux-aarch64.txt index d56770d3864f..f1cda212730a 100644 --- a/ydb/core/kqp/executer_actor/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/executer_actor/CMakeLists.linux-aarch64.txt @@ -30,6 +30,7 @@ target_link_libraries(core-kqp-executer_actor PUBLIC ydb-core-protos tx-long_tx_service-public ydb-core-ydb_convert + services-metadata-abstract ydb-library-mkql_proto library-mkql_proto-protos dq-actors-compute diff --git a/ydb/core/kqp/executer_actor/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/executer_actor/CMakeLists.linux-x86_64.txt index d56770d3864f..f1cda212730a 100644 --- a/ydb/core/kqp/executer_actor/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/executer_actor/CMakeLists.linux-x86_64.txt @@ -30,6 +30,7 @@ target_link_libraries(core-kqp-executer_actor PUBLIC ydb-core-protos tx-long_tx_service-public ydb-core-ydb_convert + services-metadata-abstract ydb-library-mkql_proto library-mkql_proto-protos dq-actors-compute diff --git a/ydb/core/kqp/executer_actor/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/executer_actor/CMakeLists.windows-x86_64.txt index b4e24b394f33..2fbf94276ed8 100644 --- a/ydb/core/kqp/executer_actor/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/executer_actor/CMakeLists.windows-x86_64.txt @@ -29,6 +29,7 @@ target_link_libraries(core-kqp-executer_actor PUBLIC ydb-core-protos tx-long_tx_service-public ydb-core-ydb_convert + services-metadata-abstract ydb-library-mkql_proto library-mkql_proto-protos dq-actors-compute diff --git a/ydb/core/kqp/executer_actor/ut/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/executer_actor/ut/CMakeLists.darwin-arm64.txt index 856dccd9196f..07f01fd81bfb 100644 --- a/ydb/core/kqp/executer_actor/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/executer_actor/ut/CMakeLists.darwin-arm64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-kqp-executer_actor-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) set_property( TARGET @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/executer_actor/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/executer_actor/ut/CMakeLists.darwin-x86_64.txt index 02d25c233cfd..655b2225784a 100644 --- a/ydb/core/kqp/executer_actor/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/executer_actor/ut/CMakeLists.darwin-x86_64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-kqp-executer_actor-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) set_property( TARGET @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/executer_actor/ut/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/executer_actor/ut/CMakeLists.linux-aarch64.txt index 28cff400cb2d..5c96e921eead 100644 --- a/ydb/core/kqp/executer_actor/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/executer_actor/ut/CMakeLists.linux-aarch64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-kqp-executer_actor-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) set_property( TARGET @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/executer_actor/ut/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/executer_actor/ut/CMakeLists.linux-x86_64.txt index 83c0e8558c26..df95e5a380be 100644 --- a/ydb/core/kqp/executer_actor/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/executer_actor/ut/CMakeLists.linux-x86_64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-kqp-executer_actor-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) set_property( TARGET @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/executer_actor/ut/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/executer_actor/ut/CMakeLists.windows-x86_64.txt index 12c22e853668..47f65063de72 100644 --- a/ydb/core/kqp/executer_actor/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/executer_actor/ut/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/expr_nodes/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/expr_nodes/CMakeLists.darwin-arm64.txt index f7bb91913a9c..85cf4746c023 100644 --- a/ydb/core/kqp/expr_nodes/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/expr_nodes/CMakeLists.darwin-arm64.txt @@ -15,6 +15,10 @@ target_link_libraries(core-kqp-expr_nodes PUBLIC yql-dq-expr_nodes ) target_sources(core-kqp-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.decl.inl.h diff --git a/ydb/core/kqp/expr_nodes/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/expr_nodes/CMakeLists.darwin-x86_64.txt index f7bb91913a9c..85cf4746c023 100644 --- a/ydb/core/kqp/expr_nodes/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/expr_nodes/CMakeLists.darwin-x86_64.txt @@ -15,6 +15,10 @@ target_link_libraries(core-kqp-expr_nodes PUBLIC yql-dq-expr_nodes ) target_sources(core-kqp-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.decl.inl.h diff --git a/ydb/core/kqp/expr_nodes/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/expr_nodes/CMakeLists.linux-aarch64.txt index d4e1a53b1363..c145c0764eb5 100644 --- a/ydb/core/kqp/expr_nodes/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/expr_nodes/CMakeLists.linux-aarch64.txt @@ -16,6 +16,10 @@ target_link_libraries(core-kqp-expr_nodes PUBLIC yql-dq-expr_nodes ) target_sources(core-kqp-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.decl.inl.h diff --git a/ydb/core/kqp/expr_nodes/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/expr_nodes/CMakeLists.linux-x86_64.txt index d4e1a53b1363..c145c0764eb5 100644 --- a/ydb/core/kqp/expr_nodes/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/expr_nodes/CMakeLists.linux-x86_64.txt @@ -16,6 +16,10 @@ target_link_libraries(core-kqp-expr_nodes PUBLIC yql-dq-expr_nodes ) target_sources(core-kqp-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.decl.inl.h diff --git a/ydb/core/kqp/expr_nodes/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/expr_nodes/CMakeLists.windows-x86_64.txt index f7bb91913a9c..85cf4746c023 100644 --- a/ydb/core/kqp/expr_nodes/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/expr_nodes/CMakeLists.windows-x86_64.txt @@ -15,6 +15,10 @@ target_link_libraries(core-kqp-expr_nodes PUBLIC yql-dq-expr_nodes ) target_sources(core-kqp-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/core/kqp/expr_nodes/kqp_expr_nodes.decl.inl.h diff --git a/ydb/core/kqp/gateway/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/gateway/CMakeLists.darwin-arm64.txt index 30e27791a7b2..0bf1ce903d33 100644 --- a/ydb/core/kqp/gateway/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/gateway/CMakeLists.darwin-arm64.txt @@ -9,6 +9,7 @@ add_subdirectory(actors) add_subdirectory(behaviour) add_subdirectory(local_rpc) +add_subdirectory(utils) add_library(core-kqp-gateway) target_compile_options(core-kqp-gateway PRIVATE @@ -27,6 +28,8 @@ target_link_libraries(core-kqp-gateway PUBLIC gateway-behaviour-tablestore gateway-behaviour-table gateway-behaviour-external_data_source + gateway-behaviour-view + kqp-gateway-utils providers-result-expr_nodes ) target_sources(core-kqp-gateway PRIVATE diff --git a/ydb/core/kqp/gateway/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/gateway/CMakeLists.darwin-x86_64.txt index 30e27791a7b2..0bf1ce903d33 100644 --- a/ydb/core/kqp/gateway/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/gateway/CMakeLists.darwin-x86_64.txt @@ -9,6 +9,7 @@ add_subdirectory(actors) add_subdirectory(behaviour) add_subdirectory(local_rpc) +add_subdirectory(utils) add_library(core-kqp-gateway) target_compile_options(core-kqp-gateway PRIVATE @@ -27,6 +28,8 @@ target_link_libraries(core-kqp-gateway PUBLIC gateway-behaviour-tablestore gateway-behaviour-table gateway-behaviour-external_data_source + gateway-behaviour-view + kqp-gateway-utils providers-result-expr_nodes ) target_sources(core-kqp-gateway PRIVATE diff --git a/ydb/core/kqp/gateway/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/gateway/CMakeLists.linux-aarch64.txt index 76972ab96b3f..af3d565d53ed 100644 --- a/ydb/core/kqp/gateway/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/gateway/CMakeLists.linux-aarch64.txt @@ -9,6 +9,7 @@ add_subdirectory(actors) add_subdirectory(behaviour) add_subdirectory(local_rpc) +add_subdirectory(utils) add_library(core-kqp-gateway) target_compile_options(core-kqp-gateway PRIVATE @@ -28,6 +29,8 @@ target_link_libraries(core-kqp-gateway PUBLIC gateway-behaviour-tablestore gateway-behaviour-table gateway-behaviour-external_data_source + gateway-behaviour-view + kqp-gateway-utils providers-result-expr_nodes ) target_sources(core-kqp-gateway PRIVATE diff --git a/ydb/core/kqp/gateway/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/gateway/CMakeLists.linux-x86_64.txt index 76972ab96b3f..af3d565d53ed 100644 --- a/ydb/core/kqp/gateway/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/gateway/CMakeLists.linux-x86_64.txt @@ -9,6 +9,7 @@ add_subdirectory(actors) add_subdirectory(behaviour) add_subdirectory(local_rpc) +add_subdirectory(utils) add_library(core-kqp-gateway) target_compile_options(core-kqp-gateway PRIVATE @@ -28,6 +29,8 @@ target_link_libraries(core-kqp-gateway PUBLIC gateway-behaviour-tablestore gateway-behaviour-table gateway-behaviour-external_data_source + gateway-behaviour-view + kqp-gateway-utils providers-result-expr_nodes ) target_sources(core-kqp-gateway PRIVATE diff --git a/ydb/core/kqp/gateway/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/gateway/CMakeLists.windows-x86_64.txt index 30e27791a7b2..0bf1ce903d33 100644 --- a/ydb/core/kqp/gateway/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/gateway/CMakeLists.windows-x86_64.txt @@ -9,6 +9,7 @@ add_subdirectory(actors) add_subdirectory(behaviour) add_subdirectory(local_rpc) +add_subdirectory(utils) add_library(core-kqp-gateway) target_compile_options(core-kqp-gateway PRIVATE @@ -27,6 +28,8 @@ target_link_libraries(core-kqp-gateway PUBLIC gateway-behaviour-tablestore gateway-behaviour-table gateway-behaviour-external_data_source + gateway-behaviour-view + kqp-gateway-utils providers-result-expr_nodes ) target_sources(core-kqp-gateway PRIVATE diff --git a/ydb/core/kqp/gateway/behaviour/CMakeLists.txt b/ydb/core/kqp/gateway/behaviour/CMakeLists.txt index 19718f063f2b..118a891d4963 100644 --- a/ydb/core/kqp/gateway/behaviour/CMakeLists.txt +++ b/ydb/core/kqp/gateway/behaviour/CMakeLists.txt @@ -9,3 +9,4 @@ add_subdirectory(external_data_source) add_subdirectory(table) add_subdirectory(tablestore) +add_subdirectory(view) diff --git a/ydb/core/kqp/gateway/behaviour/external_data_source/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/gateway/behaviour/external_data_source/CMakeLists.darwin-arm64.txt index aae8b0714bc1..70f6954d0c21 100644 --- a/ydb/core/kqp/gateway/behaviour/external_data_source/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/gateway/behaviour/external_data_source/CMakeLists.darwin-arm64.txt @@ -17,6 +17,7 @@ target_link_libraries(gateway-behaviour-external_data_source PUBLIC services-metadata-initializer services-metadata-abstract kqp-gateway-actors + kqp-gateway-utils behaviour-tablestore-operations ) target_sources(gateway-behaviour-external_data_source PRIVATE @@ -33,6 +34,7 @@ target_link_libraries(gateway-behaviour-external_data_source.global PUBLIC services-metadata-initializer services-metadata-abstract kqp-gateway-actors + kqp-gateway-utils behaviour-tablestore-operations ) target_sources(gateway-behaviour-external_data_source.global PRIVATE diff --git a/ydb/core/kqp/gateway/behaviour/external_data_source/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/gateway/behaviour/external_data_source/CMakeLists.darwin-x86_64.txt index aae8b0714bc1..70f6954d0c21 100644 --- a/ydb/core/kqp/gateway/behaviour/external_data_source/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/gateway/behaviour/external_data_source/CMakeLists.darwin-x86_64.txt @@ -17,6 +17,7 @@ target_link_libraries(gateway-behaviour-external_data_source PUBLIC services-metadata-initializer services-metadata-abstract kqp-gateway-actors + kqp-gateway-utils behaviour-tablestore-operations ) target_sources(gateway-behaviour-external_data_source PRIVATE @@ -33,6 +34,7 @@ target_link_libraries(gateway-behaviour-external_data_source.global PUBLIC services-metadata-initializer services-metadata-abstract kqp-gateway-actors + kqp-gateway-utils behaviour-tablestore-operations ) target_sources(gateway-behaviour-external_data_source.global PRIVATE diff --git a/ydb/core/kqp/gateway/behaviour/external_data_source/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/gateway/behaviour/external_data_source/CMakeLists.linux-aarch64.txt index a8d7f24f0066..c67393e5e777 100644 --- a/ydb/core/kqp/gateway/behaviour/external_data_source/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/gateway/behaviour/external_data_source/CMakeLists.linux-aarch64.txt @@ -18,6 +18,7 @@ target_link_libraries(gateway-behaviour-external_data_source PUBLIC services-metadata-initializer services-metadata-abstract kqp-gateway-actors + kqp-gateway-utils behaviour-tablestore-operations ) target_sources(gateway-behaviour-external_data_source PRIVATE @@ -35,6 +36,7 @@ target_link_libraries(gateway-behaviour-external_data_source.global PUBLIC services-metadata-initializer services-metadata-abstract kqp-gateway-actors + kqp-gateway-utils behaviour-tablestore-operations ) target_sources(gateway-behaviour-external_data_source.global PRIVATE diff --git a/ydb/core/kqp/gateway/behaviour/external_data_source/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/gateway/behaviour/external_data_source/CMakeLists.linux-x86_64.txt index a8d7f24f0066..c67393e5e777 100644 --- a/ydb/core/kqp/gateway/behaviour/external_data_source/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/gateway/behaviour/external_data_source/CMakeLists.linux-x86_64.txt @@ -18,6 +18,7 @@ target_link_libraries(gateway-behaviour-external_data_source PUBLIC services-metadata-initializer services-metadata-abstract kqp-gateway-actors + kqp-gateway-utils behaviour-tablestore-operations ) target_sources(gateway-behaviour-external_data_source PRIVATE @@ -35,6 +36,7 @@ target_link_libraries(gateway-behaviour-external_data_source.global PUBLIC services-metadata-initializer services-metadata-abstract kqp-gateway-actors + kqp-gateway-utils behaviour-tablestore-operations ) target_sources(gateway-behaviour-external_data_source.global PRIVATE diff --git a/ydb/core/kqp/gateway/behaviour/external_data_source/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/gateway/behaviour/external_data_source/CMakeLists.windows-x86_64.txt index aae8b0714bc1..70f6954d0c21 100644 --- a/ydb/core/kqp/gateway/behaviour/external_data_source/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/gateway/behaviour/external_data_source/CMakeLists.windows-x86_64.txt @@ -17,6 +17,7 @@ target_link_libraries(gateway-behaviour-external_data_source PUBLIC services-metadata-initializer services-metadata-abstract kqp-gateway-actors + kqp-gateway-utils behaviour-tablestore-operations ) target_sources(gateway-behaviour-external_data_source PRIVATE @@ -33,6 +34,7 @@ target_link_libraries(gateway-behaviour-external_data_source.global PUBLIC services-metadata-initializer services-metadata-abstract kqp-gateway-actors + kqp-gateway-utils behaviour-tablestore-operations ) target_sources(gateway-behaviour-external_data_source.global PRIVATE diff --git a/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.darwin-arm64.txt index 1fce41a48759..2b1f5330fe0e 100644 --- a/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.darwin-arm64.txt @@ -16,6 +16,7 @@ target_link_libraries(behaviour-tablestore-operations PUBLIC yutil services-metadata-manager formats-arrow-compression + kqp-gateway-utils ydb-core-protos ) target_sources(behaviour-tablestore-operations PRIVATE @@ -31,10 +32,13 @@ target_link_libraries(behaviour-tablestore-operations.global PUBLIC yutil services-metadata-manager formats-arrow-compression + kqp-gateway-utils ydb-core-protos ) target_sources(behaviour-tablestore-operations.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/add_column.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/alter_column.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/drop_column.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/upsert_index.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/drop_index.cpp ) diff --git a/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.darwin-x86_64.txt index 1fce41a48759..2b1f5330fe0e 100644 --- a/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,7 @@ target_link_libraries(behaviour-tablestore-operations PUBLIC yutil services-metadata-manager formats-arrow-compression + kqp-gateway-utils ydb-core-protos ) target_sources(behaviour-tablestore-operations PRIVATE @@ -31,10 +32,13 @@ target_link_libraries(behaviour-tablestore-operations.global PUBLIC yutil services-metadata-manager formats-arrow-compression + kqp-gateway-utils ydb-core-protos ) target_sources(behaviour-tablestore-operations.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/add_column.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/alter_column.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/drop_column.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/upsert_index.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/drop_index.cpp ) diff --git a/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.linux-aarch64.txt index f280dd081286..03ac6ec850a7 100644 --- a/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.linux-aarch64.txt @@ -17,6 +17,7 @@ target_link_libraries(behaviour-tablestore-operations PUBLIC yutil services-metadata-manager formats-arrow-compression + kqp-gateway-utils ydb-core-protos ) target_sources(behaviour-tablestore-operations PRIVATE @@ -33,10 +34,13 @@ target_link_libraries(behaviour-tablestore-operations.global PUBLIC yutil services-metadata-manager formats-arrow-compression + kqp-gateway-utils ydb-core-protos ) target_sources(behaviour-tablestore-operations.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/add_column.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/alter_column.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/drop_column.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/upsert_index.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/drop_index.cpp ) diff --git a/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.linux-x86_64.txt index f280dd081286..03ac6ec850a7 100644 --- a/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.linux-x86_64.txt @@ -17,6 +17,7 @@ target_link_libraries(behaviour-tablestore-operations PUBLIC yutil services-metadata-manager formats-arrow-compression + kqp-gateway-utils ydb-core-protos ) target_sources(behaviour-tablestore-operations PRIVATE @@ -33,10 +34,13 @@ target_link_libraries(behaviour-tablestore-operations.global PUBLIC yutil services-metadata-manager formats-arrow-compression + kqp-gateway-utils ydb-core-protos ) target_sources(behaviour-tablestore-operations.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/add_column.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/alter_column.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/drop_column.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/upsert_index.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/drop_index.cpp ) diff --git a/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.windows-x86_64.txt index 1fce41a48759..2b1f5330fe0e 100644 --- a/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.windows-x86_64.txt @@ -16,6 +16,7 @@ target_link_libraries(behaviour-tablestore-operations PUBLIC yutil services-metadata-manager formats-arrow-compression + kqp-gateway-utils ydb-core-protos ) target_sources(behaviour-tablestore-operations PRIVATE @@ -31,10 +32,13 @@ target_link_libraries(behaviour-tablestore-operations.global PUBLIC yutil services-metadata-manager formats-arrow-compression + kqp-gateway-utils ydb-core-protos ) target_sources(behaviour-tablestore-operations.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/add_column.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/alter_column.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/drop_column.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/upsert_index.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/tablestore/operations/drop_index.cpp ) diff --git a/ydb/core/kqp/gateway/behaviour/view/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/gateway/behaviour/view/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..cf426bd688c1 --- /dev/null +++ b/ydb/core/kqp/gateway/behaviour/view/CMakeLists.darwin-arm64.txt @@ -0,0 +1,42 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(gateway-behaviour-view) +target_compile_options(gateway-behaviour-view PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(gateway-behaviour-view PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-base + kqp-gateway-actors + core-tx-tx_proxy + services-metadata-abstract + services-metadata-manager +) +target_sources(gateway-behaviour-view PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/view/manager.cpp +) + +add_global_library_for(gateway-behaviour-view.global gateway-behaviour-view) +target_compile_options(gateway-behaviour-view.global PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(gateway-behaviour-view.global PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-base + kqp-gateway-actors + core-tx-tx_proxy + services-metadata-abstract + services-metadata-manager +) +target_sources(gateway-behaviour-view.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/view/behaviour.cpp +) diff --git a/ydb/core/kqp/gateway/behaviour/view/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/gateway/behaviour/view/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..cf426bd688c1 --- /dev/null +++ b/ydb/core/kqp/gateway/behaviour/view/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,42 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(gateway-behaviour-view) +target_compile_options(gateway-behaviour-view PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(gateway-behaviour-view PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-base + kqp-gateway-actors + core-tx-tx_proxy + services-metadata-abstract + services-metadata-manager +) +target_sources(gateway-behaviour-view PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/view/manager.cpp +) + +add_global_library_for(gateway-behaviour-view.global gateway-behaviour-view) +target_compile_options(gateway-behaviour-view.global PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(gateway-behaviour-view.global PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-base + kqp-gateway-actors + core-tx-tx_proxy + services-metadata-abstract + services-metadata-manager +) +target_sources(gateway-behaviour-view.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/view/behaviour.cpp +) diff --git a/ydb/core/kqp/gateway/behaviour/view/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/gateway/behaviour/view/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..c929392ad69e --- /dev/null +++ b/ydb/core/kqp/gateway/behaviour/view/CMakeLists.linux-aarch64.txt @@ -0,0 +1,44 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(gateway-behaviour-view) +target_compile_options(gateway-behaviour-view PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(gateway-behaviour-view PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-base + kqp-gateway-actors + core-tx-tx_proxy + services-metadata-abstract + services-metadata-manager +) +target_sources(gateway-behaviour-view PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/view/manager.cpp +) + +add_global_library_for(gateway-behaviour-view.global gateway-behaviour-view) +target_compile_options(gateway-behaviour-view.global PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(gateway-behaviour-view.global PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-base + kqp-gateway-actors + core-tx-tx_proxy + services-metadata-abstract + services-metadata-manager +) +target_sources(gateway-behaviour-view.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/view/behaviour.cpp +) diff --git a/ydb/core/kqp/gateway/behaviour/view/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/gateway/behaviour/view/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..c929392ad69e --- /dev/null +++ b/ydb/core/kqp/gateway/behaviour/view/CMakeLists.linux-x86_64.txt @@ -0,0 +1,44 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(gateway-behaviour-view) +target_compile_options(gateway-behaviour-view PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(gateway-behaviour-view PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-base + kqp-gateway-actors + core-tx-tx_proxy + services-metadata-abstract + services-metadata-manager +) +target_sources(gateway-behaviour-view PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/view/manager.cpp +) + +add_global_library_for(gateway-behaviour-view.global gateway-behaviour-view) +target_compile_options(gateway-behaviour-view.global PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(gateway-behaviour-view.global PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-base + kqp-gateway-actors + core-tx-tx_proxy + services-metadata-abstract + services-metadata-manager +) +target_sources(gateway-behaviour-view.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/view/behaviour.cpp +) diff --git a/ydb/core/kqp/gateway/behaviour/view/CMakeLists.txt b/ydb/core/kqp/gateway/behaviour/view/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/kqp/gateway/behaviour/view/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/kqp/gateway/behaviour/view/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/gateway/behaviour/view/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..cf426bd688c1 --- /dev/null +++ b/ydb/core/kqp/gateway/behaviour/view/CMakeLists.windows-x86_64.txt @@ -0,0 +1,42 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(gateway-behaviour-view) +target_compile_options(gateway-behaviour-view PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(gateway-behaviour-view PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-base + kqp-gateway-actors + core-tx-tx_proxy + services-metadata-abstract + services-metadata-manager +) +target_sources(gateway-behaviour-view PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/view/manager.cpp +) + +add_global_library_for(gateway-behaviour-view.global gateway-behaviour-view) +target_compile_options(gateway-behaviour-view.global PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(gateway-behaviour-view.global PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-base + kqp-gateway-actors + core-tx-tx_proxy + services-metadata-abstract + services-metadata-manager +) +target_sources(gateway-behaviour-view.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/behaviour/view/behaviour.cpp +) diff --git a/ydb/core/kqp/gateway/utils/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/gateway/utils/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..fed6e098e916 --- /dev/null +++ b/ydb/core/kqp/gateway/utils/CMakeLists.darwin-arm64.txt @@ -0,0 +1,23 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(kqp-gateway-utils) +target_compile_options(kqp-gateway-utils PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(kqp-gateway-utils PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-base + core-kqp-provider + ydb-core-protos +) +target_sources(kqp-gateway-utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/utils/scheme_helpers.cpp +) diff --git a/ydb/core/kqp/gateway/utils/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/gateway/utils/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..fed6e098e916 --- /dev/null +++ b/ydb/core/kqp/gateway/utils/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,23 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(kqp-gateway-utils) +target_compile_options(kqp-gateway-utils PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(kqp-gateway-utils PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-base + core-kqp-provider + ydb-core-protos +) +target_sources(kqp-gateway-utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/utils/scheme_helpers.cpp +) diff --git a/ydb/core/kqp/gateway/utils/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/gateway/utils/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..c6bf234fa786 --- /dev/null +++ b/ydb/core/kqp/gateway/utils/CMakeLists.linux-aarch64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(kqp-gateway-utils) +target_compile_options(kqp-gateway-utils PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(kqp-gateway-utils PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-base + core-kqp-provider + ydb-core-protos +) +target_sources(kqp-gateway-utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/utils/scheme_helpers.cpp +) diff --git a/ydb/core/kqp/gateway/utils/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/gateway/utils/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..c6bf234fa786 --- /dev/null +++ b/ydb/core/kqp/gateway/utils/CMakeLists.linux-x86_64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(kqp-gateway-utils) +target_compile_options(kqp-gateway-utils PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(kqp-gateway-utils PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-base + core-kqp-provider + ydb-core-protos +) +target_sources(kqp-gateway-utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/utils/scheme_helpers.cpp +) diff --git a/ydb/core/kqp/gateway/utils/CMakeLists.txt b/ydb/core/kqp/gateway/utils/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/kqp/gateway/utils/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/kqp/gateway/utils/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/gateway/utils/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..fed6e098e916 --- /dev/null +++ b/ydb/core/kqp/gateway/utils/CMakeLists.windows-x86_64.txt @@ -0,0 +1,23 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(kqp-gateway-utils) +target_compile_options(kqp-gateway-utils PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(kqp-gateway-utils PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-base + core-kqp-provider + ydb-core-protos +) +target_sources(kqp-gateway-utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/gateway/utils/scheme_helpers.cpp +) diff --git a/ydb/core/kqp/host/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/host/CMakeLists.darwin-arm64.txt index 905cc9c5fe60..6e6579d70b5b 100644 --- a/ydb/core/kqp/host/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/host/CMakeLists.darwin-arm64.txt @@ -17,11 +17,12 @@ target_link_libraries(core-kqp-host PUBLIC ydb-core-base core-kqp-common core-kqp-federated_query + kqp-gateway-utils core-kqp-opt core-kqp-provider tx-long_tx_service-public yql-core-services - minikql-invoke_builtins-llvm + yql-minikql-invoke_builtins library-yql-sql library-yql-core providers-common-codec diff --git a/ydb/core/kqp/host/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/host/CMakeLists.darwin-x86_64.txt index 905cc9c5fe60..6e6579d70b5b 100644 --- a/ydb/core/kqp/host/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/host/CMakeLists.darwin-x86_64.txt @@ -17,11 +17,12 @@ target_link_libraries(core-kqp-host PUBLIC ydb-core-base core-kqp-common core-kqp-federated_query + kqp-gateway-utils core-kqp-opt core-kqp-provider tx-long_tx_service-public yql-core-services - minikql-invoke_builtins-llvm + yql-minikql-invoke_builtins library-yql-sql library-yql-core providers-common-codec diff --git a/ydb/core/kqp/host/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/host/CMakeLists.linux-aarch64.txt index 42faf8147fd3..dbfa8f80dd38 100644 --- a/ydb/core/kqp/host/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/host/CMakeLists.linux-aarch64.txt @@ -18,11 +18,12 @@ target_link_libraries(core-kqp-host PUBLIC ydb-core-base core-kqp-common core-kqp-federated_query + kqp-gateway-utils core-kqp-opt core-kqp-provider tx-long_tx_service-public yql-core-services - minikql-invoke_builtins-llvm + yql-minikql-invoke_builtins library-yql-sql library-yql-core providers-common-codec diff --git a/ydb/core/kqp/host/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/host/CMakeLists.linux-x86_64.txt index 42faf8147fd3..dbfa8f80dd38 100644 --- a/ydb/core/kqp/host/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/host/CMakeLists.linux-x86_64.txt @@ -18,11 +18,12 @@ target_link_libraries(core-kqp-host PUBLIC ydb-core-base core-kqp-common core-kqp-federated_query + kqp-gateway-utils core-kqp-opt core-kqp-provider tx-long_tx_service-public yql-core-services - minikql-invoke_builtins-llvm + yql-minikql-invoke_builtins library-yql-sql library-yql-core providers-common-codec diff --git a/ydb/core/kqp/host/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/host/CMakeLists.windows-x86_64.txt index 905cc9c5fe60..6e6579d70b5b 100644 --- a/ydb/core/kqp/host/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/host/CMakeLists.windows-x86_64.txt @@ -17,11 +17,12 @@ target_link_libraries(core-kqp-host PUBLIC ydb-core-base core-kqp-common core-kqp-federated_query + kqp-gateway-utils core-kqp-opt core-kqp-provider tx-long_tx_service-public yql-core-services - minikql-invoke_builtins-llvm + yql-minikql-invoke_builtins library-yql-sql library-yql-core providers-common-codec diff --git a/ydb/core/kqp/node_service/ut/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/node_service/ut/CMakeLists.darwin-arm64.txt index 4416c4753556..bc9290e273a1 100644 --- a/ydb/core/kqp/node_service/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/node_service/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-kqp-node_service-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-node_service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/node_service/kqp_node_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/node_service/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/node_service/ut/CMakeLists.darwin-x86_64.txt index 06af17ac2e83..d8cef8599eae 100644 --- a/ydb/core/kqp/node_service/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/node_service/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-kqp-node_service-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-node_service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/node_service/kqp_node_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/node_service/ut/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/node_service/ut/CMakeLists.linux-aarch64.txt index 57cad4a781db..72080d9efb7b 100644 --- a/ydb/core/kqp/node_service/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/node_service/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-kqp-node_service-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-node_service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/node_service/kqp_node_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/node_service/ut/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/node_service/ut/CMakeLists.linux-x86_64.txt index 8fa49b95d483..a2cee4bf6827 100644 --- a/ydb/core/kqp/node_service/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/node_service/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-kqp-node_service-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-node_service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/node_service/kqp_node_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/node_service/ut/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/node_service/ut/CMakeLists.windows-x86_64.txt index 5ef69b589726..b7359e8b47c3 100644 --- a/ydb/core/kqp/node_service/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/node_service/ut/CMakeLists.windows-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/opt/logical/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/opt/logical/CMakeLists.darwin-arm64.txt index 987f3e52d211..1bc54d542c2e 100644 --- a/ydb/core/kqp/opt/logical/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/opt/logical/CMakeLists.darwin-arm64.txt @@ -31,4 +31,5 @@ target_sources(kqp-opt-logical PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/logical/kqp_opt_log_sqlin.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/logical/kqp_opt_log_sqlin_compact.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/logical/kqp_opt_log.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/logical/kqp_opt_cbo.cpp ) diff --git a/ydb/core/kqp/opt/logical/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/opt/logical/CMakeLists.darwin-x86_64.txt index 987f3e52d211..1bc54d542c2e 100644 --- a/ydb/core/kqp/opt/logical/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/opt/logical/CMakeLists.darwin-x86_64.txt @@ -31,4 +31,5 @@ target_sources(kqp-opt-logical PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/logical/kqp_opt_log_sqlin.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/logical/kqp_opt_log_sqlin_compact.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/logical/kqp_opt_log.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/logical/kqp_opt_cbo.cpp ) diff --git a/ydb/core/kqp/opt/logical/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/opt/logical/CMakeLists.linux-aarch64.txt index 37ceb4a01ef8..de4e198107af 100644 --- a/ydb/core/kqp/opt/logical/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/opt/logical/CMakeLists.linux-aarch64.txt @@ -32,4 +32,5 @@ target_sources(kqp-opt-logical PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/logical/kqp_opt_log_sqlin.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/logical/kqp_opt_log_sqlin_compact.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/logical/kqp_opt_log.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/logical/kqp_opt_cbo.cpp ) diff --git a/ydb/core/kqp/opt/logical/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/opt/logical/CMakeLists.linux-x86_64.txt index 37ceb4a01ef8..de4e198107af 100644 --- a/ydb/core/kqp/opt/logical/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/opt/logical/CMakeLists.linux-x86_64.txt @@ -32,4 +32,5 @@ target_sources(kqp-opt-logical PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/logical/kqp_opt_log_sqlin.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/logical/kqp_opt_log_sqlin_compact.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/logical/kqp_opt_log.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/logical/kqp_opt_cbo.cpp ) diff --git a/ydb/core/kqp/opt/logical/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/opt/logical/CMakeLists.windows-x86_64.txt index 987f3e52d211..1bc54d542c2e 100644 --- a/ydb/core/kqp/opt/logical/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/opt/logical/CMakeLists.windows-x86_64.txt @@ -31,4 +31,5 @@ target_sources(kqp-opt-logical PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/logical/kqp_opt_log_sqlin.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/logical/kqp_opt_log_sqlin_compact.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/logical/kqp_opt_log.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/logical/kqp_opt_cbo.cpp ) diff --git a/ydb/core/kqp/opt/physical/effects/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/opt/physical/effects/CMakeLists.darwin-arm64.txt index 5b954686cb30..1e3b93978eb2 100644 --- a/ydb/core/kqp/opt/physical/effects/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/opt/physical/effects/CMakeLists.darwin-arm64.txt @@ -28,4 +28,6 @@ target_sources(opt-physical-effects PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_update_index.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_update.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_upsert_index.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_returning.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_upsert_defaults.cpp ) diff --git a/ydb/core/kqp/opt/physical/effects/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/opt/physical/effects/CMakeLists.darwin-x86_64.txt index 5b954686cb30..1e3b93978eb2 100644 --- a/ydb/core/kqp/opt/physical/effects/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/opt/physical/effects/CMakeLists.darwin-x86_64.txt @@ -28,4 +28,6 @@ target_sources(opt-physical-effects PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_update_index.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_update.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_upsert_index.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_returning.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_upsert_defaults.cpp ) diff --git a/ydb/core/kqp/opt/physical/effects/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/opt/physical/effects/CMakeLists.linux-aarch64.txt index 2cafa69cd7e0..94e19f50eac7 100644 --- a/ydb/core/kqp/opt/physical/effects/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/opt/physical/effects/CMakeLists.linux-aarch64.txt @@ -29,4 +29,6 @@ target_sources(opt-physical-effects PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_update_index.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_update.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_upsert_index.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_returning.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_upsert_defaults.cpp ) diff --git a/ydb/core/kqp/opt/physical/effects/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/opt/physical/effects/CMakeLists.linux-x86_64.txt index 2cafa69cd7e0..94e19f50eac7 100644 --- a/ydb/core/kqp/opt/physical/effects/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/opt/physical/effects/CMakeLists.linux-x86_64.txt @@ -29,4 +29,6 @@ target_sources(opt-physical-effects PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_update_index.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_update.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_upsert_index.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_returning.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_upsert_defaults.cpp ) diff --git a/ydb/core/kqp/opt/physical/effects/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/opt/physical/effects/CMakeLists.windows-x86_64.txt index 5b954686cb30..1e3b93978eb2 100644 --- a/ydb/core/kqp/opt/physical/effects/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/opt/physical/effects/CMakeLists.windows-x86_64.txt @@ -28,4 +28,6 @@ target_sources(opt-physical-effects PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_update_index.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_update.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_upsert_index.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_returning.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/opt/physical/effects/kqp_opt_phy_upsert_defaults.cpp ) diff --git a/ydb/core/kqp/provider/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/provider/CMakeLists.darwin-arm64.txt index 2dd9cf4540cc..21adc4418a6a 100644 --- a/ydb/core/kqp/provider/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/provider/CMakeLists.darwin-arm64.txt @@ -47,12 +47,24 @@ target_link_libraries(core-kqp-provider PUBLIC providers-dq-expr_nodes providers-result-expr_nodes providers-result-provider - yql-sql-settings + library-yql-sql library-ydb_issue-proto yql-public-issue + yql-utils-log tools-enum_parser-enum_serialization_runtime ) target_sources(core-kqp-provider PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/kqp/provider/yql_kikimr_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/core/kqp/provider/yql_kikimr_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/core/kqp/provider/yql_kikimr_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_expr_nodes.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_gateway.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_provider.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_provider_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_results.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_settings.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_type_ann_pg.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/rewrite_io_utils.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_datasink.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_datasource.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_exec.cpp diff --git a/ydb/core/kqp/provider/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/provider/CMakeLists.darwin-x86_64.txt index 2dd9cf4540cc..21adc4418a6a 100644 --- a/ydb/core/kqp/provider/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/provider/CMakeLists.darwin-x86_64.txt @@ -47,12 +47,24 @@ target_link_libraries(core-kqp-provider PUBLIC providers-dq-expr_nodes providers-result-expr_nodes providers-result-provider - yql-sql-settings + library-yql-sql library-ydb_issue-proto yql-public-issue + yql-utils-log tools-enum_parser-enum_serialization_runtime ) target_sources(core-kqp-provider PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/kqp/provider/yql_kikimr_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/core/kqp/provider/yql_kikimr_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/core/kqp/provider/yql_kikimr_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_expr_nodes.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_gateway.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_provider.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_provider_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_results.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_settings.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_type_ann_pg.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/rewrite_io_utils.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_datasink.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_datasource.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_exec.cpp diff --git a/ydb/core/kqp/provider/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/provider/CMakeLists.linux-aarch64.txt index b5f0abee0e4f..7923c6ab85d3 100644 --- a/ydb/core/kqp/provider/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/provider/CMakeLists.linux-aarch64.txt @@ -48,12 +48,24 @@ target_link_libraries(core-kqp-provider PUBLIC providers-dq-expr_nodes providers-result-expr_nodes providers-result-provider - yql-sql-settings + library-yql-sql library-ydb_issue-proto yql-public-issue + yql-utils-log tools-enum_parser-enum_serialization_runtime ) target_sources(core-kqp-provider PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/kqp/provider/yql_kikimr_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/core/kqp/provider/yql_kikimr_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/core/kqp/provider/yql_kikimr_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_expr_nodes.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_gateway.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_provider.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_provider_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_results.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_settings.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_type_ann_pg.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/rewrite_io_utils.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_datasink.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_datasource.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_exec.cpp diff --git a/ydb/core/kqp/provider/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/provider/CMakeLists.linux-x86_64.txt index b5f0abee0e4f..7923c6ab85d3 100644 --- a/ydb/core/kqp/provider/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/provider/CMakeLists.linux-x86_64.txt @@ -48,12 +48,24 @@ target_link_libraries(core-kqp-provider PUBLIC providers-dq-expr_nodes providers-result-expr_nodes providers-result-provider - yql-sql-settings + library-yql-sql library-ydb_issue-proto yql-public-issue + yql-utils-log tools-enum_parser-enum_serialization_runtime ) target_sources(core-kqp-provider PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/kqp/provider/yql_kikimr_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/core/kqp/provider/yql_kikimr_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/core/kqp/provider/yql_kikimr_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_expr_nodes.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_gateway.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_provider.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_provider_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_results.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_settings.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_type_ann_pg.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/rewrite_io_utils.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_datasink.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_datasource.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_exec.cpp diff --git a/ydb/core/kqp/provider/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/provider/CMakeLists.windows-x86_64.txt index 2dd9cf4540cc..21adc4418a6a 100644 --- a/ydb/core/kqp/provider/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/provider/CMakeLists.windows-x86_64.txt @@ -47,12 +47,24 @@ target_link_libraries(core-kqp-provider PUBLIC providers-dq-expr_nodes providers-result-expr_nodes providers-result-provider - yql-sql-settings + library-yql-sql library-ydb_issue-proto yql-public-issue + yql-utils-log tools-enum_parser-enum_serialization_runtime ) target_sources(core-kqp-provider PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/kqp/provider/yql_kikimr_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/core/kqp/provider/yql_kikimr_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/core/kqp/provider/yql_kikimr_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_expr_nodes.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_gateway.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_provider.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_provider_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_results.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_settings.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_type_ann_pg.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/rewrite_io_utils.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_datasink.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_datasource.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_exec.cpp diff --git a/ydb/core/kqp/provider/ut/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/provider/ut/CMakeLists.darwin-arm64.txt index a8a209b57ece..a6c155f45a9c 100644 --- a/ydb/core/kqp/provider/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/provider/ut/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-kqp-provider-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-provider-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_gateway_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/provider/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/provider/ut/CMakeLists.darwin-x86_64.txt index a675abd60220..f58c31602740 100644 --- a/ydb/core/kqp/provider/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/provider/ut/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-kqp-provider-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-provider-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_gateway_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/provider/ut/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/provider/ut/CMakeLists.linux-aarch64.txt index f2e9889f9746..363279e0f342 100644 --- a/ydb/core/kqp/provider/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/provider/ut/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-kqp-provider-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-provider-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_gateway_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/provider/ut/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/provider/ut/CMakeLists.linux-x86_64.txt index bdfc3667d328..7fec79dd85e3 100644 --- a/ydb/core/kqp/provider/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/provider/ut/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-kqp-provider-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-provider-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/provider/yql_kikimr_gateway_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/provider/ut/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/provider/ut/CMakeLists.windows-x86_64.txt index cb69aa719a5b..985196135077 100644 --- a/ydb/core/kqp/provider/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/provider/ut/CMakeLists.windows-x86_64.txt @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/proxy_service/proto/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/proxy_service/proto/CMakeLists.darwin-arm64.txt index 77043f71f6ea..5c032f37f658 100644 --- a/ydb/core/kqp/proxy_service/proto/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/proxy_service/proto/CMakeLists.darwin-arm64.txt @@ -29,6 +29,9 @@ target_link_libraries(kqp-proxy_service-proto PUBLIC target_proto_messages(kqp-proxy_service-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/proxy_service/proto/result_set_meta.proto ) +target_sources(kqp-proxy_service-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/kqp/proxy_service/proto/result_set_meta.pb.h +) target_proto_addincls(kqp-proxy_service-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/kqp/proxy_service/proto/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/proxy_service/proto/CMakeLists.darwin-x86_64.txt index 77043f71f6ea..5c032f37f658 100644 --- a/ydb/core/kqp/proxy_service/proto/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/proxy_service/proto/CMakeLists.darwin-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(kqp-proxy_service-proto PUBLIC target_proto_messages(kqp-proxy_service-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/proxy_service/proto/result_set_meta.proto ) +target_sources(kqp-proxy_service-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/kqp/proxy_service/proto/result_set_meta.pb.h +) target_proto_addincls(kqp-proxy_service-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/kqp/proxy_service/proto/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/proxy_service/proto/CMakeLists.linux-aarch64.txt index d82687a820e6..84ed8fb8ec24 100644 --- a/ydb/core/kqp/proxy_service/proto/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/proxy_service/proto/CMakeLists.linux-aarch64.txt @@ -30,6 +30,9 @@ target_link_libraries(kqp-proxy_service-proto PUBLIC target_proto_messages(kqp-proxy_service-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/proxy_service/proto/result_set_meta.proto ) +target_sources(kqp-proxy_service-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/kqp/proxy_service/proto/result_set_meta.pb.h +) target_proto_addincls(kqp-proxy_service-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/kqp/proxy_service/proto/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/proxy_service/proto/CMakeLists.linux-x86_64.txt index d82687a820e6..84ed8fb8ec24 100644 --- a/ydb/core/kqp/proxy_service/proto/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/proxy_service/proto/CMakeLists.linux-x86_64.txt @@ -30,6 +30,9 @@ target_link_libraries(kqp-proxy_service-proto PUBLIC target_proto_messages(kqp-proxy_service-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/proxy_service/proto/result_set_meta.proto ) +target_sources(kqp-proxy_service-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/kqp/proxy_service/proto/result_set_meta.pb.h +) target_proto_addincls(kqp-proxy_service-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/kqp/proxy_service/proto/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/proxy_service/proto/CMakeLists.windows-x86_64.txt index 77043f71f6ea..5c032f37f658 100644 --- a/ydb/core/kqp/proxy_service/proto/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/proxy_service/proto/CMakeLists.windows-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(kqp-proxy_service-proto PUBLIC target_proto_messages(kqp-proxy_service-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/proxy_service/proto/result_set_meta.proto ) +target_sources(kqp-proxy_service-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/kqp/proxy_service/proto/result_set_meta.pb.h +) target_proto_addincls(kqp-proxy_service-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/kqp/proxy_service/ut/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/proxy_service/ut/CMakeLists.darwin-arm64.txt index 594d7057a1ef..31e544b0845d 100644 --- a/ydb/core/kqp/proxy_service/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/proxy_service/ut/CMakeLists.darwin-arm64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-kqp-proxy_service-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-proxy_service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/proxy_service/kqp_proxy_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/proxy_service/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/proxy_service/ut/CMakeLists.darwin-x86_64.txt index 57628ebbe8e2..9a877defd529 100644 --- a/ydb/core/kqp/proxy_service/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/proxy_service/ut/CMakeLists.darwin-x86_64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-kqp-proxy_service-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-proxy_service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/proxy_service/kqp_proxy_ut.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/proxy_service/ut/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/proxy_service/ut/CMakeLists.linux-aarch64.txt index 814ff9005136..71c3dd20d9ac 100644 --- a/ydb/core/kqp/proxy_service/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/proxy_service/ut/CMakeLists.linux-aarch64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-kqp-proxy_service-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-proxy_service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/proxy_service/kqp_proxy_ut.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/proxy_service/ut/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/proxy_service/ut/CMakeLists.linux-x86_64.txt index 02dfeb9a31aa..1dc77982d9a0 100644 --- a/ydb/core/kqp/proxy_service/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/proxy_service/ut/CMakeLists.linux-x86_64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-kqp-proxy_service-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-proxy_service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/proxy_service/kqp_proxy_ut.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/proxy_service/ut/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/proxy_service/ut/CMakeLists.windows-x86_64.txt index f212868dc99e..6ee526db91a6 100644 --- a/ydb/core/kqp/proxy_service/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/proxy_service/ut/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/rm_service/ut/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/rm_service/ut/CMakeLists.darwin-arm64.txt index 5ac5f51152e9..ccc649473f1d 100644 --- a/ydb/core/kqp/rm_service/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/rm_service/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-kqp-rm_service-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-rm_service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/rm_service/kqp_resource_estimation_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/rm_service/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/rm_service/ut/CMakeLists.darwin-x86_64.txt index 90803ca9ac0e..5c2edada9f81 100644 --- a/ydb/core/kqp/rm_service/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/rm_service/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-kqp-rm_service-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-rm_service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/rm_service/kqp_resource_estimation_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/rm_service/ut/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/rm_service/ut/CMakeLists.linux-aarch64.txt index ec9e3500580c..9f12a0585161 100644 --- a/ydb/core/kqp/rm_service/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/rm_service/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-kqp-rm_service-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-rm_service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/rm_service/kqp_resource_estimation_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/rm_service/ut/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/rm_service/ut/CMakeLists.linux-x86_64.txt index cecb6c4da74d..a7a625f72156 100644 --- a/ydb/core/kqp/rm_service/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/rm_service/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-kqp-rm_service-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-rm_service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/rm_service/kqp_resource_estimation_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/rm_service/ut/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/rm_service/ut/CMakeLists.windows-x86_64.txt index 622141b812d0..d04853f86136 100644 --- a/ydb/core/kqp/rm_service/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/rm_service/ut/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/runtime/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/runtime/CMakeLists.darwin-arm64.txt index c297a48ab8d1..e2bf7cc9e2fb 100644 --- a/ydb/core/kqp/runtime/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/runtime/CMakeLists.darwin-arm64.txt @@ -25,7 +25,8 @@ target_link_libraries(core-kqp-runtime PUBLIC ydb-core-protos ydb-core-scheme ydb-core-ydb_convert - minikql-comp_nodes-llvm + minikql-computation-llvm14 + yql-minikql-comp_nodes library-yql-utils dq-actors-protos dq-actors-spilling @@ -34,6 +35,10 @@ target_link_libraries(core-kqp-runtime PUBLIC cpp-threading-hot_swap ) target_sources(core-kqp-runtime PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_runtime_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_stream_lookup_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_stream_lookup_factory.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_stream_lookup_worker.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_compute.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_effects.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_output_stream.cpp @@ -49,4 +54,5 @@ target_sources(core-kqp-runtime PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_stream_lookup_worker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_tasks_runner.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_transport.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_write_actor.cpp ) diff --git a/ydb/core/kqp/runtime/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/runtime/CMakeLists.darwin-x86_64.txt index c297a48ab8d1..e2bf7cc9e2fb 100644 --- a/ydb/core/kqp/runtime/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/runtime/CMakeLists.darwin-x86_64.txt @@ -25,7 +25,8 @@ target_link_libraries(core-kqp-runtime PUBLIC ydb-core-protos ydb-core-scheme ydb-core-ydb_convert - minikql-comp_nodes-llvm + minikql-computation-llvm14 + yql-minikql-comp_nodes library-yql-utils dq-actors-protos dq-actors-spilling @@ -34,6 +35,10 @@ target_link_libraries(core-kqp-runtime PUBLIC cpp-threading-hot_swap ) target_sources(core-kqp-runtime PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_runtime_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_stream_lookup_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_stream_lookup_factory.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_stream_lookup_worker.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_compute.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_effects.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_output_stream.cpp @@ -49,4 +54,5 @@ target_sources(core-kqp-runtime PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_stream_lookup_worker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_tasks_runner.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_transport.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_write_actor.cpp ) diff --git a/ydb/core/kqp/runtime/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/runtime/CMakeLists.linux-aarch64.txt index ba1adf7be3e3..a6748de86839 100644 --- a/ydb/core/kqp/runtime/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/runtime/CMakeLists.linux-aarch64.txt @@ -26,7 +26,8 @@ target_link_libraries(core-kqp-runtime PUBLIC ydb-core-protos ydb-core-scheme ydb-core-ydb_convert - minikql-comp_nodes-llvm + minikql-computation-llvm14 + yql-minikql-comp_nodes library-yql-utils dq-actors-protos dq-actors-spilling @@ -35,6 +36,10 @@ target_link_libraries(core-kqp-runtime PUBLIC cpp-threading-hot_swap ) target_sources(core-kqp-runtime PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_runtime_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_stream_lookup_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_stream_lookup_factory.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_stream_lookup_worker.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_compute.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_effects.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_output_stream.cpp @@ -50,4 +55,5 @@ target_sources(core-kqp-runtime PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_stream_lookup_worker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_tasks_runner.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_transport.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_write_actor.cpp ) diff --git a/ydb/core/kqp/runtime/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/runtime/CMakeLists.linux-x86_64.txt index ba1adf7be3e3..a6748de86839 100644 --- a/ydb/core/kqp/runtime/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/runtime/CMakeLists.linux-x86_64.txt @@ -26,7 +26,8 @@ target_link_libraries(core-kqp-runtime PUBLIC ydb-core-protos ydb-core-scheme ydb-core-ydb_convert - minikql-comp_nodes-llvm + minikql-computation-llvm14 + yql-minikql-comp_nodes library-yql-utils dq-actors-protos dq-actors-spilling @@ -35,6 +36,10 @@ target_link_libraries(core-kqp-runtime PUBLIC cpp-threading-hot_swap ) target_sources(core-kqp-runtime PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_runtime_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_stream_lookup_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_stream_lookup_factory.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_stream_lookup_worker.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_compute.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_effects.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_output_stream.cpp @@ -50,4 +55,5 @@ target_sources(core-kqp-runtime PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_stream_lookup_worker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_tasks_runner.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_transport.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_write_actor.cpp ) diff --git a/ydb/core/kqp/runtime/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/runtime/CMakeLists.windows-x86_64.txt index c297a48ab8d1..e2bf7cc9e2fb 100644 --- a/ydb/core/kqp/runtime/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/runtime/CMakeLists.windows-x86_64.txt @@ -25,7 +25,8 @@ target_link_libraries(core-kqp-runtime PUBLIC ydb-core-protos ydb-core-scheme ydb-core-ydb_convert - minikql-comp_nodes-llvm + minikql-computation-llvm14 + yql-minikql-comp_nodes library-yql-utils dq-actors-protos dq-actors-spilling @@ -34,6 +35,10 @@ target_link_libraries(core-kqp-runtime PUBLIC cpp-threading-hot_swap ) target_sources(core-kqp-runtime PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_runtime_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_stream_lookup_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_stream_lookup_factory.h + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_stream_lookup_worker.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_compute.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_effects.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_output_stream.cpp @@ -49,4 +54,5 @@ target_sources(core-kqp-runtime PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_stream_lookup_worker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_tasks_runner.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_transport.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_write_actor.cpp ) diff --git a/ydb/core/kqp/runtime/ut/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/runtime/ut/CMakeLists.darwin-arm64.txt index e94555b29f8f..e557db89c91e 100644 --- a/ydb/core/kqp/runtime/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/runtime/ut/CMakeLists.darwin-arm64.txt @@ -21,14 +21,13 @@ target_link_libraries(ydb-core-kqp-runtime-ut PUBLIC core-kqp-runtime cpp-testing-unittest testlib-basics-default + minikql-comp_nodes-llvm14 udf-service-exception_policy ) target_link_options(ydb-core-kqp-runtime-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-runtime-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_scan_data_ut.cpp @@ -58,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/runtime/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/runtime/ut/CMakeLists.darwin-x86_64.txt index c4329c5beb57..4daa756aefcb 100644 --- a/ydb/core/kqp/runtime/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/runtime/ut/CMakeLists.darwin-x86_64.txt @@ -22,14 +22,13 @@ target_link_libraries(ydb-core-kqp-runtime-ut PUBLIC core-kqp-runtime cpp-testing-unittest testlib-basics-default + minikql-comp_nodes-llvm14 udf-service-exception_policy ) target_link_options(ydb-core-kqp-runtime-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-runtime-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_scan_data_ut.cpp @@ -59,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/runtime/ut/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/runtime/ut/CMakeLists.linux-aarch64.txt index 099a1c281fa5..0079ceae59f5 100644 --- a/ydb/core/kqp/runtime/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/runtime/ut/CMakeLists.linux-aarch64.txt @@ -22,6 +22,7 @@ target_link_libraries(ydb-core-kqp-runtime-ut PUBLIC core-kqp-runtime cpp-testing-unittest testlib-basics-default + minikql-comp_nodes-llvm14 udf-service-exception_policy ) target_link_options(ydb-core-kqp-runtime-ut PRIVATE @@ -30,9 +31,6 @@ target_link_options(ydb-core-kqp-runtime-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-runtime-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_scan_data_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/runtime/ut/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/runtime/ut/CMakeLists.linux-x86_64.txt index ebf4ee2a3b8a..d4a4e07ec307 100644 --- a/ydb/core/kqp/runtime/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/runtime/ut/CMakeLists.linux-x86_64.txt @@ -23,6 +23,7 @@ target_link_libraries(ydb-core-kqp-runtime-ut PUBLIC core-kqp-runtime cpp-testing-unittest testlib-basics-default + minikql-comp_nodes-llvm14 udf-service-exception_policy ) target_link_options(ydb-core-kqp-runtime-ut PRIVATE @@ -31,9 +32,6 @@ target_link_options(ydb-core-kqp-runtime-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-runtime-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/runtime/kqp_scan_data_ut.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/runtime/ut/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/runtime/ut/CMakeLists.windows-x86_64.txt index 5ac0f20fa5ab..c2973a9c6b11 100644 --- a/ydb/core/kqp/runtime/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/runtime/ut/CMakeLists.windows-x86_64.txt @@ -22,6 +22,7 @@ target_link_libraries(ydb-core-kqp-runtime-ut PUBLIC core-kqp-runtime cpp-testing-unittest testlib-basics-default + minikql-comp_nodes-llvm14 udf-service-exception_policy ) target_sources(ydb-core-kqp-runtime-ut PRIVATE @@ -52,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/session_actor/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/session_actor/CMakeLists.darwin-arm64.txt index 7d60b1ef4fa3..9c3c49af8003 100644 --- a/ydb/core/kqp/session_actor/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/session_actor/CMakeLists.darwin-arm64.txt @@ -18,6 +18,7 @@ target_link_libraries(core-kqp-session_actor PUBLIC core-kqp-common core-kqp-federated_query public-lib-operation_id + core-tx-schemeshard ) target_sources(core-kqp-session_actor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_response.cpp @@ -26,5 +27,6 @@ target_sources(core-kqp-session_actor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_worker_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_worker_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_query_state.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_query_stats.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_temp_tables_manager.cpp ) diff --git a/ydb/core/kqp/session_actor/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/session_actor/CMakeLists.darwin-x86_64.txt index 7d60b1ef4fa3..9c3c49af8003 100644 --- a/ydb/core/kqp/session_actor/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/session_actor/CMakeLists.darwin-x86_64.txt @@ -18,6 +18,7 @@ target_link_libraries(core-kqp-session_actor PUBLIC core-kqp-common core-kqp-federated_query public-lib-operation_id + core-tx-schemeshard ) target_sources(core-kqp-session_actor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_response.cpp @@ -26,5 +27,6 @@ target_sources(core-kqp-session_actor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_worker_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_worker_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_query_state.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_query_stats.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_temp_tables_manager.cpp ) diff --git a/ydb/core/kqp/session_actor/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/session_actor/CMakeLists.linux-aarch64.txt index cbb38f3df3ee..2fe56441de2b 100644 --- a/ydb/core/kqp/session_actor/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/session_actor/CMakeLists.linux-aarch64.txt @@ -19,6 +19,7 @@ target_link_libraries(core-kqp-session_actor PUBLIC core-kqp-common core-kqp-federated_query public-lib-operation_id + core-tx-schemeshard ) target_sources(core-kqp-session_actor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_response.cpp @@ -27,5 +28,6 @@ target_sources(core-kqp-session_actor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_worker_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_worker_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_query_state.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_query_stats.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_temp_tables_manager.cpp ) diff --git a/ydb/core/kqp/session_actor/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/session_actor/CMakeLists.linux-x86_64.txt index cbb38f3df3ee..2fe56441de2b 100644 --- a/ydb/core/kqp/session_actor/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/session_actor/CMakeLists.linux-x86_64.txt @@ -19,6 +19,7 @@ target_link_libraries(core-kqp-session_actor PUBLIC core-kqp-common core-kqp-federated_query public-lib-operation_id + core-tx-schemeshard ) target_sources(core-kqp-session_actor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_response.cpp @@ -27,5 +28,6 @@ target_sources(core-kqp-session_actor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_worker_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_worker_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_query_state.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_query_stats.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_temp_tables_manager.cpp ) diff --git a/ydb/core/kqp/session_actor/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/session_actor/CMakeLists.windows-x86_64.txt index 7d60b1ef4fa3..9c3c49af8003 100644 --- a/ydb/core/kqp/session_actor/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/session_actor/CMakeLists.windows-x86_64.txt @@ -18,6 +18,7 @@ target_link_libraries(core-kqp-session_actor PUBLIC core-kqp-common core-kqp-federated_query public-lib-operation_id + core-tx-schemeshard ) target_sources(core-kqp-session_actor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_response.cpp @@ -26,5 +27,6 @@ target_sources(core-kqp-session_actor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_worker_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_worker_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_query_state.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_query_stats.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/session_actor/kqp_temp_tables_manager.cpp ) diff --git a/ydb/core/kqp/topics/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/topics/CMakeLists.darwin-arm64.txt index 3bd77195ea0b..81942f91d37b 100644 --- a/ydb/core/kqp/topics/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/topics/CMakeLists.darwin-arm64.txt @@ -17,5 +17,6 @@ target_link_libraries(core-kqp-topics PUBLIC ydb-core-base ) target_sources(core-kqp-topics PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/topics/kqp_topics.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/topics/kqp_topics.cpp ) diff --git a/ydb/core/kqp/topics/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/topics/CMakeLists.darwin-x86_64.txt index 3bd77195ea0b..81942f91d37b 100644 --- a/ydb/core/kqp/topics/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/topics/CMakeLists.darwin-x86_64.txt @@ -17,5 +17,6 @@ target_link_libraries(core-kqp-topics PUBLIC ydb-core-base ) target_sources(core-kqp-topics PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/topics/kqp_topics.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/topics/kqp_topics.cpp ) diff --git a/ydb/core/kqp/topics/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/topics/CMakeLists.linux-aarch64.txt index f3a8e98bf832..a6de0719680c 100644 --- a/ydb/core/kqp/topics/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/topics/CMakeLists.linux-aarch64.txt @@ -18,5 +18,6 @@ target_link_libraries(core-kqp-topics PUBLIC ydb-core-base ) target_sources(core-kqp-topics PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/topics/kqp_topics.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/topics/kqp_topics.cpp ) diff --git a/ydb/core/kqp/topics/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/topics/CMakeLists.linux-x86_64.txt index f3a8e98bf832..a6de0719680c 100644 --- a/ydb/core/kqp/topics/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/topics/CMakeLists.linux-x86_64.txt @@ -18,5 +18,6 @@ target_link_libraries(core-kqp-topics PUBLIC ydb-core-base ) target_sources(core-kqp-topics PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/topics/kqp_topics.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/topics/kqp_topics.cpp ) diff --git a/ydb/core/kqp/topics/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/topics/CMakeLists.windows-x86_64.txt index 3bd77195ea0b..81942f91d37b 100644 --- a/ydb/core/kqp/topics/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/topics/CMakeLists.windows-x86_64.txt @@ -17,5 +17,6 @@ target_link_libraries(core-kqp-topics PUBLIC ydb-core-base ) target_sources(core-kqp-topics PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/topics/kqp_topics.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/topics/kqp_topics.cpp ) diff --git a/ydb/core/kqp/ut/CMakeLists.txt b/ydb/core/kqp/ut/CMakeLists.txt index 409905d7009a..782eabcd7df2 100644 --- a/ydb/core/kqp/ut/CMakeLists.txt +++ b/ydb/core/kqp/ut/CMakeLists.txt @@ -26,4 +26,5 @@ add_subdirectory(service) add_subdirectory(spilling) add_subdirectory(sysview) add_subdirectory(tx) +add_subdirectory(view) add_subdirectory(yql) diff --git a/ydb/core/kqp/ut/arrow/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/arrow/CMakeLists.darwin-arm64.txt index 4251ac9b53a6..7f06cd66b838 100644 --- a/ydb/core/kqp/ut/arrow/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/arrow/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-kqp-ut-arrow PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-arrow PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/arrow/kqp_arrow_in_channels_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/arrow/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/arrow/CMakeLists.darwin-x86_64.txt index 950235bd45f6..c32397df5837 100644 --- a/ydb/core/kqp/ut/arrow/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/arrow/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-kqp-ut-arrow PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-arrow PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/arrow/kqp_arrow_in_channels_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/arrow/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/arrow/CMakeLists.linux-aarch64.txt index b18377fade66..0cbb8080511a 100644 --- a/ydb/core/kqp/ut/arrow/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/arrow/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-kqp-ut-arrow PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-arrow PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/arrow/kqp_arrow_in_channels_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/arrow/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/arrow/CMakeLists.linux-x86_64.txt index 7be3e356d182..63cfc4f78148 100644 --- a/ydb/core/kqp/ut/arrow/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/arrow/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-kqp-ut-arrow PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-arrow PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/arrow/kqp_arrow_in_channels_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/arrow/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/arrow/CMakeLists.windows-x86_64.txt index d0ecc5ceb439..f38b6060d12b 100644 --- a/ydb/core/kqp/ut/arrow/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/ut/arrow/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/common/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/common/CMakeLists.darwin-arm64.txt index c2759015fac1..2268b5223d05 100644 --- a/ydb/core/kqp/ut/common/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/common/CMakeLists.darwin-arm64.txt @@ -14,6 +14,7 @@ target_compile_options(kqp-ut-common PRIVATE target_link_libraries(kqp-ut-common PUBLIC contrib-libs-cxxsupp yutil + cpp-testing-common core-kqp-federated_query ydb-core-testlib yql-public-udf @@ -28,6 +29,7 @@ target_link_libraries(kqp-ut-common PUBLIC cpp-client-ydb_topic ) target_sources(kqp-ut-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/common/kqp_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/common/json2_udf.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/common/kqp_ut_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/common/re2_udf.cpp diff --git a/ydb/core/kqp/ut/common/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/common/CMakeLists.darwin-x86_64.txt index c2759015fac1..2268b5223d05 100644 --- a/ydb/core/kqp/ut/common/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/common/CMakeLists.darwin-x86_64.txt @@ -14,6 +14,7 @@ target_compile_options(kqp-ut-common PRIVATE target_link_libraries(kqp-ut-common PUBLIC contrib-libs-cxxsupp yutil + cpp-testing-common core-kqp-federated_query ydb-core-testlib yql-public-udf @@ -28,6 +29,7 @@ target_link_libraries(kqp-ut-common PUBLIC cpp-client-ydb_topic ) target_sources(kqp-ut-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/common/kqp_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/common/json2_udf.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/common/kqp_ut_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/common/re2_udf.cpp diff --git a/ydb/core/kqp/ut/common/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/common/CMakeLists.linux-aarch64.txt index 6321770afa51..0dba001330f9 100644 --- a/ydb/core/kqp/ut/common/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/common/CMakeLists.linux-aarch64.txt @@ -15,6 +15,7 @@ target_link_libraries(kqp-ut-common PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + cpp-testing-common core-kqp-federated_query ydb-core-testlib yql-public-udf @@ -29,6 +30,7 @@ target_link_libraries(kqp-ut-common PUBLIC cpp-client-ydb_topic ) target_sources(kqp-ut-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/common/kqp_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/common/json2_udf.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/common/kqp_ut_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/common/re2_udf.cpp diff --git a/ydb/core/kqp/ut/common/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/common/CMakeLists.linux-x86_64.txt index 6321770afa51..0dba001330f9 100644 --- a/ydb/core/kqp/ut/common/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/common/CMakeLists.linux-x86_64.txt @@ -15,6 +15,7 @@ target_link_libraries(kqp-ut-common PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + cpp-testing-common core-kqp-federated_query ydb-core-testlib yql-public-udf @@ -29,6 +30,7 @@ target_link_libraries(kqp-ut-common PUBLIC cpp-client-ydb_topic ) target_sources(kqp-ut-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/common/kqp_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/common/json2_udf.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/common/kqp_ut_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/common/re2_udf.cpp diff --git a/ydb/core/kqp/ut/common/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/common/CMakeLists.windows-x86_64.txt index c2759015fac1..2268b5223d05 100644 --- a/ydb/core/kqp/ut/common/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/ut/common/CMakeLists.windows-x86_64.txt @@ -14,6 +14,7 @@ target_compile_options(kqp-ut-common PRIVATE target_link_libraries(kqp-ut-common PUBLIC contrib-libs-cxxsupp yutil + cpp-testing-common core-kqp-federated_query ydb-core-testlib yql-public-udf @@ -28,6 +29,7 @@ target_link_libraries(kqp-ut-common PUBLIC cpp-client-ydb_topic ) target_sources(kqp-ut-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/common/kqp_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/common/json2_udf.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/common/kqp_ut_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/common/re2_udf.cpp diff --git a/ydb/core/kqp/ut/cost/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/cost/CMakeLists.darwin-arm64.txt index 6e2b287bd5f2..a2d68550def8 100644 --- a/ydb/core/kqp/ut/cost/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/cost/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-kqp-ut-cost PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-cost PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/cost/kqp_cost_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/cost/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/cost/CMakeLists.darwin-x86_64.txt index 1d018bd33426..2e618bc87bcb 100644 --- a/ydb/core/kqp/ut/cost/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/cost/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-kqp-ut-cost PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-cost PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/cost/kqp_cost_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/cost/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/cost/CMakeLists.linux-aarch64.txt index 21ba4b69654d..11bc25789ded 100644 --- a/ydb/core/kqp/ut/cost/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/cost/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-kqp-ut-cost PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-cost PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/cost/kqp_cost_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/cost/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/cost/CMakeLists.linux-x86_64.txt index 3dedc00448e1..63395a7c39f2 100644 --- a/ydb/core/kqp/ut/cost/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/cost/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-kqp-ut-cost PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-cost PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/cost/kqp_cost_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/cost/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/cost/CMakeLists.windows-x86_64.txt index abc77fe8ab84..515f179d1f9a 100644 --- a/ydb/core/kqp/ut/cost/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/ut/cost/CMakeLists.windows-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/data/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/data/CMakeLists.darwin-arm64.txt index 5f39c4b4339f..2b4dbeb12137 100644 --- a/ydb/core/kqp/ut/data/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/data/CMakeLists.darwin-arm64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-core-kqp-ut-data PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-data PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/data/kqp_read_null_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/data/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/data/CMakeLists.darwin-x86_64.txt index 5857d5dd67a0..69d3f745cefd 100644 --- a/ydb/core/kqp/ut/data/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/data/CMakeLists.darwin-x86_64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-kqp-ut-data PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-data PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/data/kqp_read_null_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/data/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/data/CMakeLists.linux-aarch64.txt index e342f01493f7..3ef98ed96ba6 100644 --- a/ydb/core/kqp/ut/data/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/data/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-core-kqp-ut-data PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-data PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/data/kqp_read_null_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/data/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/data/CMakeLists.linux-x86_64.txt index ca0c8007393d..852bd54d7d66 100644 --- a/ydb/core/kqp/ut/data/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/data/CMakeLists.linux-x86_64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-kqp-ut-data PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-data PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/data/kqp_read_null_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/data/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/data/CMakeLists.windows-x86_64.txt index f6573cf3898c..7084e72278e5 100644 --- a/ydb/core/kqp/ut/data/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/ut/data/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/effects/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/effects/CMakeLists.darwin-arm64.txt index 237f251aded4..1fce39f8306b 100644 --- a/ydb/core/kqp/ut/effects/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/effects/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-kqp-ut-effects PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-effects PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/effects/kqp_effects_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/effects/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/effects/CMakeLists.darwin-x86_64.txt index 1960a82028b0..ae9e7c250f25 100644 --- a/ydb/core/kqp/ut/effects/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/effects/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-kqp-ut-effects PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-effects PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/effects/kqp_effects_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/effects/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/effects/CMakeLists.linux-aarch64.txt index 9e8e9f095004..0fd76b9d703e 100644 --- a/ydb/core/kqp/ut/effects/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/effects/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-kqp-ut-effects PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-effects PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/effects/kqp_effects_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/effects/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/effects/CMakeLists.linux-x86_64.txt index f9cc49e72273..eb9aebd66a50 100644 --- a/ydb/core/kqp/ut/effects/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/effects/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-kqp-ut-effects PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-effects PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/effects/kqp_effects_ut.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/effects/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/effects/CMakeLists.windows-x86_64.txt index 967768600613..fa3b4b7ba86e 100644 --- a/ydb/core/kqp/ut/effects/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/ut/effects/CMakeLists.windows-x86_64.txt @@ -55,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/federated_query/CMakeLists.txt b/ydb/core/kqp/ut/federated_query/CMakeLists.txt index d863ebd18067..8985a38071fd 100644 --- a/ydb/core/kqp/ut/federated_query/CMakeLists.txt +++ b/ydb/core/kqp/ut/federated_query/CMakeLists.txt @@ -6,14 +6,7 @@ # original buildsystem will not be accepted. -if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) - include(CMakeLists.linux-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) - include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) -endif() +add_subdirectory(common) +add_subdirectory(generic) +add_subdirectory(generic_ut) +add_subdirectory(s3) diff --git a/ydb/core/kqp/ut/federated_query/generic/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/federated_query/generic/CMakeLists.darwin-arm64.txt index f68976c13506..1867085d1868 100644 --- a/ydb/core/kqp/ut/federated_query/generic/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/federated_query/generic/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-kqp-ut-federated_query-generic PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-federated_query-generic PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/generic/ch_recipe_ut_helpers.cpp @@ -46,7 +44,7 @@ set_property( ydb-core-kqp-ut-federated_query-generic PROPERTY SPLIT_FACTOR - 10 + 1 ) add_yunittest( NAME @@ -65,7 +63,8 @@ set_yunittest_property( ydb-core-kqp-ut-federated_query-generic PROPERTY LABELS - SMALL + MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/federated_query/generic/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/federated_query/generic/CMakeLists.darwin-x86_64.txt index 17eb95ccc5e4..2e42a5c3ce0a 100644 --- a/ydb/core/kqp/ut/federated_query/generic/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/federated_query/generic/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-kqp-ut-federated_query-generic PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-federated_query-generic PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/generic/ch_recipe_ut_helpers.cpp @@ -47,7 +45,7 @@ set_property( ydb-core-kqp-ut-federated_query-generic PROPERTY SPLIT_FACTOR - 10 + 1 ) add_yunittest( NAME @@ -66,7 +64,8 @@ set_yunittest_property( ydb-core-kqp-ut-federated_query-generic PROPERTY LABELS - SMALL + MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/federated_query/generic/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/federated_query/generic/CMakeLists.linux-aarch64.txt index 8bd7889e9c92..bcc330b5a5e4 100644 --- a/ydb/core/kqp/ut/federated_query/generic/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/federated_query/generic/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-kqp-ut-federated_query-generic PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-federated_query-generic PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/generic/ch_recipe_ut_helpers.cpp @@ -50,7 +47,7 @@ set_property( ydb-core-kqp-ut-federated_query-generic PROPERTY SPLIT_FACTOR - 10 + 1 ) add_yunittest( NAME @@ -69,7 +66,8 @@ set_yunittest_property( ydb-core-kqp-ut-federated_query-generic PROPERTY LABELS - SMALL + MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/federated_query/generic/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/federated_query/generic/CMakeLists.linux-x86_64.txt index 735ffc77daa6..5ed0aa060c91 100644 --- a/ydb/core/kqp/ut/federated_query/generic/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/federated_query/generic/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-kqp-ut-federated_query-generic PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-federated_query-generic PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/generic/ch_recipe_ut_helpers.cpp @@ -51,7 +48,7 @@ set_property( ydb-core-kqp-ut-federated_query-generic PROPERTY SPLIT_FACTOR - 10 + 1 ) add_yunittest( NAME @@ -70,7 +67,8 @@ set_yunittest_property( ydb-core-kqp-ut-federated_query-generic PROPERTY LABELS - SMALL + MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/federated_query/generic/CMakeLists.txt b/ydb/core/kqp/ut/federated_query/generic/CMakeLists.txt index 380079ac7b4a..d863ebd18067 100644 --- a/ydb/core/kqp/ut/federated_query/generic/CMakeLists.txt +++ b/ydb/core/kqp/ut/federated_query/generic/CMakeLists.txt @@ -14,4 +14,6 @@ elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL include(CMakeLists.darwin-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) endif() diff --git a/ydb/core/kqp/ut/federated_query/generic/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/federated_query/generic/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..55466064f61b --- /dev/null +++ b/ydb/core/kqp/ut/federated_query/generic/CMakeLists.windows-x86_64.txt @@ -0,0 +1,75 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-kqp-ut-federated_query-generic) +target_compile_options(ydb-core-kqp-ut-federated_query-generic PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-kqp-ut-federated_query-generic PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp +) +target_link_libraries(ydb-core-kqp-ut-federated_query-generic PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + ydb-core-kqp + contrib-libs-fmt + contrib-libs-libpqxx + cpp-clickhouse-client + kqp-ut-common + ut-federated_query-common + generic-connector-libcpp + yql-sql-pg_dummy +) +target_sources(ydb-core-kqp-ut-federated_query-generic PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/generic/ch_recipe_ut_helpers.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/generic/connector_recipe_ut_helpers.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/generic/kqp_generic_plan_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/generic/kqp_generic_provider_join_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/generic/pg_recipe_ut_helpers.cpp +) +set_property( + TARGET + ydb-core-kqp-ut-federated_query-generic + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-kqp-ut-federated_query-generic + TEST_TARGET + ydb-core-kqp-ut-federated_query-generic + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-kqp-ut-federated_query-generic + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-kqp-ut-federated_query-generic + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-core-kqp-ut-federated_query-generic + system_allocator +) +vcs_info(ydb-core-kqp-ut-federated_query-generic) diff --git a/ydb/core/kqp/ut/federated_query/generic_ut/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/federated_query/generic_ut/CMakeLists.darwin-arm64.txt index c52a44efd007..99133507c5be 100644 --- a/ydb/core/kqp/ut/federated_query/generic_ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/federated_query/generic_ut/CMakeLists.darwin-arm64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-kqp-ut-federated_query-generic_ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-federated_query-generic_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/generic_ut/kqp_generic_provider_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/federated_query/generic_ut/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/federated_query/generic_ut/CMakeLists.darwin-x86_64.txt index fbce2488948d..e2aed5091ea2 100644 --- a/ydb/core/kqp/ut/federated_query/generic_ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/federated_query/generic_ut/CMakeLists.darwin-x86_64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-kqp-ut-federated_query-generic_ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-federated_query-generic_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/generic_ut/kqp_generic_provider_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/federated_query/generic_ut/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/federated_query/generic_ut/CMakeLists.linux-aarch64.txt index 014d631899a7..2a63b9e2944d 100644 --- a/ydb/core/kqp/ut/federated_query/generic_ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/federated_query/generic_ut/CMakeLists.linux-aarch64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-kqp-ut-federated_query-generic_ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-federated_query-generic_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/generic_ut/kqp_generic_provider_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/federated_query/generic_ut/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/federated_query/generic_ut/CMakeLists.linux-x86_64.txt index e3e0d1cf8648..fdfc4d353dff 100644 --- a/ydb/core/kqp/ut/federated_query/generic_ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/federated_query/generic_ut/CMakeLists.linux-x86_64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-kqp-ut-federated_query-generic_ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-federated_query-generic_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/generic_ut/kqp_generic_provider_ut.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/federated_query/generic_ut/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/federated_query/generic_ut/CMakeLists.windows-x86_64.txt index 14e6132d039e..7cb343edd53b 100644 --- a/ydb/core/kqp/ut/federated_query/generic_ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/ut/federated_query/generic_ut/CMakeLists.windows-x86_64.txt @@ -55,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/federated_query/s3/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/federated_query/s3/CMakeLists.darwin-arm64.txt index 4b321c2f31a2..0563817621b4 100644 --- a/ydb/core/kqp/ut/federated_query/s3/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/federated_query/s3/CMakeLists.darwin-arm64.txt @@ -29,11 +29,10 @@ target_link_options(ydb-core-kqp-ut-federated_query-s3 PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-federated_query-s3 PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/s3/kqp_federated_query_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/s3/kqp_federated_scheme_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/s3/kqp_s3_plan_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/s3/s3_recipe_ut_helpers.cpp ) @@ -62,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/federated_query/s3/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/federated_query/s3/CMakeLists.darwin-x86_64.txt index 5d2c4f5ed1f5..6da91f016b1f 100644 --- a/ydb/core/kqp/ut/federated_query/s3/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/federated_query/s3/CMakeLists.darwin-x86_64.txt @@ -30,11 +30,10 @@ target_link_options(ydb-core-kqp-ut-federated_query-s3 PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-federated_query-s3 PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/s3/kqp_federated_query_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/s3/kqp_federated_scheme_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/s3/kqp_s3_plan_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/s3/s3_recipe_ut_helpers.cpp ) @@ -63,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/federated_query/s3/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/federated_query/s3/CMakeLists.linux-aarch64.txt index 8fce9c1a58cb..72c72d7c8669 100644 --- a/ydb/core/kqp/ut/federated_query/s3/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/federated_query/s3/CMakeLists.linux-aarch64.txt @@ -32,12 +32,10 @@ target_link_options(ydb-core-kqp-ut-federated_query-s3 PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-federated_query-s3 PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/s3/kqp_federated_query_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/s3/kqp_federated_scheme_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/s3/kqp_s3_plan_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/s3/s3_recipe_ut_helpers.cpp ) @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/federated_query/s3/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/federated_query/s3/CMakeLists.linux-x86_64.txt index 92405f1754aa..4135f6bfdfe1 100644 --- a/ydb/core/kqp/ut/federated_query/s3/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/federated_query/s3/CMakeLists.linux-x86_64.txt @@ -33,12 +33,10 @@ target_link_options(ydb-core-kqp-ut-federated_query-s3 PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-federated_query-s3 PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/s3/kqp_federated_query_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/s3/kqp_federated_scheme_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/s3/kqp_s3_plan_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/s3/s3_recipe_ut_helpers.cpp ) @@ -67,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/federated_query/s3/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/federated_query/s3/CMakeLists.windows-x86_64.txt index 2a7b658fd09f..131b05b8df22 100644 --- a/ydb/core/kqp/ut/federated_query/s3/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/ut/federated_query/s3/CMakeLists.windows-x86_64.txt @@ -28,6 +28,7 @@ target_link_libraries(ydb-core-kqp-ut-federated_query-s3 PUBLIC ) target_sources(ydb-core-kqp-ut-federated_query-s3 PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/s3/kqp_federated_query_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/s3/kqp_federated_scheme_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/s3/kqp_s3_plan_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/federated_query/s3/s3_recipe_ut_helpers.cpp ) @@ -56,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/idx_test/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/idx_test/CMakeLists.darwin-arm64.txt index ae5485355fa9..ba6c4839aee1 100644 --- a/ydb/core/kqp/ut/idx_test/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/idx_test/CMakeLists.darwin-arm64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-kqp-ut-idx_test PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-idx_test PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/idx_test/ydb_index_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/idx_test/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/idx_test/CMakeLists.darwin-x86_64.txt index eafd8a9440d8..4f0a872ceb75 100644 --- a/ydb/core/kqp/ut/idx_test/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/idx_test/CMakeLists.darwin-x86_64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-kqp-ut-idx_test PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-idx_test PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/idx_test/ydb_index_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/idx_test/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/idx_test/CMakeLists.linux-aarch64.txt index 7dc3a51f0e9c..0c6c44780978 100644 --- a/ydb/core/kqp/ut/idx_test/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/idx_test/CMakeLists.linux-aarch64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-kqp-ut-idx_test PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-idx_test PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/idx_test/ydb_index_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/idx_test/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/idx_test/CMakeLists.linux-x86_64.txt index f34572652611..a2727d521d44 100644 --- a/ydb/core/kqp/ut/idx_test/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/idx_test/CMakeLists.linux-x86_64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-kqp-ut-idx_test PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-idx_test PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/idx_test/ydb_index_ut.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/idx_test/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/idx_test/CMakeLists.windows-x86_64.txt index bd73d3a934f2..76e8f96a9d20 100644 --- a/ydb/core/kqp/ut/idx_test/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/ut/idx_test/CMakeLists.windows-x86_64.txt @@ -55,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/indexes/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/indexes/CMakeLists.darwin-arm64.txt index ad43bf80fe02..6e82815ae8f4 100644 --- a/ydb/core/kqp/ut/indexes/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/indexes/CMakeLists.darwin-arm64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-kqp-ut-indexes PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-indexes PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/indexes/kqp_indexes_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/indexes/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/indexes/CMakeLists.darwin-x86_64.txt index 35c2763f52e2..f1af2b289fdf 100644 --- a/ydb/core/kqp/ut/indexes/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/indexes/CMakeLists.darwin-x86_64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-core-kqp-ut-indexes PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-indexes PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/indexes/kqp_indexes_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/indexes/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/indexes/CMakeLists.linux-aarch64.txt index 5d46f97cb4e1..059ef340e210 100644 --- a/ydb/core/kqp/ut/indexes/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/indexes/CMakeLists.linux-aarch64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-kqp-ut-indexes PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-indexes PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/indexes/kqp_indexes_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/indexes/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/indexes/CMakeLists.linux-x86_64.txt index 0b6bbe2da4ad..88482b14e295 100644 --- a/ydb/core/kqp/ut/indexes/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/indexes/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-core-kqp-ut-indexes PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-indexes PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/indexes/kqp_indexes_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/indexes/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/indexes/CMakeLists.windows-x86_64.txt index 9dc95813228d..0d6d8433c027 100644 --- a/ydb/core/kqp/ut/indexes/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/ut/indexes/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/join/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/join/CMakeLists.darwin-arm64.txt index 610c92292e00..8b747427ce53 100644 --- a/ydb/core/kqp/ut/join/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/join/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-kqp-ut-join PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-join PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/join/kqp_flip_join_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/join/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/join/CMakeLists.darwin-x86_64.txt index 44f17858ecd6..e04c7f309314 100644 --- a/ydb/core/kqp/ut/join/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/join/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-kqp-ut-join PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-join PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/join/kqp_flip_join_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/join/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/join/CMakeLists.linux-aarch64.txt index 2f8f1cfe4d2f..a0d85ed4de51 100644 --- a/ydb/core/kqp/ut/join/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/join/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-kqp-ut-join PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-join PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/join/kqp_flip_join_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/join/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/join/CMakeLists.linux-x86_64.txt index 6d8f2e29856f..573e27485522 100644 --- a/ydb/core/kqp/ut/join/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/join/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-kqp-ut-join PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-join PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/join/kqp_flip_join_ut.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/join/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/join/CMakeLists.windows-x86_64.txt index 4ea7727bf856..059364d2fb72 100644 --- a/ydb/core/kqp/ut/join/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/ut/join/CMakeLists.windows-x86_64.txt @@ -55,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/olap/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/olap/CMakeLists.darwin-arm64.txt index 3848f566964a..08bda806a131 100644 --- a/ydb/core/kqp/ut/olap/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/olap/CMakeLists.darwin-arm64.txt @@ -28,10 +28,9 @@ target_link_options(ydb-core-kqp-ut-olap PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-olap PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/olap/kqp_olap_stats_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/olap/kqp_olap_ut.cpp ) set_property( @@ -59,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/olap/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/olap/CMakeLists.darwin-x86_64.txt index 6290b56e4304..cacb8feb17e3 100644 --- a/ydb/core/kqp/ut/olap/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/olap/CMakeLists.darwin-x86_64.txt @@ -29,10 +29,9 @@ target_link_options(ydb-core-kqp-ut-olap PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-olap PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/olap/kqp_olap_stats_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/olap/kqp_olap_ut.cpp ) set_property( @@ -60,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/olap/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/olap/CMakeLists.linux-aarch64.txt index 86526389b4a2..c14f3aa30a29 100644 --- a/ydb/core/kqp/ut/olap/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/olap/CMakeLists.linux-aarch64.txt @@ -31,11 +31,9 @@ target_link_options(ydb-core-kqp-ut-olap PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-olap PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/olap/kqp_olap_stats_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/olap/kqp_olap_ut.cpp ) set_property( @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/olap/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/olap/CMakeLists.linux-x86_64.txt index 223ce831a749..03004dbf46a2 100644 --- a/ydb/core/kqp/ut/olap/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/olap/CMakeLists.linux-x86_64.txt @@ -32,11 +32,9 @@ target_link_options(ydb-core-kqp-ut-olap PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-olap PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/olap/kqp_olap_stats_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/olap/kqp_olap_ut.cpp ) set_property( @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/olap/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/olap/CMakeLists.windows-x86_64.txt index 2f0b772eb6b3..a7456bc4fe1f 100644 --- a/ydb/core/kqp/ut/olap/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/ut/olap/CMakeLists.windows-x86_64.txt @@ -26,6 +26,7 @@ target_link_libraries(ydb-core-kqp-ut-olap PUBLIC tx-datashard-ut_common ) target_sources(ydb-core-kqp-ut-olap PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/olap/kqp_olap_stats_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/olap/kqp_olap_ut.cpp ) set_property( @@ -53,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/opt/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/opt/CMakeLists.darwin-arm64.txt index 60a0c09c4b5e..7eb8118d1584 100644 --- a/ydb/core/kqp/ut/opt/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/opt/CMakeLists.darwin-arm64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-kqp-ut-opt PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-opt PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/opt/kqp_agg_ut.cpp @@ -69,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/opt/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/opt/CMakeLists.darwin-x86_64.txt index 91f0546a6aaf..405478081571 100644 --- a/ydb/core/kqp/ut/opt/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/opt/CMakeLists.darwin-x86_64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-kqp-ut-opt PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-opt PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/opt/kqp_agg_ut.cpp @@ -70,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/opt/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/opt/CMakeLists.linux-aarch64.txt index f0bda02f2f76..3a898549ca23 100644 --- a/ydb/core/kqp/ut/opt/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/opt/CMakeLists.linux-aarch64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-kqp-ut-opt PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-opt PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/opt/kqp_agg_ut.cpp @@ -73,6 +70,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/opt/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/opt/CMakeLists.linux-x86_64.txt index 714c0b37c88d..ba8624a585d0 100644 --- a/ydb/core/kqp/ut/opt/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/opt/CMakeLists.linux-x86_64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-kqp-ut-opt PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-opt PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/opt/kqp_agg_ut.cpp @@ -74,6 +71,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/opt/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/opt/CMakeLists.windows-x86_64.txt index 7d1c0599fada..7543c9e252b0 100644 --- a/ydb/core/kqp/ut/opt/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/ut/opt/CMakeLists.windows-x86_64.txt @@ -63,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/perf/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/perf/CMakeLists.darwin-arm64.txt index 60a1aa3ec228..238d9a0a9127 100644 --- a/ydb/core/kqp/ut/perf/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/perf/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-kqp-ut-perf PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-perf PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/perf/kqp_query_perf_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/perf/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/perf/CMakeLists.darwin-x86_64.txt index 41bdc4dcb4c0..afa5c6484539 100644 --- a/ydb/core/kqp/ut/perf/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/perf/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-kqp-ut-perf PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-perf PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/perf/kqp_query_perf_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/perf/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/perf/CMakeLists.linux-aarch64.txt index 64e8c6b3c279..792a82ace751 100644 --- a/ydb/core/kqp/ut/perf/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/perf/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-kqp-ut-perf PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-perf PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/perf/kqp_query_perf_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/perf/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/perf/CMakeLists.linux-x86_64.txt index 422521347afb..a6ea17c52035 100644 --- a/ydb/core/kqp/ut/perf/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/perf/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-kqp-ut-perf PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-perf PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/perf/kqp_query_perf_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/perf/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/perf/CMakeLists.windows-x86_64.txt index 297663839898..7cd7c8a4d0e5 100644 --- a/ydb/core/kqp/ut/perf/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/ut/perf/CMakeLists.windows-x86_64.txt @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/pg/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/pg/CMakeLists.darwin-arm64.txt index ff58a281d769..a1342b4b84bf 100644 --- a/ydb/core/kqp/ut/pg/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/pg/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-kqp-ut-pg PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-pg PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/pg/kqp_pg_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/pg/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/pg/CMakeLists.darwin-x86_64.txt index 941b8aea8f72..0a6feea8a32b 100644 --- a/ydb/core/kqp/ut/pg/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/pg/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-kqp-ut-pg PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-pg PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/pg/kqp_pg_ut.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/pg/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/pg/CMakeLists.linux-aarch64.txt index 363e1973748f..23d4f9e47bfc 100644 --- a/ydb/core/kqp/ut/pg/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/pg/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-kqp-ut-pg PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-pg PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/pg/kqp_pg_ut.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/pg/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/pg/CMakeLists.linux-x86_64.txt index f5472cffa5a9..5f256d9536d5 100644 --- a/ydb/core/kqp/ut/pg/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/pg/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-kqp-ut-pg PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-pg PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/pg/kqp_pg_ut.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/pg/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/pg/CMakeLists.windows-x86_64.txt index 04a0d1c7b8e2..65b0e87f8ced 100644 --- a/ydb/core/kqp/ut/pg/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/ut/pg/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/query/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/query/CMakeLists.darwin-arm64.txt index bfbd417a9770..7890b28a0cf2 100644 --- a/ydb/core/kqp/ut/query/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/query/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-kqp-ut-query PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-query PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/query/kqp_explain_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/query/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/query/CMakeLists.darwin-x86_64.txt index ec1ad6a08915..06008b45ad15 100644 --- a/ydb/core/kqp/ut/query/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/query/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-kqp-ut-query PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-query PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/query/kqp_explain_ut.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/query/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/query/CMakeLists.linux-aarch64.txt index 38ad4a0b6f72..68c373361010 100644 --- a/ydb/core/kqp/ut/query/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/query/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-kqp-ut-query PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-query PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/query/kqp_explain_ut.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/query/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/query/CMakeLists.linux-x86_64.txt index 1201b9132d2c..17a4b48e4d1e 100644 --- a/ydb/core/kqp/ut/query/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/query/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-kqp-ut-query PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-query PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/query/kqp_explain_ut.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/query/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/query/CMakeLists.windows-x86_64.txt index b6a1a94bc2b7..32074d338ccb 100644 --- a/ydb/core/kqp/ut/query/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/ut/query/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/scan/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/scan/CMakeLists.darwin-arm64.txt index aae33bbba550..44b2b7664c1e 100644 --- a/ydb/core/kqp/ut/scan/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/scan/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-kqp-ut-scan PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-scan PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/scan/kqp_flowcontrol_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/scan/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/scan/CMakeLists.darwin-x86_64.txt index 861c014a9d22..444da0661bf3 100644 --- a/ydb/core/kqp/ut/scan/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/scan/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-kqp-ut-scan PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-scan PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/scan/kqp_flowcontrol_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/scan/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/scan/CMakeLists.linux-aarch64.txt index 9a3e0b8e717c..d5e71e635bc8 100644 --- a/ydb/core/kqp/ut/scan/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/scan/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-kqp-ut-scan PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-scan PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/scan/kqp_flowcontrol_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/scan/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/scan/CMakeLists.linux-x86_64.txt index 79e20884b555..b4dd857c3f14 100644 --- a/ydb/core/kqp/ut/scan/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/scan/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-kqp-ut-scan PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-scan PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/scan/kqp_flowcontrol_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/scan/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/scan/CMakeLists.windows-x86_64.txt index 887b40c1693d..948da05b40d7 100644 --- a/ydb/core/kqp/ut/scan/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/ut/scan/CMakeLists.windows-x86_64.txt @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/scheme/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/scheme/CMakeLists.darwin-arm64.txt index e6bba7cfd3fd..4e621fc6f40f 100644 --- a/ydb/core/kqp/ut/scheme/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/scheme/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-kqp-ut-scheme PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-scheme PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/scheme/kqp_acl_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/scheme/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/scheme/CMakeLists.darwin-x86_64.txt index ef893a915df7..a10b5eaeb6c3 100644 --- a/ydb/core/kqp/ut/scheme/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/scheme/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-kqp-ut-scheme PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-scheme PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/scheme/kqp_acl_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/scheme/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/scheme/CMakeLists.linux-aarch64.txt index b5e6e51a7d08..58ac4d0f77d8 100644 --- a/ydb/core/kqp/ut/scheme/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/scheme/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-kqp-ut-scheme PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-scheme PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/scheme/kqp_acl_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/scheme/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/scheme/CMakeLists.linux-x86_64.txt index 12bf405db0ec..a576f9093a6c 100644 --- a/ydb/core/kqp/ut/scheme/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/scheme/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-kqp-ut-scheme PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-scheme PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/scheme/kqp_acl_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/scheme/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/scheme/CMakeLists.windows-x86_64.txt index f048afbc85c3..c44246c7a5c6 100644 --- a/ydb/core/kqp/ut/scheme/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/ut/scheme/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/service/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/service/CMakeLists.darwin-arm64.txt index 69ab448fc667..e0a806da1b04 100644 --- a/ydb/core/kqp/ut/service/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/service/CMakeLists.darwin-arm64.txt @@ -19,6 +19,7 @@ target_link_libraries(ydb-core-kqp-ut-service PUBLIC yutil cpp-testing-unittest_main ydb-core-kqp + contrib-libs-fmt cpp-threading-local_executor kqp-ut-common yql-sql-pg @@ -31,8 +32,6 @@ target_link_options(ydb-core-kqp-ut-service PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-service PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/service/kqp_document_api_ut.cpp @@ -65,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/service/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/service/CMakeLists.darwin-x86_64.txt index b018c01b4658..90c55ef51fee 100644 --- a/ydb/core/kqp/ut/service/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/service/CMakeLists.darwin-x86_64.txt @@ -20,6 +20,7 @@ target_link_libraries(ydb-core-kqp-ut-service PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main ydb-core-kqp + contrib-libs-fmt cpp-threading-local_executor kqp-ut-common yql-sql-pg @@ -32,8 +33,6 @@ target_link_options(ydb-core-kqp-ut-service PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-service PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/service/kqp_document_api_ut.cpp @@ -66,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/service/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/service/CMakeLists.linux-aarch64.txt index 2af7a6dca82d..4515436fbf96 100644 --- a/ydb/core/kqp/ut/service/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/service/CMakeLists.linux-aarch64.txt @@ -20,6 +20,7 @@ target_link_libraries(ydb-core-kqp-ut-service PUBLIC yutil cpp-testing-unittest_main ydb-core-kqp + contrib-libs-fmt cpp-threading-local_executor kqp-ut-common yql-sql-pg @@ -34,9 +35,6 @@ target_link_options(ydb-core-kqp-ut-service PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-service PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/service/kqp_document_api_ut.cpp @@ -69,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/service/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/service/CMakeLists.linux-x86_64.txt index 47e075715903..4d5946d57f9e 100644 --- a/ydb/core/kqp/ut/service/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/service/CMakeLists.linux-x86_64.txt @@ -21,6 +21,7 @@ target_link_libraries(ydb-core-kqp-ut-service PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main ydb-core-kqp + contrib-libs-fmt cpp-threading-local_executor kqp-ut-common yql-sql-pg @@ -35,9 +36,6 @@ target_link_options(ydb-core-kqp-ut-service PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-service PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/service/kqp_document_api_ut.cpp @@ -70,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/service/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/service/CMakeLists.windows-x86_64.txt index 69865b7eeecb..c2e1d661a027 100644 --- a/ydb/core/kqp/ut/service/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/ut/service/CMakeLists.windows-x86_64.txt @@ -20,6 +20,7 @@ target_link_libraries(ydb-core-kqp-ut-service PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main ydb-core-kqp + contrib-libs-fmt cpp-threading-local_executor kqp-ut-common yql-sql-pg @@ -59,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/spilling/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/spilling/CMakeLists.darwin-arm64.txt index a5d55a21c994..65d533b817ed 100644 --- a/ydb/core/kqp/ut/spilling/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/spilling/CMakeLists.darwin-arm64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-kqp-ut-spilling PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-spilling PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/spilling/kqp_scan_spilling_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/spilling/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/spilling/CMakeLists.darwin-x86_64.txt index 10b942cf5dbb..d432d81ff8d1 100644 --- a/ydb/core/kqp/ut/spilling/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/spilling/CMakeLists.darwin-x86_64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-kqp-ut-spilling PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-spilling PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/spilling/kqp_scan_spilling_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/spilling/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/spilling/CMakeLists.linux-aarch64.txt index e8a070085beb..8775c4d845ff 100644 --- a/ydb/core/kqp/ut/spilling/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/spilling/CMakeLists.linux-aarch64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-kqp-ut-spilling PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-spilling PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/spilling/kqp_scan_spilling_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/spilling/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/spilling/CMakeLists.linux-x86_64.txt index f6fee0ec8856..bdbe78c7a7f9 100644 --- a/ydb/core/kqp/ut/spilling/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/spilling/CMakeLists.linux-x86_64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-kqp-ut-spilling PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-spilling PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/spilling/kqp_scan_spilling_ut.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/spilling/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/spilling/CMakeLists.windows-x86_64.txt index 045a7a8bbe21..48fc56a54de2 100644 --- a/ydb/core/kqp/ut/spilling/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/ut/spilling/CMakeLists.windows-x86_64.txt @@ -55,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/sysview/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/sysview/CMakeLists.darwin-arm64.txt index 0f3ce6ed0d08..5fce5e3cdbfe 100644 --- a/ydb/core/kqp/ut/sysview/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/sysview/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-kqp-ut-sysview PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-sysview PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/sysview/kqp_sys_col_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/sysview/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/sysview/CMakeLists.darwin-x86_64.txt index 444e09c65ed7..ef24f01983f7 100644 --- a/ydb/core/kqp/ut/sysview/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/sysview/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-kqp-ut-sysview PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-sysview PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/sysview/kqp_sys_col_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/sysview/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/sysview/CMakeLists.linux-aarch64.txt index ba8827188dc3..2bf058997d04 100644 --- a/ydb/core/kqp/ut/sysview/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/sysview/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-kqp-ut-sysview PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-sysview PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/sysview/kqp_sys_col_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/sysview/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/sysview/CMakeLists.linux-x86_64.txt index f94adcfb421d..e494adeaa4dc 100644 --- a/ydb/core/kqp/ut/sysview/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/sysview/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-kqp-ut-sysview PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-sysview PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/sysview/kqp_sys_col_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/sysview/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/sysview/CMakeLists.windows-x86_64.txt index 9e916da5df39..f1929c215aaf 100644 --- a/ydb/core/kqp/ut/sysview/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/ut/sysview/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/tx/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/tx/CMakeLists.darwin-arm64.txt index 56226845dca8..b011f8c4796c 100644 --- a/ydb/core/kqp/ut/tx/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/tx/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-kqp-ut-tx PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-tx PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/tx/kqp_locks_tricky_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/tx/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/tx/CMakeLists.darwin-x86_64.txt index 3acc9f49dbad..711bf8f8fed3 100644 --- a/ydb/core/kqp/ut/tx/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/tx/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-kqp-ut-tx PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-tx PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/tx/kqp_locks_tricky_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/tx/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/tx/CMakeLists.linux-aarch64.txt index d58da1818bba..3e470abf81b4 100644 --- a/ydb/core/kqp/ut/tx/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/tx/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-kqp-ut-tx PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-tx PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/tx/kqp_locks_tricky_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/tx/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/tx/CMakeLists.linux-x86_64.txt index 74f0bb738c6e..4340f184c997 100644 --- a/ydb/core/kqp/ut/tx/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/tx/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-kqp-ut-tx PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-tx PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/tx/kqp_locks_tricky_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/tx/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/tx/CMakeLists.windows-x86_64.txt index 2d757f0af955..181572024227 100644 --- a/ydb/core/kqp/ut/tx/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/ut/tx/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/view/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/view/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..d8cf46f21422 --- /dev/null +++ b/ydb/core/kqp/ut/view/CMakeLists.darwin-arm64.txt @@ -0,0 +1,72 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-kqp-ut-view) +target_compile_options(ydb-core-kqp-ut-view PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-kqp-ut-view PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp +) +target_link_libraries(ydb-core-kqp-ut-view PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + ydb-core-kqp + kqp-ut-common + library-yql-sql + yql-utils-log + testlib-basics-default +) +target_link_options(ydb-core-kqp-ut-view PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-core-kqp-ut-view PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/view/view_ut.cpp +) +set_property( + TARGET + ydb-core-kqp-ut-view + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-kqp-ut-view + TEST_TARGET + ydb-core-kqp-ut-view + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-kqp-ut-view + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-kqp-ut-view + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-core-kqp-ut-view + system_allocator +) +vcs_info(ydb-core-kqp-ut-view) diff --git a/ydb/core/kqp/ut/view/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/view/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..daf4fe6b167c --- /dev/null +++ b/ydb/core/kqp/ut/view/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,73 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-kqp-ut-view) +target_compile_options(ydb-core-kqp-ut-view PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-kqp-ut-view PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp +) +target_link_libraries(ydb-core-kqp-ut-view PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + ydb-core-kqp + kqp-ut-common + library-yql-sql + yql-utils-log + testlib-basics-default +) +target_link_options(ydb-core-kqp-ut-view PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-core-kqp-ut-view PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/view/view_ut.cpp +) +set_property( + TARGET + ydb-core-kqp-ut-view + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-kqp-ut-view + TEST_TARGET + ydb-core-kqp-ut-view + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-kqp-ut-view + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-kqp-ut-view + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-core-kqp-ut-view + system_allocator +) +vcs_info(ydb-core-kqp-ut-view) diff --git a/ydb/core/kqp/ut/view/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/view/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..9c969dd7f3e2 --- /dev/null +++ b/ydb/core/kqp/ut/view/CMakeLists.linux-aarch64.txt @@ -0,0 +1,75 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-kqp-ut-view) +target_compile_options(ydb-core-kqp-ut-view PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-kqp-ut-view PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp +) +target_link_libraries(ydb-core-kqp-ut-view PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + ydb-core-kqp + kqp-ut-common + library-yql-sql + yql-utils-log + testlib-basics-default +) +target_link_options(ydb-core-kqp-ut-view PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-core-kqp-ut-view PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/view/view_ut.cpp +) +set_property( + TARGET + ydb-core-kqp-ut-view + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-kqp-ut-view + TEST_TARGET + ydb-core-kqp-ut-view + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-kqp-ut-view + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-kqp-ut-view + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-core-kqp-ut-view + cpp-malloc-jemalloc +) +vcs_info(ydb-core-kqp-ut-view) diff --git a/ydb/core/kqp/ut/view/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/view/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..0058c325d1f3 --- /dev/null +++ b/ydb/core/kqp/ut/view/CMakeLists.linux-x86_64.txt @@ -0,0 +1,77 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-kqp-ut-view) +target_compile_options(ydb-core-kqp-ut-view PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-kqp-ut-view PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp +) +target_link_libraries(ydb-core-kqp-ut-view PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + ydb-core-kqp + kqp-ut-common + library-yql-sql + yql-utils-log + testlib-basics-default +) +target_link_options(ydb-core-kqp-ut-view PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-core-kqp-ut-view PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/view/view_ut.cpp +) +set_property( + TARGET + ydb-core-kqp-ut-view + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-kqp-ut-view + TEST_TARGET + ydb-core-kqp-ut-view + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-kqp-ut-view + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-kqp-ut-view + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-core-kqp-ut-view + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(ydb-core-kqp-ut-view) diff --git a/ydb/core/kqp/ut/view/CMakeLists.txt b/ydb/core/kqp/ut/view/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/kqp/ut/view/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/kqp/ut/view/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/view/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..75d6ffb60f23 --- /dev/null +++ b/ydb/core/kqp/ut/view/CMakeLists.windows-x86_64.txt @@ -0,0 +1,68 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-kqp-ut-view) +target_compile_options(ydb-core-kqp-ut-view PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-kqp-ut-view PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp +) +target_link_libraries(ydb-core-kqp-ut-view PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + ydb-core-kqp + kqp-ut-common + library-yql-sql + yql-utils-log + testlib-basics-default +) +target_sources(ydb-core-kqp-ut-view PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/view/view_ut.cpp +) +set_property( + TARGET + ydb-core-kqp-ut-view + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-core-kqp-ut-view + TEST_TARGET + ydb-core-kqp-ut-view + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-kqp-ut-view + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-kqp-ut-view + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-core-kqp-ut-view + system_allocator +) +vcs_info(ydb-core-kqp-ut-view) diff --git a/ydb/core/kqp/ut/yql/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/ut/yql/CMakeLists.darwin-arm64.txt index 25daf9104e03..629ccc80ca7e 100644 --- a/ydb/core/kqp/ut/yql/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/ut/yql/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-kqp-ut-yql PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-yql PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/yql/kqp_pragma_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/yql/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/ut/yql/CMakeLists.darwin-x86_64.txt index 5435e5c7d928..baf44792979f 100644 --- a/ydb/core/kqp/ut/yql/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/ut/yql/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-kqp-ut-yql PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-kqp-ut-yql PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/yql/kqp_pragma_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/yql/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/ut/yql/CMakeLists.linux-aarch64.txt index 395fe66328c2..779147f6150f 100644 --- a/ydb/core/kqp/ut/yql/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/ut/yql/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-kqp-ut-yql PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-yql PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/yql/kqp_pragma_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/yql/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/ut/yql/CMakeLists.linux-x86_64.txt index a1884e2913f9..899c5be142cd 100644 --- a/ydb/core/kqp/ut/yql/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/ut/yql/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-kqp-ut-yql PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-kqp-ut-yql PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/ut/yql/kqp_pragma_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/kqp/ut/yql/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/ut/yql/CMakeLists.windows-x86_64.txt index 2df2e09b818f..46275bd2d3ed 100644 --- a/ydb/core/kqp/ut/yql/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/ut/yql/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/load_test/CMakeLists.darwin-arm64.txt b/ydb/core/load_test/CMakeLists.darwin-arm64.txt index 165bbf63620c..45d3f932ff72 100644 --- a/ydb/core/load_test/CMakeLists.darwin-arm64.txt +++ b/ydb/core/load_test/CMakeLists.darwin-arm64.txt @@ -43,6 +43,11 @@ target_link_libraries(ydb-core-load_test PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(ydb-core-load_test PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/actors.h + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/common.h + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/info_collector.h + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/test_load_actor.h ${CMAKE_SOURCE_DIR}/ydb/core/load_test/aggregated_result.cpp ${CMAKE_SOURCE_DIR}/ydb/core/load_test/archive.cpp ${CMAKE_SOURCE_DIR}/ydb/core/load_test/config_examples.cpp diff --git a/ydb/core/load_test/CMakeLists.darwin-x86_64.txt b/ydb/core/load_test/CMakeLists.darwin-x86_64.txt index 165bbf63620c..45d3f932ff72 100644 --- a/ydb/core/load_test/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/load_test/CMakeLists.darwin-x86_64.txt @@ -43,6 +43,11 @@ target_link_libraries(ydb-core-load_test PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(ydb-core-load_test PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/actors.h + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/common.h + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/info_collector.h + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/test_load_actor.h ${CMAKE_SOURCE_DIR}/ydb/core/load_test/aggregated_result.cpp ${CMAKE_SOURCE_DIR}/ydb/core/load_test/archive.cpp ${CMAKE_SOURCE_DIR}/ydb/core/load_test/config_examples.cpp diff --git a/ydb/core/load_test/CMakeLists.linux-aarch64.txt b/ydb/core/load_test/CMakeLists.linux-aarch64.txt index 460b2009bc20..34d39b18ad3b 100644 --- a/ydb/core/load_test/CMakeLists.linux-aarch64.txt +++ b/ydb/core/load_test/CMakeLists.linux-aarch64.txt @@ -44,6 +44,11 @@ target_link_libraries(ydb-core-load_test PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(ydb-core-load_test PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/actors.h + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/common.h + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/info_collector.h + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/test_load_actor.h ${CMAKE_SOURCE_DIR}/ydb/core/load_test/aggregated_result.cpp ${CMAKE_SOURCE_DIR}/ydb/core/load_test/archive.cpp ${CMAKE_SOURCE_DIR}/ydb/core/load_test/config_examples.cpp diff --git a/ydb/core/load_test/CMakeLists.linux-x86_64.txt b/ydb/core/load_test/CMakeLists.linux-x86_64.txt index 460b2009bc20..34d39b18ad3b 100644 --- a/ydb/core/load_test/CMakeLists.linux-x86_64.txt +++ b/ydb/core/load_test/CMakeLists.linux-x86_64.txt @@ -44,6 +44,11 @@ target_link_libraries(ydb-core-load_test PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(ydb-core-load_test PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/actors.h + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/common.h + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/info_collector.h + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/test_load_actor.h ${CMAKE_SOURCE_DIR}/ydb/core/load_test/aggregated_result.cpp ${CMAKE_SOURCE_DIR}/ydb/core/load_test/archive.cpp ${CMAKE_SOURCE_DIR}/ydb/core/load_test/config_examples.cpp diff --git a/ydb/core/load_test/CMakeLists.windows-x86_64.txt b/ydb/core/load_test/CMakeLists.windows-x86_64.txt index 165bbf63620c..45d3f932ff72 100644 --- a/ydb/core/load_test/CMakeLists.windows-x86_64.txt +++ b/ydb/core/load_test/CMakeLists.windows-x86_64.txt @@ -43,6 +43,11 @@ target_link_libraries(ydb-core-load_test PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(ydb-core-load_test PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/actors.h + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/common.h + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/info_collector.h + ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ycsb/test_load_actor.h ${CMAKE_SOURCE_DIR}/ydb/core/load_test/aggregated_result.cpp ${CMAKE_SOURCE_DIR}/ydb/core/load_test/archive.cpp ${CMAKE_SOURCE_DIR}/ydb/core/load_test/config_examples.cpp diff --git a/ydb/core/load_test/ut_ycsb/CMakeLists.darwin-arm64.txt b/ydb/core/load_test/ut_ycsb/CMakeLists.darwin-arm64.txt index fbb5e2cf2ecd..06aba26f932a 100644 --- a/ydb/core/load_test/ut_ycsb/CMakeLists.darwin-arm64.txt +++ b/ydb/core/load_test/ut_ycsb/CMakeLists.darwin-arm64.txt @@ -33,8 +33,6 @@ target_link_options(ydb-core-load_test-ut_ycsb PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-load_test-ut_ycsb PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ut_ycsb.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/load_test/ut_ycsb/CMakeLists.darwin-x86_64.txt b/ydb/core/load_test/ut_ycsb/CMakeLists.darwin-x86_64.txt index 84a088bbd057..ca2dcae0900f 100644 --- a/ydb/core/load_test/ut_ycsb/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/load_test/ut_ycsb/CMakeLists.darwin-x86_64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-load_test-ut_ycsb PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-load_test-ut_ycsb PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ut_ycsb.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/load_test/ut_ycsb/CMakeLists.linux-aarch64.txt b/ydb/core/load_test/ut_ycsb/CMakeLists.linux-aarch64.txt index 22330944e729..b71f8fe0c253 100644 --- a/ydb/core/load_test/ut_ycsb/CMakeLists.linux-aarch64.txt +++ b/ydb/core/load_test/ut_ycsb/CMakeLists.linux-aarch64.txt @@ -36,9 +36,6 @@ target_link_options(ydb-core-load_test-ut_ycsb PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-load_test-ut_ycsb PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ut_ycsb.cpp @@ -68,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/load_test/ut_ycsb/CMakeLists.linux-x86_64.txt b/ydb/core/load_test/ut_ycsb/CMakeLists.linux-x86_64.txt index e4e06f548fcb..2d8ab051b8c5 100644 --- a/ydb/core/load_test/ut_ycsb/CMakeLists.linux-x86_64.txt +++ b/ydb/core/load_test/ut_ycsb/CMakeLists.linux-x86_64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-load_test-ut_ycsb PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-load_test-ut_ycsb PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/load_test/ut_ycsb.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/load_test/ut_ycsb/CMakeLists.windows-x86_64.txt b/ydb/core/load_test/ut_ycsb/CMakeLists.windows-x86_64.txt index 2792b431ed6c..403d37d51c51 100644 --- a/ydb/core/load_test/ut_ycsb/CMakeLists.windows-x86_64.txt +++ b/ydb/core/load_test/ut_ycsb/CMakeLists.windows-x86_64.txt @@ -58,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/local_pgwire/CMakeLists.darwin-arm64.txt b/ydb/core/local_pgwire/CMakeLists.darwin-arm64.txt index 3e3737ea5d59..676da89c2c21 100644 --- a/ydb/core/local_pgwire/CMakeLists.darwin-arm64.txt +++ b/ydb/core/local_pgwire/CMakeLists.darwin-arm64.txt @@ -28,6 +28,10 @@ target_link_libraries(ydb-core-local_pgwire PUBLIC lib-operation_id-protos ) target_sources(ydb-core-local_pgwire PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire.h + ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire_util.h + ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/sql_parser.h ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire_connection.cpp ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire.cpp ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire_util.cpp diff --git a/ydb/core/local_pgwire/CMakeLists.darwin-x86_64.txt b/ydb/core/local_pgwire/CMakeLists.darwin-x86_64.txt index 3e3737ea5d59..676da89c2c21 100644 --- a/ydb/core/local_pgwire/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/local_pgwire/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,10 @@ target_link_libraries(ydb-core-local_pgwire PUBLIC lib-operation_id-protos ) target_sources(ydb-core-local_pgwire PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire.h + ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire_util.h + ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/sql_parser.h ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire_connection.cpp ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire.cpp ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire_util.cpp diff --git a/ydb/core/local_pgwire/CMakeLists.linux-aarch64.txt b/ydb/core/local_pgwire/CMakeLists.linux-aarch64.txt index ac36041765ba..78789c725276 100644 --- a/ydb/core/local_pgwire/CMakeLists.linux-aarch64.txt +++ b/ydb/core/local_pgwire/CMakeLists.linux-aarch64.txt @@ -29,6 +29,10 @@ target_link_libraries(ydb-core-local_pgwire PUBLIC lib-operation_id-protos ) target_sources(ydb-core-local_pgwire PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire.h + ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire_util.h + ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/sql_parser.h ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire_connection.cpp ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire.cpp ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire_util.cpp diff --git a/ydb/core/local_pgwire/CMakeLists.linux-x86_64.txt b/ydb/core/local_pgwire/CMakeLists.linux-x86_64.txt index ac36041765ba..78789c725276 100644 --- a/ydb/core/local_pgwire/CMakeLists.linux-x86_64.txt +++ b/ydb/core/local_pgwire/CMakeLists.linux-x86_64.txt @@ -29,6 +29,10 @@ target_link_libraries(ydb-core-local_pgwire PUBLIC lib-operation_id-protos ) target_sources(ydb-core-local_pgwire PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire.h + ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire_util.h + ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/sql_parser.h ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire_connection.cpp ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire.cpp ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire_util.cpp diff --git a/ydb/core/local_pgwire/CMakeLists.windows-x86_64.txt b/ydb/core/local_pgwire/CMakeLists.windows-x86_64.txt index 3e3737ea5d59..676da89c2c21 100644 --- a/ydb/core/local_pgwire/CMakeLists.windows-x86_64.txt +++ b/ydb/core/local_pgwire/CMakeLists.windows-x86_64.txt @@ -28,6 +28,10 @@ target_link_libraries(ydb-core-local_pgwire PUBLIC lib-operation_id-protos ) target_sources(ydb-core-local_pgwire PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire.h + ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire_util.h + ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/sql_parser.h ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire_connection.cpp ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire.cpp ${CMAKE_SOURCE_DIR}/ydb/core/local_pgwire/local_pgwire_util.cpp diff --git a/ydb/core/log_backend/CMakeLists.darwin-arm64.txt b/ydb/core/log_backend/CMakeLists.darwin-arm64.txt index 94831d48f3c1..f8e53969f5d7 100644 --- a/ydb/core/log_backend/CMakeLists.darwin-arm64.txt +++ b/ydb/core/log_backend/CMakeLists.darwin-arm64.txt @@ -18,6 +18,8 @@ target_link_libraries(ydb-core-log_backend PUBLIC ydb-core-base ) target_sources(ydb-core-log_backend PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/log_backend/log_backend.h + ${CMAKE_SOURCE_DIR}/ydb/core/log_backend/log_backend_build.h ${CMAKE_SOURCE_DIR}/ydb/core/log_backend/log_backend.cpp ${CMAKE_SOURCE_DIR}/ydb/core/log_backend/log_backend_build.cpp ) diff --git a/ydb/core/log_backend/CMakeLists.darwin-x86_64.txt b/ydb/core/log_backend/CMakeLists.darwin-x86_64.txt index 94831d48f3c1..f8e53969f5d7 100644 --- a/ydb/core/log_backend/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/log_backend/CMakeLists.darwin-x86_64.txt @@ -18,6 +18,8 @@ target_link_libraries(ydb-core-log_backend PUBLIC ydb-core-base ) target_sources(ydb-core-log_backend PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/log_backend/log_backend.h + ${CMAKE_SOURCE_DIR}/ydb/core/log_backend/log_backend_build.h ${CMAKE_SOURCE_DIR}/ydb/core/log_backend/log_backend.cpp ${CMAKE_SOURCE_DIR}/ydb/core/log_backend/log_backend_build.cpp ) diff --git a/ydb/core/log_backend/CMakeLists.linux-aarch64.txt b/ydb/core/log_backend/CMakeLists.linux-aarch64.txt index 57ef405c9b74..44d817e6b12a 100644 --- a/ydb/core/log_backend/CMakeLists.linux-aarch64.txt +++ b/ydb/core/log_backend/CMakeLists.linux-aarch64.txt @@ -19,6 +19,8 @@ target_link_libraries(ydb-core-log_backend PUBLIC ydb-core-base ) target_sources(ydb-core-log_backend PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/log_backend/log_backend.h + ${CMAKE_SOURCE_DIR}/ydb/core/log_backend/log_backend_build.h ${CMAKE_SOURCE_DIR}/ydb/core/log_backend/log_backend.cpp ${CMAKE_SOURCE_DIR}/ydb/core/log_backend/log_backend_build.cpp ) diff --git a/ydb/core/log_backend/CMakeLists.linux-x86_64.txt b/ydb/core/log_backend/CMakeLists.linux-x86_64.txt index 57ef405c9b74..44d817e6b12a 100644 --- a/ydb/core/log_backend/CMakeLists.linux-x86_64.txt +++ b/ydb/core/log_backend/CMakeLists.linux-x86_64.txt @@ -19,6 +19,8 @@ target_link_libraries(ydb-core-log_backend PUBLIC ydb-core-base ) target_sources(ydb-core-log_backend PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/log_backend/log_backend.h + ${CMAKE_SOURCE_DIR}/ydb/core/log_backend/log_backend_build.h ${CMAKE_SOURCE_DIR}/ydb/core/log_backend/log_backend.cpp ${CMAKE_SOURCE_DIR}/ydb/core/log_backend/log_backend_build.cpp ) diff --git a/ydb/core/log_backend/CMakeLists.windows-x86_64.txt b/ydb/core/log_backend/CMakeLists.windows-x86_64.txt index 94831d48f3c1..f8e53969f5d7 100644 --- a/ydb/core/log_backend/CMakeLists.windows-x86_64.txt +++ b/ydb/core/log_backend/CMakeLists.windows-x86_64.txt @@ -18,6 +18,8 @@ target_link_libraries(ydb-core-log_backend PUBLIC ydb-core-base ) target_sources(ydb-core-log_backend PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/log_backend/log_backend.h + ${CMAKE_SOURCE_DIR}/ydb/core/log_backend/log_backend_build.h ${CMAKE_SOURCE_DIR}/ydb/core/log_backend/log_backend.cpp ${CMAKE_SOURCE_DIR}/ydb/core/log_backend/log_backend_build.cpp ) diff --git a/ydb/core/metering/CMakeLists.darwin-arm64.txt b/ydb/core/metering/CMakeLists.darwin-arm64.txt index 41220d343f26..b9a5743743f7 100644 --- a/ydb/core/metering/CMakeLists.darwin-arm64.txt +++ b/ydb/core/metering/CMakeLists.darwin-arm64.txt @@ -32,6 +32,9 @@ target_link_libraries(ydb-core-metering PUBLIC library-cpp-resource ) target_sources(ydb-core-metering PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/metering/bill_record.h + ${CMAKE_SOURCE_DIR}/ydb/core/metering/metering.h + ${CMAKE_SOURCE_DIR}/ydb/core/metering/time_grid.h ${CMAKE_SOURCE_DIR}/ydb/core/metering/bill_record.cpp ${CMAKE_SOURCE_DIR}/ydb/core/metering/metering.cpp ${CMAKE_SOURCE_DIR}/ydb/core/metering/stream_ru_calculator.cpp diff --git a/ydb/core/metering/CMakeLists.darwin-x86_64.txt b/ydb/core/metering/CMakeLists.darwin-x86_64.txt index 41220d343f26..b9a5743743f7 100644 --- a/ydb/core/metering/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/metering/CMakeLists.darwin-x86_64.txt @@ -32,6 +32,9 @@ target_link_libraries(ydb-core-metering PUBLIC library-cpp-resource ) target_sources(ydb-core-metering PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/metering/bill_record.h + ${CMAKE_SOURCE_DIR}/ydb/core/metering/metering.h + ${CMAKE_SOURCE_DIR}/ydb/core/metering/time_grid.h ${CMAKE_SOURCE_DIR}/ydb/core/metering/bill_record.cpp ${CMAKE_SOURCE_DIR}/ydb/core/metering/metering.cpp ${CMAKE_SOURCE_DIR}/ydb/core/metering/stream_ru_calculator.cpp diff --git a/ydb/core/metering/CMakeLists.linux-aarch64.txt b/ydb/core/metering/CMakeLists.linux-aarch64.txt index cc32b93e4bf0..f42a1b6919a5 100644 --- a/ydb/core/metering/CMakeLists.linux-aarch64.txt +++ b/ydb/core/metering/CMakeLists.linux-aarch64.txt @@ -33,6 +33,9 @@ target_link_libraries(ydb-core-metering PUBLIC library-cpp-resource ) target_sources(ydb-core-metering PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/metering/bill_record.h + ${CMAKE_SOURCE_DIR}/ydb/core/metering/metering.h + ${CMAKE_SOURCE_DIR}/ydb/core/metering/time_grid.h ${CMAKE_SOURCE_DIR}/ydb/core/metering/bill_record.cpp ${CMAKE_SOURCE_DIR}/ydb/core/metering/metering.cpp ${CMAKE_SOURCE_DIR}/ydb/core/metering/stream_ru_calculator.cpp diff --git a/ydb/core/metering/CMakeLists.linux-x86_64.txt b/ydb/core/metering/CMakeLists.linux-x86_64.txt index cc32b93e4bf0..f42a1b6919a5 100644 --- a/ydb/core/metering/CMakeLists.linux-x86_64.txt +++ b/ydb/core/metering/CMakeLists.linux-x86_64.txt @@ -33,6 +33,9 @@ target_link_libraries(ydb-core-metering PUBLIC library-cpp-resource ) target_sources(ydb-core-metering PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/metering/bill_record.h + ${CMAKE_SOURCE_DIR}/ydb/core/metering/metering.h + ${CMAKE_SOURCE_DIR}/ydb/core/metering/time_grid.h ${CMAKE_SOURCE_DIR}/ydb/core/metering/bill_record.cpp ${CMAKE_SOURCE_DIR}/ydb/core/metering/metering.cpp ${CMAKE_SOURCE_DIR}/ydb/core/metering/stream_ru_calculator.cpp diff --git a/ydb/core/metering/CMakeLists.windows-x86_64.txt b/ydb/core/metering/CMakeLists.windows-x86_64.txt index 41220d343f26..b9a5743743f7 100644 --- a/ydb/core/metering/CMakeLists.windows-x86_64.txt +++ b/ydb/core/metering/CMakeLists.windows-x86_64.txt @@ -32,6 +32,9 @@ target_link_libraries(ydb-core-metering PUBLIC library-cpp-resource ) target_sources(ydb-core-metering PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/metering/bill_record.h + ${CMAKE_SOURCE_DIR}/ydb/core/metering/metering.h + ${CMAKE_SOURCE_DIR}/ydb/core/metering/time_grid.h ${CMAKE_SOURCE_DIR}/ydb/core/metering/bill_record.cpp ${CMAKE_SOURCE_DIR}/ydb/core/metering/metering.cpp ${CMAKE_SOURCE_DIR}/ydb/core/metering/stream_ru_calculator.cpp diff --git a/ydb/core/metering/ut/CMakeLists.darwin-arm64.txt b/ydb/core/metering/ut/CMakeLists.darwin-arm64.txt index e8a736588981..07b7e47985c2 100644 --- a/ydb/core/metering/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/metering/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-core-metering-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-metering-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/metering/stream_ru_calculator_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/metering/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/metering/ut/CMakeLists.darwin-x86_64.txt index 9507a0e45f69..a24c2b8e3918 100644 --- a/ydb/core/metering/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/metering/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-core-metering-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-metering-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/metering/stream_ru_calculator_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/metering/ut/CMakeLists.linux-aarch64.txt b/ydb/core/metering/ut/CMakeLists.linux-aarch64.txt index 253a913bae3e..43eec0da0be6 100644 --- a/ydb/core/metering/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/metering/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-core-metering-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-metering-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/metering/stream_ru_calculator_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/metering/ut/CMakeLists.linux-x86_64.txt b/ydb/core/metering/ut/CMakeLists.linux-x86_64.txt index b3bd83fcc96c..0db07b2b1175 100644 --- a/ydb/core/metering/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/metering/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-core-metering-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-metering-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/metering/stream_ru_calculator_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/metering/ut/CMakeLists.windows-x86_64.txt b/ydb/core/metering/ut/CMakeLists.windows-x86_64.txt index bc728e82506c..dff051d4abae 100644 --- a/ydb/core/metering/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/metering/ut/CMakeLists.windows-x86_64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/CMakeLists.darwin-arm64.txt b/ydb/core/mind/CMakeLists.darwin-arm64.txt index d8549961e1f3..69767b590ee1 100644 --- a/ydb/core/mind/CMakeLists.darwin-arm64.txt +++ b/ydb/core/mind/CMakeLists.darwin-arm64.txt @@ -41,6 +41,22 @@ target_link_libraries(ydb-core-mind PUBLIC core-tx-schemeshard ) target_sources(ydb-core-mind PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mind/configured_tablet_bootstrapper.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/dynamic_nameserver.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/dynamic_nameserver_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/labels_maintainer.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/lease_holder.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/local.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/node_broker.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/node_broker_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/node_broker__scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/table_adapter.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_node_enumeration.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_pool.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_slot_broker.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_slot_broker_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_slot_broker__scheme.h ${CMAKE_SOURCE_DIR}/ydb/core/mind/configured_tablet_bootstrapper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/dynamic_nameserver.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/dynamic_nameserver_mon.cpp diff --git a/ydb/core/mind/CMakeLists.darwin-x86_64.txt b/ydb/core/mind/CMakeLists.darwin-x86_64.txt index d8549961e1f3..69767b590ee1 100644 --- a/ydb/core/mind/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/mind/CMakeLists.darwin-x86_64.txt @@ -41,6 +41,22 @@ target_link_libraries(ydb-core-mind PUBLIC core-tx-schemeshard ) target_sources(ydb-core-mind PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mind/configured_tablet_bootstrapper.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/dynamic_nameserver.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/dynamic_nameserver_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/labels_maintainer.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/lease_holder.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/local.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/node_broker.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/node_broker_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/node_broker__scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/table_adapter.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_node_enumeration.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_pool.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_slot_broker.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_slot_broker_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_slot_broker__scheme.h ${CMAKE_SOURCE_DIR}/ydb/core/mind/configured_tablet_bootstrapper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/dynamic_nameserver.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/dynamic_nameserver_mon.cpp diff --git a/ydb/core/mind/CMakeLists.linux-aarch64.txt b/ydb/core/mind/CMakeLists.linux-aarch64.txt index fe19ce801d0e..08a0484b888c 100644 --- a/ydb/core/mind/CMakeLists.linux-aarch64.txt +++ b/ydb/core/mind/CMakeLists.linux-aarch64.txt @@ -42,6 +42,22 @@ target_link_libraries(ydb-core-mind PUBLIC core-tx-schemeshard ) target_sources(ydb-core-mind PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mind/configured_tablet_bootstrapper.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/dynamic_nameserver.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/dynamic_nameserver_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/labels_maintainer.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/lease_holder.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/local.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/node_broker.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/node_broker_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/node_broker__scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/table_adapter.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_node_enumeration.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_pool.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_slot_broker.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_slot_broker_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_slot_broker__scheme.h ${CMAKE_SOURCE_DIR}/ydb/core/mind/configured_tablet_bootstrapper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/dynamic_nameserver.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/dynamic_nameserver_mon.cpp diff --git a/ydb/core/mind/CMakeLists.linux-x86_64.txt b/ydb/core/mind/CMakeLists.linux-x86_64.txt index fe19ce801d0e..08a0484b888c 100644 --- a/ydb/core/mind/CMakeLists.linux-x86_64.txt +++ b/ydb/core/mind/CMakeLists.linux-x86_64.txt @@ -42,6 +42,22 @@ target_link_libraries(ydb-core-mind PUBLIC core-tx-schemeshard ) target_sources(ydb-core-mind PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mind/configured_tablet_bootstrapper.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/dynamic_nameserver.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/dynamic_nameserver_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/labels_maintainer.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/lease_holder.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/local.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/node_broker.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/node_broker_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/node_broker__scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/table_adapter.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_node_enumeration.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_pool.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_slot_broker.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_slot_broker_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_slot_broker__scheme.h ${CMAKE_SOURCE_DIR}/ydb/core/mind/configured_tablet_bootstrapper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/dynamic_nameserver.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/dynamic_nameserver_mon.cpp diff --git a/ydb/core/mind/CMakeLists.windows-x86_64.txt b/ydb/core/mind/CMakeLists.windows-x86_64.txt index d8549961e1f3..69767b590ee1 100644 --- a/ydb/core/mind/CMakeLists.windows-x86_64.txt +++ b/ydb/core/mind/CMakeLists.windows-x86_64.txt @@ -41,6 +41,22 @@ target_link_libraries(ydb-core-mind PUBLIC core-tx-schemeshard ) target_sources(ydb-core-mind PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mind/configured_tablet_bootstrapper.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/dynamic_nameserver.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/dynamic_nameserver_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/labels_maintainer.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/lease_holder.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/local.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/node_broker.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/node_broker_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/node_broker__scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/table_adapter.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_node_enumeration.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_pool.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_slot_broker.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_slot_broker_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/tenant_slot_broker__scheme.h ${CMAKE_SOURCE_DIR}/ydb/core/mind/configured_tablet_bootstrapper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/dynamic_nameserver.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/dynamic_nameserver_mon.cpp diff --git a/ydb/core/mind/address_classification/ut/CMakeLists.darwin-arm64.txt b/ydb/core/mind/address_classification/ut/CMakeLists.darwin-arm64.txt index 38e28684aa90..38cf713229c6 100644 --- a/ydb/core/mind/address_classification/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/mind/address_classification/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-mind-address_classification-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-mind-address_classification-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/address_classification/net_classifier_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/address_classification/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/mind/address_classification/ut/CMakeLists.darwin-x86_64.txt index 1a117c20ed76..2a40a7e3cc9a 100644 --- a/ydb/core/mind/address_classification/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/mind/address_classification/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-mind-address_classification-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-mind-address_classification-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/address_classification/net_classifier_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/address_classification/ut/CMakeLists.linux-aarch64.txt b/ydb/core/mind/address_classification/ut/CMakeLists.linux-aarch64.txt index eeb1ce39f836..be78bdab774b 100644 --- a/ydb/core/mind/address_classification/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/mind/address_classification/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-mind-address_classification-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-mind-address_classification-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/address_classification/net_classifier_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/address_classification/ut/CMakeLists.linux-x86_64.txt b/ydb/core/mind/address_classification/ut/CMakeLists.linux-x86_64.txt index aa925270168c..743e33ba1eee 100644 --- a/ydb/core/mind/address_classification/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/mind/address_classification/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-mind-address_classification-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-mind-address_classification-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/address_classification/net_classifier_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/address_classification/ut/CMakeLists.windows-x86_64.txt b/ydb/core/mind/address_classification/ut/CMakeLists.windows-x86_64.txt index a2d9b3b24ee3..24d82a5374ca 100644 --- a/ydb/core/mind/address_classification/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/mind/address_classification/ut/CMakeLists.windows-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/bscontroller/CMakeLists.darwin-arm64.txt b/ydb/core/mind/bscontroller/CMakeLists.darwin-arm64.txt index d1becb96e37d..cbe98c670d6a 100644 --- a/ydb/core/mind/bscontroller/CMakeLists.darwin-arm64.txt +++ b/ydb/core/mind/bscontroller/CMakeLists.darwin-arm64.txt @@ -29,6 +29,29 @@ target_link_libraries(core-mind-bscontroller PUBLIC core-tx-tx_proxy ) target_sources(core-mind-bscontroller PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/bsc.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/config.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/diff.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/error.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/grouper.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/group_layout_checker.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/group_mapper.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/indir.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/layout_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/mood.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/mv_object_map.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/resources.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/select_groups.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/self_heal.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/stat_processor.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/storage_pool_stat.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/sys_view.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/table_merger.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/types.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/vdisk_status_tracker.h ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/bsc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/cmds_box.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/cmds_drive_status.cpp diff --git a/ydb/core/mind/bscontroller/CMakeLists.darwin-x86_64.txt b/ydb/core/mind/bscontroller/CMakeLists.darwin-x86_64.txt index d1becb96e37d..cbe98c670d6a 100644 --- a/ydb/core/mind/bscontroller/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/mind/bscontroller/CMakeLists.darwin-x86_64.txt @@ -29,6 +29,29 @@ target_link_libraries(core-mind-bscontroller PUBLIC core-tx-tx_proxy ) target_sources(core-mind-bscontroller PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/bsc.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/config.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/diff.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/error.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/grouper.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/group_layout_checker.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/group_mapper.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/indir.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/layout_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/mood.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/mv_object_map.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/resources.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/select_groups.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/self_heal.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/stat_processor.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/storage_pool_stat.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/sys_view.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/table_merger.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/types.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/vdisk_status_tracker.h ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/bsc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/cmds_box.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/cmds_drive_status.cpp diff --git a/ydb/core/mind/bscontroller/CMakeLists.linux-aarch64.txt b/ydb/core/mind/bscontroller/CMakeLists.linux-aarch64.txt index e3db61c58a04..c24acec2e2f6 100644 --- a/ydb/core/mind/bscontroller/CMakeLists.linux-aarch64.txt +++ b/ydb/core/mind/bscontroller/CMakeLists.linux-aarch64.txt @@ -30,6 +30,29 @@ target_link_libraries(core-mind-bscontroller PUBLIC core-tx-tx_proxy ) target_sources(core-mind-bscontroller PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/bsc.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/config.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/diff.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/error.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/grouper.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/group_layout_checker.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/group_mapper.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/indir.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/layout_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/mood.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/mv_object_map.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/resources.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/select_groups.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/self_heal.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/stat_processor.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/storage_pool_stat.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/sys_view.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/table_merger.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/types.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/vdisk_status_tracker.h ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/bsc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/cmds_box.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/cmds_drive_status.cpp diff --git a/ydb/core/mind/bscontroller/CMakeLists.linux-x86_64.txt b/ydb/core/mind/bscontroller/CMakeLists.linux-x86_64.txt index e3db61c58a04..c24acec2e2f6 100644 --- a/ydb/core/mind/bscontroller/CMakeLists.linux-x86_64.txt +++ b/ydb/core/mind/bscontroller/CMakeLists.linux-x86_64.txt @@ -30,6 +30,29 @@ target_link_libraries(core-mind-bscontroller PUBLIC core-tx-tx_proxy ) target_sources(core-mind-bscontroller PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/bsc.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/config.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/diff.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/error.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/grouper.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/group_layout_checker.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/group_mapper.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/indir.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/layout_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/mood.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/mv_object_map.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/resources.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/select_groups.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/self_heal.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/stat_processor.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/storage_pool_stat.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/sys_view.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/table_merger.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/types.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/vdisk_status_tracker.h ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/bsc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/cmds_box.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/cmds_drive_status.cpp diff --git a/ydb/core/mind/bscontroller/CMakeLists.windows-x86_64.txt b/ydb/core/mind/bscontroller/CMakeLists.windows-x86_64.txt index d1becb96e37d..cbe98c670d6a 100644 --- a/ydb/core/mind/bscontroller/CMakeLists.windows-x86_64.txt +++ b/ydb/core/mind/bscontroller/CMakeLists.windows-x86_64.txt @@ -29,6 +29,29 @@ target_link_libraries(core-mind-bscontroller PUBLIC core-tx-tx_proxy ) target_sources(core-mind-bscontroller PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/bsc.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/config.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/diff.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/error.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/grouper.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/group_layout_checker.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/group_mapper.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/indir.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/layout_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/mood.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/mv_object_map.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/resources.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/select_groups.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/self_heal.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/stat_processor.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/storage_pool_stat.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/sys_view.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/table_merger.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/types.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/vdisk_status_tracker.h ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/bsc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/cmds_box.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/cmds_drive_status.cpp diff --git a/ydb/core/mind/bscontroller/ut/CMakeLists.darwin-arm64.txt b/ydb/core/mind/bscontroller/ut/CMakeLists.darwin-arm64.txt index 572a45cf856f..bdef62be45f0 100644 --- a/ydb/core/mind/bscontroller/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/mind/bscontroller/ut/CMakeLists.darwin-arm64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-core-mind-bscontroller-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-mind-bscontroller-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/grouper_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/bscontroller/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/mind/bscontroller/ut/CMakeLists.darwin-x86_64.txt index 15676e0763dd..5908b2157dee 100644 --- a/ydb/core/mind/bscontroller/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/mind/bscontroller/ut/CMakeLists.darwin-x86_64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-core-mind-bscontroller-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-mind-bscontroller-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/grouper_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/bscontroller/ut/CMakeLists.linux-aarch64.txt b/ydb/core/mind/bscontroller/ut/CMakeLists.linux-aarch64.txt index dfd36fcd43f7..b3af03617337 100644 --- a/ydb/core/mind/bscontroller/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/mind/bscontroller/ut/CMakeLists.linux-aarch64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-core-mind-bscontroller-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-mind-bscontroller-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/grouper_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/bscontroller/ut/CMakeLists.linux-x86_64.txt b/ydb/core/mind/bscontroller/ut/CMakeLists.linux-x86_64.txt index 4831f360f7b2..d4ea35533f8d 100644 --- a/ydb/core/mind/bscontroller/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/mind/bscontroller/ut/CMakeLists.linux-x86_64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-core-mind-bscontroller-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-mind-bscontroller-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/grouper_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/bscontroller/ut/CMakeLists.windows-x86_64.txt b/ydb/core/mind/bscontroller/ut/CMakeLists.windows-x86_64.txt index 198c5df517cc..6c63e67a8e32 100644 --- a/ydb/core/mind/bscontroller/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/mind/bscontroller/ut/CMakeLists.windows-x86_64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/bscontroller/ut_bscontroller/CMakeLists.darwin-arm64.txt b/ydb/core/mind/bscontroller/ut_bscontroller/CMakeLists.darwin-arm64.txt index ec2b8803a86f..5ed499c07cb6 100644 --- a/ydb/core/mind/bscontroller/ut_bscontroller/CMakeLists.darwin-arm64.txt +++ b/ydb/core/mind/bscontroller/ut_bscontroller/CMakeLists.darwin-arm64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-mind-bscontroller-ut_bscontroller PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-mind-bscontroller-ut_bscontroller PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_bscontroller/main.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/bscontroller/ut_bscontroller/CMakeLists.darwin-x86_64.txt b/ydb/core/mind/bscontroller/ut_bscontroller/CMakeLists.darwin-x86_64.txt index 79d6928d1cb5..e7af80e75afb 100644 --- a/ydb/core/mind/bscontroller/ut_bscontroller/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/mind/bscontroller/ut_bscontroller/CMakeLists.darwin-x86_64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-core-mind-bscontroller-ut_bscontroller PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-mind-bscontroller-ut_bscontroller PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_bscontroller/main.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/bscontroller/ut_bscontroller/CMakeLists.linux-aarch64.txt b/ydb/core/mind/bscontroller/ut_bscontroller/CMakeLists.linux-aarch64.txt index d43673ebbe38..1138bd48f075 100644 --- a/ydb/core/mind/bscontroller/ut_bscontroller/CMakeLists.linux-aarch64.txt +++ b/ydb/core/mind/bscontroller/ut_bscontroller/CMakeLists.linux-aarch64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-mind-bscontroller-ut_bscontroller PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-mind-bscontroller-ut_bscontroller PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_bscontroller/main.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/bscontroller/ut_bscontroller/CMakeLists.linux-x86_64.txt b/ydb/core/mind/bscontroller/ut_bscontroller/CMakeLists.linux-x86_64.txt index 08ac9f2d4fd1..8bee19234d44 100644 --- a/ydb/core/mind/bscontroller/ut_bscontroller/CMakeLists.linux-x86_64.txt +++ b/ydb/core/mind/bscontroller/ut_bscontroller/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-core-mind-bscontroller-ut_bscontroller PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-mind-bscontroller-ut_bscontroller PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_bscontroller/main.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/bscontroller/ut_bscontroller/CMakeLists.windows-x86_64.txt b/ydb/core/mind/bscontroller/ut_bscontroller/CMakeLists.windows-x86_64.txt index 219184edbdd1..24464e4f3f45 100644 --- a/ydb/core/mind/bscontroller/ut_bscontroller/CMakeLists.windows-x86_64.txt +++ b/ydb/core/mind/bscontroller/ut_bscontroller/CMakeLists.windows-x86_64.txt @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.darwin-arm64.txt b/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.darwin-arm64.txt index b300851b7d8a..a58014c2f253 100644 --- a/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.darwin-arm64.txt +++ b/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.darwin-arm64.txt @@ -19,6 +19,7 @@ target_link_libraries(ydb-core-mind-bscontroller-ut_selfheal PUBLIC blobstorage-pdisk-mock core-mind-bscontroller core-tx-scheme_board + minikql-comp_nodes-llvm14 udf-service-stub yql-sql-pg_dummy ) @@ -26,10 +27,14 @@ target_link_options(ydb-core-mind-bscontroller-ut_selfheal PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-mind-bscontroller-ut_selfheal PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/env.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/node_warden_mock.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/timer_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/vdisk_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/main.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/self_heal_actor_ut.cpp ) @@ -58,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.darwin-x86_64.txt b/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.darwin-x86_64.txt index c876fd15d3fd..556785ce5eec 100644 --- a/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.darwin-x86_64.txt @@ -20,6 +20,7 @@ target_link_libraries(ydb-core-mind-bscontroller-ut_selfheal PUBLIC blobstorage-pdisk-mock core-mind-bscontroller core-tx-scheme_board + minikql-comp_nodes-llvm14 udf-service-stub yql-sql-pg_dummy ) @@ -27,10 +28,14 @@ target_link_options(ydb-core-mind-bscontroller-ut_selfheal PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-mind-bscontroller-ut_selfheal PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/env.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/node_warden_mock.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/timer_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/vdisk_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/main.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/self_heal_actor_ut.cpp ) @@ -59,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.linux-aarch64.txt b/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.linux-aarch64.txt index f70a4460c33a..e70a88c2eace 100644 --- a/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.linux-aarch64.txt +++ b/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.linux-aarch64.txt @@ -20,6 +20,7 @@ target_link_libraries(ydb-core-mind-bscontroller-ut_selfheal PUBLIC blobstorage-pdisk-mock core-mind-bscontroller core-tx-scheme_board + minikql-comp_nodes-llvm14 udf-service-stub yql-sql-pg_dummy ) @@ -29,11 +30,14 @@ target_link_options(ydb-core-mind-bscontroller-ut_selfheal PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-mind-bscontroller-ut_selfheal PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/env.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/node_warden_mock.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/timer_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/vdisk_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/main.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/self_heal_actor_ut.cpp ) @@ -62,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.linux-x86_64.txt b/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.linux-x86_64.txt index f42e2b8e6ef2..85bda2ed3f1a 100644 --- a/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.linux-x86_64.txt +++ b/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.linux-x86_64.txt @@ -21,6 +21,7 @@ target_link_libraries(ydb-core-mind-bscontroller-ut_selfheal PUBLIC blobstorage-pdisk-mock core-mind-bscontroller core-tx-scheme_board + minikql-comp_nodes-llvm14 udf-service-stub yql-sql-pg_dummy ) @@ -30,11 +31,14 @@ target_link_options(ydb-core-mind-bscontroller-ut_selfheal PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-mind-bscontroller-ut_selfheal PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/env.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/node_warden_mock.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/timer_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/vdisk_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/main.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/self_heal_actor_ut.cpp ) @@ -63,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.windows-x86_64.txt b/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.windows-x86_64.txt index 8cc3a5a9749f..8b59fa168205 100644 --- a/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.windows-x86_64.txt +++ b/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.windows-x86_64.txt @@ -20,10 +20,17 @@ target_link_libraries(ydb-core-mind-bscontroller-ut_selfheal PUBLIC blobstorage-pdisk-mock core-mind-bscontroller core-tx-scheme_board + minikql-comp_nodes-llvm14 udf-service-stub yql-sql-pg_dummy ) target_sources(ydb-core-mind-bscontroller-ut_selfheal PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/env.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/node_warden_mock.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/timer_actor.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/vdisk_mock.h ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/main.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/bscontroller/ut_selfheal/self_heal_actor_ut.cpp ) @@ -52,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/hive/CMakeLists.darwin-arm64.txt b/ydb/core/mind/hive/CMakeLists.darwin-arm64.txt index c27474ff6d08..c7e0dc8d4a6c 100644 --- a/ydb/core/mind/hive/CMakeLists.darwin-arm64.txt +++ b/ydb/core/mind/hive/CMakeLists.darwin-arm64.txt @@ -29,8 +29,29 @@ target_link_libraries(core-mind-hive PUBLIC ydb-core-tablet_flat ) target_sources(core-mind-hive PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/balancer.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/boot_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/domain_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_domains.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_transactions.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/leader_tablet_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/metrics.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/node_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/object_distribution.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/sequencer.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/follower_group.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/follower_tablet_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_group_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_pool_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/tablet_info.h ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/balancer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/boot_queue.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/domain_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/drain.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/fill.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive.cpp @@ -43,6 +64,7 @@ target_sources(core-mind-hive PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/node_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/sequencer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/follower_tablet_info.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_balancer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_group_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_pool_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/tablet_info.cpp diff --git a/ydb/core/mind/hive/CMakeLists.darwin-x86_64.txt b/ydb/core/mind/hive/CMakeLists.darwin-x86_64.txt index c27474ff6d08..c7e0dc8d4a6c 100644 --- a/ydb/core/mind/hive/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/mind/hive/CMakeLists.darwin-x86_64.txt @@ -29,8 +29,29 @@ target_link_libraries(core-mind-hive PUBLIC ydb-core-tablet_flat ) target_sources(core-mind-hive PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/balancer.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/boot_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/domain_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_domains.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_transactions.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/leader_tablet_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/metrics.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/node_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/object_distribution.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/sequencer.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/follower_group.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/follower_tablet_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_group_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_pool_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/tablet_info.h ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/balancer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/boot_queue.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/domain_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/drain.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/fill.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive.cpp @@ -43,6 +64,7 @@ target_sources(core-mind-hive PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/node_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/sequencer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/follower_tablet_info.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_balancer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_group_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_pool_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/tablet_info.cpp diff --git a/ydb/core/mind/hive/CMakeLists.linux-aarch64.txt b/ydb/core/mind/hive/CMakeLists.linux-aarch64.txt index 5e71b60eb101..46862e7d9dff 100644 --- a/ydb/core/mind/hive/CMakeLists.linux-aarch64.txt +++ b/ydb/core/mind/hive/CMakeLists.linux-aarch64.txt @@ -30,8 +30,29 @@ target_link_libraries(core-mind-hive PUBLIC ydb-core-tablet_flat ) target_sources(core-mind-hive PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/balancer.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/boot_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/domain_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_domains.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_transactions.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/leader_tablet_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/metrics.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/node_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/object_distribution.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/sequencer.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/follower_group.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/follower_tablet_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_group_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_pool_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/tablet_info.h ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/balancer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/boot_queue.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/domain_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/drain.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/fill.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive.cpp @@ -44,6 +65,7 @@ target_sources(core-mind-hive PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/node_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/sequencer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/follower_tablet_info.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_balancer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_group_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_pool_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/tablet_info.cpp diff --git a/ydb/core/mind/hive/CMakeLists.linux-x86_64.txt b/ydb/core/mind/hive/CMakeLists.linux-x86_64.txt index 5e71b60eb101..46862e7d9dff 100644 --- a/ydb/core/mind/hive/CMakeLists.linux-x86_64.txt +++ b/ydb/core/mind/hive/CMakeLists.linux-x86_64.txt @@ -30,8 +30,29 @@ target_link_libraries(core-mind-hive PUBLIC ydb-core-tablet_flat ) target_sources(core-mind-hive PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/balancer.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/boot_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/domain_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_domains.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_transactions.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/leader_tablet_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/metrics.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/node_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/object_distribution.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/sequencer.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/follower_group.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/follower_tablet_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_group_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_pool_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/tablet_info.h ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/balancer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/boot_queue.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/domain_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/drain.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/fill.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive.cpp @@ -44,6 +65,7 @@ target_sources(core-mind-hive PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/node_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/sequencer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/follower_tablet_info.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_balancer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_group_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_pool_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/tablet_info.cpp diff --git a/ydb/core/mind/hive/CMakeLists.windows-x86_64.txt b/ydb/core/mind/hive/CMakeLists.windows-x86_64.txt index c27474ff6d08..c7e0dc8d4a6c 100644 --- a/ydb/core/mind/hive/CMakeLists.windows-x86_64.txt +++ b/ydb/core/mind/hive/CMakeLists.windows-x86_64.txt @@ -29,8 +29,29 @@ target_link_libraries(core-mind-hive PUBLIC ydb-core-tablet_flat ) target_sources(core-mind-hive PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/balancer.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/boot_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/domain_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_domains.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive_transactions.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/leader_tablet_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/metrics.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/node_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/object_distribution.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/sequencer.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/follower_group.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/follower_tablet_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_group_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_pool_info.h + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/tablet_info.h ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/balancer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/boot_queue.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/domain_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/drain.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/fill.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/hive.cpp @@ -43,6 +64,7 @@ target_sources(core-mind-hive PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/node_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/sequencer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/follower_tablet_info.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_balancer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_group_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/storage_pool_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/tablet_info.cpp diff --git a/ydb/core/mind/hive/ut/CMakeLists.darwin-arm64.txt b/ydb/core/mind/hive/ut/CMakeLists.darwin-arm64.txt index cd8e70ab0da7..81b03089febf 100644 --- a/ydb/core/mind/hive/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/mind/hive/ut/CMakeLists.darwin-arm64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-mind-hive-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-mind-hive-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/object_distribution_ut.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/hive/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/mind/hive/ut/CMakeLists.darwin-x86_64.txt index 6cb64b59e069..ea803123c688 100644 --- a/ydb/core/mind/hive/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/mind/hive/ut/CMakeLists.darwin-x86_64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-mind-hive-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-mind-hive-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/object_distribution_ut.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/hive/ut/CMakeLists.linux-aarch64.txt b/ydb/core/mind/hive/ut/CMakeLists.linux-aarch64.txt index 5cade2b4aea9..5072dfdf460f 100644 --- a/ydb/core/mind/hive/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/mind/hive/ut/CMakeLists.linux-aarch64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-mind-hive-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-mind-hive-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/object_distribution_ut.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/hive/ut/CMakeLists.linux-x86_64.txt b/ydb/core/mind/hive/ut/CMakeLists.linux-x86_64.txt index f632b9896250..20cc17facd23 100644 --- a/ydb/core/mind/hive/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/mind/hive/ut/CMakeLists.linux-x86_64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-mind-hive-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-mind-hive-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/hive/object_distribution_ut.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/hive/ut/CMakeLists.windows-x86_64.txt b/ydb/core/mind/hive/ut/CMakeLists.windows-x86_64.txt index 40987ea5c1d5..8f50e8affd7e 100644 --- a/ydb/core/mind/hive/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/mind/hive/ut/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/ut/CMakeLists.darwin-arm64.txt b/ydb/core/mind/ut/CMakeLists.darwin-arm64.txt index e2921f43eadd..e330dbab86ec 100644 --- a/ydb/core/mind/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/mind/ut/CMakeLists.darwin-arm64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-mind-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-mind-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/node_broker_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/mind/ut/CMakeLists.darwin-x86_64.txt index fdc58adead72..a32c24a0a699 100644 --- a/ydb/core/mind/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/mind/ut/CMakeLists.darwin-x86_64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-core-mind-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-mind-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/node_broker_ut.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/ut/CMakeLists.linux-aarch64.txt b/ydb/core/mind/ut/CMakeLists.linux-aarch64.txt index 5ce27c64f6e4..13c25f085629 100644 --- a/ydb/core/mind/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/mind/ut/CMakeLists.linux-aarch64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-mind-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-mind-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/node_broker_ut.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/ut/CMakeLists.linux-x86_64.txt b/ydb/core/mind/ut/CMakeLists.linux-x86_64.txt index 0af8cc28e42d..139b578a333b 100644 --- a/ydb/core/mind/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/mind/ut/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-core-mind-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-mind-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/node_broker_ut.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/ut/CMakeLists.windows-x86_64.txt b/ydb/core/mind/ut/CMakeLists.windows-x86_64.txt index adb46e4defd2..c8395820e1e8 100644 --- a/ydb/core/mind/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/mind/ut/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/ut_fat/CMakeLists.darwin-arm64.txt b/ydb/core/mind/ut_fat/CMakeLists.darwin-arm64.txt index e4faf39d5e41..7381965f5e3e 100644 --- a/ydb/core/mind/ut_fat/CMakeLists.darwin-arm64.txt +++ b/ydb/core/mind/ut_fat/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-mind-ut_fat PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-mind-ut_fat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/ut_fat/blobstorage_node_warden_ut_fat.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/ut_fat/CMakeLists.darwin-x86_64.txt b/ydb/core/mind/ut_fat/CMakeLists.darwin-x86_64.txt index fd3564ca728d..a8b8f1e858fc 100644 --- a/ydb/core/mind/ut_fat/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/mind/ut_fat/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-mind-ut_fat PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-mind-ut_fat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/ut_fat/blobstorage_node_warden_ut_fat.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/ut_fat/CMakeLists.linux-aarch64.txt b/ydb/core/mind/ut_fat/CMakeLists.linux-aarch64.txt index e51d42f93b5b..f2c9af251696 100644 --- a/ydb/core/mind/ut_fat/CMakeLists.linux-aarch64.txt +++ b/ydb/core/mind/ut_fat/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-mind-ut_fat PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-mind-ut_fat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/ut_fat/blobstorage_node_warden_ut_fat.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/ut_fat/CMakeLists.linux-x86_64.txt b/ydb/core/mind/ut_fat/CMakeLists.linux-x86_64.txt index e7264e0ae66e..50822e57a5e6 100644 --- a/ydb/core/mind/ut_fat/CMakeLists.linux-x86_64.txt +++ b/ydb/core/mind/ut_fat/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-mind-ut_fat PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-mind-ut_fat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/mind/ut_fat/blobstorage_node_warden_ut_fat.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mind/ut_fat/CMakeLists.windows-x86_64.txt b/ydb/core/mind/ut_fat/CMakeLists.windows-x86_64.txt index f87c06b75856..7535972b0f9a 100644 --- a/ydb/core/mind/ut_fat/CMakeLists.windows-x86_64.txt +++ b/ydb/core/mind/ut_fat/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/mon/CMakeLists.darwin-arm64.txt b/ydb/core/mon/CMakeLists.darwin-arm64.txt index f683461e9858..05d9de86873d 100644 --- a/ydb/core/mon/CMakeLists.darwin-arm64.txt +++ b/ydb/core/mon/CMakeLists.darwin-arm64.txt @@ -20,6 +20,10 @@ target_link_libraries(ydb-core-mon PUBLIC ydb-library-aclib ) target_sources(ydb-core-mon PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mon/async_http_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/mon/mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/mon/sync_http_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/mon/crossref.h ${CMAKE_SOURCE_DIR}/ydb/core/mon/async_http_mon.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mon/mon.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mon/sync_http_mon.cpp diff --git a/ydb/core/mon/CMakeLists.darwin-x86_64.txt b/ydb/core/mon/CMakeLists.darwin-x86_64.txt index f683461e9858..05d9de86873d 100644 --- a/ydb/core/mon/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/mon/CMakeLists.darwin-x86_64.txt @@ -20,6 +20,10 @@ target_link_libraries(ydb-core-mon PUBLIC ydb-library-aclib ) target_sources(ydb-core-mon PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mon/async_http_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/mon/mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/mon/sync_http_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/mon/crossref.h ${CMAKE_SOURCE_DIR}/ydb/core/mon/async_http_mon.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mon/mon.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mon/sync_http_mon.cpp diff --git a/ydb/core/mon/CMakeLists.linux-aarch64.txt b/ydb/core/mon/CMakeLists.linux-aarch64.txt index 59e5f0d27518..54f3d5850ad8 100644 --- a/ydb/core/mon/CMakeLists.linux-aarch64.txt +++ b/ydb/core/mon/CMakeLists.linux-aarch64.txt @@ -21,6 +21,10 @@ target_link_libraries(ydb-core-mon PUBLIC ydb-library-aclib ) target_sources(ydb-core-mon PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mon/async_http_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/mon/mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/mon/sync_http_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/mon/crossref.h ${CMAKE_SOURCE_DIR}/ydb/core/mon/async_http_mon.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mon/mon.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mon/sync_http_mon.cpp diff --git a/ydb/core/mon/CMakeLists.linux-x86_64.txt b/ydb/core/mon/CMakeLists.linux-x86_64.txt index 59e5f0d27518..54f3d5850ad8 100644 --- a/ydb/core/mon/CMakeLists.linux-x86_64.txt +++ b/ydb/core/mon/CMakeLists.linux-x86_64.txt @@ -21,6 +21,10 @@ target_link_libraries(ydb-core-mon PUBLIC ydb-library-aclib ) target_sources(ydb-core-mon PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mon/async_http_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/mon/mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/mon/sync_http_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/mon/crossref.h ${CMAKE_SOURCE_DIR}/ydb/core/mon/async_http_mon.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mon/mon.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mon/sync_http_mon.cpp diff --git a/ydb/core/mon/CMakeLists.windows-x86_64.txt b/ydb/core/mon/CMakeLists.windows-x86_64.txt index f683461e9858..05d9de86873d 100644 --- a/ydb/core/mon/CMakeLists.windows-x86_64.txt +++ b/ydb/core/mon/CMakeLists.windows-x86_64.txt @@ -20,6 +20,10 @@ target_link_libraries(ydb-core-mon PUBLIC ydb-library-aclib ) target_sources(ydb-core-mon PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/mon/async_http_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/mon/mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/mon/sync_http_mon.h + ${CMAKE_SOURCE_DIR}/ydb/core/mon/crossref.h ${CMAKE_SOURCE_DIR}/ydb/core/mon/async_http_mon.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mon/mon.cpp ${CMAKE_SOURCE_DIR}/ydb/core/mon/sync_http_mon.cpp diff --git a/ydb/core/mon_alloc/CMakeLists.darwin-arm64.txt b/ydb/core/mon_alloc/CMakeLists.darwin-arm64.txt index fbc45458896f..ed544936e5d1 100644 --- a/ydb/core/mon_alloc/CMakeLists.darwin-arm64.txt +++ b/ydb/core/mon_alloc/CMakeLists.darwin-arm64.txt @@ -19,8 +19,6 @@ target_link_libraries(ydb-core-mon_alloc PUBLIC cpp-lfalloc-dbg_info cpp-malloc-api monlib-service-pages - cpp-ytalloc-api - cpp-yt-memory ydb-core-base ydb-core-control ydb-library-services diff --git a/ydb/core/mon_alloc/CMakeLists.darwin-x86_64.txt b/ydb/core/mon_alloc/CMakeLists.darwin-x86_64.txt index fbc45458896f..ed544936e5d1 100644 --- a/ydb/core/mon_alloc/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/mon_alloc/CMakeLists.darwin-x86_64.txt @@ -19,8 +19,6 @@ target_link_libraries(ydb-core-mon_alloc PUBLIC cpp-lfalloc-dbg_info cpp-malloc-api monlib-service-pages - cpp-ytalloc-api - cpp-yt-memory ydb-core-base ydb-core-control ydb-library-services diff --git a/ydb/core/mon_alloc/CMakeLists.linux-aarch64.txt b/ydb/core/mon_alloc/CMakeLists.linux-aarch64.txt index 475a5001b1ee..b2bd9cf3d318 100644 --- a/ydb/core/mon_alloc/CMakeLists.linux-aarch64.txt +++ b/ydb/core/mon_alloc/CMakeLists.linux-aarch64.txt @@ -20,8 +20,6 @@ target_link_libraries(ydb-core-mon_alloc PUBLIC cpp-lfalloc-dbg_info cpp-malloc-api monlib-service-pages - cpp-ytalloc-api - cpp-yt-memory ydb-core-base ydb-core-control ydb-library-services diff --git a/ydb/core/mon_alloc/CMakeLists.linux-x86_64.txt b/ydb/core/mon_alloc/CMakeLists.linux-x86_64.txt index 475a5001b1ee..b2bd9cf3d318 100644 --- a/ydb/core/mon_alloc/CMakeLists.linux-x86_64.txt +++ b/ydb/core/mon_alloc/CMakeLists.linux-x86_64.txt @@ -20,8 +20,6 @@ target_link_libraries(ydb-core-mon_alloc PUBLIC cpp-lfalloc-dbg_info cpp-malloc-api monlib-service-pages - cpp-ytalloc-api - cpp-yt-memory ydb-core-base ydb-core-control ydb-library-services diff --git a/ydb/core/mon_alloc/CMakeLists.windows-x86_64.txt b/ydb/core/mon_alloc/CMakeLists.windows-x86_64.txt index fbc45458896f..ed544936e5d1 100644 --- a/ydb/core/mon_alloc/CMakeLists.windows-x86_64.txt +++ b/ydb/core/mon_alloc/CMakeLists.windows-x86_64.txt @@ -19,8 +19,6 @@ target_link_libraries(ydb-core-mon_alloc PUBLIC cpp-lfalloc-dbg_info cpp-malloc-api monlib-service-pages - cpp-ytalloc-api - cpp-yt-memory ydb-core-base ydb-core-control ydb-library-services diff --git a/ydb/core/node_whiteboard/CMakeLists.darwin-arm64.txt b/ydb/core/node_whiteboard/CMakeLists.darwin-arm64.txt index db5dfc82a951..b951ef0ae9a6 100644 --- a/ydb/core/node_whiteboard/CMakeLists.darwin-arm64.txt +++ b/ydb/core/node_whiteboard/CMakeLists.darwin-arm64.txt @@ -28,3 +28,6 @@ target_link_libraries(ydb-core-node_whiteboard INTERFACE ydb-core-erasure ydb-core-protos ) +target_sources(ydb-core-node_whiteboard INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/node_whiteboard/node_whiteboard.h +) diff --git a/ydb/core/node_whiteboard/CMakeLists.darwin-x86_64.txt b/ydb/core/node_whiteboard/CMakeLists.darwin-x86_64.txt index db5dfc82a951..b951ef0ae9a6 100644 --- a/ydb/core/node_whiteboard/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/node_whiteboard/CMakeLists.darwin-x86_64.txt @@ -28,3 +28,6 @@ target_link_libraries(ydb-core-node_whiteboard INTERFACE ydb-core-erasure ydb-core-protos ) +target_sources(ydb-core-node_whiteboard INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/node_whiteboard/node_whiteboard.h +) diff --git a/ydb/core/node_whiteboard/CMakeLists.linux-aarch64.txt b/ydb/core/node_whiteboard/CMakeLists.linux-aarch64.txt index bee4d79041c0..58a2756be4ad 100644 --- a/ydb/core/node_whiteboard/CMakeLists.linux-aarch64.txt +++ b/ydb/core/node_whiteboard/CMakeLists.linux-aarch64.txt @@ -29,3 +29,6 @@ target_link_libraries(ydb-core-node_whiteboard INTERFACE ydb-core-erasure ydb-core-protos ) +target_sources(ydb-core-node_whiteboard INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/node_whiteboard/node_whiteboard.h +) diff --git a/ydb/core/node_whiteboard/CMakeLists.linux-x86_64.txt b/ydb/core/node_whiteboard/CMakeLists.linux-x86_64.txt index bee4d79041c0..58a2756be4ad 100644 --- a/ydb/core/node_whiteboard/CMakeLists.linux-x86_64.txt +++ b/ydb/core/node_whiteboard/CMakeLists.linux-x86_64.txt @@ -29,3 +29,6 @@ target_link_libraries(ydb-core-node_whiteboard INTERFACE ydb-core-erasure ydb-core-protos ) +target_sources(ydb-core-node_whiteboard INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/node_whiteboard/node_whiteboard.h +) diff --git a/ydb/core/node_whiteboard/CMakeLists.windows-x86_64.txt b/ydb/core/node_whiteboard/CMakeLists.windows-x86_64.txt index db5dfc82a951..b951ef0ae9a6 100644 --- a/ydb/core/node_whiteboard/CMakeLists.windows-x86_64.txt +++ b/ydb/core/node_whiteboard/CMakeLists.windows-x86_64.txt @@ -28,3 +28,6 @@ target_link_libraries(ydb-core-node_whiteboard INTERFACE ydb-core-erasure ydb-core-protos ) +target_sources(ydb-core-node_whiteboard INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/node_whiteboard/node_whiteboard.h +) diff --git a/ydb/core/persqueue/CMakeLists.darwin-arm64.txt b/ydb/core/persqueue/CMakeLists.darwin-arm64.txt index 6c3e709acf7d..af6cac9b983f 100644 --- a/ydb/core/persqueue/CMakeLists.darwin-arm64.txt +++ b/ydb/core/persqueue/CMakeLists.darwin-arm64.txt @@ -46,6 +46,8 @@ target_link_libraries(ydb-core-persqueue PUBLIC cpp-client-ydb_persqueue_core ) target_sources(ydb-core-persqueue PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/actor_persqueue_client_iface.h + ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/mirrorer.h ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/blob.cpp ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/cluster_tracker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/event_helpers.cpp diff --git a/ydb/core/persqueue/CMakeLists.darwin-x86_64.txt b/ydb/core/persqueue/CMakeLists.darwin-x86_64.txt index 6c3e709acf7d..af6cac9b983f 100644 --- a/ydb/core/persqueue/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/persqueue/CMakeLists.darwin-x86_64.txt @@ -46,6 +46,8 @@ target_link_libraries(ydb-core-persqueue PUBLIC cpp-client-ydb_persqueue_core ) target_sources(ydb-core-persqueue PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/actor_persqueue_client_iface.h + ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/mirrorer.h ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/blob.cpp ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/cluster_tracker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/event_helpers.cpp diff --git a/ydb/core/persqueue/CMakeLists.linux-aarch64.txt b/ydb/core/persqueue/CMakeLists.linux-aarch64.txt index 38253dbbae61..61193413c3e9 100644 --- a/ydb/core/persqueue/CMakeLists.linux-aarch64.txt +++ b/ydb/core/persqueue/CMakeLists.linux-aarch64.txt @@ -47,6 +47,8 @@ target_link_libraries(ydb-core-persqueue PUBLIC cpp-client-ydb_persqueue_core ) target_sources(ydb-core-persqueue PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/actor_persqueue_client_iface.h + ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/mirrorer.h ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/blob.cpp ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/cluster_tracker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/event_helpers.cpp diff --git a/ydb/core/persqueue/CMakeLists.linux-x86_64.txt b/ydb/core/persqueue/CMakeLists.linux-x86_64.txt index 38253dbbae61..61193413c3e9 100644 --- a/ydb/core/persqueue/CMakeLists.linux-x86_64.txt +++ b/ydb/core/persqueue/CMakeLists.linux-x86_64.txt @@ -47,6 +47,8 @@ target_link_libraries(ydb-core-persqueue PUBLIC cpp-client-ydb_persqueue_core ) target_sources(ydb-core-persqueue PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/actor_persqueue_client_iface.h + ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/mirrorer.h ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/blob.cpp ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/cluster_tracker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/event_helpers.cpp diff --git a/ydb/core/persqueue/CMakeLists.windows-x86_64.txt b/ydb/core/persqueue/CMakeLists.windows-x86_64.txt index 6c3e709acf7d..af6cac9b983f 100644 --- a/ydb/core/persqueue/CMakeLists.windows-x86_64.txt +++ b/ydb/core/persqueue/CMakeLists.windows-x86_64.txt @@ -46,6 +46,8 @@ target_link_libraries(ydb-core-persqueue PUBLIC cpp-client-ydb_persqueue_core ) target_sources(ydb-core-persqueue PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/actor_persqueue_client_iface.h + ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/mirrorer.h ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/blob.cpp ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/cluster_tracker.cpp ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/event_helpers.cpp diff --git a/ydb/core/persqueue/config/CMakeLists.darwin-arm64.txt b/ydb/core/persqueue/config/CMakeLists.darwin-arm64.txt index 197328427c4d..5fea746c39f7 100644 --- a/ydb/core/persqueue/config/CMakeLists.darwin-arm64.txt +++ b/ydb/core/persqueue/config/CMakeLists.darwin-arm64.txt @@ -14,5 +14,6 @@ target_link_libraries(core-persqueue-config PUBLIC ydb-core-protos ) target_sources(core-persqueue-config PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/config/config.h ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/config/config.cpp ) diff --git a/ydb/core/persqueue/config/CMakeLists.darwin-x86_64.txt b/ydb/core/persqueue/config/CMakeLists.darwin-x86_64.txt index 197328427c4d..5fea746c39f7 100644 --- a/ydb/core/persqueue/config/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/persqueue/config/CMakeLists.darwin-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(core-persqueue-config PUBLIC ydb-core-protos ) target_sources(core-persqueue-config PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/config/config.h ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/config/config.cpp ) diff --git a/ydb/core/persqueue/config/CMakeLists.linux-aarch64.txt b/ydb/core/persqueue/config/CMakeLists.linux-aarch64.txt index af94c1e823af..c710ab126d6d 100644 --- a/ydb/core/persqueue/config/CMakeLists.linux-aarch64.txt +++ b/ydb/core/persqueue/config/CMakeLists.linux-aarch64.txt @@ -15,5 +15,6 @@ target_link_libraries(core-persqueue-config PUBLIC ydb-core-protos ) target_sources(core-persqueue-config PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/config/config.h ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/config/config.cpp ) diff --git a/ydb/core/persqueue/config/CMakeLists.linux-x86_64.txt b/ydb/core/persqueue/config/CMakeLists.linux-x86_64.txt index af94c1e823af..c710ab126d6d 100644 --- a/ydb/core/persqueue/config/CMakeLists.linux-x86_64.txt +++ b/ydb/core/persqueue/config/CMakeLists.linux-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(core-persqueue-config PUBLIC ydb-core-protos ) target_sources(core-persqueue-config PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/config/config.h ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/config/config.cpp ) diff --git a/ydb/core/persqueue/config/CMakeLists.windows-x86_64.txt b/ydb/core/persqueue/config/CMakeLists.windows-x86_64.txt index 197328427c4d..5fea746c39f7 100644 --- a/ydb/core/persqueue/config/CMakeLists.windows-x86_64.txt +++ b/ydb/core/persqueue/config/CMakeLists.windows-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(core-persqueue-config PUBLIC ydb-core-protos ) target_sources(core-persqueue-config PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/config/config.h ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/config/config.cpp ) diff --git a/ydb/core/persqueue/dread_cache_service/ut/CMakeLists.darwin-arm64.txt b/ydb/core/persqueue/dread_cache_service/ut/CMakeLists.darwin-arm64.txt index a8a2d23b429f..0883754599df 100644 --- a/ydb/core/persqueue/dread_cache_service/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/persqueue/dread_cache_service/ut/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-persqueue-dread_cache_service-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-persqueue-dread_cache_service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/dread_cache_service/ut/caching_proxy_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/persqueue/dread_cache_service/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/persqueue/dread_cache_service/ut/CMakeLists.darwin-x86_64.txt index 4809c9a47116..4c173626144e 100644 --- a/ydb/core/persqueue/dread_cache_service/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/persqueue/dread_cache_service/ut/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-persqueue-dread_cache_service-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-persqueue-dread_cache_service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/dread_cache_service/ut/caching_proxy_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/persqueue/dread_cache_service/ut/CMakeLists.linux-aarch64.txt b/ydb/core/persqueue/dread_cache_service/ut/CMakeLists.linux-aarch64.txt index 6fba9d2680d8..401edfa59486 100644 --- a/ydb/core/persqueue/dread_cache_service/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/persqueue/dread_cache_service/ut/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-persqueue-dread_cache_service-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-persqueue-dread_cache_service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/dread_cache_service/ut/caching_proxy_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/persqueue/dread_cache_service/ut/CMakeLists.linux-x86_64.txt b/ydb/core/persqueue/dread_cache_service/ut/CMakeLists.linux-x86_64.txt index a8c5e30700cd..53439ee73606 100644 --- a/ydb/core/persqueue/dread_cache_service/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/persqueue/dread_cache_service/ut/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-persqueue-dread_cache_service-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-persqueue-dread_cache_service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/dread_cache_service/ut/caching_proxy_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/persqueue/dread_cache_service/ut/CMakeLists.windows-x86_64.txt b/ydb/core/persqueue/dread_cache_service/ut/CMakeLists.windows-x86_64.txt index 1c348b2635ed..93b2f9822ba7 100644 --- a/ydb/core/persqueue/dread_cache_service/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/persqueue/dread_cache_service/ut/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/persqueue/ut/CMakeLists.darwin-arm64.txt b/ydb/core/persqueue/ut/CMakeLists.darwin-arm64.txt index fd827df0f8b7..9f3c96a06397 100644 --- a/ydb/core/persqueue/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/persqueue/ut/CMakeLists.darwin-arm64.txt @@ -41,8 +41,6 @@ target_link_options(ydb-core-persqueue-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-persqueue-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/ut/counters_ut.cpp @@ -91,6 +89,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/persqueue/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/persqueue/ut/CMakeLists.darwin-x86_64.txt index baa1f03c9403..b439439a33f9 100644 --- a/ydb/core/persqueue/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/persqueue/ut/CMakeLists.darwin-x86_64.txt @@ -42,8 +42,6 @@ target_link_options(ydb-core-persqueue-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-persqueue-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/ut/counters_ut.cpp @@ -92,6 +90,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/persqueue/ut/CMakeLists.linux-aarch64.txt b/ydb/core/persqueue/ut/CMakeLists.linux-aarch64.txt index 20ae12d2efd5..ea17e023dc49 100644 --- a/ydb/core/persqueue/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/persqueue/ut/CMakeLists.linux-aarch64.txt @@ -44,9 +44,6 @@ target_link_options(ydb-core-persqueue-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-persqueue-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/ut/counters_ut.cpp @@ -95,6 +92,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/persqueue/ut/CMakeLists.linux-x86_64.txt b/ydb/core/persqueue/ut/CMakeLists.linux-x86_64.txt index 8f96adf6bc7a..ac7adfb80672 100644 --- a/ydb/core/persqueue/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/persqueue/ut/CMakeLists.linux-x86_64.txt @@ -45,9 +45,6 @@ target_link_options(ydb-core-persqueue-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-persqueue-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/ut/counters_ut.cpp @@ -96,6 +93,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/persqueue/ut/CMakeLists.windows-x86_64.txt b/ydb/core/persqueue/ut/CMakeLists.windows-x86_64.txt index 138371397cb9..8879929fbbfc 100644 --- a/ydb/core/persqueue/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/persqueue/ut/CMakeLists.windows-x86_64.txt @@ -85,6 +85,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/persqueue/ut/common/CMakeLists.darwin-arm64.txt b/ydb/core/persqueue/ut/common/CMakeLists.darwin-arm64.txt index f398910fc5c2..32387e9d8ac2 100644 --- a/ydb/core/persqueue/ut/common/CMakeLists.darwin-arm64.txt +++ b/ydb/core/persqueue/ut/common/CMakeLists.darwin-arm64.txt @@ -18,5 +18,6 @@ target_link_libraries(persqueue-ut-common PUBLIC ydb-core-persqueue ) target_sources(persqueue-ut-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/ut/common/pq_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/ut/common/pq_ut_common.cpp ) diff --git a/ydb/core/persqueue/ut/common/CMakeLists.darwin-x86_64.txt b/ydb/core/persqueue/ut/common/CMakeLists.darwin-x86_64.txt index f398910fc5c2..32387e9d8ac2 100644 --- a/ydb/core/persqueue/ut/common/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/persqueue/ut/common/CMakeLists.darwin-x86_64.txt @@ -18,5 +18,6 @@ target_link_libraries(persqueue-ut-common PUBLIC ydb-core-persqueue ) target_sources(persqueue-ut-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/ut/common/pq_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/ut/common/pq_ut_common.cpp ) diff --git a/ydb/core/persqueue/ut/common/CMakeLists.linux-aarch64.txt b/ydb/core/persqueue/ut/common/CMakeLists.linux-aarch64.txt index a533a7288d39..353c744a0217 100644 --- a/ydb/core/persqueue/ut/common/CMakeLists.linux-aarch64.txt +++ b/ydb/core/persqueue/ut/common/CMakeLists.linux-aarch64.txt @@ -19,5 +19,6 @@ target_link_libraries(persqueue-ut-common PUBLIC ydb-core-persqueue ) target_sources(persqueue-ut-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/ut/common/pq_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/ut/common/pq_ut_common.cpp ) diff --git a/ydb/core/persqueue/ut/common/CMakeLists.linux-x86_64.txt b/ydb/core/persqueue/ut/common/CMakeLists.linux-x86_64.txt index a533a7288d39..353c744a0217 100644 --- a/ydb/core/persqueue/ut/common/CMakeLists.linux-x86_64.txt +++ b/ydb/core/persqueue/ut/common/CMakeLists.linux-x86_64.txt @@ -19,5 +19,6 @@ target_link_libraries(persqueue-ut-common PUBLIC ydb-core-persqueue ) target_sources(persqueue-ut-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/ut/common/pq_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/ut/common/pq_ut_common.cpp ) diff --git a/ydb/core/persqueue/ut/common/CMakeLists.windows-x86_64.txt b/ydb/core/persqueue/ut/common/CMakeLists.windows-x86_64.txt index f398910fc5c2..32387e9d8ac2 100644 --- a/ydb/core/persqueue/ut/common/CMakeLists.windows-x86_64.txt +++ b/ydb/core/persqueue/ut/common/CMakeLists.windows-x86_64.txt @@ -18,5 +18,6 @@ target_link_libraries(persqueue-ut-common PUBLIC ydb-core-persqueue ) target_sources(persqueue-ut-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/ut/common/pq_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/ut/common/pq_ut_common.cpp ) diff --git a/ydb/core/persqueue/ut/slow/CMakeLists.darwin-arm64.txt b/ydb/core/persqueue/ut/slow/CMakeLists.darwin-arm64.txt index af5db37f3f9b..f6a5b3b93a25 100644 --- a/ydb/core/persqueue/ut/slow/CMakeLists.darwin-arm64.txt +++ b/ydb/core/persqueue/ut/slow/CMakeLists.darwin-arm64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-core-persqueue-ut-slow PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-persqueue-ut-slow PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/ut/slow/pq_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/persqueue/ut/slow/CMakeLists.darwin-x86_64.txt b/ydb/core/persqueue/ut/slow/CMakeLists.darwin-x86_64.txt index f4c8fe469017..6244fb3a2ae8 100644 --- a/ydb/core/persqueue/ut/slow/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/persqueue/ut/slow/CMakeLists.darwin-x86_64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-persqueue-ut-slow PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-persqueue-ut-slow PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/ut/slow/pq_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/persqueue/ut/slow/CMakeLists.linux-aarch64.txt b/ydb/core/persqueue/ut/slow/CMakeLists.linux-aarch64.txt index 61af201f3f0f..2c86a5fead77 100644 --- a/ydb/core/persqueue/ut/slow/CMakeLists.linux-aarch64.txt +++ b/ydb/core/persqueue/ut/slow/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-core-persqueue-ut-slow PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-persqueue-ut-slow PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/ut/slow/pq_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/persqueue/ut/slow/CMakeLists.linux-x86_64.txt b/ydb/core/persqueue/ut/slow/CMakeLists.linux-x86_64.txt index 00505047721b..ad3a9eafd60f 100644 --- a/ydb/core/persqueue/ut/slow/CMakeLists.linux-x86_64.txt +++ b/ydb/core/persqueue/ut/slow/CMakeLists.linux-x86_64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-persqueue-ut-slow PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-persqueue-ut-slow PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/persqueue/ut/slow/pq_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/persqueue/ut/slow/CMakeLists.windows-x86_64.txt b/ydb/core/persqueue/ut/slow/CMakeLists.windows-x86_64.txt index 761d09dcaeb1..fbc3aceb6dd7 100644 --- a/ydb/core/persqueue/ut/slow/CMakeLists.windows-x86_64.txt +++ b/ydb/core/persqueue/ut/slow/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/pgproxy/CMakeLists.darwin-arm64.txt b/ydb/core/pgproxy/CMakeLists.darwin-arm64.txt index d80e827506bc..543188333056 100644 --- a/ydb/core/pgproxy/CMakeLists.darwin-arm64.txt +++ b/ydb/core/pgproxy/CMakeLists.darwin-arm64.txt @@ -22,6 +22,14 @@ target_link_libraries(ydb-core-pgproxy PUBLIC ydb-core-raw_socket ) target_sources(ydb-core-pgproxy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_connection.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_listener.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_stream.h ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_connection.cpp ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy_types.cpp ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy.cpp diff --git a/ydb/core/pgproxy/CMakeLists.darwin-x86_64.txt b/ydb/core/pgproxy/CMakeLists.darwin-x86_64.txt index d80e827506bc..543188333056 100644 --- a/ydb/core/pgproxy/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/pgproxy/CMakeLists.darwin-x86_64.txt @@ -22,6 +22,14 @@ target_link_libraries(ydb-core-pgproxy PUBLIC ydb-core-raw_socket ) target_sources(ydb-core-pgproxy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_connection.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_listener.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_stream.h ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_connection.cpp ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy_types.cpp ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy.cpp diff --git a/ydb/core/pgproxy/CMakeLists.linux-aarch64.txt b/ydb/core/pgproxy/CMakeLists.linux-aarch64.txt index 8d6571d09848..5bf6c9470520 100644 --- a/ydb/core/pgproxy/CMakeLists.linux-aarch64.txt +++ b/ydb/core/pgproxy/CMakeLists.linux-aarch64.txt @@ -23,6 +23,14 @@ target_link_libraries(ydb-core-pgproxy PUBLIC ydb-core-raw_socket ) target_sources(ydb-core-pgproxy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_connection.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_listener.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_stream.h ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_connection.cpp ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy_types.cpp ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy.cpp diff --git a/ydb/core/pgproxy/CMakeLists.linux-x86_64.txt b/ydb/core/pgproxy/CMakeLists.linux-x86_64.txt index 8d6571d09848..5bf6c9470520 100644 --- a/ydb/core/pgproxy/CMakeLists.linux-x86_64.txt +++ b/ydb/core/pgproxy/CMakeLists.linux-x86_64.txt @@ -23,6 +23,14 @@ target_link_libraries(ydb-core-pgproxy PUBLIC ydb-core-raw_socket ) target_sources(ydb-core-pgproxy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_connection.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_listener.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_stream.h ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_connection.cpp ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy_types.cpp ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy.cpp diff --git a/ydb/core/pgproxy/CMakeLists.windows-x86_64.txt b/ydb/core/pgproxy/CMakeLists.windows-x86_64.txt index d80e827506bc..543188333056 100644 --- a/ydb/core/pgproxy/CMakeLists.windows-x86_64.txt +++ b/ydb/core/pgproxy/CMakeLists.windows-x86_64.txt @@ -22,6 +22,14 @@ target_link_libraries(ydb-core-pgproxy PUBLIC ydb-core-raw_socket ) target_sources(ydb-core-pgproxy PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_connection.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_listener.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_log_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_log.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy_events.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_stream.h ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_connection.cpp ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy_types.cpp ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy.cpp diff --git a/ydb/core/pgproxy/protos/CMakeLists.darwin-arm64.txt b/ydb/core/pgproxy/protos/CMakeLists.darwin-arm64.txt index d186da46127d..7caf463fd095 100644 --- a/ydb/core/pgproxy/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/core/pgproxy/protos/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(core-pgproxy-protos PUBLIC target_proto_messages(core-pgproxy-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/protos/pgproxy.proto ) +target_sources(core-pgproxy-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/pgproxy/protos/pgproxy.pb.h +) target_proto_addincls(core-pgproxy-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/pgproxy/protos/CMakeLists.darwin-x86_64.txt b/ydb/core/pgproxy/protos/CMakeLists.darwin-x86_64.txt index d186da46127d..7caf463fd095 100644 --- a/ydb/core/pgproxy/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/pgproxy/protos/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(core-pgproxy-protos PUBLIC target_proto_messages(core-pgproxy-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/protos/pgproxy.proto ) +target_sources(core-pgproxy-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/pgproxy/protos/pgproxy.pb.h +) target_proto_addincls(core-pgproxy-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/pgproxy/protos/CMakeLists.linux-aarch64.txt b/ydb/core/pgproxy/protos/CMakeLists.linux-aarch64.txt index 71c3d8adf545..cf045f59de59 100644 --- a/ydb/core/pgproxy/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/core/pgproxy/protos/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(core-pgproxy-protos PUBLIC target_proto_messages(core-pgproxy-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/protos/pgproxy.proto ) +target_sources(core-pgproxy-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/pgproxy/protos/pgproxy.pb.h +) target_proto_addincls(core-pgproxy-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/pgproxy/protos/CMakeLists.linux-x86_64.txt b/ydb/core/pgproxy/protos/CMakeLists.linux-x86_64.txt index 71c3d8adf545..cf045f59de59 100644 --- a/ydb/core/pgproxy/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/core/pgproxy/protos/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(core-pgproxy-protos PUBLIC target_proto_messages(core-pgproxy-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/protos/pgproxy.proto ) +target_sources(core-pgproxy-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/pgproxy/protos/pgproxy.pb.h +) target_proto_addincls(core-pgproxy-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/pgproxy/protos/CMakeLists.windows-x86_64.txt b/ydb/core/pgproxy/protos/CMakeLists.windows-x86_64.txt index d186da46127d..7caf463fd095 100644 --- a/ydb/core/pgproxy/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/core/pgproxy/protos/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(core-pgproxy-protos PUBLIC target_proto_messages(core-pgproxy-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/protos/pgproxy.proto ) +target_sources(core-pgproxy-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/pgproxy/protos/pgproxy.pb.h +) target_proto_addincls(core-pgproxy-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/pgproxy/ut/CMakeLists.darwin-arm64.txt b/ydb/core/pgproxy/ut/CMakeLists.darwin-arm64.txt index e212cb277d93..3011832625ea 100644 --- a/ydb/core/pgproxy/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/pgproxy/ut/CMakeLists.darwin-arm64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-core-pgproxy-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-pgproxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/pgproxy/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/pgproxy/ut/CMakeLists.darwin-x86_64.txt index 965cc5d674a7..8a5316b0643b 100644 --- a/ydb/core/pgproxy/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/pgproxy/ut/CMakeLists.darwin-x86_64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-core-pgproxy-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-pgproxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/pgproxy/ut/CMakeLists.linux-aarch64.txt b/ydb/core/pgproxy/ut/CMakeLists.linux-aarch64.txt index 6e752138af60..ef845cc42cef 100644 --- a/ydb/core/pgproxy/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/pgproxy/ut/CMakeLists.linux-aarch64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-core-pgproxy-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-pgproxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/pgproxy/ut/CMakeLists.linux-x86_64.txt b/ydb/core/pgproxy/ut/CMakeLists.linux-x86_64.txt index 72deda1b9472..a69c361ddba0 100644 --- a/ydb/core/pgproxy/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/pgproxy/ut/CMakeLists.linux-x86_64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-core-pgproxy-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-pgproxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/pgproxy/pg_proxy_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/pgproxy/ut/CMakeLists.windows-x86_64.txt b/ydb/core/pgproxy/ut/CMakeLists.windows-x86_64.txt index eae0e77e40bf..95717e655f53 100644 --- a/ydb/core/pgproxy/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/pgproxy/ut/CMakeLists.windows-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/protos/CMakeLists.darwin-arm64.txt b/ydb/core/protos/CMakeLists.darwin-arm64.txt index e7effd7204b1..51b7d6db4f04 100644 --- a/ydb/core/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/core/protos/CMakeLists.darwin-arm64.txt @@ -1756,6 +1756,270 @@ target_proto_messages(ydb-core-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/protos/scheme_board_mon.proto ${CMAKE_SOURCE_DIR}/ydb/core/protos/sys_view.proto ) +target_sources(ydb-core-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/protos/alloc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/alloc.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/base.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/base.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/bind_channel_storage_pool.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/bind_channel_storage_pool.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blob_depot.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blob_depot.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blob_depot_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blob_depot_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_base.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_base.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_base3.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_base3.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_disk.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_disk.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_disk_color.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_disk_color.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_distributed_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_distributed_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_pdisk_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_pdisk_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_vdisk_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_vdisk_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_vdisk_internal.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_vdisk_internal.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blockstore_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blockstore_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/datashard_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/datashard_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/db_metadata_cache.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/db_metadata_cache.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/feature_flags.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/feature_flags.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/filestore_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/filestore_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/bootstrapper.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/bootstrapper.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/change_exchange.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/change_exchange.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/channel_purpose.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/channel_purpose.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/cms.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/cms.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/config_units.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/config_units.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_base.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_base.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_tenant.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_tenant.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_tx_allocator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_tx_allocator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_blob_depot.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_blob_depot.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_bs_controller.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_bs_controller.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_cms.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_cms.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_coordinator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_coordinator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_columnshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_columnshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_datashard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_datashard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_hive.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_hive.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_kesus.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_kesus.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_keyvalue.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_keyvalue.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_pq.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_pq.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_replication.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_replication.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_schemeshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_schemeshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_sequenceshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_sequenceshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_statistics_aggregator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_statistics_aggregator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_sysview_processor.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_sysview_processor.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_testshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_testshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_tx_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_tx_proxy.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_mediator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_mediator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/database_basic_sausage_metainfo.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/database_basic_sausage_metainfo.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/data_events.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/data_events.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/datashard_load.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/datashard_load.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/drivemodel.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/drivemodel.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/export.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/export.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/external_sources.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/external_sources.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/flat_tx_scheme.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/flat_tx_scheme.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/flat_scheme_op.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/flat_scheme_op.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/health.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/health.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/hive.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/hive.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/http_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/http_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/import.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/import.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/index_builder.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/index_builder.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kesus.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kesus.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp_physical.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp_physical.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp_stats.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/labeled_counters.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/labeled_counters.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/load_test.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/load_test.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/local.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/local.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/long_tx_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/long_tx_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/maintenance.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/maintenance.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/metrics.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/metrics.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/minikql_engine.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/minikql_engine.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/mon.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/mon.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_health.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_health.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_kv.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_kv.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_pq.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_pq.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/netclassifier.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/netclassifier.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_broker.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_broker.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_limits.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_limits.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/profiler.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/profiler.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/query_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/query_stats.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/replication.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/replication.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/resource_broker.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/resource_broker.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_log.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_log.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_type_metadata.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_type_metadata.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_type_operation.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_type_operation.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/serverless_proxy_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/serverless_proxy_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/shared_cache.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/shared_cache.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/sqs.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/sqs.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/follower_group.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/follower_group.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ssa.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ssa.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/statestorage.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/statestorage.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/statistics.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/statistics.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/stream.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/stream.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/subdomains.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/subdomains.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/table_service_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/table_service_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/table_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/table_stats.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_counters.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_counters.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_counters_aggregator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_counters_aggregator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_database.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_database.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_pipe.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_pipe.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_tracing_signals.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_tracing_signals.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_tx.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_tx.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tenant_pool.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tenant_pool.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tenant_slot_broker.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tenant_slot_broker.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/test_shard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/test_shard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tracing.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tracing.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_whiteboard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_whiteboard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_columnshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_columnshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_datashard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_datashard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_mediator_timecast.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_mediator_timecast.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_proxy.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_scheme.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_scheme.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_sequenceshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_sequenceshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/pdiskfit.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/pdiskfit.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/pqconfig.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/pqconfig.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/auth.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/auth.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/key.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/key.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc_pq_old.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc_pq_old.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc_status_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc_status_proxy.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ydb_result_set_old.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ydb_result_set_old.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ydb_table_impl.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ydb_table_impl.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_board.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_board.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_board_mon.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_board_mon.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/sys_view.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/sys_view.grpc.pb.h +) generate_enum_serilization(ydb-core-protos ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_pdisk_config.pb.h INCLUDE_HEADERS diff --git a/ydb/core/protos/CMakeLists.darwin-x86_64.txt b/ydb/core/protos/CMakeLists.darwin-x86_64.txt index e7effd7204b1..51b7d6db4f04 100644 --- a/ydb/core/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/protos/CMakeLists.darwin-x86_64.txt @@ -1756,6 +1756,270 @@ target_proto_messages(ydb-core-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/protos/scheme_board_mon.proto ${CMAKE_SOURCE_DIR}/ydb/core/protos/sys_view.proto ) +target_sources(ydb-core-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/protos/alloc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/alloc.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/base.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/base.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/bind_channel_storage_pool.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/bind_channel_storage_pool.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blob_depot.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blob_depot.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blob_depot_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blob_depot_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_base.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_base.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_base3.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_base3.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_disk.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_disk.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_disk_color.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_disk_color.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_distributed_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_distributed_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_pdisk_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_pdisk_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_vdisk_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_vdisk_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_vdisk_internal.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_vdisk_internal.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blockstore_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blockstore_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/datashard_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/datashard_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/db_metadata_cache.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/db_metadata_cache.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/feature_flags.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/feature_flags.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/filestore_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/filestore_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/bootstrapper.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/bootstrapper.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/change_exchange.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/change_exchange.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/channel_purpose.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/channel_purpose.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/cms.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/cms.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/config_units.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/config_units.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_base.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_base.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_tenant.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_tenant.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_tx_allocator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_tx_allocator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_blob_depot.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_blob_depot.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_bs_controller.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_bs_controller.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_cms.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_cms.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_coordinator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_coordinator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_columnshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_columnshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_datashard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_datashard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_hive.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_hive.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_kesus.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_kesus.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_keyvalue.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_keyvalue.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_pq.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_pq.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_replication.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_replication.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_schemeshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_schemeshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_sequenceshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_sequenceshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_statistics_aggregator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_statistics_aggregator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_sysview_processor.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_sysview_processor.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_testshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_testshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_tx_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_tx_proxy.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_mediator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_mediator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/database_basic_sausage_metainfo.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/database_basic_sausage_metainfo.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/data_events.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/data_events.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/datashard_load.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/datashard_load.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/drivemodel.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/drivemodel.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/export.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/export.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/external_sources.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/external_sources.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/flat_tx_scheme.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/flat_tx_scheme.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/flat_scheme_op.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/flat_scheme_op.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/health.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/health.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/hive.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/hive.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/http_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/http_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/import.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/import.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/index_builder.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/index_builder.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kesus.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kesus.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp_physical.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp_physical.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp_stats.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/labeled_counters.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/labeled_counters.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/load_test.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/load_test.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/local.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/local.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/long_tx_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/long_tx_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/maintenance.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/maintenance.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/metrics.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/metrics.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/minikql_engine.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/minikql_engine.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/mon.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/mon.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_health.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_health.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_kv.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_kv.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_pq.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_pq.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/netclassifier.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/netclassifier.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_broker.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_broker.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_limits.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_limits.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/profiler.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/profiler.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/query_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/query_stats.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/replication.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/replication.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/resource_broker.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/resource_broker.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_log.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_log.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_type_metadata.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_type_metadata.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_type_operation.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_type_operation.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/serverless_proxy_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/serverless_proxy_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/shared_cache.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/shared_cache.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/sqs.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/sqs.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/follower_group.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/follower_group.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ssa.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ssa.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/statestorage.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/statestorage.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/statistics.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/statistics.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/stream.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/stream.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/subdomains.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/subdomains.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/table_service_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/table_service_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/table_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/table_stats.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_counters.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_counters.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_counters_aggregator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_counters_aggregator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_database.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_database.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_pipe.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_pipe.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_tracing_signals.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_tracing_signals.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_tx.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_tx.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tenant_pool.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tenant_pool.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tenant_slot_broker.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tenant_slot_broker.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/test_shard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/test_shard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tracing.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tracing.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_whiteboard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_whiteboard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_columnshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_columnshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_datashard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_datashard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_mediator_timecast.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_mediator_timecast.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_proxy.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_scheme.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_scheme.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_sequenceshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_sequenceshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/pdiskfit.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/pdiskfit.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/pqconfig.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/pqconfig.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/auth.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/auth.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/key.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/key.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc_pq_old.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc_pq_old.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc_status_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc_status_proxy.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ydb_result_set_old.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ydb_result_set_old.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ydb_table_impl.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ydb_table_impl.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_board.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_board.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_board_mon.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_board_mon.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/sys_view.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/sys_view.grpc.pb.h +) generate_enum_serilization(ydb-core-protos ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_pdisk_config.pb.h INCLUDE_HEADERS diff --git a/ydb/core/protos/CMakeLists.linux-aarch64.txt b/ydb/core/protos/CMakeLists.linux-aarch64.txt index 5dec083df11e..ff9451308fe8 100644 --- a/ydb/core/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/core/protos/CMakeLists.linux-aarch64.txt @@ -1757,6 +1757,270 @@ target_proto_messages(ydb-core-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/protos/scheme_board_mon.proto ${CMAKE_SOURCE_DIR}/ydb/core/protos/sys_view.proto ) +target_sources(ydb-core-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/protos/alloc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/alloc.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/base.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/base.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/bind_channel_storage_pool.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/bind_channel_storage_pool.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blob_depot.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blob_depot.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blob_depot_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blob_depot_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_base.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_base.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_base3.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_base3.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_disk.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_disk.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_disk_color.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_disk_color.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_distributed_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_distributed_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_pdisk_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_pdisk_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_vdisk_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_vdisk_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_vdisk_internal.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_vdisk_internal.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blockstore_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blockstore_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/datashard_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/datashard_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/db_metadata_cache.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/db_metadata_cache.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/feature_flags.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/feature_flags.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/filestore_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/filestore_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/bootstrapper.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/bootstrapper.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/change_exchange.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/change_exchange.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/channel_purpose.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/channel_purpose.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/cms.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/cms.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/config_units.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/config_units.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_base.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_base.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_tenant.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_tenant.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_tx_allocator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_tx_allocator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_blob_depot.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_blob_depot.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_bs_controller.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_bs_controller.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_cms.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_cms.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_coordinator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_coordinator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_columnshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_columnshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_datashard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_datashard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_hive.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_hive.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_kesus.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_kesus.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_keyvalue.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_keyvalue.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_pq.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_pq.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_replication.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_replication.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_schemeshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_schemeshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_sequenceshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_sequenceshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_statistics_aggregator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_statistics_aggregator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_sysview_processor.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_sysview_processor.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_testshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_testshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_tx_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_tx_proxy.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_mediator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_mediator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/database_basic_sausage_metainfo.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/database_basic_sausage_metainfo.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/data_events.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/data_events.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/datashard_load.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/datashard_load.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/drivemodel.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/drivemodel.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/export.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/export.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/external_sources.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/external_sources.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/flat_tx_scheme.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/flat_tx_scheme.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/flat_scheme_op.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/flat_scheme_op.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/health.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/health.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/hive.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/hive.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/http_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/http_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/import.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/import.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/index_builder.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/index_builder.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kesus.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kesus.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp_physical.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp_physical.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp_stats.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/labeled_counters.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/labeled_counters.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/load_test.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/load_test.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/local.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/local.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/long_tx_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/long_tx_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/maintenance.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/maintenance.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/metrics.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/metrics.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/minikql_engine.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/minikql_engine.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/mon.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/mon.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_health.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_health.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_kv.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_kv.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_pq.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_pq.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/netclassifier.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/netclassifier.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_broker.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_broker.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_limits.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_limits.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/profiler.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/profiler.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/query_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/query_stats.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/replication.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/replication.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/resource_broker.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/resource_broker.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_log.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_log.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_type_metadata.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_type_metadata.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_type_operation.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_type_operation.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/serverless_proxy_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/serverless_proxy_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/shared_cache.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/shared_cache.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/sqs.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/sqs.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/follower_group.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/follower_group.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ssa.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ssa.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/statestorage.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/statestorage.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/statistics.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/statistics.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/stream.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/stream.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/subdomains.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/subdomains.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/table_service_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/table_service_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/table_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/table_stats.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_counters.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_counters.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_counters_aggregator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_counters_aggregator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_database.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_database.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_pipe.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_pipe.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_tracing_signals.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_tracing_signals.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_tx.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_tx.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tenant_pool.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tenant_pool.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tenant_slot_broker.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tenant_slot_broker.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/test_shard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/test_shard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tracing.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tracing.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_whiteboard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_whiteboard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_columnshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_columnshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_datashard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_datashard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_mediator_timecast.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_mediator_timecast.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_proxy.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_scheme.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_scheme.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_sequenceshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_sequenceshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/pdiskfit.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/pdiskfit.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/pqconfig.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/pqconfig.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/auth.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/auth.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/key.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/key.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc_pq_old.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc_pq_old.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc_status_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc_status_proxy.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ydb_result_set_old.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ydb_result_set_old.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ydb_table_impl.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ydb_table_impl.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_board.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_board.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_board_mon.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_board_mon.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/sys_view.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/sys_view.grpc.pb.h +) generate_enum_serilization(ydb-core-protos ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_pdisk_config.pb.h INCLUDE_HEADERS diff --git a/ydb/core/protos/CMakeLists.linux-x86_64.txt b/ydb/core/protos/CMakeLists.linux-x86_64.txt index 5dec083df11e..ff9451308fe8 100644 --- a/ydb/core/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/core/protos/CMakeLists.linux-x86_64.txt @@ -1757,6 +1757,270 @@ target_proto_messages(ydb-core-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/protos/scheme_board_mon.proto ${CMAKE_SOURCE_DIR}/ydb/core/protos/sys_view.proto ) +target_sources(ydb-core-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/protos/alloc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/alloc.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/base.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/base.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/bind_channel_storage_pool.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/bind_channel_storage_pool.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blob_depot.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blob_depot.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blob_depot_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blob_depot_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_base.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_base.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_base3.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_base3.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_disk.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_disk.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_disk_color.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_disk_color.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_distributed_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_distributed_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_pdisk_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_pdisk_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_vdisk_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_vdisk_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_vdisk_internal.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_vdisk_internal.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blockstore_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blockstore_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/datashard_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/datashard_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/db_metadata_cache.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/db_metadata_cache.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/feature_flags.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/feature_flags.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/filestore_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/filestore_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/bootstrapper.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/bootstrapper.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/change_exchange.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/change_exchange.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/channel_purpose.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/channel_purpose.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/cms.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/cms.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/config_units.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/config_units.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_base.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_base.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_tenant.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_tenant.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_tx_allocator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_tx_allocator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_blob_depot.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_blob_depot.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_bs_controller.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_bs_controller.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_cms.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_cms.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_coordinator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_coordinator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_columnshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_columnshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_datashard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_datashard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_hive.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_hive.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_kesus.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_kesus.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_keyvalue.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_keyvalue.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_pq.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_pq.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_replication.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_replication.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_schemeshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_schemeshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_sequenceshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_sequenceshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_statistics_aggregator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_statistics_aggregator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_sysview_processor.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_sysview_processor.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_testshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_testshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_tx_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_tx_proxy.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_mediator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_mediator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/database_basic_sausage_metainfo.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/database_basic_sausage_metainfo.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/data_events.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/data_events.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/datashard_load.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/datashard_load.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/drivemodel.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/drivemodel.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/export.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/export.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/external_sources.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/external_sources.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/flat_tx_scheme.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/flat_tx_scheme.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/flat_scheme_op.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/flat_scheme_op.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/health.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/health.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/hive.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/hive.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/http_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/http_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/import.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/import.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/index_builder.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/index_builder.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kesus.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kesus.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp_physical.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp_physical.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp_stats.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/labeled_counters.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/labeled_counters.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/load_test.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/load_test.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/local.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/local.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/long_tx_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/long_tx_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/maintenance.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/maintenance.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/metrics.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/metrics.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/minikql_engine.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/minikql_engine.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/mon.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/mon.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_health.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_health.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_kv.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_kv.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_pq.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_pq.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/netclassifier.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/netclassifier.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_broker.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_broker.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_limits.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_limits.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/profiler.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/profiler.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/query_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/query_stats.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/replication.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/replication.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/resource_broker.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/resource_broker.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_log.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_log.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_type_metadata.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_type_metadata.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_type_operation.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_type_operation.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/serverless_proxy_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/serverless_proxy_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/shared_cache.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/shared_cache.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/sqs.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/sqs.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/follower_group.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/follower_group.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ssa.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ssa.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/statestorage.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/statestorage.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/statistics.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/statistics.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/stream.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/stream.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/subdomains.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/subdomains.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/table_service_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/table_service_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/table_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/table_stats.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_counters.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_counters.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_counters_aggregator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_counters_aggregator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_database.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_database.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_pipe.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_pipe.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_tracing_signals.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_tracing_signals.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_tx.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_tx.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tenant_pool.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tenant_pool.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tenant_slot_broker.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tenant_slot_broker.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/test_shard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/test_shard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tracing.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tracing.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_whiteboard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_whiteboard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_columnshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_columnshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_datashard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_datashard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_mediator_timecast.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_mediator_timecast.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_proxy.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_scheme.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_scheme.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_sequenceshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_sequenceshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/pdiskfit.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/pdiskfit.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/pqconfig.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/pqconfig.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/auth.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/auth.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/key.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/key.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc_pq_old.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc_pq_old.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc_status_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc_status_proxy.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ydb_result_set_old.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ydb_result_set_old.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ydb_table_impl.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ydb_table_impl.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_board.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_board.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_board_mon.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_board_mon.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/sys_view.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/sys_view.grpc.pb.h +) generate_enum_serilization(ydb-core-protos ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_pdisk_config.pb.h INCLUDE_HEADERS diff --git a/ydb/core/protos/CMakeLists.windows-x86_64.txt b/ydb/core/protos/CMakeLists.windows-x86_64.txt index e7effd7204b1..51b7d6db4f04 100644 --- a/ydb/core/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/core/protos/CMakeLists.windows-x86_64.txt @@ -1756,6 +1756,270 @@ target_proto_messages(ydb-core-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/protos/scheme_board_mon.proto ${CMAKE_SOURCE_DIR}/ydb/core/protos/sys_view.proto ) +target_sources(ydb-core-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/protos/alloc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/alloc.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/base.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/base.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/bind_channel_storage_pool.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/bind_channel_storage_pool.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blob_depot.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blob_depot.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blob_depot_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blob_depot_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_base.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_base.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_base3.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_base3.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_disk.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_disk.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_disk_color.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_disk_color.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_distributed_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_distributed_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_pdisk_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_pdisk_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_vdisk_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_vdisk_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_vdisk_internal.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_vdisk_internal.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blockstore_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/blockstore_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/datashard_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/datashard_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/db_metadata_cache.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/db_metadata_cache.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/feature_flags.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/feature_flags.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/filestore_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/filestore_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/bootstrapper.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/bootstrapper.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/change_exchange.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/change_exchange.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/channel_purpose.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/channel_purpose.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/cms.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/cms.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/config_units.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/config_units.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_base.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_base.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_tenant.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/console_tenant.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_tx_allocator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_tx_allocator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_blob_depot.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_blob_depot.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_bs_controller.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_bs_controller.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_cms.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_cms.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_coordinator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_coordinator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_columnshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_columnshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_datashard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_datashard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_hive.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_hive.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_kesus.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_kesus.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_keyvalue.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_keyvalue.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_pq.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_pq.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_replication.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_replication.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_schemeshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_schemeshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_sequenceshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_sequenceshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_statistics_aggregator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_statistics_aggregator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_sysview_processor.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_sysview_processor.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_testshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_testshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_tx_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_tx_proxy.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_mediator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters_mediator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/counters.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/database_basic_sausage_metainfo.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/database_basic_sausage_metainfo.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/data_events.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/data_events.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/datashard_load.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/datashard_load.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/drivemodel.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/drivemodel.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/export.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/export.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/external_sources.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/external_sources.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/flat_tx_scheme.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/flat_tx_scheme.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/flat_scheme_op.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/flat_scheme_op.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/health.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/health.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/hive.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/hive.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/http_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/http_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/import.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/import.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/index_builder.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/index_builder.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kesus.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kesus.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp_physical.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp_physical.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp_stats.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/kqp.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/labeled_counters.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/labeled_counters.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/load_test.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/load_test.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/local.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/local.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/long_tx_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/long_tx_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/maintenance.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/maintenance.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/metrics.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/metrics.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/minikql_engine.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/minikql_engine.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/mon.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/mon.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_health.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_health.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_kv.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_kv.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_pq.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/msgbus_pq.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/netclassifier.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/netclassifier.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_broker.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_broker.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_limits.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_limits.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/profiler.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/profiler.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/query_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/query_stats.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/replication.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/replication.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/resource_broker.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/resource_broker.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_log.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_log.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_type_metadata.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_type_metadata.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_type_operation.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_type_operation.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/serverless_proxy_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/serverless_proxy_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/shared_cache.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/shared_cache.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/sqs.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/sqs.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/follower_group.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/follower_group.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ssa.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ssa.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/statestorage.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/statestorage.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/statistics.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/statistics.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/stream.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/stream.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/subdomains.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/subdomains.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/table_service_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/table_service_config.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/table_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/table_stats.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_counters.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_counters.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_counters_aggregator.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_counters_aggregator.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_database.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_database.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_pipe.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_pipe.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_tracing_signals.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_tracing_signals.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_tx.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tablet_tx.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tenant_pool.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tenant_pool.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tenant_slot_broker.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tenant_slot_broker.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/test_shard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/test_shard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tracing.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tracing.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_whiteboard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/node_whiteboard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_columnshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_columnshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_datashard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_datashard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_mediator_timecast.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_mediator_timecast.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_proxy.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_scheme.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_scheme.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_sequenceshard.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/tx_sequenceshard.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/pdiskfit.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/pdiskfit.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/pqconfig.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/pqconfig.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/auth.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/auth.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/key.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/key.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc_pq_old.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc_pq_old.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc_status_proxy.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/grpc_status_proxy.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ydb_result_set_old.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ydb_result_set_old.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ydb_table_impl.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/ydb_table_impl.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_board.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_board.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_board_mon.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/scheme_board_mon.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/sys_view.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/protos/sys_view.grpc.pb.h +) generate_enum_serilization(ydb-core-protos ${CMAKE_BINARY_DIR}/ydb/core/protos/blobstorage_pdisk_config.pb.h INCLUDE_HEADERS diff --git a/ydb/core/public_http/CMakeLists.darwin-arm64.txt b/ydb/core/public_http/CMakeLists.darwin-arm64.txt index 96a7abc7bc23..8bbfe352b6f8 100644 --- a/ydb/core/public_http/CMakeLists.darwin-arm64.txt +++ b/ydb/core/public_http/CMakeLists.darwin-arm64.txt @@ -37,6 +37,10 @@ target_link_libraries(ydb-core-public_http PUBLIC cpp-client-ydb_types ) target_sources(ydb-core-public_http PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_req.h + ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_router.h + ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/public_http/grpc_request_context_wrapper.h ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_req.cpp ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_router.cpp ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_service.cpp diff --git a/ydb/core/public_http/CMakeLists.darwin-x86_64.txt b/ydb/core/public_http/CMakeLists.darwin-x86_64.txt index 96a7abc7bc23..8bbfe352b6f8 100644 --- a/ydb/core/public_http/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/public_http/CMakeLists.darwin-x86_64.txt @@ -37,6 +37,10 @@ target_link_libraries(ydb-core-public_http PUBLIC cpp-client-ydb_types ) target_sources(ydb-core-public_http PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_req.h + ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_router.h + ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/public_http/grpc_request_context_wrapper.h ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_req.cpp ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_router.cpp ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_service.cpp diff --git a/ydb/core/public_http/CMakeLists.linux-aarch64.txt b/ydb/core/public_http/CMakeLists.linux-aarch64.txt index 3246c1a67708..b444adcd479a 100644 --- a/ydb/core/public_http/CMakeLists.linux-aarch64.txt +++ b/ydb/core/public_http/CMakeLists.linux-aarch64.txt @@ -38,6 +38,10 @@ target_link_libraries(ydb-core-public_http PUBLIC cpp-client-ydb_types ) target_sources(ydb-core-public_http PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_req.h + ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_router.h + ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/public_http/grpc_request_context_wrapper.h ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_req.cpp ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_router.cpp ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_service.cpp diff --git a/ydb/core/public_http/CMakeLists.linux-x86_64.txt b/ydb/core/public_http/CMakeLists.linux-x86_64.txt index 3246c1a67708..b444adcd479a 100644 --- a/ydb/core/public_http/CMakeLists.linux-x86_64.txt +++ b/ydb/core/public_http/CMakeLists.linux-x86_64.txt @@ -38,6 +38,10 @@ target_link_libraries(ydb-core-public_http PUBLIC cpp-client-ydb_types ) target_sources(ydb-core-public_http PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_req.h + ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_router.h + ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/public_http/grpc_request_context_wrapper.h ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_req.cpp ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_router.cpp ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_service.cpp diff --git a/ydb/core/public_http/CMakeLists.windows-x86_64.txt b/ydb/core/public_http/CMakeLists.windows-x86_64.txt index 96a7abc7bc23..8bbfe352b6f8 100644 --- a/ydb/core/public_http/CMakeLists.windows-x86_64.txt +++ b/ydb/core/public_http/CMakeLists.windows-x86_64.txt @@ -37,6 +37,10 @@ target_link_libraries(ydb-core-public_http PUBLIC cpp-client-ydb_types ) target_sources(ydb-core-public_http PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_req.h + ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_router.h + ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/public_http/grpc_request_context_wrapper.h ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_req.cpp ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_router.cpp ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_service.cpp diff --git a/ydb/core/public_http/protos/CMakeLists.darwin-arm64.txt b/ydb/core/public_http/protos/CMakeLists.darwin-arm64.txt index 69379327d8f1..f1d9ca482cad 100644 --- a/ydb/core/public_http/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/core/public_http/protos/CMakeLists.darwin-arm64.txt @@ -29,6 +29,9 @@ target_link_libraries(core-public_http-protos PUBLIC target_proto_messages(core-public_http-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/public_http/protos/fq.proto ) +target_sources(core-public_http-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/public_http/protos/fq.pb.h +) target_proto_addincls(core-public_http-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/public_http/protos/CMakeLists.darwin-x86_64.txt b/ydb/core/public_http/protos/CMakeLists.darwin-x86_64.txt index 69379327d8f1..f1d9ca482cad 100644 --- a/ydb/core/public_http/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/public_http/protos/CMakeLists.darwin-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(core-public_http-protos PUBLIC target_proto_messages(core-public_http-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/public_http/protos/fq.proto ) +target_sources(core-public_http-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/public_http/protos/fq.pb.h +) target_proto_addincls(core-public_http-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/public_http/protos/CMakeLists.linux-aarch64.txt b/ydb/core/public_http/protos/CMakeLists.linux-aarch64.txt index 55f98c96cbf6..d61e9c73107f 100644 --- a/ydb/core/public_http/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/core/public_http/protos/CMakeLists.linux-aarch64.txt @@ -30,6 +30,9 @@ target_link_libraries(core-public_http-protos PUBLIC target_proto_messages(core-public_http-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/public_http/protos/fq.proto ) +target_sources(core-public_http-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/public_http/protos/fq.pb.h +) target_proto_addincls(core-public_http-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/public_http/protos/CMakeLists.linux-x86_64.txt b/ydb/core/public_http/protos/CMakeLists.linux-x86_64.txt index 55f98c96cbf6..d61e9c73107f 100644 --- a/ydb/core/public_http/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/core/public_http/protos/CMakeLists.linux-x86_64.txt @@ -30,6 +30,9 @@ target_link_libraries(core-public_http-protos PUBLIC target_proto_messages(core-public_http-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/public_http/protos/fq.proto ) +target_sources(core-public_http-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/public_http/protos/fq.pb.h +) target_proto_addincls(core-public_http-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/public_http/protos/CMakeLists.windows-x86_64.txt b/ydb/core/public_http/protos/CMakeLists.windows-x86_64.txt index 69379327d8f1..f1d9ca482cad 100644 --- a/ydb/core/public_http/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/core/public_http/protos/CMakeLists.windows-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(core-public_http-protos PUBLIC target_proto_messages(core-public_http-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/public_http/protos/fq.proto ) +target_sources(core-public_http-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/public_http/protos/fq.pb.h +) target_proto_addincls(core-public_http-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/public_http/ut/CMakeLists.darwin-arm64.txt b/ydb/core/public_http/ut/CMakeLists.darwin-arm64.txt index 8500657040b2..1b818c9ba33b 100644 --- a/ydb/core/public_http/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/public_http/ut/CMakeLists.darwin-arm64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-public_http-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-public_http-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_router_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/public_http/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/public_http/ut/CMakeLists.darwin-x86_64.txt index ed51bde73c89..e174fb774f2c 100644 --- a/ydb/core/public_http/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/public_http/ut/CMakeLists.darwin-x86_64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-core-public_http-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-public_http-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_router_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/public_http/ut/CMakeLists.linux-aarch64.txt b/ydb/core/public_http/ut/CMakeLists.linux-aarch64.txt index 7e4336e99727..1a73f592a997 100644 --- a/ydb/core/public_http/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/public_http/ut/CMakeLists.linux-aarch64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-public_http-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-public_http-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_router_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/public_http/ut/CMakeLists.linux-x86_64.txt b/ydb/core/public_http/ut/CMakeLists.linux-x86_64.txt index ec56fc75c9f9..b07cda110288 100644 --- a/ydb/core/public_http/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/public_http/ut/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-core-public_http-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-public_http-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/public_http/http_router_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/public_http/ut/CMakeLists.windows-x86_64.txt b/ydb/core/public_http/ut/CMakeLists.windows-x86_64.txt index a09328b774eb..97280d433a27 100644 --- a/ydb/core/public_http/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/public_http/ut/CMakeLists.windows-x86_64.txt @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/quoter/CMakeLists.darwin-arm64.txt b/ydb/core/quoter/CMakeLists.darwin-arm64.txt index ccb2250206f7..907b1685bee3 100644 --- a/ydb/core/quoter/CMakeLists.darwin-arm64.txt +++ b/ydb/core/quoter/CMakeLists.darwin-arm64.txt @@ -24,6 +24,9 @@ target_link_libraries(ydb-core-quoter PUBLIC ydb-library-time_series_vec ) target_sources(ydb-core-quoter PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/quoter/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/quoter/quoter_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/quoter/quoter_service_impl.h ${CMAKE_SOURCE_DIR}/ydb/core/quoter/debug_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/quoter/kesus_quoter_proxy.cpp ${CMAKE_SOURCE_DIR}/ydb/core/quoter/probes.cpp diff --git a/ydb/core/quoter/CMakeLists.darwin-x86_64.txt b/ydb/core/quoter/CMakeLists.darwin-x86_64.txt index ccb2250206f7..907b1685bee3 100644 --- a/ydb/core/quoter/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/quoter/CMakeLists.darwin-x86_64.txt @@ -24,6 +24,9 @@ target_link_libraries(ydb-core-quoter PUBLIC ydb-library-time_series_vec ) target_sources(ydb-core-quoter PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/quoter/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/quoter/quoter_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/quoter/quoter_service_impl.h ${CMAKE_SOURCE_DIR}/ydb/core/quoter/debug_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/quoter/kesus_quoter_proxy.cpp ${CMAKE_SOURCE_DIR}/ydb/core/quoter/probes.cpp diff --git a/ydb/core/quoter/CMakeLists.linux-aarch64.txt b/ydb/core/quoter/CMakeLists.linux-aarch64.txt index f6c84e24261a..c9fcb5eed294 100644 --- a/ydb/core/quoter/CMakeLists.linux-aarch64.txt +++ b/ydb/core/quoter/CMakeLists.linux-aarch64.txt @@ -25,6 +25,9 @@ target_link_libraries(ydb-core-quoter PUBLIC ydb-library-time_series_vec ) target_sources(ydb-core-quoter PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/quoter/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/quoter/quoter_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/quoter/quoter_service_impl.h ${CMAKE_SOURCE_DIR}/ydb/core/quoter/debug_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/quoter/kesus_quoter_proxy.cpp ${CMAKE_SOURCE_DIR}/ydb/core/quoter/probes.cpp diff --git a/ydb/core/quoter/CMakeLists.linux-x86_64.txt b/ydb/core/quoter/CMakeLists.linux-x86_64.txt index f6c84e24261a..c9fcb5eed294 100644 --- a/ydb/core/quoter/CMakeLists.linux-x86_64.txt +++ b/ydb/core/quoter/CMakeLists.linux-x86_64.txt @@ -25,6 +25,9 @@ target_link_libraries(ydb-core-quoter PUBLIC ydb-library-time_series_vec ) target_sources(ydb-core-quoter PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/quoter/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/quoter/quoter_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/quoter/quoter_service_impl.h ${CMAKE_SOURCE_DIR}/ydb/core/quoter/debug_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/quoter/kesus_quoter_proxy.cpp ${CMAKE_SOURCE_DIR}/ydb/core/quoter/probes.cpp diff --git a/ydb/core/quoter/CMakeLists.windows-x86_64.txt b/ydb/core/quoter/CMakeLists.windows-x86_64.txt index 729e08ea4d58..ace2426b2c28 100644 --- a/ydb/core/quoter/CMakeLists.windows-x86_64.txt +++ b/ydb/core/quoter/CMakeLists.windows-x86_64.txt @@ -23,6 +23,9 @@ target_link_libraries(ydb-core-quoter PUBLIC ydb-library-time_series_vec ) target_sources(ydb-core-quoter PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/quoter/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/quoter/quoter_service.h + ${CMAKE_SOURCE_DIR}/ydb/core/quoter/quoter_service_impl.h ${CMAKE_SOURCE_DIR}/ydb/core/quoter/debug_info.cpp ${CMAKE_SOURCE_DIR}/ydb/core/quoter/kesus_quoter_proxy.cpp ${CMAKE_SOURCE_DIR}/ydb/core/quoter/probes.cpp diff --git a/ydb/core/quoter/public/CMakeLists.darwin-arm64.txt b/ydb/core/quoter/public/CMakeLists.darwin-arm64.txt index c11b5d5b8aa5..80ffbff8b634 100644 --- a/ydb/core/quoter/public/CMakeLists.darwin-arm64.txt +++ b/ydb/core/quoter/public/CMakeLists.darwin-arm64.txt @@ -25,6 +25,7 @@ target_link_libraries(core-quoter-public PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(core-quoter-public PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/quoter/public/quoter.h ${CMAKE_SOURCE_DIR}/ydb/core/quoter/public/quoter.cpp ) generate_enum_serilization(core-quoter-public diff --git a/ydb/core/quoter/public/CMakeLists.darwin-x86_64.txt b/ydb/core/quoter/public/CMakeLists.darwin-x86_64.txt index c11b5d5b8aa5..80ffbff8b634 100644 --- a/ydb/core/quoter/public/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/quoter/public/CMakeLists.darwin-x86_64.txt @@ -25,6 +25,7 @@ target_link_libraries(core-quoter-public PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(core-quoter-public PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/quoter/public/quoter.h ${CMAKE_SOURCE_DIR}/ydb/core/quoter/public/quoter.cpp ) generate_enum_serilization(core-quoter-public diff --git a/ydb/core/quoter/public/CMakeLists.linux-aarch64.txt b/ydb/core/quoter/public/CMakeLists.linux-aarch64.txt index 15344b765f70..52abb766ca2e 100644 --- a/ydb/core/quoter/public/CMakeLists.linux-aarch64.txt +++ b/ydb/core/quoter/public/CMakeLists.linux-aarch64.txt @@ -26,6 +26,7 @@ target_link_libraries(core-quoter-public PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(core-quoter-public PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/quoter/public/quoter.h ${CMAKE_SOURCE_DIR}/ydb/core/quoter/public/quoter.cpp ) generate_enum_serilization(core-quoter-public diff --git a/ydb/core/quoter/public/CMakeLists.linux-x86_64.txt b/ydb/core/quoter/public/CMakeLists.linux-x86_64.txt index 15344b765f70..52abb766ca2e 100644 --- a/ydb/core/quoter/public/CMakeLists.linux-x86_64.txt +++ b/ydb/core/quoter/public/CMakeLists.linux-x86_64.txt @@ -26,6 +26,7 @@ target_link_libraries(core-quoter-public PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(core-quoter-public PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/quoter/public/quoter.h ${CMAKE_SOURCE_DIR}/ydb/core/quoter/public/quoter.cpp ) generate_enum_serilization(core-quoter-public diff --git a/ydb/core/quoter/public/CMakeLists.windows-x86_64.txt b/ydb/core/quoter/public/CMakeLists.windows-x86_64.txt index c11b5d5b8aa5..80ffbff8b634 100644 --- a/ydb/core/quoter/public/CMakeLists.windows-x86_64.txt +++ b/ydb/core/quoter/public/CMakeLists.windows-x86_64.txt @@ -25,6 +25,7 @@ target_link_libraries(core-quoter-public PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(core-quoter-public PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/quoter/public/quoter.h ${CMAKE_SOURCE_DIR}/ydb/core/quoter/public/quoter.cpp ) generate_enum_serilization(core-quoter-public diff --git a/ydb/core/quoter/quoter_service_bandwidth_test/CMakeLists.darwin-arm64.txt b/ydb/core/quoter/quoter_service_bandwidth_test/CMakeLists.darwin-arm64.txt index 1b5748a5bd0c..a33b96a98cc5 100644 --- a/ydb/core/quoter/quoter_service_bandwidth_test/CMakeLists.darwin-arm64.txt +++ b/ydb/core/quoter/quoter_service_bandwidth_test/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(quoter_service_bandwidth_test PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(quoter_service_bandwidth_test PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/quoter/quoter_service_bandwidth_test/main.cpp diff --git a/ydb/core/quoter/quoter_service_bandwidth_test/CMakeLists.darwin-x86_64.txt b/ydb/core/quoter/quoter_service_bandwidth_test/CMakeLists.darwin-x86_64.txt index 30406f7e8cca..80b36e151139 100644 --- a/ydb/core/quoter/quoter_service_bandwidth_test/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/quoter/quoter_service_bandwidth_test/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(quoter_service_bandwidth_test PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(quoter_service_bandwidth_test PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/quoter/quoter_service_bandwidth_test/main.cpp diff --git a/ydb/core/quoter/quoter_service_bandwidth_test/CMakeLists.linux-aarch64.txt b/ydb/core/quoter/quoter_service_bandwidth_test/CMakeLists.linux-aarch64.txt index 967d47bc58cc..13d2a6c86731 100644 --- a/ydb/core/quoter/quoter_service_bandwidth_test/CMakeLists.linux-aarch64.txt +++ b/ydb/core/quoter/quoter_service_bandwidth_test/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(quoter_service_bandwidth_test PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(quoter_service_bandwidth_test PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/quoter/quoter_service_bandwidth_test/main.cpp diff --git a/ydb/core/quoter/quoter_service_bandwidth_test/CMakeLists.linux-x86_64.txt b/ydb/core/quoter/quoter_service_bandwidth_test/CMakeLists.linux-x86_64.txt index e250b9e32e95..4ce9be97eff3 100644 --- a/ydb/core/quoter/quoter_service_bandwidth_test/CMakeLists.linux-x86_64.txt +++ b/ydb/core/quoter/quoter_service_bandwidth_test/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(quoter_service_bandwidth_test PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(quoter_service_bandwidth_test PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/quoter/quoter_service_bandwidth_test/main.cpp diff --git a/ydb/core/quoter/ut/CMakeLists.darwin-arm64.txt b/ydb/core/quoter/ut/CMakeLists.darwin-arm64.txt index 91fcd9d17599..f9ca060e266c 100644 --- a/ydb/core/quoter/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/quoter/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-quoter-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-quoter-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/quoter/kesus_quoter_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/quoter/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/quoter/ut/CMakeLists.darwin-x86_64.txt index 700d6c672e28..655fb6e5dcff 100644 --- a/ydb/core/quoter/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/quoter/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-quoter-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-quoter-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/quoter/kesus_quoter_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/quoter/ut/CMakeLists.linux-aarch64.txt b/ydb/core/quoter/ut/CMakeLists.linux-aarch64.txt index 0fdf358104ed..b9973921a344 100644 --- a/ydb/core/quoter/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/quoter/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-quoter-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-quoter-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/quoter/kesus_quoter_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/quoter/ut/CMakeLists.linux-x86_64.txt b/ydb/core/quoter/ut/CMakeLists.linux-x86_64.txt index 27a18de59ac9..1918130f9715 100644 --- a/ydb/core/quoter/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/quoter/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-quoter-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-quoter-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/quoter/kesus_quoter_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/raw_socket/CMakeLists.darwin-arm64.txt b/ydb/core/raw_socket/CMakeLists.darwin-arm64.txt index d02778f522a7..be147208b936 100644 --- a/ydb/core/raw_socket/CMakeLists.darwin-arm64.txt +++ b/ydb/core/raw_socket/CMakeLists.darwin-arm64.txt @@ -17,5 +17,10 @@ target_link_libraries(ydb-core-raw_socket PUBLIC ydb-core-protos ) target_sources(ydb-core-raw_socket PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock64.h + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_listener.h + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_ssl.h ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_listener.cpp ) diff --git a/ydb/core/raw_socket/CMakeLists.darwin-x86_64.txt b/ydb/core/raw_socket/CMakeLists.darwin-x86_64.txt index d02778f522a7..be147208b936 100644 --- a/ydb/core/raw_socket/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/raw_socket/CMakeLists.darwin-x86_64.txt @@ -17,5 +17,10 @@ target_link_libraries(ydb-core-raw_socket PUBLIC ydb-core-protos ) target_sources(ydb-core-raw_socket PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock64.h + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_listener.h + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_ssl.h ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_listener.cpp ) diff --git a/ydb/core/raw_socket/CMakeLists.linux-aarch64.txt b/ydb/core/raw_socket/CMakeLists.linux-aarch64.txt index 5ef99c0d5b22..a5840a8abd17 100644 --- a/ydb/core/raw_socket/CMakeLists.linux-aarch64.txt +++ b/ydb/core/raw_socket/CMakeLists.linux-aarch64.txt @@ -18,5 +18,10 @@ target_link_libraries(ydb-core-raw_socket PUBLIC ydb-core-protos ) target_sources(ydb-core-raw_socket PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock64.h + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_listener.h + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_ssl.h ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_listener.cpp ) diff --git a/ydb/core/raw_socket/CMakeLists.linux-x86_64.txt b/ydb/core/raw_socket/CMakeLists.linux-x86_64.txt index 5ef99c0d5b22..a5840a8abd17 100644 --- a/ydb/core/raw_socket/CMakeLists.linux-x86_64.txt +++ b/ydb/core/raw_socket/CMakeLists.linux-x86_64.txt @@ -18,5 +18,10 @@ target_link_libraries(ydb-core-raw_socket PUBLIC ydb-core-protos ) target_sources(ydb-core-raw_socket PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock64.h + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_listener.h + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_ssl.h ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_listener.cpp ) diff --git a/ydb/core/raw_socket/CMakeLists.windows-x86_64.txt b/ydb/core/raw_socket/CMakeLists.windows-x86_64.txt index d02778f522a7..be147208b936 100644 --- a/ydb/core/raw_socket/CMakeLists.windows-x86_64.txt +++ b/ydb/core/raw_socket/CMakeLists.windows-x86_64.txt @@ -17,5 +17,10 @@ target_link_libraries(ydb-core-raw_socket PUBLIC ydb-core-protos ) target_sources(ydb-core-raw_socket PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock64.h + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_listener.h + ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_ssl.h ${CMAKE_SOURCE_DIR}/ydb/core/raw_socket/sock_listener.cpp ) diff --git a/ydb/core/scheme/protos/CMakeLists.darwin-arm64.txt b/ydb/core/scheme/protos/CMakeLists.darwin-arm64.txt index 0191fcd83372..5e4a2bfc10ad 100644 --- a/ydb/core/scheme/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/core/scheme/protos/CMakeLists.darwin-arm64.txt @@ -64,6 +64,14 @@ target_proto_messages(core-scheme-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/scheme/protos/key_range.proto ${CMAKE_SOURCE_DIR}/ydb/core/scheme/protos/pathid.proto ) +target_sources(core-scheme-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/type_info.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/type_info.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/key_range.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/key_range.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/pathid.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/pathid.grpc.pb.h +) target_proto_addincls(core-scheme-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/scheme/protos/CMakeLists.darwin-x86_64.txt b/ydb/core/scheme/protos/CMakeLists.darwin-x86_64.txt index 0191fcd83372..5e4a2bfc10ad 100644 --- a/ydb/core/scheme/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/scheme/protos/CMakeLists.darwin-x86_64.txt @@ -64,6 +64,14 @@ target_proto_messages(core-scheme-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/scheme/protos/key_range.proto ${CMAKE_SOURCE_DIR}/ydb/core/scheme/protos/pathid.proto ) +target_sources(core-scheme-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/type_info.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/type_info.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/key_range.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/key_range.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/pathid.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/pathid.grpc.pb.h +) target_proto_addincls(core-scheme-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/scheme/protos/CMakeLists.linux-aarch64.txt b/ydb/core/scheme/protos/CMakeLists.linux-aarch64.txt index c8f537f77c45..c2ccd028ae93 100644 --- a/ydb/core/scheme/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/core/scheme/protos/CMakeLists.linux-aarch64.txt @@ -65,6 +65,14 @@ target_proto_messages(core-scheme-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/scheme/protos/key_range.proto ${CMAKE_SOURCE_DIR}/ydb/core/scheme/protos/pathid.proto ) +target_sources(core-scheme-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/type_info.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/type_info.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/key_range.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/key_range.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/pathid.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/pathid.grpc.pb.h +) target_proto_addincls(core-scheme-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/scheme/protos/CMakeLists.linux-x86_64.txt b/ydb/core/scheme/protos/CMakeLists.linux-x86_64.txt index c8f537f77c45..c2ccd028ae93 100644 --- a/ydb/core/scheme/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/core/scheme/protos/CMakeLists.linux-x86_64.txt @@ -65,6 +65,14 @@ target_proto_messages(core-scheme-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/scheme/protos/key_range.proto ${CMAKE_SOURCE_DIR}/ydb/core/scheme/protos/pathid.proto ) +target_sources(core-scheme-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/type_info.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/type_info.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/key_range.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/key_range.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/pathid.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/pathid.grpc.pb.h +) target_proto_addincls(core-scheme-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/scheme/protos/CMakeLists.windows-x86_64.txt b/ydb/core/scheme/protos/CMakeLists.windows-x86_64.txt index 0191fcd83372..5e4a2bfc10ad 100644 --- a/ydb/core/scheme/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/core/scheme/protos/CMakeLists.windows-x86_64.txt @@ -64,6 +64,14 @@ target_proto_messages(core-scheme-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/scheme/protos/key_range.proto ${CMAKE_SOURCE_DIR}/ydb/core/scheme/protos/pathid.proto ) +target_sources(core-scheme-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/type_info.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/type_info.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/key_range.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/key_range.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/pathid.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/scheme/protos/pathid.grpc.pb.h +) target_proto_addincls(core-scheme-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/scheme/ut/CMakeLists.darwin-arm64.txt b/ydb/core/scheme/ut/CMakeLists.darwin-arm64.txt index 603023a1a642..4adcf2e10ded 100644 --- a/ydb/core/scheme/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/scheme/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-scheme-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-scheme-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/scheme/scheme_borders_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/scheme/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/scheme/ut/CMakeLists.darwin-x86_64.txt index 6b2abd07fcdb..263358cb4407 100644 --- a/ydb/core/scheme/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/scheme/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-scheme-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-scheme-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/scheme/scheme_borders_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/scheme/ut/CMakeLists.linux-aarch64.txt b/ydb/core/scheme/ut/CMakeLists.linux-aarch64.txt index 4bac93ddfc7a..7b08279165ed 100644 --- a/ydb/core/scheme/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/scheme/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-scheme-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-scheme-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/scheme/scheme_borders_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/scheme/ut/CMakeLists.linux-x86_64.txt b/ydb/core/scheme/ut/CMakeLists.linux-x86_64.txt index 8f8e9fc1d8f4..1f6994162734 100644 --- a/ydb/core/scheme/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/scheme/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-scheme-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-scheme-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/scheme/scheme_borders_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/scheme/ut/CMakeLists.windows-x86_64.txt b/ydb/core/scheme/ut/CMakeLists.windows-x86_64.txt index 9e546a0dccae..a2cf47da1397 100644 --- a/ydb/core/scheme/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/scheme/ut/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/security/CMakeLists.darwin-arm64.txt b/ydb/core/security/CMakeLists.darwin-arm64.txt index 0f944354284a..0797517591de 100644 --- a/ydb/core/security/CMakeLists.darwin-arm64.txt +++ b/ydb/core/security/CMakeLists.darwin-arm64.txt @@ -27,6 +27,10 @@ target_link_libraries(ydb-core-security PUBLIC ydb-library-security ) target_sources(ydb-core-security PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/security/login_page.h + ${CMAKE_SOURCE_DIR}/ydb/core/security/secure_request.h + ${CMAKE_SOURCE_DIR}/ydb/core/security/ticket_parser_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/security/ticket_parser.h ${CMAKE_SOURCE_DIR}/ydb/core/security/login_page.cpp ${CMAKE_SOURCE_DIR}/ydb/core/security/login_shared_func.cpp ${CMAKE_SOURCE_DIR}/ydb/core/security/ticket_parser.cpp diff --git a/ydb/core/security/CMakeLists.darwin-x86_64.txt b/ydb/core/security/CMakeLists.darwin-x86_64.txt index 0f944354284a..0797517591de 100644 --- a/ydb/core/security/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/security/CMakeLists.darwin-x86_64.txt @@ -27,6 +27,10 @@ target_link_libraries(ydb-core-security PUBLIC ydb-library-security ) target_sources(ydb-core-security PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/security/login_page.h + ${CMAKE_SOURCE_DIR}/ydb/core/security/secure_request.h + ${CMAKE_SOURCE_DIR}/ydb/core/security/ticket_parser_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/security/ticket_parser.h ${CMAKE_SOURCE_DIR}/ydb/core/security/login_page.cpp ${CMAKE_SOURCE_DIR}/ydb/core/security/login_shared_func.cpp ${CMAKE_SOURCE_DIR}/ydb/core/security/ticket_parser.cpp diff --git a/ydb/core/security/CMakeLists.linux-aarch64.txt b/ydb/core/security/CMakeLists.linux-aarch64.txt index 07a1b95a48c5..f3c51958ddb6 100644 --- a/ydb/core/security/CMakeLists.linux-aarch64.txt +++ b/ydb/core/security/CMakeLists.linux-aarch64.txt @@ -28,6 +28,10 @@ target_link_libraries(ydb-core-security PUBLIC ydb-library-security ) target_sources(ydb-core-security PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/security/login_page.h + ${CMAKE_SOURCE_DIR}/ydb/core/security/secure_request.h + ${CMAKE_SOURCE_DIR}/ydb/core/security/ticket_parser_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/security/ticket_parser.h ${CMAKE_SOURCE_DIR}/ydb/core/security/login_page.cpp ${CMAKE_SOURCE_DIR}/ydb/core/security/login_shared_func.cpp ${CMAKE_SOURCE_DIR}/ydb/core/security/ticket_parser.cpp diff --git a/ydb/core/security/CMakeLists.linux-x86_64.txt b/ydb/core/security/CMakeLists.linux-x86_64.txt index 07a1b95a48c5..f3c51958ddb6 100644 --- a/ydb/core/security/CMakeLists.linux-x86_64.txt +++ b/ydb/core/security/CMakeLists.linux-x86_64.txt @@ -28,6 +28,10 @@ target_link_libraries(ydb-core-security PUBLIC ydb-library-security ) target_sources(ydb-core-security PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/security/login_page.h + ${CMAKE_SOURCE_DIR}/ydb/core/security/secure_request.h + ${CMAKE_SOURCE_DIR}/ydb/core/security/ticket_parser_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/security/ticket_parser.h ${CMAKE_SOURCE_DIR}/ydb/core/security/login_page.cpp ${CMAKE_SOURCE_DIR}/ydb/core/security/login_shared_func.cpp ${CMAKE_SOURCE_DIR}/ydb/core/security/ticket_parser.cpp diff --git a/ydb/core/security/CMakeLists.windows-x86_64.txt b/ydb/core/security/CMakeLists.windows-x86_64.txt index 531caa341e70..ba03c962beba 100644 --- a/ydb/core/security/CMakeLists.windows-x86_64.txt +++ b/ydb/core/security/CMakeLists.windows-x86_64.txt @@ -31,6 +31,10 @@ target_link_options(ydb-core-security INTERFACE -Wl,-Bdynamic ) target_sources(ydb-core-security PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/security/login_page.h + ${CMAKE_SOURCE_DIR}/ydb/core/security/secure_request.h + ${CMAKE_SOURCE_DIR}/ydb/core/security/ticket_parser_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/security/ticket_parser.h ${CMAKE_SOURCE_DIR}/ydb/core/security/login_page.cpp ${CMAKE_SOURCE_DIR}/ydb/core/security/login_shared_func.cpp ${CMAKE_SOURCE_DIR}/ydb/core/security/ticket_parser.cpp diff --git a/ydb/core/security/ut/CMakeLists.darwin-arm64.txt b/ydb/core/security/ut/CMakeLists.darwin-arm64.txt index d16e98dde380..e766776d24a2 100644 --- a/ydb/core/security/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/security/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-security-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-security-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/security/ticket_parser_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/security/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/security/ut/CMakeLists.darwin-x86_64.txt index d11e6e8b61ea..cebad89acc6c 100644 --- a/ydb/core/security/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/security/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-security-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-security-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/security/ticket_parser_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/security/ut/CMakeLists.linux-aarch64.txt b/ydb/core/security/ut/CMakeLists.linux-aarch64.txt index b6ce8a934667..b331a5c55c12 100644 --- a/ydb/core/security/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/security/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-security-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-security-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/security/ticket_parser_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/security/ut/CMakeLists.linux-x86_64.txt b/ydb/core/security/ut/CMakeLists.linux-x86_64.txt index b4529a02e319..be3152dfc89d 100644 --- a/ydb/core/security/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/security/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-security-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-security-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/security/ticket_parser_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/security/ut/CMakeLists.windows-x86_64.txt b/ydb/core/security/ut/CMakeLists.windows-x86_64.txt index 854de82b68d8..0268ca3c6ee5 100644 --- a/ydb/core/security/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/security/ut/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/statistics/CMakeLists.darwin-arm64.txt b/ydb/core/statistics/CMakeLists.darwin-arm64.txt index 7c3f7b142de2..1e8001aa995f 100644 --- a/ydb/core/statistics/CMakeLists.darwin-arm64.txt +++ b/ydb/core/statistics/CMakeLists.darwin-arm64.txt @@ -18,5 +18,7 @@ target_link_libraries(ydb-core-statistics PUBLIC ydb-core-scheme ) target_sources(ydb-core-statistics PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/stat_service.h ${CMAKE_SOURCE_DIR}/ydb/core/statistics/stat_service.cpp ) diff --git a/ydb/core/statistics/CMakeLists.darwin-x86_64.txt b/ydb/core/statistics/CMakeLists.darwin-x86_64.txt index 7c3f7b142de2..1e8001aa995f 100644 --- a/ydb/core/statistics/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/statistics/CMakeLists.darwin-x86_64.txt @@ -18,5 +18,7 @@ target_link_libraries(ydb-core-statistics PUBLIC ydb-core-scheme ) target_sources(ydb-core-statistics PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/stat_service.h ${CMAKE_SOURCE_DIR}/ydb/core/statistics/stat_service.cpp ) diff --git a/ydb/core/statistics/CMakeLists.linux-aarch64.txt b/ydb/core/statistics/CMakeLists.linux-aarch64.txt index 6cdf95956f7f..886916f54251 100644 --- a/ydb/core/statistics/CMakeLists.linux-aarch64.txt +++ b/ydb/core/statistics/CMakeLists.linux-aarch64.txt @@ -19,5 +19,7 @@ target_link_libraries(ydb-core-statistics PUBLIC ydb-core-scheme ) target_sources(ydb-core-statistics PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/stat_service.h ${CMAKE_SOURCE_DIR}/ydb/core/statistics/stat_service.cpp ) diff --git a/ydb/core/statistics/CMakeLists.linux-x86_64.txt b/ydb/core/statistics/CMakeLists.linux-x86_64.txt index 6cdf95956f7f..886916f54251 100644 --- a/ydb/core/statistics/CMakeLists.linux-x86_64.txt +++ b/ydb/core/statistics/CMakeLists.linux-x86_64.txt @@ -19,5 +19,7 @@ target_link_libraries(ydb-core-statistics PUBLIC ydb-core-scheme ) target_sources(ydb-core-statistics PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/stat_service.h ${CMAKE_SOURCE_DIR}/ydb/core/statistics/stat_service.cpp ) diff --git a/ydb/core/statistics/CMakeLists.windows-x86_64.txt b/ydb/core/statistics/CMakeLists.windows-x86_64.txt index 7c3f7b142de2..1e8001aa995f 100644 --- a/ydb/core/statistics/CMakeLists.windows-x86_64.txt +++ b/ydb/core/statistics/CMakeLists.windows-x86_64.txt @@ -18,5 +18,7 @@ target_link_libraries(ydb-core-statistics PUBLIC ydb-core-scheme ) target_sources(ydb-core-statistics PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/stat_service.h ${CMAKE_SOURCE_DIR}/ydb/core/statistics/stat_service.cpp ) diff --git a/ydb/core/statistics/aggregator/CMakeLists.darwin-arm64.txt b/ydb/core/statistics/aggregator/CMakeLists.darwin-arm64.txt index fe736bf693e3..1328ae69276e 100644 --- a/ydb/core/statistics/aggregator/CMakeLists.darwin-arm64.txt +++ b/ydb/core/statistics/aggregator/CMakeLists.darwin-arm64.txt @@ -21,10 +21,14 @@ target_link_libraries(core-statistics-aggregator PUBLIC ydb-core-tablet_flat ) target_sources(core-statistics-aggregator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/aggregator.h + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/aggregator_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/schema.h ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/aggregator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/aggregator_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/schema.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/tx_configure.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/tx_init.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/tx_init_schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/tx_schemeshard_stats.cpp ) diff --git a/ydb/core/statistics/aggregator/CMakeLists.darwin-x86_64.txt b/ydb/core/statistics/aggregator/CMakeLists.darwin-x86_64.txt index fe736bf693e3..1328ae69276e 100644 --- a/ydb/core/statistics/aggregator/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/statistics/aggregator/CMakeLists.darwin-x86_64.txt @@ -21,10 +21,14 @@ target_link_libraries(core-statistics-aggregator PUBLIC ydb-core-tablet_flat ) target_sources(core-statistics-aggregator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/aggregator.h + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/aggregator_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/schema.h ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/aggregator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/aggregator_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/schema.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/tx_configure.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/tx_init.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/tx_init_schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/tx_schemeshard_stats.cpp ) diff --git a/ydb/core/statistics/aggregator/CMakeLists.linux-aarch64.txt b/ydb/core/statistics/aggregator/CMakeLists.linux-aarch64.txt index 5b8294cd5909..1b9e0912b029 100644 --- a/ydb/core/statistics/aggregator/CMakeLists.linux-aarch64.txt +++ b/ydb/core/statistics/aggregator/CMakeLists.linux-aarch64.txt @@ -22,10 +22,14 @@ target_link_libraries(core-statistics-aggregator PUBLIC ydb-core-tablet_flat ) target_sources(core-statistics-aggregator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/aggregator.h + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/aggregator_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/schema.h ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/aggregator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/aggregator_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/schema.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/tx_configure.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/tx_init.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/tx_init_schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/tx_schemeshard_stats.cpp ) diff --git a/ydb/core/statistics/aggregator/CMakeLists.linux-x86_64.txt b/ydb/core/statistics/aggregator/CMakeLists.linux-x86_64.txt index 5b8294cd5909..1b9e0912b029 100644 --- a/ydb/core/statistics/aggregator/CMakeLists.linux-x86_64.txt +++ b/ydb/core/statistics/aggregator/CMakeLists.linux-x86_64.txt @@ -22,10 +22,14 @@ target_link_libraries(core-statistics-aggregator PUBLIC ydb-core-tablet_flat ) target_sources(core-statistics-aggregator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/aggregator.h + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/aggregator_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/schema.h ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/aggregator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/aggregator_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/schema.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/tx_configure.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/tx_init.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/tx_init_schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/tx_schemeshard_stats.cpp ) diff --git a/ydb/core/statistics/aggregator/CMakeLists.windows-x86_64.txt b/ydb/core/statistics/aggregator/CMakeLists.windows-x86_64.txt index fe736bf693e3..1328ae69276e 100644 --- a/ydb/core/statistics/aggregator/CMakeLists.windows-x86_64.txt +++ b/ydb/core/statistics/aggregator/CMakeLists.windows-x86_64.txt @@ -21,10 +21,14 @@ target_link_libraries(core-statistics-aggregator PUBLIC ydb-core-tablet_flat ) target_sources(core-statistics-aggregator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/aggregator.h + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/aggregator_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/schema.h ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/aggregator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/aggregator_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/schema.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/tx_configure.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/tx_init.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/tx_init_schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/aggregator/tx_schemeshard_stats.cpp ) diff --git a/ydb/core/statistics/ut/CMakeLists.darwin-arm64.txt b/ydb/core/statistics/ut/CMakeLists.darwin-arm64.txt index 89362fbe8d0e..42fe197fe370 100644 --- a/ydb/core/statistics/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/statistics/ut/CMakeLists.darwin-arm64.txt @@ -26,10 +26,9 @@ target_link_options(ydb-core-statistics-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-statistics-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/ut/ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/statistics/ut/ut_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/ut/ut_statistics.cpp ) @@ -58,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/statistics/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/statistics/ut/CMakeLists.darwin-x86_64.txt index 43701cc1d001..d56c6feb5598 100644 --- a/ydb/core/statistics/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/statistics/ut/CMakeLists.darwin-x86_64.txt @@ -27,10 +27,9 @@ target_link_options(ydb-core-statistics-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-statistics-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/ut/ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/statistics/ut/ut_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/ut/ut_statistics.cpp ) @@ -59,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/statistics/ut/CMakeLists.linux-aarch64.txt b/ydb/core/statistics/ut/CMakeLists.linux-aarch64.txt index 271cc0e38498..8115fd2d3810 100644 --- a/ydb/core/statistics/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/statistics/ut/CMakeLists.linux-aarch64.txt @@ -29,11 +29,9 @@ target_link_options(ydb-core-statistics-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-statistics-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/ut/ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/statistics/ut/ut_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/ut/ut_statistics.cpp ) @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/statistics/ut/CMakeLists.linux-x86_64.txt b/ydb/core/statistics/ut/CMakeLists.linux-x86_64.txt index 2c59ef260b94..9fcc48d5e176 100644 --- a/ydb/core/statistics/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/statistics/ut/CMakeLists.linux-x86_64.txt @@ -30,11 +30,9 @@ target_link_options(ydb-core-statistics-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-statistics-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/ut/ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/statistics/ut/ut_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/ut/ut_statistics.cpp ) @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/statistics/ut/CMakeLists.windows-x86_64.txt b/ydb/core/statistics/ut/CMakeLists.windows-x86_64.txt index 521755982cfe..5ade7e71de87 100644 --- a/ydb/core/statistics/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/statistics/ut/CMakeLists.windows-x86_64.txt @@ -24,6 +24,7 @@ target_link_libraries(ydb-core-statistics-ut PUBLIC core-testlib-default ) target_sources(ydb-core-statistics-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/statistics/ut/ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/statistics/ut/ut_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/statistics/ut/ut_statistics.cpp ) @@ -52,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/sys_view/CMakeLists.darwin-arm64.txt b/ydb/core/sys_view/CMakeLists.darwin-arm64.txt index 79cb54391a44..8189b7c78f17 100644 --- a/ydb/core/sys_view/CMakeLists.darwin-arm64.txt +++ b/ydb/core/sys_view/CMakeLists.darwin-arm64.txt @@ -34,5 +34,6 @@ target_link_libraries(ydb-core-sys_view PUBLIC core-sys_view-tablets ) target_sources(ydb-core-sys_view PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/scan.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/scan.cpp ) diff --git a/ydb/core/sys_view/CMakeLists.darwin-x86_64.txt b/ydb/core/sys_view/CMakeLists.darwin-x86_64.txt index 79cb54391a44..8189b7c78f17 100644 --- a/ydb/core/sys_view/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/sys_view/CMakeLists.darwin-x86_64.txt @@ -34,5 +34,6 @@ target_link_libraries(ydb-core-sys_view PUBLIC core-sys_view-tablets ) target_sources(ydb-core-sys_view PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/scan.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/scan.cpp ) diff --git a/ydb/core/sys_view/CMakeLists.linux-aarch64.txt b/ydb/core/sys_view/CMakeLists.linux-aarch64.txt index b8c03c3cd724..b9e1fc6e2b5e 100644 --- a/ydb/core/sys_view/CMakeLists.linux-aarch64.txt +++ b/ydb/core/sys_view/CMakeLists.linux-aarch64.txt @@ -35,5 +35,6 @@ target_link_libraries(ydb-core-sys_view PUBLIC core-sys_view-tablets ) target_sources(ydb-core-sys_view PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/scan.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/scan.cpp ) diff --git a/ydb/core/sys_view/CMakeLists.linux-x86_64.txt b/ydb/core/sys_view/CMakeLists.linux-x86_64.txt index b8c03c3cd724..b9e1fc6e2b5e 100644 --- a/ydb/core/sys_view/CMakeLists.linux-x86_64.txt +++ b/ydb/core/sys_view/CMakeLists.linux-x86_64.txt @@ -35,5 +35,6 @@ target_link_libraries(ydb-core-sys_view PUBLIC core-sys_view-tablets ) target_sources(ydb-core-sys_view PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/scan.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/scan.cpp ) diff --git a/ydb/core/sys_view/CMakeLists.windows-x86_64.txt b/ydb/core/sys_view/CMakeLists.windows-x86_64.txt index 79cb54391a44..8189b7c78f17 100644 --- a/ydb/core/sys_view/CMakeLists.windows-x86_64.txt +++ b/ydb/core/sys_view/CMakeLists.windows-x86_64.txt @@ -34,5 +34,6 @@ target_link_libraries(ydb-core-sys_view PUBLIC core-sys_view-tablets ) target_sources(ydb-core-sys_view PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/scan.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/scan.cpp ) diff --git a/ydb/core/sys_view/common/CMakeLists.darwin-arm64.txt b/ydb/core/sys_view/common/CMakeLists.darwin-arm64.txt index a8737ef5d537..ecaab58d570f 100644 --- a/ydb/core/sys_view/common/CMakeLists.darwin-arm64.txt +++ b/ydb/core/sys_view/common/CMakeLists.darwin-arm64.txt @@ -18,5 +18,13 @@ target_link_libraries(core-sys_view-common PUBLIC cpp-deprecated-atomic ) target_sources(core-sys_view-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/common.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/keys.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/path.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/scan_actor_base_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/utils.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/processor_scan.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/schema.cpp ) diff --git a/ydb/core/sys_view/common/CMakeLists.darwin-x86_64.txt b/ydb/core/sys_view/common/CMakeLists.darwin-x86_64.txt index a8737ef5d537..ecaab58d570f 100644 --- a/ydb/core/sys_view/common/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/sys_view/common/CMakeLists.darwin-x86_64.txt @@ -18,5 +18,13 @@ target_link_libraries(core-sys_view-common PUBLIC cpp-deprecated-atomic ) target_sources(core-sys_view-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/common.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/keys.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/path.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/scan_actor_base_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/utils.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/processor_scan.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/schema.cpp ) diff --git a/ydb/core/sys_view/common/CMakeLists.linux-aarch64.txt b/ydb/core/sys_view/common/CMakeLists.linux-aarch64.txt index 52ede2b3a125..c6e83fae95a8 100644 --- a/ydb/core/sys_view/common/CMakeLists.linux-aarch64.txt +++ b/ydb/core/sys_view/common/CMakeLists.linux-aarch64.txt @@ -19,5 +19,13 @@ target_link_libraries(core-sys_view-common PUBLIC cpp-deprecated-atomic ) target_sources(core-sys_view-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/common.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/keys.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/path.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/scan_actor_base_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/utils.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/processor_scan.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/schema.cpp ) diff --git a/ydb/core/sys_view/common/CMakeLists.linux-x86_64.txt b/ydb/core/sys_view/common/CMakeLists.linux-x86_64.txt index 52ede2b3a125..c6e83fae95a8 100644 --- a/ydb/core/sys_view/common/CMakeLists.linux-x86_64.txt +++ b/ydb/core/sys_view/common/CMakeLists.linux-x86_64.txt @@ -19,5 +19,13 @@ target_link_libraries(core-sys_view-common PUBLIC cpp-deprecated-atomic ) target_sources(core-sys_view-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/common.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/keys.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/path.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/scan_actor_base_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/utils.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/processor_scan.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/schema.cpp ) diff --git a/ydb/core/sys_view/common/CMakeLists.windows-x86_64.txt b/ydb/core/sys_view/common/CMakeLists.windows-x86_64.txt index a8737ef5d537..ecaab58d570f 100644 --- a/ydb/core/sys_view/common/CMakeLists.windows-x86_64.txt +++ b/ydb/core/sys_view/common/CMakeLists.windows-x86_64.txt @@ -18,5 +18,13 @@ target_link_libraries(core-sys_view-common PUBLIC cpp-deprecated-atomic ) target_sources(core-sys_view-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/common.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/keys.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/path.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/scan_actor_base_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/utils.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/processor_scan.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/common/schema.cpp ) diff --git a/ydb/core/sys_view/nodes/CMakeLists.darwin-arm64.txt b/ydb/core/sys_view/nodes/CMakeLists.darwin-arm64.txt index 3bce0c0e8b8d..6f472f28b3f3 100644 --- a/ydb/core/sys_view/nodes/CMakeLists.darwin-arm64.txt +++ b/ydb/core/sys_view/nodes/CMakeLists.darwin-arm64.txt @@ -20,5 +20,6 @@ target_link_libraries(core-sys_view-nodes PUBLIC core-sys_view-common ) target_sources(core-sys_view-nodes PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/nodes/nodes.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/nodes/nodes.cpp ) diff --git a/ydb/core/sys_view/nodes/CMakeLists.darwin-x86_64.txt b/ydb/core/sys_view/nodes/CMakeLists.darwin-x86_64.txt index 3bce0c0e8b8d..6f472f28b3f3 100644 --- a/ydb/core/sys_view/nodes/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/sys_view/nodes/CMakeLists.darwin-x86_64.txt @@ -20,5 +20,6 @@ target_link_libraries(core-sys_view-nodes PUBLIC core-sys_view-common ) target_sources(core-sys_view-nodes PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/nodes/nodes.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/nodes/nodes.cpp ) diff --git a/ydb/core/sys_view/nodes/CMakeLists.linux-aarch64.txt b/ydb/core/sys_view/nodes/CMakeLists.linux-aarch64.txt index 6f8c33fe300a..ba2c544383fd 100644 --- a/ydb/core/sys_view/nodes/CMakeLists.linux-aarch64.txt +++ b/ydb/core/sys_view/nodes/CMakeLists.linux-aarch64.txt @@ -21,5 +21,6 @@ target_link_libraries(core-sys_view-nodes PUBLIC core-sys_view-common ) target_sources(core-sys_view-nodes PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/nodes/nodes.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/nodes/nodes.cpp ) diff --git a/ydb/core/sys_view/nodes/CMakeLists.linux-x86_64.txt b/ydb/core/sys_view/nodes/CMakeLists.linux-x86_64.txt index 6f8c33fe300a..ba2c544383fd 100644 --- a/ydb/core/sys_view/nodes/CMakeLists.linux-x86_64.txt +++ b/ydb/core/sys_view/nodes/CMakeLists.linux-x86_64.txt @@ -21,5 +21,6 @@ target_link_libraries(core-sys_view-nodes PUBLIC core-sys_view-common ) target_sources(core-sys_view-nodes PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/nodes/nodes.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/nodes/nodes.cpp ) diff --git a/ydb/core/sys_view/nodes/CMakeLists.windows-x86_64.txt b/ydb/core/sys_view/nodes/CMakeLists.windows-x86_64.txt index 3bce0c0e8b8d..6f472f28b3f3 100644 --- a/ydb/core/sys_view/nodes/CMakeLists.windows-x86_64.txt +++ b/ydb/core/sys_view/nodes/CMakeLists.windows-x86_64.txt @@ -20,5 +20,6 @@ target_link_libraries(core-sys_view-nodes PUBLIC core-sys_view-common ) target_sources(core-sys_view-nodes PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/nodes/nodes.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/nodes/nodes.cpp ) diff --git a/ydb/core/sys_view/partition_stats/CMakeLists.darwin-arm64.txt b/ydb/core/sys_view/partition_stats/CMakeLists.darwin-arm64.txt index a42808d784e2..024628e1ac88 100644 --- a/ydb/core/sys_view/partition_stats/CMakeLists.darwin-arm64.txt +++ b/ydb/core/sys_view/partition_stats/CMakeLists.darwin-arm64.txt @@ -21,6 +21,8 @@ target_link_libraries(core-sys_view-partition_stats PUBLIC core-sys_view-common ) target_sources(core-sys_view-partition_stats PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/partition_stats.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/top_partitions.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/partition_stats.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/top_partitions.cpp ) diff --git a/ydb/core/sys_view/partition_stats/CMakeLists.darwin-x86_64.txt b/ydb/core/sys_view/partition_stats/CMakeLists.darwin-x86_64.txt index a42808d784e2..024628e1ac88 100644 --- a/ydb/core/sys_view/partition_stats/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/sys_view/partition_stats/CMakeLists.darwin-x86_64.txt @@ -21,6 +21,8 @@ target_link_libraries(core-sys_view-partition_stats PUBLIC core-sys_view-common ) target_sources(core-sys_view-partition_stats PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/partition_stats.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/top_partitions.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/partition_stats.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/top_partitions.cpp ) diff --git a/ydb/core/sys_view/partition_stats/CMakeLists.linux-aarch64.txt b/ydb/core/sys_view/partition_stats/CMakeLists.linux-aarch64.txt index 120505a82732..c6149cffd8a1 100644 --- a/ydb/core/sys_view/partition_stats/CMakeLists.linux-aarch64.txt +++ b/ydb/core/sys_view/partition_stats/CMakeLists.linux-aarch64.txt @@ -22,6 +22,8 @@ target_link_libraries(core-sys_view-partition_stats PUBLIC core-sys_view-common ) target_sources(core-sys_view-partition_stats PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/partition_stats.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/top_partitions.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/partition_stats.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/top_partitions.cpp ) diff --git a/ydb/core/sys_view/partition_stats/CMakeLists.linux-x86_64.txt b/ydb/core/sys_view/partition_stats/CMakeLists.linux-x86_64.txt index 120505a82732..c6149cffd8a1 100644 --- a/ydb/core/sys_view/partition_stats/CMakeLists.linux-x86_64.txt +++ b/ydb/core/sys_view/partition_stats/CMakeLists.linux-x86_64.txt @@ -22,6 +22,8 @@ target_link_libraries(core-sys_view-partition_stats PUBLIC core-sys_view-common ) target_sources(core-sys_view-partition_stats PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/partition_stats.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/top_partitions.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/partition_stats.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/top_partitions.cpp ) diff --git a/ydb/core/sys_view/partition_stats/CMakeLists.windows-x86_64.txt b/ydb/core/sys_view/partition_stats/CMakeLists.windows-x86_64.txt index a42808d784e2..024628e1ac88 100644 --- a/ydb/core/sys_view/partition_stats/CMakeLists.windows-x86_64.txt +++ b/ydb/core/sys_view/partition_stats/CMakeLists.windows-x86_64.txt @@ -21,6 +21,8 @@ target_link_libraries(core-sys_view-partition_stats PUBLIC core-sys_view-common ) target_sources(core-sys_view-partition_stats PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/partition_stats.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/top_partitions.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/partition_stats.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/top_partitions.cpp ) diff --git a/ydb/core/sys_view/partition_stats/ut/CMakeLists.darwin-arm64.txt b/ydb/core/sys_view/partition_stats/ut/CMakeLists.darwin-arm64.txt index 352c30294533..fafd97cd6117 100644 --- a/ydb/core/sys_view/partition_stats/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/sys_view/partition_stats/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-sys_view-partition_stats-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-sys_view-partition_stats-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/partition_stats_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/sys_view/partition_stats/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/sys_view/partition_stats/ut/CMakeLists.darwin-x86_64.txt index a8cecba9db1a..b53b87641509 100644 --- a/ydb/core/sys_view/partition_stats/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/sys_view/partition_stats/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-sys_view-partition_stats-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-sys_view-partition_stats-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/partition_stats_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/sys_view/partition_stats/ut/CMakeLists.linux-aarch64.txt b/ydb/core/sys_view/partition_stats/ut/CMakeLists.linux-aarch64.txt index 63ae273da7f5..6099b1377e0b 100644 --- a/ydb/core/sys_view/partition_stats/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/sys_view/partition_stats/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-sys_view-partition_stats-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-sys_view-partition_stats-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/partition_stats_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/sys_view/partition_stats/ut/CMakeLists.linux-x86_64.txt b/ydb/core/sys_view/partition_stats/ut/CMakeLists.linux-x86_64.txt index ac0db6a41671..3d1fd19c14b5 100644 --- a/ydb/core/sys_view/partition_stats/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/sys_view/partition_stats/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-sys_view-partition_stats-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-sys_view-partition_stats-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/partition_stats/partition_stats_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/sys_view/partition_stats/ut/CMakeLists.windows-x86_64.txt b/ydb/core/sys_view/partition_stats/ut/CMakeLists.windows-x86_64.txt index 8f8fd615fb20..2b37b74ebf1a 100644 --- a/ydb/core/sys_view/partition_stats/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/sys_view/partition_stats/ut/CMakeLists.windows-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/sys_view/processor/CMakeLists.darwin-arm64.txt b/ydb/core/sys_view/processor/CMakeLists.darwin-arm64.txt index 1416bcdbe8de..b2ab3d15fea5 100644 --- a/ydb/core/sys_view/processor/CMakeLists.darwin-arm64.txt +++ b/ydb/core/sys_view/processor/CMakeLists.darwin-arm64.txt @@ -24,6 +24,9 @@ target_link_libraries(core-sys_view-processor PUBLIC core-tx-scheme_cache ) target_sources(core-sys_view-processor PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/processor.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/processor_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/schema.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/processor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/processor_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/schema.cpp diff --git a/ydb/core/sys_view/processor/CMakeLists.darwin-x86_64.txt b/ydb/core/sys_view/processor/CMakeLists.darwin-x86_64.txt index 1416bcdbe8de..b2ab3d15fea5 100644 --- a/ydb/core/sys_view/processor/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/sys_view/processor/CMakeLists.darwin-x86_64.txt @@ -24,6 +24,9 @@ target_link_libraries(core-sys_view-processor PUBLIC core-tx-scheme_cache ) target_sources(core-sys_view-processor PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/processor.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/processor_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/schema.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/processor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/processor_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/schema.cpp diff --git a/ydb/core/sys_view/processor/CMakeLists.linux-aarch64.txt b/ydb/core/sys_view/processor/CMakeLists.linux-aarch64.txt index aa745310f911..b3fc9b6346c6 100644 --- a/ydb/core/sys_view/processor/CMakeLists.linux-aarch64.txt +++ b/ydb/core/sys_view/processor/CMakeLists.linux-aarch64.txt @@ -25,6 +25,9 @@ target_link_libraries(core-sys_view-processor PUBLIC core-tx-scheme_cache ) target_sources(core-sys_view-processor PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/processor.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/processor_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/schema.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/processor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/processor_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/schema.cpp diff --git a/ydb/core/sys_view/processor/CMakeLists.linux-x86_64.txt b/ydb/core/sys_view/processor/CMakeLists.linux-x86_64.txt index aa745310f911..b3fc9b6346c6 100644 --- a/ydb/core/sys_view/processor/CMakeLists.linux-x86_64.txt +++ b/ydb/core/sys_view/processor/CMakeLists.linux-x86_64.txt @@ -25,6 +25,9 @@ target_link_libraries(core-sys_view-processor PUBLIC core-tx-scheme_cache ) target_sources(core-sys_view-processor PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/processor.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/processor_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/schema.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/processor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/processor_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/schema.cpp diff --git a/ydb/core/sys_view/processor/CMakeLists.windows-x86_64.txt b/ydb/core/sys_view/processor/CMakeLists.windows-x86_64.txt index 1416bcdbe8de..b2ab3d15fea5 100644 --- a/ydb/core/sys_view/processor/CMakeLists.windows-x86_64.txt +++ b/ydb/core/sys_view/processor/CMakeLists.windows-x86_64.txt @@ -24,6 +24,9 @@ target_link_libraries(core-sys_view-processor PUBLIC core-tx-scheme_cache ) target_sources(core-sys_view-processor PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/processor.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/processor_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/schema.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/processor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/processor_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/processor/schema.cpp diff --git a/ydb/core/sys_view/query_stats/CMakeLists.darwin-arm64.txt b/ydb/core/sys_view/query_stats/CMakeLists.darwin-arm64.txt index e770f8445cbb..c98f8a9826de 100644 --- a/ydb/core/sys_view/query_stats/CMakeLists.darwin-arm64.txt +++ b/ydb/core/sys_view/query_stats/CMakeLists.darwin-arm64.txt @@ -22,6 +22,8 @@ target_link_libraries(core-sys_view-query_stats PUBLIC core-sys_view-service ) target_sources(core-sys_view-query_stats PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_metrics.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_stats.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_metrics.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_stats.cpp ) diff --git a/ydb/core/sys_view/query_stats/CMakeLists.darwin-x86_64.txt b/ydb/core/sys_view/query_stats/CMakeLists.darwin-x86_64.txt index e770f8445cbb..c98f8a9826de 100644 --- a/ydb/core/sys_view/query_stats/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/sys_view/query_stats/CMakeLists.darwin-x86_64.txt @@ -22,6 +22,8 @@ target_link_libraries(core-sys_view-query_stats PUBLIC core-sys_view-service ) target_sources(core-sys_view-query_stats PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_metrics.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_stats.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_metrics.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_stats.cpp ) diff --git a/ydb/core/sys_view/query_stats/CMakeLists.linux-aarch64.txt b/ydb/core/sys_view/query_stats/CMakeLists.linux-aarch64.txt index 7ad392e641bb..8990143f46c3 100644 --- a/ydb/core/sys_view/query_stats/CMakeLists.linux-aarch64.txt +++ b/ydb/core/sys_view/query_stats/CMakeLists.linux-aarch64.txt @@ -23,6 +23,8 @@ target_link_libraries(core-sys_view-query_stats PUBLIC core-sys_view-service ) target_sources(core-sys_view-query_stats PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_metrics.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_stats.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_metrics.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_stats.cpp ) diff --git a/ydb/core/sys_view/query_stats/CMakeLists.linux-x86_64.txt b/ydb/core/sys_view/query_stats/CMakeLists.linux-x86_64.txt index 7ad392e641bb..8990143f46c3 100644 --- a/ydb/core/sys_view/query_stats/CMakeLists.linux-x86_64.txt +++ b/ydb/core/sys_view/query_stats/CMakeLists.linux-x86_64.txt @@ -23,6 +23,8 @@ target_link_libraries(core-sys_view-query_stats PUBLIC core-sys_view-service ) target_sources(core-sys_view-query_stats PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_metrics.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_stats.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_metrics.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_stats.cpp ) diff --git a/ydb/core/sys_view/query_stats/CMakeLists.windows-x86_64.txt b/ydb/core/sys_view/query_stats/CMakeLists.windows-x86_64.txt index e770f8445cbb..c98f8a9826de 100644 --- a/ydb/core/sys_view/query_stats/CMakeLists.windows-x86_64.txt +++ b/ydb/core/sys_view/query_stats/CMakeLists.windows-x86_64.txt @@ -22,6 +22,8 @@ target_link_libraries(core-sys_view-query_stats PUBLIC core-sys_view-service ) target_sources(core-sys_view-query_stats PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_metrics.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_stats.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_metrics.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_stats.cpp ) diff --git a/ydb/core/sys_view/query_stats/ut/CMakeLists.darwin-arm64.txt b/ydb/core/sys_view/query_stats/ut/CMakeLists.darwin-arm64.txt index c117eb4d241c..06af818741f7 100644 --- a/ydb/core/sys_view/query_stats/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/sys_view/query_stats/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-sys_view-query_stats-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-sys_view-query_stats-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_stats_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/sys_view/query_stats/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/sys_view/query_stats/ut/CMakeLists.darwin-x86_64.txt index 531926a0a791..2951a02c0547 100644 --- a/ydb/core/sys_view/query_stats/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/sys_view/query_stats/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-sys_view-query_stats-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-sys_view-query_stats-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_stats_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/sys_view/query_stats/ut/CMakeLists.linux-aarch64.txt b/ydb/core/sys_view/query_stats/ut/CMakeLists.linux-aarch64.txt index d4447465b8e1..59b337841c6d 100644 --- a/ydb/core/sys_view/query_stats/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/sys_view/query_stats/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-sys_view-query_stats-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-sys_view-query_stats-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_stats_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/sys_view/query_stats/ut/CMakeLists.linux-x86_64.txt b/ydb/core/sys_view/query_stats/ut/CMakeLists.linux-x86_64.txt index 60407dae0b93..1d02893f1d1c 100644 --- a/ydb/core/sys_view/query_stats/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/sys_view/query_stats/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-sys_view-query_stats-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-sys_view-query_stats-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/query_stats/query_stats_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/sys_view/query_stats/ut/CMakeLists.windows-x86_64.txt b/ydb/core/sys_view/query_stats/ut/CMakeLists.windows-x86_64.txt index 4d3a2ec8f7b7..e04a86875c9f 100644 --- a/ydb/core/sys_view/query_stats/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/sys_view/query_stats/ut/CMakeLists.windows-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/sys_view/service/CMakeLists.darwin-arm64.txt b/ydb/core/sys_view/service/CMakeLists.darwin-arm64.txt index 7a1438743919..32fa5a7ff3a9 100644 --- a/ydb/core/sys_view/service/CMakeLists.darwin-arm64.txt +++ b/ydb/core/sys_view/service/CMakeLists.darwin-arm64.txt @@ -15,9 +15,16 @@ target_link_libraries(core-sys_view-service PUBLIC library-actors-core ydb-core-base ydb-core-protos + core-graph-api + core-graph-service library-aclib-protos ) target_sources(core-sys_view-service PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/db_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/ext_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/query_history.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/query_interval.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/sysview_service.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/db_counters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/ext_counters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/query_interval.cpp diff --git a/ydb/core/sys_view/service/CMakeLists.darwin-x86_64.txt b/ydb/core/sys_view/service/CMakeLists.darwin-x86_64.txt index 7a1438743919..32fa5a7ff3a9 100644 --- a/ydb/core/sys_view/service/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/sys_view/service/CMakeLists.darwin-x86_64.txt @@ -15,9 +15,16 @@ target_link_libraries(core-sys_view-service PUBLIC library-actors-core ydb-core-base ydb-core-protos + core-graph-api + core-graph-service library-aclib-protos ) target_sources(core-sys_view-service PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/db_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/ext_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/query_history.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/query_interval.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/sysview_service.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/db_counters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/ext_counters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/query_interval.cpp diff --git a/ydb/core/sys_view/service/CMakeLists.linux-aarch64.txt b/ydb/core/sys_view/service/CMakeLists.linux-aarch64.txt index 38c72e1030db..d3ad9ad55fb9 100644 --- a/ydb/core/sys_view/service/CMakeLists.linux-aarch64.txt +++ b/ydb/core/sys_view/service/CMakeLists.linux-aarch64.txt @@ -16,9 +16,16 @@ target_link_libraries(core-sys_view-service PUBLIC library-actors-core ydb-core-base ydb-core-protos + core-graph-api + core-graph-service library-aclib-protos ) target_sources(core-sys_view-service PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/db_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/ext_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/query_history.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/query_interval.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/sysview_service.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/db_counters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/ext_counters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/query_interval.cpp diff --git a/ydb/core/sys_view/service/CMakeLists.linux-x86_64.txt b/ydb/core/sys_view/service/CMakeLists.linux-x86_64.txt index 38c72e1030db..d3ad9ad55fb9 100644 --- a/ydb/core/sys_view/service/CMakeLists.linux-x86_64.txt +++ b/ydb/core/sys_view/service/CMakeLists.linux-x86_64.txt @@ -16,9 +16,16 @@ target_link_libraries(core-sys_view-service PUBLIC library-actors-core ydb-core-base ydb-core-protos + core-graph-api + core-graph-service library-aclib-protos ) target_sources(core-sys_view-service PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/db_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/ext_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/query_history.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/query_interval.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/sysview_service.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/db_counters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/ext_counters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/query_interval.cpp diff --git a/ydb/core/sys_view/service/CMakeLists.windows-x86_64.txt b/ydb/core/sys_view/service/CMakeLists.windows-x86_64.txt index 7a1438743919..32fa5a7ff3a9 100644 --- a/ydb/core/sys_view/service/CMakeLists.windows-x86_64.txt +++ b/ydb/core/sys_view/service/CMakeLists.windows-x86_64.txt @@ -15,9 +15,16 @@ target_link_libraries(core-sys_view-service PUBLIC library-actors-core ydb-core-base ydb-core-protos + core-graph-api + core-graph-service library-aclib-protos ) target_sources(core-sys_view-service PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/db_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/ext_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/query_history.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/query_interval.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/sysview_service.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/db_counters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/ext_counters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/query_interval.cpp diff --git a/ydb/core/sys_view/service/ut/CMakeLists.darwin-arm64.txt b/ydb/core/sys_view/service/ut/CMakeLists.darwin-arm64.txt index 2977856841e9..177d0c748a4f 100644 --- a/ydb/core/sys_view/service/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/sys_view/service/ut/CMakeLists.darwin-arm64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-core-sys_view-service-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-sys_view-service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/query_history_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/sys_view/service/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/sys_view/service/ut/CMakeLists.darwin-x86_64.txt index 481cfefbddfd..a0352a8dca2c 100644 --- a/ydb/core/sys_view/service/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/sys_view/service/ut/CMakeLists.darwin-x86_64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-core-sys_view-service-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-sys_view-service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/query_history_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/sys_view/service/ut/CMakeLists.linux-aarch64.txt b/ydb/core/sys_view/service/ut/CMakeLists.linux-aarch64.txt index 347b7e3bf6d0..d10be56887c6 100644 --- a/ydb/core/sys_view/service/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/sys_view/service/ut/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-core-sys_view-service-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-sys_view-service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/query_history_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/sys_view/service/ut/CMakeLists.linux-x86_64.txt b/ydb/core/sys_view/service/ut/CMakeLists.linux-x86_64.txt index 0d606eaa98ee..9f229634f268 100644 --- a/ydb/core/sys_view/service/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/sys_view/service/ut/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-core-sys_view-service-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-sys_view-service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/service/query_history_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/sys_view/service/ut/CMakeLists.windows-x86_64.txt b/ydb/core/sys_view/service/ut/CMakeLists.windows-x86_64.txt index 17272ade88a9..d3ed9f89e03d 100644 --- a/ydb/core/sys_view/service/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/sys_view/service/ut/CMakeLists.windows-x86_64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/sys_view/storage/CMakeLists.darwin-arm64.txt b/ydb/core/sys_view/storage/CMakeLists.darwin-arm64.txt index 7604f2d0b843..f3fb76c355ba 100644 --- a/ydb/core/sys_view/storage/CMakeLists.darwin-arm64.txt +++ b/ydb/core/sys_view/storage/CMakeLists.darwin-arm64.txt @@ -20,6 +20,11 @@ target_link_libraries(core-sys_view-storage PUBLIC core-sys_view-common ) target_sources(core-sys_view-storage PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/groups.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/pdisks.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/storage_pools.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/storage_stats.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/vslots.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/groups.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/pdisks.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/storage_pools.cpp diff --git a/ydb/core/sys_view/storage/CMakeLists.darwin-x86_64.txt b/ydb/core/sys_view/storage/CMakeLists.darwin-x86_64.txt index 7604f2d0b843..f3fb76c355ba 100644 --- a/ydb/core/sys_view/storage/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/sys_view/storage/CMakeLists.darwin-x86_64.txt @@ -20,6 +20,11 @@ target_link_libraries(core-sys_view-storage PUBLIC core-sys_view-common ) target_sources(core-sys_view-storage PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/groups.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/pdisks.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/storage_pools.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/storage_stats.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/vslots.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/groups.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/pdisks.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/storage_pools.cpp diff --git a/ydb/core/sys_view/storage/CMakeLists.linux-aarch64.txt b/ydb/core/sys_view/storage/CMakeLists.linux-aarch64.txt index 00cc264e8463..da16dc2e0e8f 100644 --- a/ydb/core/sys_view/storage/CMakeLists.linux-aarch64.txt +++ b/ydb/core/sys_view/storage/CMakeLists.linux-aarch64.txt @@ -21,6 +21,11 @@ target_link_libraries(core-sys_view-storage PUBLIC core-sys_view-common ) target_sources(core-sys_view-storage PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/groups.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/pdisks.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/storage_pools.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/storage_stats.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/vslots.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/groups.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/pdisks.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/storage_pools.cpp diff --git a/ydb/core/sys_view/storage/CMakeLists.linux-x86_64.txt b/ydb/core/sys_view/storage/CMakeLists.linux-x86_64.txt index 00cc264e8463..da16dc2e0e8f 100644 --- a/ydb/core/sys_view/storage/CMakeLists.linux-x86_64.txt +++ b/ydb/core/sys_view/storage/CMakeLists.linux-x86_64.txt @@ -21,6 +21,11 @@ target_link_libraries(core-sys_view-storage PUBLIC core-sys_view-common ) target_sources(core-sys_view-storage PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/groups.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/pdisks.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/storage_pools.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/storage_stats.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/vslots.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/groups.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/pdisks.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/storage_pools.cpp diff --git a/ydb/core/sys_view/storage/CMakeLists.windows-x86_64.txt b/ydb/core/sys_view/storage/CMakeLists.windows-x86_64.txt index 7604f2d0b843..f3fb76c355ba 100644 --- a/ydb/core/sys_view/storage/CMakeLists.windows-x86_64.txt +++ b/ydb/core/sys_view/storage/CMakeLists.windows-x86_64.txt @@ -20,6 +20,11 @@ target_link_libraries(core-sys_view-storage PUBLIC core-sys_view-common ) target_sources(core-sys_view-storage PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/groups.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/pdisks.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/storage_pools.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/storage_stats.h + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/vslots.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/groups.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/pdisks.cpp ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/storage/storage_pools.cpp diff --git a/ydb/core/sys_view/tablets/CMakeLists.darwin-arm64.txt b/ydb/core/sys_view/tablets/CMakeLists.darwin-arm64.txt index 681f82119654..bf3c08eef02f 100644 --- a/ydb/core/sys_view/tablets/CMakeLists.darwin-arm64.txt +++ b/ydb/core/sys_view/tablets/CMakeLists.darwin-arm64.txt @@ -20,5 +20,6 @@ target_link_libraries(core-sys_view-tablets PUBLIC core-sys_view-common ) target_sources(core-sys_view-tablets PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/tablets/tablets.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/tablets/tablets.cpp ) diff --git a/ydb/core/sys_view/tablets/CMakeLists.darwin-x86_64.txt b/ydb/core/sys_view/tablets/CMakeLists.darwin-x86_64.txt index 681f82119654..bf3c08eef02f 100644 --- a/ydb/core/sys_view/tablets/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/sys_view/tablets/CMakeLists.darwin-x86_64.txt @@ -20,5 +20,6 @@ target_link_libraries(core-sys_view-tablets PUBLIC core-sys_view-common ) target_sources(core-sys_view-tablets PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/tablets/tablets.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/tablets/tablets.cpp ) diff --git a/ydb/core/sys_view/tablets/CMakeLists.linux-aarch64.txt b/ydb/core/sys_view/tablets/CMakeLists.linux-aarch64.txt index 2438cf1f1f82..03633e4fca54 100644 --- a/ydb/core/sys_view/tablets/CMakeLists.linux-aarch64.txt +++ b/ydb/core/sys_view/tablets/CMakeLists.linux-aarch64.txt @@ -21,5 +21,6 @@ target_link_libraries(core-sys_view-tablets PUBLIC core-sys_view-common ) target_sources(core-sys_view-tablets PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/tablets/tablets.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/tablets/tablets.cpp ) diff --git a/ydb/core/sys_view/tablets/CMakeLists.linux-x86_64.txt b/ydb/core/sys_view/tablets/CMakeLists.linux-x86_64.txt index 2438cf1f1f82..03633e4fca54 100644 --- a/ydb/core/sys_view/tablets/CMakeLists.linux-x86_64.txt +++ b/ydb/core/sys_view/tablets/CMakeLists.linux-x86_64.txt @@ -21,5 +21,6 @@ target_link_libraries(core-sys_view-tablets PUBLIC core-sys_view-common ) target_sources(core-sys_view-tablets PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/tablets/tablets.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/tablets/tablets.cpp ) diff --git a/ydb/core/sys_view/tablets/CMakeLists.windows-x86_64.txt b/ydb/core/sys_view/tablets/CMakeLists.windows-x86_64.txt index 681f82119654..bf3c08eef02f 100644 --- a/ydb/core/sys_view/tablets/CMakeLists.windows-x86_64.txt +++ b/ydb/core/sys_view/tablets/CMakeLists.windows-x86_64.txt @@ -20,5 +20,6 @@ target_link_libraries(core-sys_view-tablets PUBLIC core-sys_view-common ) target_sources(core-sys_view-tablets PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/tablets/tablets.h ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/tablets/tablets.cpp ) diff --git a/ydb/core/sys_view/ut_kqp/CMakeLists.darwin-arm64.txt b/ydb/core/sys_view/ut_kqp/CMakeLists.darwin-arm64.txt index c965eb2907a7..f4fd441a89be 100644 --- a/ydb/core/sys_view/ut_kqp/CMakeLists.darwin-arm64.txt +++ b/ydb/core/sys_view/ut_kqp/CMakeLists.darwin-arm64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-sys_view-ut_kqp PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-sys_view-ut_kqp PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/ut_kqp.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/sys_view/ut_kqp/CMakeLists.darwin-x86_64.txt b/ydb/core/sys_view/ut_kqp/CMakeLists.darwin-x86_64.txt index 828e9c220930..63d13f5f9239 100644 --- a/ydb/core/sys_view/ut_kqp/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/sys_view/ut_kqp/CMakeLists.darwin-x86_64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-sys_view-ut_kqp PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-sys_view-ut_kqp PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/ut_kqp.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/sys_view/ut_kqp/CMakeLists.linux-aarch64.txt b/ydb/core/sys_view/ut_kqp/CMakeLists.linux-aarch64.txt index 6a80caf25186..875132a292e2 100644 --- a/ydb/core/sys_view/ut_kqp/CMakeLists.linux-aarch64.txt +++ b/ydb/core/sys_view/ut_kqp/CMakeLists.linux-aarch64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-sys_view-ut_kqp PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-sys_view-ut_kqp PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/ut_kqp.cpp @@ -68,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/sys_view/ut_kqp/CMakeLists.linux-x86_64.txt b/ydb/core/sys_view/ut_kqp/CMakeLists.linux-x86_64.txt index 7c3f4f79607d..c0a84a8aafaf 100644 --- a/ydb/core/sys_view/ut_kqp/CMakeLists.linux-x86_64.txt +++ b/ydb/core/sys_view/ut_kqp/CMakeLists.linux-x86_64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-sys_view-ut_kqp PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-sys_view-ut_kqp PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/sys_view/ut_kqp.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/sys_view/ut_kqp/CMakeLists.windows-x86_64.txt b/ydb/core/sys_view/ut_kqp/CMakeLists.windows-x86_64.txt index 3e0591e2b283..89fe7ac0562a 100644 --- a/ydb/core/sys_view/ut_kqp/CMakeLists.windows-x86_64.txt +++ b/ydb/core/sys_view/ut_kqp/CMakeLists.windows-x86_64.txt @@ -58,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet/CMakeLists.darwin-arm64.txt b/ydb/core/tablet/CMakeLists.darwin-arm64.txt index a7833addf686..72d5761ffd4d 100644 --- a/ydb/core/tablet/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tablet/CMakeLists.darwin-arm64.txt @@ -20,6 +20,7 @@ target_link_libraries(ydb-core-tablet PUBLIC cpp-deprecated-enum_codegen library-cpp-yson ydb-core-base + graph-shard-protos ydb-core-mon ydb-core-mon_alloc ydb-core-node_whiteboard @@ -32,6 +33,29 @@ target_link_libraries(ydb-core-tablet PUBLIC ydb-library-services ) target_sources(ydb-core-tablet PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/labeled_counters_merger.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/labeled_db_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/node_tablet_monitor.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/pipe_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/resource_broker.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/resource_broker_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_counters_aggregator.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_counters_app.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_counters_protobuf.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_exception.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_list_renderer.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_metrics.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_monitoring_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_pipe_client_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_responsiveness_pinger.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_setup.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_sys.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_tracing_signals.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/private/aggregated_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/private/labeled_db_counters.h ${CMAKE_SOURCE_DIR}/ydb/core/tablet/bootstrapper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet/labeled_counters_merger.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet/labeled_db_counters.cpp diff --git a/ydb/core/tablet/CMakeLists.darwin-x86_64.txt b/ydb/core/tablet/CMakeLists.darwin-x86_64.txt index a7833addf686..72d5761ffd4d 100644 --- a/ydb/core/tablet/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tablet/CMakeLists.darwin-x86_64.txt @@ -20,6 +20,7 @@ target_link_libraries(ydb-core-tablet PUBLIC cpp-deprecated-enum_codegen library-cpp-yson ydb-core-base + graph-shard-protos ydb-core-mon ydb-core-mon_alloc ydb-core-node_whiteboard @@ -32,6 +33,29 @@ target_link_libraries(ydb-core-tablet PUBLIC ydb-library-services ) target_sources(ydb-core-tablet PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/labeled_counters_merger.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/labeled_db_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/node_tablet_monitor.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/pipe_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/resource_broker.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/resource_broker_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_counters_aggregator.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_counters_app.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_counters_protobuf.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_exception.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_list_renderer.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_metrics.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_monitoring_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_pipe_client_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_responsiveness_pinger.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_setup.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_sys.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_tracing_signals.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/private/aggregated_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/private/labeled_db_counters.h ${CMAKE_SOURCE_DIR}/ydb/core/tablet/bootstrapper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet/labeled_counters_merger.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet/labeled_db_counters.cpp diff --git a/ydb/core/tablet/CMakeLists.linux-aarch64.txt b/ydb/core/tablet/CMakeLists.linux-aarch64.txt index 46c903f24f8d..2e03bd027110 100644 --- a/ydb/core/tablet/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tablet/CMakeLists.linux-aarch64.txt @@ -21,6 +21,7 @@ target_link_libraries(ydb-core-tablet PUBLIC cpp-deprecated-enum_codegen library-cpp-yson ydb-core-base + graph-shard-protos ydb-core-mon ydb-core-mon_alloc ydb-core-node_whiteboard @@ -33,6 +34,29 @@ target_link_libraries(ydb-core-tablet PUBLIC ydb-library-services ) target_sources(ydb-core-tablet PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/labeled_counters_merger.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/labeled_db_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/node_tablet_monitor.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/pipe_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/resource_broker.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/resource_broker_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_counters_aggregator.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_counters_app.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_counters_protobuf.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_exception.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_list_renderer.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_metrics.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_monitoring_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_pipe_client_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_responsiveness_pinger.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_setup.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_sys.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_tracing_signals.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/private/aggregated_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/private/labeled_db_counters.h ${CMAKE_SOURCE_DIR}/ydb/core/tablet/bootstrapper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet/labeled_counters_merger.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet/labeled_db_counters.cpp diff --git a/ydb/core/tablet/CMakeLists.linux-x86_64.txt b/ydb/core/tablet/CMakeLists.linux-x86_64.txt index 46c903f24f8d..2e03bd027110 100644 --- a/ydb/core/tablet/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tablet/CMakeLists.linux-x86_64.txt @@ -21,6 +21,7 @@ target_link_libraries(ydb-core-tablet PUBLIC cpp-deprecated-enum_codegen library-cpp-yson ydb-core-base + graph-shard-protos ydb-core-mon ydb-core-mon_alloc ydb-core-node_whiteboard @@ -33,6 +34,29 @@ target_link_libraries(ydb-core-tablet PUBLIC ydb-library-services ) target_sources(ydb-core-tablet PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/labeled_counters_merger.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/labeled_db_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/node_tablet_monitor.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/pipe_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/resource_broker.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/resource_broker_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_counters_aggregator.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_counters_app.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_counters_protobuf.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_exception.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_list_renderer.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_metrics.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_monitoring_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_pipe_client_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_responsiveness_pinger.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_setup.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_sys.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_tracing_signals.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/private/aggregated_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/private/labeled_db_counters.h ${CMAKE_SOURCE_DIR}/ydb/core/tablet/bootstrapper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet/labeled_counters_merger.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet/labeled_db_counters.cpp diff --git a/ydb/core/tablet/CMakeLists.windows-x86_64.txt b/ydb/core/tablet/CMakeLists.windows-x86_64.txt index a7833addf686..72d5761ffd4d 100644 --- a/ydb/core/tablet/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tablet/CMakeLists.windows-x86_64.txt @@ -20,6 +20,7 @@ target_link_libraries(ydb-core-tablet PUBLIC cpp-deprecated-enum_codegen library-cpp-yson ydb-core-base + graph-shard-protos ydb-core-mon ydb-core-mon_alloc ydb-core-node_whiteboard @@ -32,6 +33,29 @@ target_link_libraries(ydb-core-tablet PUBLIC ydb-library-services ) target_sources(ydb-core-tablet PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/labeled_counters_merger.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/labeled_db_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/node_tablet_monitor.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/pipe_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/resource_broker.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/resource_broker_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_counters_aggregator.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_counters_app.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_counters_protobuf.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_exception.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_list_renderer.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_metrics.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_monitoring_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_pipe_client_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_responsiveness_pinger.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_setup.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_sys.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/tablet_tracing_signals.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/private/aggregated_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet/private/labeled_db_counters.h ${CMAKE_SOURCE_DIR}/ydb/core/tablet/bootstrapper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet/labeled_counters_merger.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet/labeled_db_counters.cpp diff --git a/ydb/core/tablet/ut/CMakeLists.darwin-arm64.txt b/ydb/core/tablet/ut/CMakeLists.darwin-arm64.txt index ed42817bd055..8e15f699635c 100644 --- a/ydb/core/tablet/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tablet/ut/CMakeLists.darwin-arm64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-tablet-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tablet-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet/pipe_tracker_ut.cpp @@ -67,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/tablet/ut/CMakeLists.darwin-x86_64.txt index dc9d21b44b63..c9aa887ef6bc 100644 --- a/ydb/core/tablet/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tablet/ut/CMakeLists.darwin-x86_64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-core-tablet-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tablet-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet/pipe_tracker_ut.cpp @@ -68,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet/ut/CMakeLists.linux-aarch64.txt b/ydb/core/tablet/ut/CMakeLists.linux-aarch64.txt index e7aa378a708d..f9bdf71575c3 100644 --- a/ydb/core/tablet/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tablet/ut/CMakeLists.linux-aarch64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-tablet-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tablet-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet/pipe_tracker_ut.cpp @@ -71,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet/ut/CMakeLists.linux-x86_64.txt b/ydb/core/tablet/ut/CMakeLists.linux-x86_64.txt index 5664fae257f1..856a053aa71a 100644 --- a/ydb/core/tablet/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tablet/ut/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-core-tablet-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tablet-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet/pipe_tracker_ut.cpp @@ -72,6 +69,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet/ut/CMakeLists.windows-x86_64.txt b/ydb/core/tablet/ut/CMakeLists.windows-x86_64.txt index 7d5197ab64b7..d3c0aa3b21ca 100644 --- a/ydb/core/tablet/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tablet/ut/CMakeLists.windows-x86_64.txt @@ -61,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet_flat/CMakeLists.darwin-arm64.txt b/ydb/core/tablet_flat/CMakeLists.darwin-arm64.txt index 1ec29730846e..0bc8fa0292c2 100644 --- a/ydb/core/tablet_flat/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tablet_flat/CMakeLists.darwin-arm64.txt @@ -80,6 +80,30 @@ target_proto_messages(ydb-core-tablet_flat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor.proto ) target_sources(ydb-core-tablet_flat PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/tablet_flat/flat_executor.pb.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_cxx_database.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_database.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_bootlogic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_borrowlogic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_compaction_logic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_gclogic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_tx_env.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_txloglogic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_iterator.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_sausagecache.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_stat_part.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_stat_table.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_table.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_table_part.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_table_observer.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_update_op.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/shared_sausagecache.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/shared_cache_memtable.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/tablet_flat_executor.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/tablet_flat_executed.h ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_boot_lease.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_boot_misc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_comp.cpp diff --git a/ydb/core/tablet_flat/CMakeLists.darwin-x86_64.txt b/ydb/core/tablet_flat/CMakeLists.darwin-x86_64.txt index 1ec29730846e..0bc8fa0292c2 100644 --- a/ydb/core/tablet_flat/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tablet_flat/CMakeLists.darwin-x86_64.txt @@ -80,6 +80,30 @@ target_proto_messages(ydb-core-tablet_flat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor.proto ) target_sources(ydb-core-tablet_flat PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/tablet_flat/flat_executor.pb.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_cxx_database.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_database.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_bootlogic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_borrowlogic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_compaction_logic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_gclogic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_tx_env.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_txloglogic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_iterator.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_sausagecache.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_stat_part.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_stat_table.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_table.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_table_part.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_table_observer.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_update_op.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/shared_sausagecache.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/shared_cache_memtable.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/tablet_flat_executor.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/tablet_flat_executed.h ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_boot_lease.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_boot_misc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_comp.cpp diff --git a/ydb/core/tablet_flat/CMakeLists.linux-aarch64.txt b/ydb/core/tablet_flat/CMakeLists.linux-aarch64.txt index 6a78f839ed8d..efffc701df17 100644 --- a/ydb/core/tablet_flat/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tablet_flat/CMakeLists.linux-aarch64.txt @@ -81,6 +81,30 @@ target_proto_messages(ydb-core-tablet_flat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor.proto ) target_sources(ydb-core-tablet_flat PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/tablet_flat/flat_executor.pb.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_cxx_database.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_database.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_bootlogic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_borrowlogic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_compaction_logic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_gclogic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_tx_env.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_txloglogic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_iterator.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_sausagecache.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_stat_part.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_stat_table.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_table.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_table_part.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_table_observer.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_update_op.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/shared_sausagecache.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/shared_cache_memtable.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/tablet_flat_executor.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/tablet_flat_executed.h ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_boot_lease.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_boot_misc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_comp.cpp diff --git a/ydb/core/tablet_flat/CMakeLists.linux-x86_64.txt b/ydb/core/tablet_flat/CMakeLists.linux-x86_64.txt index 6a78f839ed8d..efffc701df17 100644 --- a/ydb/core/tablet_flat/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tablet_flat/CMakeLists.linux-x86_64.txt @@ -81,6 +81,30 @@ target_proto_messages(ydb-core-tablet_flat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor.proto ) target_sources(ydb-core-tablet_flat PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/tablet_flat/flat_executor.pb.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_cxx_database.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_database.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_bootlogic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_borrowlogic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_compaction_logic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_gclogic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_tx_env.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_txloglogic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_iterator.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_sausagecache.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_stat_part.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_stat_table.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_table.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_table_part.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_table_observer.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_update_op.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/shared_sausagecache.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/shared_cache_memtable.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/tablet_flat_executor.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/tablet_flat_executed.h ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_boot_lease.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_boot_misc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_comp.cpp diff --git a/ydb/core/tablet_flat/CMakeLists.windows-x86_64.txt b/ydb/core/tablet_flat/CMakeLists.windows-x86_64.txt index 1ec29730846e..0bc8fa0292c2 100644 --- a/ydb/core/tablet_flat/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tablet_flat/CMakeLists.windows-x86_64.txt @@ -80,6 +80,30 @@ target_proto_messages(ydb-core-tablet_flat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor.proto ) target_sources(ydb-core-tablet_flat PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/tablet_flat/flat_executor.pb.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_cxx_database.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_database.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_bootlogic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_borrowlogic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_compaction_logic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_gclogic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_tx_env.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_txloglogic.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_iterator.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_sausagecache.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_stat_part.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_stat_table.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_table.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_table_part.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_table_observer.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_update_op.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/shared_sausagecache.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/shared_cache_memtable.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/tablet_flat_executor.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/tablet_flat_executed.h ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_boot_lease.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_boot_misc.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_comp.cpp diff --git a/ydb/core/tablet_flat/benchmark/CMakeLists.darwin-arm64.txt b/ydb/core/tablet_flat/benchmark/CMakeLists.darwin-arm64.txt index 631455d532aa..57f022776433 100644 --- a/ydb/core/tablet_flat/benchmark/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tablet_flat/benchmark/CMakeLists.darwin-arm64.txt @@ -22,11 +22,10 @@ target_link_options(benchmark PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(benchmark PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/benchmark/b_charge.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/benchmark/b_part_index.cpp ) add_test( NAME @@ -40,6 +39,7 @@ set_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_property( TEST diff --git a/ydb/core/tablet_flat/benchmark/CMakeLists.darwin-x86_64.txt b/ydb/core/tablet_flat/benchmark/CMakeLists.darwin-x86_64.txt index fc10ba19f6b6..81245fe70c48 100644 --- a/ydb/core/tablet_flat/benchmark/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tablet_flat/benchmark/CMakeLists.darwin-x86_64.txt @@ -23,11 +23,10 @@ target_link_options(benchmark PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(benchmark PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/benchmark/b_charge.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/benchmark/b_part_index.cpp ) add_test( NAME @@ -41,6 +40,7 @@ set_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_property( TEST diff --git a/ydb/core/tablet_flat/benchmark/CMakeLists.linux-aarch64.txt b/ydb/core/tablet_flat/benchmark/CMakeLists.linux-aarch64.txt index 84d07a5980d1..bd51b6083bf6 100644 --- a/ydb/core/tablet_flat/benchmark/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tablet_flat/benchmark/CMakeLists.linux-aarch64.txt @@ -25,12 +25,10 @@ target_link_options(benchmark PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(benchmark PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/benchmark/b_charge.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/benchmark/b_part_index.cpp ) add_test( NAME @@ -44,6 +42,7 @@ set_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_property( TEST diff --git a/ydb/core/tablet_flat/benchmark/CMakeLists.linux-x86_64.txt b/ydb/core/tablet_flat/benchmark/CMakeLists.linux-x86_64.txt index 308e2ed89b2a..0662df500ae0 100644 --- a/ydb/core/tablet_flat/benchmark/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tablet_flat/benchmark/CMakeLists.linux-x86_64.txt @@ -26,12 +26,10 @@ target_link_options(benchmark PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(benchmark PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/benchmark/b_charge.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/benchmark/b_part_index.cpp ) add_test( NAME @@ -45,6 +43,7 @@ set_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_property( TEST diff --git a/ydb/core/tablet_flat/benchmark/CMakeLists.windows-x86_64.txt b/ydb/core/tablet_flat/benchmark/CMakeLists.windows-x86_64.txt index da491eea7f30..a3ec94d5e528 100644 --- a/ydb/core/tablet_flat/benchmark/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tablet_flat/benchmark/CMakeLists.windows-x86_64.txt @@ -21,6 +21,7 @@ target_link_libraries(benchmark PUBLIC ) target_sources(benchmark PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/benchmark/b_charge.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/benchmark/b_part_index.cpp ) add_test( NAME @@ -34,6 +35,7 @@ set_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_property( TEST diff --git a/ydb/core/tablet_flat/protos/CMakeLists.darwin-arm64.txt b/ydb/core/tablet_flat/protos/CMakeLists.darwin-arm64.txt index a04498fa62cc..1e8fec728c50 100644 --- a/ydb/core/tablet_flat/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tablet_flat/protos/CMakeLists.darwin-arm64.txt @@ -43,6 +43,10 @@ target_proto_messages(core-tablet_flat-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/protos/flat_table_part.proto ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/protos/flat_table_shard.proto ) +target_sources(core-tablet_flat-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/tablet_flat/protos/flat_table_part.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/tablet_flat/protos/flat_table_shard.pb.h +) target_proto_addincls(core-tablet_flat-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/tablet_flat/protos/CMakeLists.darwin-x86_64.txt b/ydb/core/tablet_flat/protos/CMakeLists.darwin-x86_64.txt index a04498fa62cc..1e8fec728c50 100644 --- a/ydb/core/tablet_flat/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tablet_flat/protos/CMakeLists.darwin-x86_64.txt @@ -43,6 +43,10 @@ target_proto_messages(core-tablet_flat-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/protos/flat_table_part.proto ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/protos/flat_table_shard.proto ) +target_sources(core-tablet_flat-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/tablet_flat/protos/flat_table_part.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/tablet_flat/protos/flat_table_shard.pb.h +) target_proto_addincls(core-tablet_flat-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/tablet_flat/protos/CMakeLists.linux-aarch64.txt b/ydb/core/tablet_flat/protos/CMakeLists.linux-aarch64.txt index d9797a00bb79..70f2baa0edb3 100644 --- a/ydb/core/tablet_flat/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tablet_flat/protos/CMakeLists.linux-aarch64.txt @@ -44,6 +44,10 @@ target_proto_messages(core-tablet_flat-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/protos/flat_table_part.proto ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/protos/flat_table_shard.proto ) +target_sources(core-tablet_flat-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/tablet_flat/protos/flat_table_part.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/tablet_flat/protos/flat_table_shard.pb.h +) target_proto_addincls(core-tablet_flat-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/tablet_flat/protos/CMakeLists.linux-x86_64.txt b/ydb/core/tablet_flat/protos/CMakeLists.linux-x86_64.txt index d9797a00bb79..70f2baa0edb3 100644 --- a/ydb/core/tablet_flat/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tablet_flat/protos/CMakeLists.linux-x86_64.txt @@ -44,6 +44,10 @@ target_proto_messages(core-tablet_flat-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/protos/flat_table_part.proto ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/protos/flat_table_shard.proto ) +target_sources(core-tablet_flat-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/tablet_flat/protos/flat_table_part.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/tablet_flat/protos/flat_table_shard.pb.h +) target_proto_addincls(core-tablet_flat-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/tablet_flat/protos/CMakeLists.windows-x86_64.txt b/ydb/core/tablet_flat/protos/CMakeLists.windows-x86_64.txt index a04498fa62cc..1e8fec728c50 100644 --- a/ydb/core/tablet_flat/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tablet_flat/protos/CMakeLists.windows-x86_64.txt @@ -43,6 +43,10 @@ target_proto_messages(core-tablet_flat-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/protos/flat_table_part.proto ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/protos/flat_table_shard.proto ) +target_sources(core-tablet_flat-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/tablet_flat/protos/flat_table_part.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/tablet_flat/protos/flat_table_shard.pb.h +) target_proto_addincls(core-tablet_flat-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/tablet_flat/test/tool/perf/CMakeLists.darwin-arm64.txt b/ydb/core/tablet_flat/test/tool/perf/CMakeLists.darwin-arm64.txt index ca9ec50ab5c4..4a42eed1141b 100644 --- a/ydb/core/tablet_flat/test/tool/perf/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tablet_flat/test/tool/perf/CMakeLists.darwin-arm64.txt @@ -22,8 +22,6 @@ target_link_options(table-perf PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(table-perf PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/test/tool/perf/colons.cpp diff --git a/ydb/core/tablet_flat/test/tool/perf/CMakeLists.darwin-x86_64.txt b/ydb/core/tablet_flat/test/tool/perf/CMakeLists.darwin-x86_64.txt index 94089b8cd040..6b7e0bea3702 100644 --- a/ydb/core/tablet_flat/test/tool/perf/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tablet_flat/test/tool/perf/CMakeLists.darwin-x86_64.txt @@ -23,8 +23,6 @@ target_link_options(table-perf PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(table-perf PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/test/tool/perf/colons.cpp diff --git a/ydb/core/tablet_flat/test/tool/perf/CMakeLists.linux-aarch64.txt b/ydb/core/tablet_flat/test/tool/perf/CMakeLists.linux-aarch64.txt index 1d1f6bd0b18b..377d62f9ced9 100644 --- a/ydb/core/tablet_flat/test/tool/perf/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tablet_flat/test/tool/perf/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(table-perf PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(table-perf PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/test/tool/perf/colons.cpp diff --git a/ydb/core/tablet_flat/test/tool/perf/CMakeLists.linux-x86_64.txt b/ydb/core/tablet_flat/test/tool/perf/CMakeLists.linux-x86_64.txt index c598b1424975..b66e3cc1b758 100644 --- a/ydb/core/tablet_flat/test/tool/perf/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tablet_flat/test/tool/perf/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(table-perf PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(table-perf PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/test/tool/perf/colons.cpp diff --git a/ydb/core/tablet_flat/test/tool/surg/CMakeLists.darwin-arm64.txt b/ydb/core/tablet_flat/test/tool/surg/CMakeLists.darwin-arm64.txt index 3c96dc149aa3..60973bbdca2d 100644 --- a/ydb/core/tablet_flat/test/tool/surg/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tablet_flat/test/tool/surg/CMakeLists.darwin-arm64.txt @@ -20,8 +20,6 @@ target_link_options(surg PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(surg PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/test/tool/surg/main.cpp diff --git a/ydb/core/tablet_flat/test/tool/surg/CMakeLists.darwin-x86_64.txt b/ydb/core/tablet_flat/test/tool/surg/CMakeLists.darwin-x86_64.txt index ba6956d053d1..fde2c4ee737b 100644 --- a/ydb/core/tablet_flat/test/tool/surg/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tablet_flat/test/tool/surg/CMakeLists.darwin-x86_64.txt @@ -21,8 +21,6 @@ target_link_options(surg PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(surg PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/test/tool/surg/main.cpp diff --git a/ydb/core/tablet_flat/test/tool/surg/CMakeLists.linux-aarch64.txt b/ydb/core/tablet_flat/test/tool/surg/CMakeLists.linux-aarch64.txt index e19ba1394b40..90d969c77f2f 100644 --- a/ydb/core/tablet_flat/test/tool/surg/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tablet_flat/test/tool/surg/CMakeLists.linux-aarch64.txt @@ -23,9 +23,6 @@ target_link_options(surg PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(surg PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/test/tool/surg/main.cpp diff --git a/ydb/core/tablet_flat/test/tool/surg/CMakeLists.linux-x86_64.txt b/ydb/core/tablet_flat/test/tool/surg/CMakeLists.linux-x86_64.txt index d8c42e753075..b1df8bae321d 100644 --- a/ydb/core/tablet_flat/test/tool/surg/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tablet_flat/test/tool/surg/CMakeLists.linux-x86_64.txt @@ -24,9 +24,6 @@ target_link_options(surg PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(surg PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/test/tool/surg/main.cpp diff --git a/ydb/core/tablet_flat/ut/CMakeLists.darwin-arm64.txt b/ydb/core/tablet_flat/ut/CMakeLists.darwin-arm64.txt index 5eb16e5ba1f5..2e122027117d 100644 --- a/ydb/core/tablet_flat/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tablet_flat/ut/CMakeLists.darwin-arm64.txt @@ -33,10 +33,10 @@ target_link_options(ydb-core-tablet_flat-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tablet_flat-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/flat_test_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/flat_test_db_helpers.h ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/datetime_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/decimal_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_cxx_database_ut.cpp @@ -51,7 +51,8 @@ target_sources(ydb-core-tablet_flat-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_table_part_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/flat_test_db.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/shared_handle_ut.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_btree_index.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_btree_index_nodes.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_btree_index_iter_charge.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_self.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_iterator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_memtable.cpp @@ -103,6 +104,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet_flat/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/tablet_flat/ut/CMakeLists.darwin-x86_64.txt index 5f7ccdb8dbfc..dabc022e235d 100644 --- a/ydb/core/tablet_flat/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tablet_flat/ut/CMakeLists.darwin-x86_64.txt @@ -34,10 +34,10 @@ target_link_options(ydb-core-tablet_flat-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tablet_flat-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/flat_test_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/flat_test_db_helpers.h ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/datetime_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/decimal_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_cxx_database_ut.cpp @@ -52,7 +52,8 @@ target_sources(ydb-core-tablet_flat-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_table_part_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/flat_test_db.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/shared_handle_ut.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_btree_index.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_btree_index_nodes.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_btree_index_iter_charge.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_self.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_iterator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_memtable.cpp @@ -104,6 +105,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet_flat/ut/CMakeLists.linux-aarch64.txt b/ydb/core/tablet_flat/ut/CMakeLists.linux-aarch64.txt index 38753b3d83ef..7ba00d869f0a 100644 --- a/ydb/core/tablet_flat/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tablet_flat/ut/CMakeLists.linux-aarch64.txt @@ -36,11 +36,10 @@ target_link_options(ydb-core-tablet_flat-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tablet_flat-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/flat_test_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/flat_test_db_helpers.h ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/datetime_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/decimal_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_cxx_database_ut.cpp @@ -55,7 +54,8 @@ target_sources(ydb-core-tablet_flat-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_table_part_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/flat_test_db.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/shared_handle_ut.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_btree_index.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_btree_index_nodes.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_btree_index_iter_charge.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_self.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_iterator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_memtable.cpp @@ -107,6 +107,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet_flat/ut/CMakeLists.linux-x86_64.txt b/ydb/core/tablet_flat/ut/CMakeLists.linux-x86_64.txt index 922c5115c778..5179e1f91a40 100644 --- a/ydb/core/tablet_flat/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tablet_flat/ut/CMakeLists.linux-x86_64.txt @@ -37,11 +37,10 @@ target_link_options(ydb-core-tablet_flat-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tablet_flat-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/flat_test_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/flat_test_db_helpers.h ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/datetime_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/decimal_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_cxx_database_ut.cpp @@ -56,7 +55,8 @@ target_sources(ydb-core-tablet_flat-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_table_part_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/flat_test_db.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/shared_handle_ut.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_btree_index.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_btree_index_nodes.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_btree_index_iter_charge.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_self.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_iterator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_memtable.cpp @@ -108,6 +108,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet_flat/ut/CMakeLists.windows-x86_64.txt b/ydb/core/tablet_flat/ut/CMakeLists.windows-x86_64.txt index 2233ba3a10e6..41ef7b7e3f37 100644 --- a/ydb/core/tablet_flat/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tablet_flat/ut/CMakeLists.windows-x86_64.txt @@ -31,6 +31,8 @@ target_link_libraries(ydb-core-tablet_flat-ut PUBLIC udf-service-exception_policy ) target_sources(ydb-core-tablet_flat-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/flat_test_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/flat_test_db_helpers.h ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/datetime_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/decimal_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_cxx_database_ut.cpp @@ -45,7 +47,8 @@ target_sources(ydb-core-tablet_flat-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_table_part_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/flat_test_db.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/shared_handle_ut.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_btree_index.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_btree_index_nodes.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_btree_index_iter_charge.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_self.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_iterator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut/ut_memtable.cpp @@ -97,6 +100,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet_flat/ut_large/CMakeLists.darwin-arm64.txt b/ydb/core/tablet_flat/ut_large/CMakeLists.darwin-arm64.txt index 92088277e997..a8d82f466835 100644 --- a/ydb/core/tablet_flat/ut_large/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tablet_flat/ut_large/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-tablet_flat-ut_large PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tablet_flat-ut_large PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_ut_large.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet_flat/ut_large/CMakeLists.darwin-x86_64.txt b/ydb/core/tablet_flat/ut_large/CMakeLists.darwin-x86_64.txt index fcfc3639f5ee..aaf7575d9d7d 100644 --- a/ydb/core/tablet_flat/ut_large/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tablet_flat/ut_large/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-tablet_flat-ut_large PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tablet_flat-ut_large PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_ut_large.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet_flat/ut_large/CMakeLists.linux-aarch64.txt b/ydb/core/tablet_flat/ut_large/CMakeLists.linux-aarch64.txt index bac5c7dc9b52..8f9c4e9d13e6 100644 --- a/ydb/core/tablet_flat/ut_large/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tablet_flat/ut_large/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-tablet_flat-ut_large PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tablet_flat-ut_large PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_ut_large.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet_flat/ut_large/CMakeLists.linux-x86_64.txt b/ydb/core/tablet_flat/ut_large/CMakeLists.linux-x86_64.txt index 878a674553cd..70e409d8d075 100644 --- a/ydb/core/tablet_flat/ut_large/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tablet_flat/ut_large/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-tablet_flat-ut_large PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tablet_flat-ut_large PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/flat_executor_ut_large.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet_flat/ut_large/CMakeLists.windows-x86_64.txt b/ydb/core/tablet_flat/ut_large/CMakeLists.windows-x86_64.txt index 6756b3c633f5..b9266559d1a3 100644 --- a/ydb/core/tablet_flat/ut_large/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tablet_flat/ut_large/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet_flat/ut_pg/CMakeLists.darwin-arm64.txt b/ydb/core/tablet_flat/ut_pg/CMakeLists.darwin-arm64.txt index 300882289ada..41c9c38c1c39 100644 --- a/ydb/core/tablet_flat/ut_pg/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tablet_flat/ut_pg/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tablet_flat-ut_pg PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tablet_flat-ut_pg PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut_pg/flat_database_pg_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet_flat/ut_pg/CMakeLists.darwin-x86_64.txt b/ydb/core/tablet_flat/ut_pg/CMakeLists.darwin-x86_64.txt index 5c80d5a5fb72..c8afbd39d5ba 100644 --- a/ydb/core/tablet_flat/ut_pg/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tablet_flat/ut_pg/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tablet_flat-ut_pg PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tablet_flat-ut_pg PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut_pg/flat_database_pg_ut.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet_flat/ut_pg/CMakeLists.linux-aarch64.txt b/ydb/core/tablet_flat/ut_pg/CMakeLists.linux-aarch64.txt index 5f5ea010ab45..2ce7f2d95c39 100644 --- a/ydb/core/tablet_flat/ut_pg/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tablet_flat/ut_pg/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tablet_flat-ut_pg PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tablet_flat-ut_pg PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut_pg/flat_database_pg_ut.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet_flat/ut_pg/CMakeLists.linux-x86_64.txt b/ydb/core/tablet_flat/ut_pg/CMakeLists.linux-x86_64.txt index 1a1d324e73ab..1c4fb1cb1484 100644 --- a/ydb/core/tablet_flat/ut_pg/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tablet_flat/ut_pg/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tablet_flat-ut_pg PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tablet_flat-ut_pg PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/ut_pg/flat_database_pg_ut.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet_flat/ut_pg/CMakeLists.windows-x86_64.txt b/ydb/core/tablet_flat/ut_pg/CMakeLists.windows-x86_64.txt index 9f55862ee2a3..71d71a147468 100644 --- a/ydb/core/tablet_flat/ut_pg/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tablet_flat/ut_pg/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet_flat/ut_util/CMakeLists.darwin-arm64.txt b/ydb/core/tablet_flat/ut_util/CMakeLists.darwin-arm64.txt index 08c6d2e0f58f..cbcd351b4292 100644 --- a/ydb/core/tablet_flat/ut_util/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tablet_flat/ut_util/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-core-tablet_flat-ut_util PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tablet_flat-ut_util PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/util_pool_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet_flat/ut_util/CMakeLists.darwin-x86_64.txt b/ydb/core/tablet_flat/ut_util/CMakeLists.darwin-x86_64.txt index ef00170d4bf7..3c7498c6ef30 100644 --- a/ydb/core/tablet_flat/ut_util/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tablet_flat/ut_util/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-core-tablet_flat-ut_util PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tablet_flat-ut_util PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/util_pool_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet_flat/ut_util/CMakeLists.linux-aarch64.txt b/ydb/core/tablet_flat/ut_util/CMakeLists.linux-aarch64.txt index 1db598c5ea4a..291d3ebcca45 100644 --- a/ydb/core/tablet_flat/ut_util/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tablet_flat/ut_util/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-core-tablet_flat-ut_util PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tablet_flat-ut_util PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/util_pool_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet_flat/ut_util/CMakeLists.linux-x86_64.txt b/ydb/core/tablet_flat/ut_util/CMakeLists.linux-x86_64.txt index 71b81b4ee60f..06d58cbdbfa1 100644 --- a/ydb/core/tablet_flat/ut_util/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tablet_flat/ut_util/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-core-tablet_flat-ut_util PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tablet_flat-ut_util PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tablet_flat/util_pool_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tablet_flat/ut_util/CMakeLists.windows-x86_64.txt b/ydb/core/tablet_flat/ut_util/CMakeLists.windows-x86_64.txt index 3865b70295fb..2886f13aea50 100644 --- a/ydb/core/tablet_flat/ut_util/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tablet_flat/ut_util/CMakeLists.windows-x86_64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/test_tablet/CMakeLists.darwin-arm64.txt b/ydb/core/test_tablet/CMakeLists.darwin-arm64.txt index 202454e85c0e..f076915a3b89 100644 --- a/ydb/core/test_tablet/CMakeLists.darwin-arm64.txt +++ b/ydb/core/test_tablet/CMakeLists.darwin-arm64.txt @@ -18,6 +18,15 @@ target_link_libraries(ydb-core-test_tablet PUBLIC ydb-core-util ) target_sources(ydb-core-test_tablet PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/load_actor_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/processor.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/state_server_interface.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/test_shard_context.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/test_shard_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/test_tablet.h ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/load_actor_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/load_actor_delete.cpp ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/load_actor_mon.cpp diff --git a/ydb/core/test_tablet/CMakeLists.darwin-x86_64.txt b/ydb/core/test_tablet/CMakeLists.darwin-x86_64.txt index 202454e85c0e..f076915a3b89 100644 --- a/ydb/core/test_tablet/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/test_tablet/CMakeLists.darwin-x86_64.txt @@ -18,6 +18,15 @@ target_link_libraries(ydb-core-test_tablet PUBLIC ydb-core-util ) target_sources(ydb-core-test_tablet PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/load_actor_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/processor.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/state_server_interface.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/test_shard_context.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/test_shard_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/test_tablet.h ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/load_actor_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/load_actor_delete.cpp ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/load_actor_mon.cpp diff --git a/ydb/core/test_tablet/CMakeLists.linux-aarch64.txt b/ydb/core/test_tablet/CMakeLists.linux-aarch64.txt index ebf27ccc07b7..d35a064754d5 100644 --- a/ydb/core/test_tablet/CMakeLists.linux-aarch64.txt +++ b/ydb/core/test_tablet/CMakeLists.linux-aarch64.txt @@ -19,6 +19,15 @@ target_link_libraries(ydb-core-test_tablet PUBLIC ydb-core-util ) target_sources(ydb-core-test_tablet PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/load_actor_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/processor.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/state_server_interface.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/test_shard_context.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/test_shard_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/test_tablet.h ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/load_actor_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/load_actor_delete.cpp ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/load_actor_mon.cpp diff --git a/ydb/core/test_tablet/CMakeLists.linux-x86_64.txt b/ydb/core/test_tablet/CMakeLists.linux-x86_64.txt index ebf27ccc07b7..d35a064754d5 100644 --- a/ydb/core/test_tablet/CMakeLists.linux-x86_64.txt +++ b/ydb/core/test_tablet/CMakeLists.linux-x86_64.txt @@ -19,6 +19,15 @@ target_link_libraries(ydb-core-test_tablet PUBLIC ydb-core-util ) target_sources(ydb-core-test_tablet PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/load_actor_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/processor.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/state_server_interface.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/test_shard_context.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/test_shard_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/test_tablet.h ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/load_actor_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/load_actor_delete.cpp ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/load_actor_mon.cpp diff --git a/ydb/core/test_tablet/CMakeLists.windows-x86_64.txt b/ydb/core/test_tablet/CMakeLists.windows-x86_64.txt index 202454e85c0e..f076915a3b89 100644 --- a/ydb/core/test_tablet/CMakeLists.windows-x86_64.txt +++ b/ydb/core/test_tablet/CMakeLists.windows-x86_64.txt @@ -18,6 +18,15 @@ target_link_libraries(ydb-core-test_tablet PUBLIC ydb-core-util ) target_sources(ydb-core-test_tablet PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/events.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/load_actor_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/processor.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/scheme.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/state_server_interface.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/test_shard_context.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/test_shard_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/test_tablet.h ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/load_actor_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/load_actor_delete.cpp ${CMAKE_SOURCE_DIR}/ydb/core/test_tablet/load_actor_mon.cpp diff --git a/ydb/core/testlib/CMakeLists.darwin-arm64.txt b/ydb/core/testlib/CMakeLists.darwin-arm64.txt index fa7ea6967877..d234d9d9e6a0 100644 --- a/ydb/core/testlib/CMakeLists.darwin-arm64.txt +++ b/ydb/core/testlib/CMakeLists.darwin-arm64.txt @@ -77,12 +77,13 @@ target_link_libraries(ydb-core-testlib PUBLIC library-mkql_proto-protos library-persqueue-topic_parser ydb-library-security - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 udf-service-exception_policy public-lib-base lib-deprecated-kicli cpp-client-ydb_driver client-ydb_persqueue_public-codecs + cpp-client-ydb_query cpp-client-ydb_table ydb-services-auth ydb-services-cms @@ -103,6 +104,15 @@ target_link_libraries(ydb-core-testlib PUBLIC ydb-core-http_proxy ) target_sources(ydb-core-testlib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/actor_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/fake_coordinator.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/fake_scheme_shard.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/minikql_compile.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/mock_pq_metacache.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/tablet_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/tenant_runtime.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/test_client.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/tx_helpers.h ${CMAKE_SOURCE_DIR}/ydb/core/testlib/actor_helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/core/testlib/common_helper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/testlib/cs_helper.cpp diff --git a/ydb/core/testlib/CMakeLists.darwin-x86_64.txt b/ydb/core/testlib/CMakeLists.darwin-x86_64.txt index fa7ea6967877..d234d9d9e6a0 100644 --- a/ydb/core/testlib/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/testlib/CMakeLists.darwin-x86_64.txt @@ -77,12 +77,13 @@ target_link_libraries(ydb-core-testlib PUBLIC library-mkql_proto-protos library-persqueue-topic_parser ydb-library-security - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 udf-service-exception_policy public-lib-base lib-deprecated-kicli cpp-client-ydb_driver client-ydb_persqueue_public-codecs + cpp-client-ydb_query cpp-client-ydb_table ydb-services-auth ydb-services-cms @@ -103,6 +104,15 @@ target_link_libraries(ydb-core-testlib PUBLIC ydb-core-http_proxy ) target_sources(ydb-core-testlib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/actor_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/fake_coordinator.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/fake_scheme_shard.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/minikql_compile.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/mock_pq_metacache.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/tablet_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/tenant_runtime.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/test_client.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/tx_helpers.h ${CMAKE_SOURCE_DIR}/ydb/core/testlib/actor_helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/core/testlib/common_helper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/testlib/cs_helper.cpp diff --git a/ydb/core/testlib/CMakeLists.linux-aarch64.txt b/ydb/core/testlib/CMakeLists.linux-aarch64.txt index 72c1af1e9901..f5e108c012be 100644 --- a/ydb/core/testlib/CMakeLists.linux-aarch64.txt +++ b/ydb/core/testlib/CMakeLists.linux-aarch64.txt @@ -78,12 +78,13 @@ target_link_libraries(ydb-core-testlib PUBLIC library-mkql_proto-protos library-persqueue-topic_parser ydb-library-security - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 udf-service-exception_policy public-lib-base lib-deprecated-kicli cpp-client-ydb_driver client-ydb_persqueue_public-codecs + cpp-client-ydb_query cpp-client-ydb_table ydb-services-auth ydb-services-cms @@ -104,6 +105,15 @@ target_link_libraries(ydb-core-testlib PUBLIC ydb-core-http_proxy ) target_sources(ydb-core-testlib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/actor_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/fake_coordinator.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/fake_scheme_shard.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/minikql_compile.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/mock_pq_metacache.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/tablet_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/tenant_runtime.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/test_client.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/tx_helpers.h ${CMAKE_SOURCE_DIR}/ydb/core/testlib/actor_helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/core/testlib/common_helper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/testlib/cs_helper.cpp diff --git a/ydb/core/testlib/CMakeLists.linux-x86_64.txt b/ydb/core/testlib/CMakeLists.linux-x86_64.txt index 72c1af1e9901..f5e108c012be 100644 --- a/ydb/core/testlib/CMakeLists.linux-x86_64.txt +++ b/ydb/core/testlib/CMakeLists.linux-x86_64.txt @@ -78,12 +78,13 @@ target_link_libraries(ydb-core-testlib PUBLIC library-mkql_proto-protos library-persqueue-topic_parser ydb-library-security - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 udf-service-exception_policy public-lib-base lib-deprecated-kicli cpp-client-ydb_driver client-ydb_persqueue_public-codecs + cpp-client-ydb_query cpp-client-ydb_table ydb-services-auth ydb-services-cms @@ -104,6 +105,15 @@ target_link_libraries(ydb-core-testlib PUBLIC ydb-core-http_proxy ) target_sources(ydb-core-testlib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/actor_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/fake_coordinator.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/fake_scheme_shard.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/minikql_compile.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/mock_pq_metacache.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/tablet_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/tenant_runtime.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/test_client.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/tx_helpers.h ${CMAKE_SOURCE_DIR}/ydb/core/testlib/actor_helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/core/testlib/common_helper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/testlib/cs_helper.cpp diff --git a/ydb/core/testlib/CMakeLists.windows-x86_64.txt b/ydb/core/testlib/CMakeLists.windows-x86_64.txt index fa7ea6967877..d234d9d9e6a0 100644 --- a/ydb/core/testlib/CMakeLists.windows-x86_64.txt +++ b/ydb/core/testlib/CMakeLists.windows-x86_64.txt @@ -77,12 +77,13 @@ target_link_libraries(ydb-core-testlib PUBLIC library-mkql_proto-protos library-persqueue-topic_parser ydb-library-security - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 udf-service-exception_policy public-lib-base lib-deprecated-kicli cpp-client-ydb_driver client-ydb_persqueue_public-codecs + cpp-client-ydb_query cpp-client-ydb_table ydb-services-auth ydb-services-cms @@ -103,6 +104,15 @@ target_link_libraries(ydb-core-testlib PUBLIC ydb-core-http_proxy ) target_sources(ydb-core-testlib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/actor_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/fake_coordinator.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/fake_scheme_shard.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/minikql_compile.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/mock_pq_metacache.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/tablet_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/tenant_runtime.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/test_client.h + ${CMAKE_SOURCE_DIR}/ydb/core/testlib/tx_helpers.h ${CMAKE_SOURCE_DIR}/ydb/core/testlib/actor_helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/core/testlib/common_helper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/testlib/cs_helper.cpp diff --git a/ydb/core/testlib/actors/ut/CMakeLists.darwin-arm64.txt b/ydb/core/testlib/actors/ut/CMakeLists.darwin-arm64.txt index e6c7dc04e6d7..84829fbffe28 100644 --- a/ydb/core/testlib/actors/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/testlib/actors/ut/CMakeLists.darwin-arm64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-core-testlib-actors-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-testlib-actors-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/testlib/actors/test_runtime_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/testlib/actors/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/testlib/actors/ut/CMakeLists.darwin-x86_64.txt index 73979023cf38..99766cf7b610 100644 --- a/ydb/core/testlib/actors/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/testlib/actors/ut/CMakeLists.darwin-x86_64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-testlib-actors-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-testlib-actors-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/testlib/actors/test_runtime_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/testlib/actors/ut/CMakeLists.linux-aarch64.txt b/ydb/core/testlib/actors/ut/CMakeLists.linux-aarch64.txt index 8501cf978da4..52bfd4f0b41a 100644 --- a/ydb/core/testlib/actors/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/testlib/actors/ut/CMakeLists.linux-aarch64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-core-testlib-actors-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-testlib-actors-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/testlib/actors/test_runtime_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/testlib/actors/ut/CMakeLists.linux-x86_64.txt b/ydb/core/testlib/actors/ut/CMakeLists.linux-x86_64.txt index c692329fc31a..d74a45269c5e 100644 --- a/ydb/core/testlib/actors/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/testlib/actors/ut/CMakeLists.linux-x86_64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-testlib-actors-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-testlib-actors-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/testlib/actors/test_runtime_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/testlib/actors/ut/CMakeLists.windows-x86_64.txt b/ydb/core/testlib/actors/ut/CMakeLists.windows-x86_64.txt index e6ca409368fe..66ba0724e960 100644 --- a/ydb/core/testlib/actors/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/testlib/actors/ut/CMakeLists.windows-x86_64.txt @@ -49,6 +49,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/testlib/basics/CMakeLists.darwin-arm64.txt b/ydb/core/testlib/basics/CMakeLists.darwin-arm64.txt index ef3ff3c707ea..098eae692918 100644 --- a/ydb/core/testlib/basics/CMakeLists.darwin-arm64.txt +++ b/ydb/core/testlib/basics/CMakeLists.darwin-arm64.txt @@ -33,8 +33,11 @@ target_link_libraries(core-testlib-basics PUBLIC core-tx-columnshard core-tx-scheme_board ydb-core-util - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 udf-service-exception_policy + ydb-services-kesus + ydb-services-persqueue_cluster_discovery + ydb-services-ydb ) target_sources(core-testlib-basics PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/testlib/basics/appdata.cpp diff --git a/ydb/core/testlib/basics/CMakeLists.darwin-x86_64.txt b/ydb/core/testlib/basics/CMakeLists.darwin-x86_64.txt index ef3ff3c707ea..098eae692918 100644 --- a/ydb/core/testlib/basics/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/testlib/basics/CMakeLists.darwin-x86_64.txt @@ -33,8 +33,11 @@ target_link_libraries(core-testlib-basics PUBLIC core-tx-columnshard core-tx-scheme_board ydb-core-util - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 udf-service-exception_policy + ydb-services-kesus + ydb-services-persqueue_cluster_discovery + ydb-services-ydb ) target_sources(core-testlib-basics PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/testlib/basics/appdata.cpp diff --git a/ydb/core/testlib/basics/CMakeLists.linux-aarch64.txt b/ydb/core/testlib/basics/CMakeLists.linux-aarch64.txt index 03e87b86e064..eea1fa51d23c 100644 --- a/ydb/core/testlib/basics/CMakeLists.linux-aarch64.txt +++ b/ydb/core/testlib/basics/CMakeLists.linux-aarch64.txt @@ -34,8 +34,11 @@ target_link_libraries(core-testlib-basics PUBLIC core-tx-columnshard core-tx-scheme_board ydb-core-util - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 udf-service-exception_policy + ydb-services-kesus + ydb-services-persqueue_cluster_discovery + ydb-services-ydb ) target_sources(core-testlib-basics PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/testlib/basics/appdata.cpp diff --git a/ydb/core/testlib/basics/CMakeLists.linux-x86_64.txt b/ydb/core/testlib/basics/CMakeLists.linux-x86_64.txt index 03e87b86e064..eea1fa51d23c 100644 --- a/ydb/core/testlib/basics/CMakeLists.linux-x86_64.txt +++ b/ydb/core/testlib/basics/CMakeLists.linux-x86_64.txt @@ -34,8 +34,11 @@ target_link_libraries(core-testlib-basics PUBLIC core-tx-columnshard core-tx-scheme_board ydb-core-util - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 udf-service-exception_policy + ydb-services-kesus + ydb-services-persqueue_cluster_discovery + ydb-services-ydb ) target_sources(core-testlib-basics PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/testlib/basics/appdata.cpp diff --git a/ydb/core/testlib/basics/CMakeLists.windows-x86_64.txt b/ydb/core/testlib/basics/CMakeLists.windows-x86_64.txt index ef3ff3c707ea..098eae692918 100644 --- a/ydb/core/testlib/basics/CMakeLists.windows-x86_64.txt +++ b/ydb/core/testlib/basics/CMakeLists.windows-x86_64.txt @@ -33,8 +33,11 @@ target_link_libraries(core-testlib-basics PUBLIC core-tx-columnshard core-tx-scheme_board ydb-core-util - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 udf-service-exception_policy + ydb-services-kesus + ydb-services-persqueue_cluster_discovery + ydb-services-ydb ) target_sources(core-testlib-basics PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/testlib/basics/appdata.cpp diff --git a/ydb/core/tx/CMakeLists.darwin-arm64.txt b/ydb/core/tx/CMakeLists.darwin-arm64.txt index 0e0f45463d83..193995cc0e2d 100644 --- a/ydb/core/tx/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/CMakeLists.darwin-arm64.txt @@ -43,6 +43,10 @@ target_link_libraries(ydb-core-tx PUBLIC ydb-library-aclib ) target_sources(ydb-core-tx PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/message_seqno.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_processing.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy_schemereq.cpp ) diff --git a/ydb/core/tx/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/CMakeLists.darwin-x86_64.txt index 0e0f45463d83..193995cc0e2d 100644 --- a/ydb/core/tx/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/CMakeLists.darwin-x86_64.txt @@ -43,6 +43,10 @@ target_link_libraries(ydb-core-tx PUBLIC ydb-library-aclib ) target_sources(ydb-core-tx PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/message_seqno.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_processing.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy_schemereq.cpp ) diff --git a/ydb/core/tx/CMakeLists.linux-aarch64.txt b/ydb/core/tx/CMakeLists.linux-aarch64.txt index f4b2b39fcf2c..ef01c3fcc783 100644 --- a/ydb/core/tx/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/CMakeLists.linux-aarch64.txt @@ -44,6 +44,10 @@ target_link_libraries(ydb-core-tx PUBLIC ydb-library-aclib ) target_sources(ydb-core-tx PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/message_seqno.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_processing.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy_schemereq.cpp ) diff --git a/ydb/core/tx/CMakeLists.linux-x86_64.txt b/ydb/core/tx/CMakeLists.linux-x86_64.txt index f4b2b39fcf2c..ef01c3fcc783 100644 --- a/ydb/core/tx/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/CMakeLists.linux-x86_64.txt @@ -44,6 +44,10 @@ target_link_libraries(ydb-core-tx PUBLIC ydb-library-aclib ) target_sources(ydb-core-tx PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/message_seqno.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_processing.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy_schemereq.cpp ) diff --git a/ydb/core/tx/CMakeLists.windows-x86_64.txt b/ydb/core/tx/CMakeLists.windows-x86_64.txt index 0e0f45463d83..193995cc0e2d 100644 --- a/ydb/core/tx/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/CMakeLists.windows-x86_64.txt @@ -43,6 +43,10 @@ target_link_libraries(ydb-core-tx PUBLIC ydb-library-aclib ) target_sources(ydb-core-tx PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/message_seqno.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_processing.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy_schemereq.cpp ) diff --git a/ydb/core/tx/balance_coverage/ut/CMakeLists.darwin-arm64.txt b/ydb/core/tx/balance_coverage/ut/CMakeLists.darwin-arm64.txt index 09206b832098..039610328e3e 100644 --- a/ydb/core/tx/balance_coverage/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/balance_coverage/ut/CMakeLists.darwin-arm64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-core-tx-balance_coverage-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-balance_coverage-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/balance_coverage/balance_coverage_builder_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/balance_coverage/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/balance_coverage/ut/CMakeLists.darwin-x86_64.txt index 11d2645be356..6dab671950b9 100644 --- a/ydb/core/tx/balance_coverage/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/balance_coverage/ut/CMakeLists.darwin-x86_64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-core-tx-balance_coverage-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-balance_coverage-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/balance_coverage/balance_coverage_builder_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/balance_coverage/ut/CMakeLists.linux-aarch64.txt b/ydb/core/tx/balance_coverage/ut/CMakeLists.linux-aarch64.txt index ea47db16a214..67e222763a9d 100644 --- a/ydb/core/tx/balance_coverage/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/balance_coverage/ut/CMakeLists.linux-aarch64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-core-tx-balance_coverage-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-balance_coverage-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/balance_coverage/balance_coverage_builder_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/balance_coverage/ut/CMakeLists.linux-x86_64.txt b/ydb/core/tx/balance_coverage/ut/CMakeLists.linux-x86_64.txt index b5f38c7a1294..e2a5af197e83 100644 --- a/ydb/core/tx/balance_coverage/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/balance_coverage/ut/CMakeLists.linux-x86_64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-core-tx-balance_coverage-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-balance_coverage-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/balance_coverage/balance_coverage_builder_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/balance_coverage/ut/CMakeLists.windows-x86_64.txt b/ydb/core/tx/balance_coverage/ut/CMakeLists.windows-x86_64.txt index 002d93ed84da..97af22b19a99 100644 --- a/ydb/core/tx/balance_coverage/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/balance_coverage/ut/CMakeLists.windows-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/columnshard/CMakeLists.darwin-arm64.txt b/ydb/core/tx/columnshard/CMakeLists.darwin-arm64.txt index b2e4f43959b3..f13653ae54d1 100644 --- a/ydb/core/tx/columnshard/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/columnshard/CMakeLists.darwin-arm64.txt @@ -17,6 +17,7 @@ add_subdirectory(operations) add_subdirectory(resource_subscriber) add_subdirectory(resources) add_subdirectory(splitter) +add_subdirectory(transactions) add_subdirectory(ut_rw) add_subdirectory(ut_schema) get_built_tool_path( @@ -49,12 +50,15 @@ target_link_libraries(core-tx-columnshard PUBLIC ydb-core-protos ydb-core-tablet ydb-core-tablet_flat + core-tx-time_cast tx-columnshard-engines columnshard-engines-writer tx-columnshard-counters tx-columnshard-common tx-columnshard-splitter tx-columnshard-operations + tx-columnshard-transactions + columnshard-transactions-operators tx-columnshard-blobs_reader tx-columnshard-blobs_action tx-columnshard-resource_subscriber @@ -80,7 +84,6 @@ target_sources(core-tx-columnshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__progress_tx.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__propose_cancel.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__propose_transaction.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__read.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__read_base.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__scan.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__index_scan.cpp @@ -95,10 +98,8 @@ target_sources(core-tx-columnshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard_view.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/defs.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/read_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/write_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/tables_manager.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/tx_controller.cpp ) generate_enum_serilization(core-tx-columnshard ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard.h diff --git a/ydb/core/tx/columnshard/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/columnshard/CMakeLists.darwin-x86_64.txt index b2e4f43959b3..f13653ae54d1 100644 --- a/ydb/core/tx/columnshard/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/columnshard/CMakeLists.darwin-x86_64.txt @@ -17,6 +17,7 @@ add_subdirectory(operations) add_subdirectory(resource_subscriber) add_subdirectory(resources) add_subdirectory(splitter) +add_subdirectory(transactions) add_subdirectory(ut_rw) add_subdirectory(ut_schema) get_built_tool_path( @@ -49,12 +50,15 @@ target_link_libraries(core-tx-columnshard PUBLIC ydb-core-protos ydb-core-tablet ydb-core-tablet_flat + core-tx-time_cast tx-columnshard-engines columnshard-engines-writer tx-columnshard-counters tx-columnshard-common tx-columnshard-splitter tx-columnshard-operations + tx-columnshard-transactions + columnshard-transactions-operators tx-columnshard-blobs_reader tx-columnshard-blobs_action tx-columnshard-resource_subscriber @@ -80,7 +84,6 @@ target_sources(core-tx-columnshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__progress_tx.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__propose_cancel.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__propose_transaction.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__read.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__read_base.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__scan.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__index_scan.cpp @@ -95,10 +98,8 @@ target_sources(core-tx-columnshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard_view.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/defs.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/read_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/write_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/tables_manager.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/tx_controller.cpp ) generate_enum_serilization(core-tx-columnshard ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard.h diff --git a/ydb/core/tx/columnshard/CMakeLists.linux-aarch64.txt b/ydb/core/tx/columnshard/CMakeLists.linux-aarch64.txt index b80449d91da1..3c3c5f0ba7c1 100644 --- a/ydb/core/tx/columnshard/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/columnshard/CMakeLists.linux-aarch64.txt @@ -17,6 +17,7 @@ add_subdirectory(operations) add_subdirectory(resource_subscriber) add_subdirectory(resources) add_subdirectory(splitter) +add_subdirectory(transactions) add_subdirectory(ut_rw) add_subdirectory(ut_schema) get_built_tool_path( @@ -50,12 +51,15 @@ target_link_libraries(core-tx-columnshard PUBLIC ydb-core-protos ydb-core-tablet ydb-core-tablet_flat + core-tx-time_cast tx-columnshard-engines columnshard-engines-writer tx-columnshard-counters tx-columnshard-common tx-columnshard-splitter tx-columnshard-operations + tx-columnshard-transactions + columnshard-transactions-operators tx-columnshard-blobs_reader tx-columnshard-blobs_action tx-columnshard-resource_subscriber @@ -81,7 +85,6 @@ target_sources(core-tx-columnshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__progress_tx.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__propose_cancel.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__propose_transaction.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__read.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__read_base.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__scan.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__index_scan.cpp @@ -96,10 +99,8 @@ target_sources(core-tx-columnshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard_view.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/defs.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/read_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/write_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/tables_manager.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/tx_controller.cpp ) generate_enum_serilization(core-tx-columnshard ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard.h diff --git a/ydb/core/tx/columnshard/CMakeLists.linux-x86_64.txt b/ydb/core/tx/columnshard/CMakeLists.linux-x86_64.txt index b80449d91da1..3c3c5f0ba7c1 100644 --- a/ydb/core/tx/columnshard/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/columnshard/CMakeLists.linux-x86_64.txt @@ -17,6 +17,7 @@ add_subdirectory(operations) add_subdirectory(resource_subscriber) add_subdirectory(resources) add_subdirectory(splitter) +add_subdirectory(transactions) add_subdirectory(ut_rw) add_subdirectory(ut_schema) get_built_tool_path( @@ -50,12 +51,15 @@ target_link_libraries(core-tx-columnshard PUBLIC ydb-core-protos ydb-core-tablet ydb-core-tablet_flat + core-tx-time_cast tx-columnshard-engines columnshard-engines-writer tx-columnshard-counters tx-columnshard-common tx-columnshard-splitter tx-columnshard-operations + tx-columnshard-transactions + columnshard-transactions-operators tx-columnshard-blobs_reader tx-columnshard-blobs_action tx-columnshard-resource_subscriber @@ -81,7 +85,6 @@ target_sources(core-tx-columnshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__progress_tx.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__propose_cancel.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__propose_transaction.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__read.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__read_base.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__scan.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__index_scan.cpp @@ -96,10 +99,8 @@ target_sources(core-tx-columnshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard_view.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/defs.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/read_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/write_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/tables_manager.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/tx_controller.cpp ) generate_enum_serilization(core-tx-columnshard ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard.h diff --git a/ydb/core/tx/columnshard/CMakeLists.windows-x86_64.txt b/ydb/core/tx/columnshard/CMakeLists.windows-x86_64.txt index 22054ed5de6c..7724c86a6f8b 100644 --- a/ydb/core/tx/columnshard/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/columnshard/CMakeLists.windows-x86_64.txt @@ -17,6 +17,7 @@ add_subdirectory(operations) add_subdirectory(resource_subscriber) add_subdirectory(resources) add_subdirectory(splitter) +add_subdirectory(transactions) add_subdirectory(ut_rw) add_subdirectory(ut_schema) get_built_tool_path( @@ -50,12 +51,15 @@ target_link_libraries(core-tx-columnshard PUBLIC ydb-core-protos ydb-core-tablet ydb-core-tablet_flat + core-tx-time_cast tx-columnshard-engines columnshard-engines-writer tx-columnshard-counters tx-columnshard-common tx-columnshard-splitter tx-columnshard-operations + tx-columnshard-transactions + columnshard-transactions-operators tx-columnshard-blobs_reader tx-columnshard-blobs_action tx-columnshard-resource_subscriber @@ -81,7 +85,6 @@ target_sources(core-tx-columnshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__progress_tx.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__propose_cancel.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__propose_transaction.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__read.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__read_base.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__scan.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard__index_scan.cpp @@ -96,10 +99,8 @@ target_sources(core-tx-columnshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard_view.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/defs.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/read_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/write_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/tables_manager.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/tx_controller.cpp ) generate_enum_serilization(core-tx-columnshard ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard.h diff --git a/ydb/core/tx/columnshard/engines/predicate/CMakeLists.darwin-arm64.txt b/ydb/core/tx/columnshard/engines/predicate/CMakeLists.darwin-arm64.txt index 0c1f4b43211f..3246d3a047d5 100644 --- a/ydb/core/tx/columnshard/engines/predicate/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/columnshard/engines/predicate/CMakeLists.darwin-arm64.txt @@ -8,6 +8,9 @@ add_library(columnshard-engines-predicate) +target_compile_options(columnshard-engines-predicate PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) target_link_libraries(columnshard-engines-predicate PUBLIC contrib-libs-cxxsupp yutil diff --git a/ydb/core/tx/columnshard/engines/predicate/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/columnshard/engines/predicate/CMakeLists.darwin-x86_64.txt index 0c1f4b43211f..3246d3a047d5 100644 --- a/ydb/core/tx/columnshard/engines/predicate/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/columnshard/engines/predicate/CMakeLists.darwin-x86_64.txt @@ -8,6 +8,9 @@ add_library(columnshard-engines-predicate) +target_compile_options(columnshard-engines-predicate PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) target_link_libraries(columnshard-engines-predicate PUBLIC contrib-libs-cxxsupp yutil diff --git a/ydb/core/tx/columnshard/engines/predicate/CMakeLists.linux-aarch64.txt b/ydb/core/tx/columnshard/engines/predicate/CMakeLists.linux-aarch64.txt index 1fedfdeb94a5..54501ee5fdb6 100644 --- a/ydb/core/tx/columnshard/engines/predicate/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/columnshard/engines/predicate/CMakeLists.linux-aarch64.txt @@ -8,6 +8,9 @@ add_library(columnshard-engines-predicate) +target_compile_options(columnshard-engines-predicate PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) target_link_libraries(columnshard-engines-predicate PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp diff --git a/ydb/core/tx/columnshard/engines/predicate/CMakeLists.linux-x86_64.txt b/ydb/core/tx/columnshard/engines/predicate/CMakeLists.linux-x86_64.txt index 1fedfdeb94a5..54501ee5fdb6 100644 --- a/ydb/core/tx/columnshard/engines/predicate/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/columnshard/engines/predicate/CMakeLists.linux-x86_64.txt @@ -8,6 +8,9 @@ add_library(columnshard-engines-predicate) +target_compile_options(columnshard-engines-predicate PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) target_link_libraries(columnshard-engines-predicate PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp diff --git a/ydb/core/tx/columnshard/engines/predicate/CMakeLists.windows-x86_64.txt b/ydb/core/tx/columnshard/engines/predicate/CMakeLists.windows-x86_64.txt index 0c1f4b43211f..3246d3a047d5 100644 --- a/ydb/core/tx/columnshard/engines/predicate/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/columnshard/engines/predicate/CMakeLists.windows-x86_64.txt @@ -8,6 +8,9 @@ add_library(columnshard-engines-predicate) +target_compile_options(columnshard-engines-predicate PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) target_link_libraries(columnshard-engines-predicate PUBLIC contrib-libs-cxxsupp yutil diff --git a/ydb/core/tx/columnshard/engines/reader/plain_reader/CMakeLists.darwin-arm64.txt b/ydb/core/tx/columnshard/engines/reader/plain_reader/CMakeLists.darwin-arm64.txt index a2a2b2fef8cc..1ae5e959e98b 100644 --- a/ydb/core/tx/columnshard/engines/reader/plain_reader/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/columnshard/engines/reader/plain_reader/CMakeLists.darwin-arm64.txt @@ -17,14 +17,12 @@ target_link_libraries(engines-reader-plain_reader PUBLIC ) target_sources(engines-reader-plain_reader PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/scanner.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/source.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/constructor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/source.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/interval.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/fetched_data.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/plain_read_data.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/filter_assembler.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/column_assembler.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/committed_assembler.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/columns_set.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/context.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/fetching.cpp ) diff --git a/ydb/core/tx/columnshard/engines/reader/plain_reader/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/columnshard/engines/reader/plain_reader/CMakeLists.darwin-x86_64.txt index a2a2b2fef8cc..1ae5e959e98b 100644 --- a/ydb/core/tx/columnshard/engines/reader/plain_reader/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/columnshard/engines/reader/plain_reader/CMakeLists.darwin-x86_64.txt @@ -17,14 +17,12 @@ target_link_libraries(engines-reader-plain_reader PUBLIC ) target_sources(engines-reader-plain_reader PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/scanner.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/source.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/constructor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/source.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/interval.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/fetched_data.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/plain_read_data.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/filter_assembler.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/column_assembler.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/committed_assembler.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/columns_set.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/context.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/fetching.cpp ) diff --git a/ydb/core/tx/columnshard/engines/reader/plain_reader/CMakeLists.linux-aarch64.txt b/ydb/core/tx/columnshard/engines/reader/plain_reader/CMakeLists.linux-aarch64.txt index 44d5df1539f1..4df4f212d2e6 100644 --- a/ydb/core/tx/columnshard/engines/reader/plain_reader/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/columnshard/engines/reader/plain_reader/CMakeLists.linux-aarch64.txt @@ -18,14 +18,12 @@ target_link_libraries(engines-reader-plain_reader PUBLIC ) target_sources(engines-reader-plain_reader PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/scanner.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/source.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/constructor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/source.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/interval.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/fetched_data.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/plain_read_data.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/filter_assembler.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/column_assembler.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/committed_assembler.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/columns_set.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/context.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/fetching.cpp ) diff --git a/ydb/core/tx/columnshard/engines/reader/plain_reader/CMakeLists.linux-x86_64.txt b/ydb/core/tx/columnshard/engines/reader/plain_reader/CMakeLists.linux-x86_64.txt index 44d5df1539f1..4df4f212d2e6 100644 --- a/ydb/core/tx/columnshard/engines/reader/plain_reader/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/columnshard/engines/reader/plain_reader/CMakeLists.linux-x86_64.txt @@ -18,14 +18,12 @@ target_link_libraries(engines-reader-plain_reader PUBLIC ) target_sources(engines-reader-plain_reader PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/scanner.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/source.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/constructor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/source.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/interval.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/fetched_data.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/plain_read_data.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/filter_assembler.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/column_assembler.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/committed_assembler.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/columns_set.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/context.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/fetching.cpp ) diff --git a/ydb/core/tx/columnshard/engines/reader/plain_reader/CMakeLists.windows-x86_64.txt b/ydb/core/tx/columnshard/engines/reader/plain_reader/CMakeLists.windows-x86_64.txt index a2a2b2fef8cc..1ae5e959e98b 100644 --- a/ydb/core/tx/columnshard/engines/reader/plain_reader/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/columnshard/engines/reader/plain_reader/CMakeLists.windows-x86_64.txt @@ -17,14 +17,12 @@ target_link_libraries(engines-reader-plain_reader PUBLIC ) target_sources(engines-reader-plain_reader PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/scanner.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/source.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/constructor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/source.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/interval.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/fetched_data.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/plain_read_data.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/filter_assembler.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/column_assembler.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/committed_assembler.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/columns_set.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/context.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/reader/plain_reader/fetching.cpp ) diff --git a/ydb/core/tx/columnshard/engines/scheme/CMakeLists.darwin-arm64.txt b/ydb/core/tx/columnshard/engines/scheme/CMakeLists.darwin-arm64.txt index 8a4b2b5ca5fe..ff848baca1a6 100644 --- a/ydb/core/tx/columnshard/engines/scheme/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/columnshard/engines/scheme/CMakeLists.darwin-arm64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(indexes) add_library(columnshard-engines-scheme) target_compile_options(columnshard-engines-scheme PRIVATE @@ -17,6 +18,7 @@ target_link_libraries(columnshard-engines-scheme PUBLIC ydb-core-protos core-formats-arrow library-actors-core + engines-scheme-indexes ) target_sources(columnshard-engines-scheme PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/abstract_scheme.cpp diff --git a/ydb/core/tx/columnshard/engines/scheme/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/columnshard/engines/scheme/CMakeLists.darwin-x86_64.txt index 8a4b2b5ca5fe..ff848baca1a6 100644 --- a/ydb/core/tx/columnshard/engines/scheme/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/columnshard/engines/scheme/CMakeLists.darwin-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(indexes) add_library(columnshard-engines-scheme) target_compile_options(columnshard-engines-scheme PRIVATE @@ -17,6 +18,7 @@ target_link_libraries(columnshard-engines-scheme PUBLIC ydb-core-protos core-formats-arrow library-actors-core + engines-scheme-indexes ) target_sources(columnshard-engines-scheme PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/abstract_scheme.cpp diff --git a/ydb/core/tx/columnshard/engines/scheme/CMakeLists.linux-aarch64.txt b/ydb/core/tx/columnshard/engines/scheme/CMakeLists.linux-aarch64.txt index b4c04478cd3e..df52b32b8c5d 100644 --- a/ydb/core/tx/columnshard/engines/scheme/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/columnshard/engines/scheme/CMakeLists.linux-aarch64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(indexes) add_library(columnshard-engines-scheme) target_compile_options(columnshard-engines-scheme PRIVATE @@ -18,6 +19,7 @@ target_link_libraries(columnshard-engines-scheme PUBLIC ydb-core-protos core-formats-arrow library-actors-core + engines-scheme-indexes ) target_sources(columnshard-engines-scheme PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/abstract_scheme.cpp diff --git a/ydb/core/tx/columnshard/engines/scheme/CMakeLists.linux-x86_64.txt b/ydb/core/tx/columnshard/engines/scheme/CMakeLists.linux-x86_64.txt index b4c04478cd3e..df52b32b8c5d 100644 --- a/ydb/core/tx/columnshard/engines/scheme/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/columnshard/engines/scheme/CMakeLists.linux-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(indexes) add_library(columnshard-engines-scheme) target_compile_options(columnshard-engines-scheme PRIVATE @@ -18,6 +19,7 @@ target_link_libraries(columnshard-engines-scheme PUBLIC ydb-core-protos core-formats-arrow library-actors-core + engines-scheme-indexes ) target_sources(columnshard-engines-scheme PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/abstract_scheme.cpp diff --git a/ydb/core/tx/columnshard/engines/scheme/CMakeLists.windows-x86_64.txt b/ydb/core/tx/columnshard/engines/scheme/CMakeLists.windows-x86_64.txt index 8a4b2b5ca5fe..ff848baca1a6 100644 --- a/ydb/core/tx/columnshard/engines/scheme/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/columnshard/engines/scheme/CMakeLists.windows-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(indexes) add_library(columnshard-engines-scheme) target_compile_options(columnshard-engines-scheme PRIVATE @@ -17,6 +18,7 @@ target_link_libraries(columnshard-engines-scheme PUBLIC ydb-core-protos core-formats-arrow library-actors-core + engines-scheme-indexes ) target_sources(columnshard-engines-scheme PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/abstract_scheme.cpp diff --git a/ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.darwin-arm64.txt b/ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..91fd0677fbe8 --- /dev/null +++ b/ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.darwin-arm64.txt @@ -0,0 +1,18 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(abstract) +add_subdirectory(bloom) + +add_library(engines-scheme-indexes INTERFACE) +target_link_libraries(engines-scheme-indexes INTERFACE + contrib-libs-cxxsupp + yutil + scheme-indexes-abstract + scheme-indexes-bloom +) diff --git a/ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..91fd0677fbe8 --- /dev/null +++ b/ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,18 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(abstract) +add_subdirectory(bloom) + +add_library(engines-scheme-indexes INTERFACE) +target_link_libraries(engines-scheme-indexes INTERFACE + contrib-libs-cxxsupp + yutil + scheme-indexes-abstract + scheme-indexes-bloom +) diff --git a/ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.linux-aarch64.txt b/ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..81afd01ecc00 --- /dev/null +++ b/ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.linux-aarch64.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(abstract) +add_subdirectory(bloom) + +add_library(engines-scheme-indexes INTERFACE) +target_link_libraries(engines-scheme-indexes INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + scheme-indexes-abstract + scheme-indexes-bloom +) diff --git a/ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.linux-x86_64.txt b/ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..81afd01ecc00 --- /dev/null +++ b/ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.linux-x86_64.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(abstract) +add_subdirectory(bloom) + +add_library(engines-scheme-indexes INTERFACE) +target_link_libraries(engines-scheme-indexes INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + scheme-indexes-abstract + scheme-indexes-bloom +) diff --git a/ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.txt b/ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.windows-x86_64.txt b/ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..91fd0677fbe8 --- /dev/null +++ b/ydb/core/tx/columnshard/engines/scheme/indexes/CMakeLists.windows-x86_64.txt @@ -0,0 +1,18 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(abstract) +add_subdirectory(bloom) + +add_library(engines-scheme-indexes INTERFACE) +target_link_libraries(engines-scheme-indexes INTERFACE + contrib-libs-cxxsupp + yutil + scheme-indexes-abstract + scheme-indexes-bloom +) diff --git a/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.darwin-arm64.txt b/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..f1fe2605a6fa --- /dev/null +++ b/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.darwin-arm64.txt @@ -0,0 +1,40 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(scheme-indexes-abstract) +target_compile_options(scheme-indexes-abstract PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(scheme-indexes-abstract PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-protos + core-formats-arrow +) +target_sources(scheme-indexes-abstract PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/constructor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/meta.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/checker.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/program.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/simple.cpp +) + +add_global_library_for(scheme-indexes-abstract.global scheme-indexes-abstract) +target_compile_options(scheme-indexes-abstract.global PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(scheme-indexes-abstract.global PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-protos + core-formats-arrow +) +target_sources(scheme-indexes-abstract.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/composite.cpp +) diff --git a/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..f1fe2605a6fa --- /dev/null +++ b/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,40 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(scheme-indexes-abstract) +target_compile_options(scheme-indexes-abstract PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(scheme-indexes-abstract PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-protos + core-formats-arrow +) +target_sources(scheme-indexes-abstract PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/constructor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/meta.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/checker.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/program.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/simple.cpp +) + +add_global_library_for(scheme-indexes-abstract.global scheme-indexes-abstract) +target_compile_options(scheme-indexes-abstract.global PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(scheme-indexes-abstract.global PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-protos + core-formats-arrow +) +target_sources(scheme-indexes-abstract.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/composite.cpp +) diff --git a/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.linux-aarch64.txt b/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..156f15256004 --- /dev/null +++ b/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.linux-aarch64.txt @@ -0,0 +1,42 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(scheme-indexes-abstract) +target_compile_options(scheme-indexes-abstract PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(scheme-indexes-abstract PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-protos + core-formats-arrow +) +target_sources(scheme-indexes-abstract PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/constructor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/meta.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/checker.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/program.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/simple.cpp +) + +add_global_library_for(scheme-indexes-abstract.global scheme-indexes-abstract) +target_compile_options(scheme-indexes-abstract.global PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(scheme-indexes-abstract.global PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-protos + core-formats-arrow +) +target_sources(scheme-indexes-abstract.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/composite.cpp +) diff --git a/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.linux-x86_64.txt b/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..156f15256004 --- /dev/null +++ b/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.linux-x86_64.txt @@ -0,0 +1,42 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(scheme-indexes-abstract) +target_compile_options(scheme-indexes-abstract PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(scheme-indexes-abstract PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-protos + core-formats-arrow +) +target_sources(scheme-indexes-abstract PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/constructor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/meta.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/checker.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/program.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/simple.cpp +) + +add_global_library_for(scheme-indexes-abstract.global scheme-indexes-abstract) +target_compile_options(scheme-indexes-abstract.global PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(scheme-indexes-abstract.global PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-protos + core-formats-arrow +) +target_sources(scheme-indexes-abstract.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/composite.cpp +) diff --git a/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.txt b/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.windows-x86_64.txt b/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..f1fe2605a6fa --- /dev/null +++ b/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/CMakeLists.windows-x86_64.txt @@ -0,0 +1,40 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(scheme-indexes-abstract) +target_compile_options(scheme-indexes-abstract PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(scheme-indexes-abstract PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-protos + core-formats-arrow +) +target_sources(scheme-indexes-abstract PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/constructor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/meta.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/checker.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/program.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/simple.cpp +) + +add_global_library_for(scheme-indexes-abstract.global scheme-indexes-abstract) +target_compile_options(scheme-indexes-abstract.global PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(scheme-indexes-abstract.global PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-protos + core-formats-arrow +) +target_sources(scheme-indexes-abstract.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/abstract/composite.cpp +) diff --git a/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.darwin-arm64.txt b/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..e5282c0d2e12 --- /dev/null +++ b/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.darwin-arm64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(scheme-indexes-bloom INTERFACE) +target_link_libraries(scheme-indexes-bloom INTERFACE + contrib-libs-cxxsupp + yutil + ydb-core-protos + core-formats-arrow +) + +add_global_library_for(scheme-indexes-bloom.global scheme-indexes-bloom) +target_link_libraries(scheme-indexes-bloom.global PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-protos + core-formats-arrow +) +target_sources(scheme-indexes-bloom.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/constructor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/meta.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/checker.cpp +) diff --git a/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..e5282c0d2e12 --- /dev/null +++ b/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(scheme-indexes-bloom INTERFACE) +target_link_libraries(scheme-indexes-bloom INTERFACE + contrib-libs-cxxsupp + yutil + ydb-core-protos + core-formats-arrow +) + +add_global_library_for(scheme-indexes-bloom.global scheme-indexes-bloom) +target_link_libraries(scheme-indexes-bloom.global PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-protos + core-formats-arrow +) +target_sources(scheme-indexes-bloom.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/constructor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/meta.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/checker.cpp +) diff --git a/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.linux-aarch64.txt b/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..66fa2e29226a --- /dev/null +++ b/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.linux-aarch64.txt @@ -0,0 +1,31 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(scheme-indexes-bloom INTERFACE) +target_link_libraries(scheme-indexes-bloom INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-protos + core-formats-arrow +) + +add_global_library_for(scheme-indexes-bloom.global scheme-indexes-bloom) +target_link_libraries(scheme-indexes-bloom.global PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-protos + core-formats-arrow +) +target_sources(scheme-indexes-bloom.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/constructor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/meta.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/checker.cpp +) diff --git a/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.linux-x86_64.txt b/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..66fa2e29226a --- /dev/null +++ b/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.linux-x86_64.txt @@ -0,0 +1,31 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(scheme-indexes-bloom INTERFACE) +target_link_libraries(scheme-indexes-bloom INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-protos + core-formats-arrow +) + +add_global_library_for(scheme-indexes-bloom.global scheme-indexes-bloom) +target_link_libraries(scheme-indexes-bloom.global PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-protos + core-formats-arrow +) +target_sources(scheme-indexes-bloom.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/constructor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/meta.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/checker.cpp +) diff --git a/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.txt b/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.windows-x86_64.txt b/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..e5282c0d2e12 --- /dev/null +++ b/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/CMakeLists.windows-x86_64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(scheme-indexes-bloom INTERFACE) +target_link_libraries(scheme-indexes-bloom INTERFACE + contrib-libs-cxxsupp + yutil + ydb-core-protos + core-formats-arrow +) + +add_global_library_for(scheme-indexes-bloom.global scheme-indexes-bloom) +target_link_libraries(scheme-indexes-bloom.global PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-protos + core-formats-arrow +) +target_sources(scheme-indexes-bloom.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/constructor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/meta.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/scheme/indexes/bloom/checker.cpp +) diff --git a/ydb/core/tx/columnshard/engines/ut/CMakeLists.darwin-arm64.txt b/ydb/core/tx/columnshard/engines/ut/CMakeLists.darwin-arm64.txt index 38152a164d0e..3c22c9b91012 100644 --- a/ydb/core/tx/columnshard/engines/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/columnshard/engines/ut/CMakeLists.darwin-arm64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-columnshard-engines-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-columnshard-engines-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut_insert_table.cpp @@ -69,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/columnshard/engines/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/columnshard/engines/ut/CMakeLists.darwin-x86_64.txt index b2ebd6d00523..dc865136f54a 100644 --- a/ydb/core/tx/columnshard/engines/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/columnshard/engines/ut/CMakeLists.darwin-x86_64.txt @@ -36,8 +36,6 @@ target_link_options(ydb-core-tx-columnshard-engines-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-columnshard-engines-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut_insert_table.cpp @@ -70,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/columnshard/engines/ut/CMakeLists.linux-aarch64.txt b/ydb/core/tx/columnshard/engines/ut/CMakeLists.linux-aarch64.txt index c60d79794a3c..76a2f24b957f 100644 --- a/ydb/core/tx/columnshard/engines/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/columnshard/engines/ut/CMakeLists.linux-aarch64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-columnshard-engines-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-columnshard-engines-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut_insert_table.cpp @@ -73,6 +70,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/columnshard/engines/ut/CMakeLists.linux-x86_64.txt b/ydb/core/tx/columnshard/engines/ut/CMakeLists.linux-x86_64.txt index 9748cc589aff..87d5326bd1d9 100644 --- a/ydb/core/tx/columnshard/engines/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/columnshard/engines/ut/CMakeLists.linux-x86_64.txt @@ -39,9 +39,6 @@ target_link_options(ydb-core-tx-columnshard-engines-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-columnshard-engines-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut_insert_table.cpp @@ -74,6 +71,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/columnshard/engines/ut/CMakeLists.windows-x86_64.txt b/ydb/core/tx/columnshard/engines/ut/CMakeLists.windows-x86_64.txt index 687550a86063..455116c18f12 100644 --- a/ydb/core/tx/columnshard/engines/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/columnshard/engines/ut/CMakeLists.windows-x86_64.txt @@ -63,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/columnshard/engines/writer/CMakeLists.darwin-arm64.txt b/ydb/core/tx/columnshard/engines/writer/CMakeLists.darwin-arm64.txt index b2d1bcb6c402..f9552befc4cd 100644 --- a/ydb/core/tx/columnshard/engines/writer/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/columnshard/engines/writer/CMakeLists.darwin-arm64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(buffer) add_library(columnshard-engines-writer) target_compile_options(columnshard-engines-writer PRIVATE @@ -19,6 +20,7 @@ target_link_libraries(columnshard-engines-writer PUBLIC blobstorage-vdisk-protos ydb-core-tablet_flat core-formats-arrow + engines-writer-buffer library-actors-core ) target_sources(columnshard-engines-writer PRIVATE diff --git a/ydb/core/tx/columnshard/engines/writer/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/columnshard/engines/writer/CMakeLists.darwin-x86_64.txt index b2d1bcb6c402..f9552befc4cd 100644 --- a/ydb/core/tx/columnshard/engines/writer/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/columnshard/engines/writer/CMakeLists.darwin-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(buffer) add_library(columnshard-engines-writer) target_compile_options(columnshard-engines-writer PRIVATE @@ -19,6 +20,7 @@ target_link_libraries(columnshard-engines-writer PUBLIC blobstorage-vdisk-protos ydb-core-tablet_flat core-formats-arrow + engines-writer-buffer library-actors-core ) target_sources(columnshard-engines-writer PRIVATE diff --git a/ydb/core/tx/columnshard/engines/writer/CMakeLists.linux-aarch64.txt b/ydb/core/tx/columnshard/engines/writer/CMakeLists.linux-aarch64.txt index f583bbb57571..059239b8a589 100644 --- a/ydb/core/tx/columnshard/engines/writer/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/columnshard/engines/writer/CMakeLists.linux-aarch64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(buffer) add_library(columnshard-engines-writer) target_compile_options(columnshard-engines-writer PRIVATE @@ -20,6 +21,7 @@ target_link_libraries(columnshard-engines-writer PUBLIC blobstorage-vdisk-protos ydb-core-tablet_flat core-formats-arrow + engines-writer-buffer library-actors-core ) target_sources(columnshard-engines-writer PRIVATE diff --git a/ydb/core/tx/columnshard/engines/writer/CMakeLists.linux-x86_64.txt b/ydb/core/tx/columnshard/engines/writer/CMakeLists.linux-x86_64.txt index f583bbb57571..059239b8a589 100644 --- a/ydb/core/tx/columnshard/engines/writer/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/columnshard/engines/writer/CMakeLists.linux-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(buffer) add_library(columnshard-engines-writer) target_compile_options(columnshard-engines-writer PRIVATE @@ -20,6 +21,7 @@ target_link_libraries(columnshard-engines-writer PUBLIC blobstorage-vdisk-protos ydb-core-tablet_flat core-formats-arrow + engines-writer-buffer library-actors-core ) target_sources(columnshard-engines-writer PRIVATE diff --git a/ydb/core/tx/columnshard/engines/writer/CMakeLists.windows-x86_64.txt b/ydb/core/tx/columnshard/engines/writer/CMakeLists.windows-x86_64.txt index b2d1bcb6c402..f9552befc4cd 100644 --- a/ydb/core/tx/columnshard/engines/writer/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/columnshard/engines/writer/CMakeLists.windows-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(buffer) add_library(columnshard-engines-writer) target_compile_options(columnshard-engines-writer PRIVATE @@ -19,6 +20,7 @@ target_link_libraries(columnshard-engines-writer PUBLIC blobstorage-vdisk-protos ydb-core-tablet_flat core-formats-arrow + engines-writer-buffer library-actors-core ) target_sources(columnshard-engines-writer PRIVATE diff --git a/ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.darwin-arm64.txt b/ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..0dbf8dfecb14 --- /dev/null +++ b/ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.darwin-arm64.txt @@ -0,0 +1,23 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(engines-writer-buffer) +target_link_libraries(engines-writer-buffer PUBLIC + contrib-libs-cxxsupp + yutil + library-actors-core + ydb-core-protos + ydb-core-tablet_flat + yql-core-expr_nodes + actors-testlib-common +) +target_sources(engines-writer-buffer PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/writer/buffer/actor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/writer/buffer/events.cpp +) diff --git a/ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..0dbf8dfecb14 --- /dev/null +++ b/ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,23 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(engines-writer-buffer) +target_link_libraries(engines-writer-buffer PUBLIC + contrib-libs-cxxsupp + yutil + library-actors-core + ydb-core-protos + ydb-core-tablet_flat + yql-core-expr_nodes + actors-testlib-common +) +target_sources(engines-writer-buffer PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/writer/buffer/actor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/writer/buffer/events.cpp +) diff --git a/ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.linux-aarch64.txt b/ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..7d54501a3a89 --- /dev/null +++ b/ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.linux-aarch64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(engines-writer-buffer) +target_link_libraries(engines-writer-buffer PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-actors-core + ydb-core-protos + ydb-core-tablet_flat + yql-core-expr_nodes + actors-testlib-common +) +target_sources(engines-writer-buffer PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/writer/buffer/actor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/writer/buffer/events.cpp +) diff --git a/ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.linux-x86_64.txt b/ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..7d54501a3a89 --- /dev/null +++ b/ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.linux-x86_64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(engines-writer-buffer) +target_link_libraries(engines-writer-buffer PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-actors-core + ydb-core-protos + ydb-core-tablet_flat + yql-core-expr_nodes + actors-testlib-common +) +target_sources(engines-writer-buffer PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/writer/buffer/actor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/writer/buffer/events.cpp +) diff --git a/ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.txt b/ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.windows-x86_64.txt b/ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..0dbf8dfecb14 --- /dev/null +++ b/ydb/core/tx/columnshard/engines/writer/buffer/CMakeLists.windows-x86_64.txt @@ -0,0 +1,23 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(engines-writer-buffer) +target_link_libraries(engines-writer-buffer PUBLIC + contrib-libs-cxxsupp + yutil + library-actors-core + ydb-core-protos + ydb-core-tablet_flat + yql-core-expr_nodes + actors-testlib-common +) +target_sources(engines-writer-buffer PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/writer/buffer/actor.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/writer/buffer/events.cpp +) diff --git a/ydb/core/tx/columnshard/splitter/ut/CMakeLists.darwin-arm64.txt b/ydb/core/tx/columnshard/splitter/ut/CMakeLists.darwin-arm64.txt index a3bb444c1e83..f98480ff1618 100644 --- a/ydb/core/tx/columnshard/splitter/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/columnshard/splitter/ut/CMakeLists.darwin-arm64.txt @@ -25,6 +25,7 @@ target_link_libraries(ydb-core-tx-columnshard-splitter-ut PUBLIC ydb-library-arrow_kernels tx-columnshard-counters formats-arrow-compression + columnshard-engines-portions core-kqp-common yql-parser-pg_wrapper yql-public-udf @@ -33,15 +34,17 @@ target_link_libraries(ydb-core-tx-columnshard-splitter-ut PUBLIC core-tx-tx_proxy ydb-core-tx ydb-core-mind + minikql-comp_nodes-llvm14 udf-service-exception_policy yql-sql-pg + ydb-services-kesus + ydb-services-persqueue_cluster_discovery + ydb-services-ydb ) target_link_options(ydb-core-tx-columnshard-splitter-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-columnshard-splitter-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/splitter/ut/ut_splitter.cpp @@ -71,6 +74,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/columnshard/splitter/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/columnshard/splitter/ut/CMakeLists.darwin-x86_64.txt index 9a37386f9988..1464bd756537 100644 --- a/ydb/core/tx/columnshard/splitter/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/columnshard/splitter/ut/CMakeLists.darwin-x86_64.txt @@ -26,6 +26,7 @@ target_link_libraries(ydb-core-tx-columnshard-splitter-ut PUBLIC ydb-library-arrow_kernels tx-columnshard-counters formats-arrow-compression + columnshard-engines-portions core-kqp-common yql-parser-pg_wrapper yql-public-udf @@ -34,15 +35,17 @@ target_link_libraries(ydb-core-tx-columnshard-splitter-ut PUBLIC core-tx-tx_proxy ydb-core-tx ydb-core-mind + minikql-comp_nodes-llvm14 udf-service-exception_policy yql-sql-pg + ydb-services-kesus + ydb-services-persqueue_cluster_discovery + ydb-services-ydb ) target_link_options(ydb-core-tx-columnshard-splitter-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-columnshard-splitter-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/splitter/ut/ut_splitter.cpp @@ -72,6 +75,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/columnshard/splitter/ut/CMakeLists.linux-aarch64.txt b/ydb/core/tx/columnshard/splitter/ut/CMakeLists.linux-aarch64.txt index 4004fb00acab..9a8695fb440f 100644 --- a/ydb/core/tx/columnshard/splitter/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/columnshard/splitter/ut/CMakeLists.linux-aarch64.txt @@ -26,6 +26,7 @@ target_link_libraries(ydb-core-tx-columnshard-splitter-ut PUBLIC ydb-library-arrow_kernels tx-columnshard-counters formats-arrow-compression + columnshard-engines-portions core-kqp-common yql-parser-pg_wrapper yql-public-udf @@ -34,8 +35,12 @@ target_link_libraries(ydb-core-tx-columnshard-splitter-ut PUBLIC core-tx-tx_proxy ydb-core-tx ydb-core-mind + minikql-comp_nodes-llvm14 udf-service-exception_policy yql-sql-pg + ydb-services-kesus + ydb-services-persqueue_cluster_discovery + ydb-services-ydb ) target_link_options(ydb-core-tx-columnshard-splitter-ut PRIVATE -ldl @@ -43,9 +48,6 @@ target_link_options(ydb-core-tx-columnshard-splitter-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-columnshard-splitter-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/splitter/ut/ut_splitter.cpp @@ -75,6 +77,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/columnshard/splitter/ut/CMakeLists.linux-x86_64.txt b/ydb/core/tx/columnshard/splitter/ut/CMakeLists.linux-x86_64.txt index 78af7fd737f9..2835eecec505 100644 --- a/ydb/core/tx/columnshard/splitter/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/columnshard/splitter/ut/CMakeLists.linux-x86_64.txt @@ -27,6 +27,7 @@ target_link_libraries(ydb-core-tx-columnshard-splitter-ut PUBLIC ydb-library-arrow_kernels tx-columnshard-counters formats-arrow-compression + columnshard-engines-portions core-kqp-common yql-parser-pg_wrapper yql-public-udf @@ -35,8 +36,12 @@ target_link_libraries(ydb-core-tx-columnshard-splitter-ut PUBLIC core-tx-tx_proxy ydb-core-tx ydb-core-mind + minikql-comp_nodes-llvm14 udf-service-exception_policy yql-sql-pg + ydb-services-kesus + ydb-services-persqueue_cluster_discovery + ydb-services-ydb ) target_link_options(ydb-core-tx-columnshard-splitter-ut PRIVATE -ldl @@ -44,9 +49,6 @@ target_link_options(ydb-core-tx-columnshard-splitter-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-columnshard-splitter-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/splitter/ut/ut_splitter.cpp @@ -76,6 +78,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/columnshard/splitter/ut/CMakeLists.windows-x86_64.txt b/ydb/core/tx/columnshard/splitter/ut/CMakeLists.windows-x86_64.txt index 344442f4e89c..93e1b126e61a 100644 --- a/ydb/core/tx/columnshard/splitter/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/columnshard/splitter/ut/CMakeLists.windows-x86_64.txt @@ -26,6 +26,7 @@ target_link_libraries(ydb-core-tx-columnshard-splitter-ut PUBLIC ydb-library-arrow_kernels tx-columnshard-counters formats-arrow-compression + columnshard-engines-portions core-kqp-common yql-parser-pg_wrapper yql-public-udf @@ -34,8 +35,12 @@ target_link_libraries(ydb-core-tx-columnshard-splitter-ut PUBLIC core-tx-tx_proxy ydb-core-tx ydb-core-mind + minikql-comp_nodes-llvm14 udf-service-exception_policy yql-sql-pg + ydb-services-kesus + ydb-services-persqueue_cluster_discovery + ydb-services-ydb ) target_sources(ydb-core-tx-columnshard-splitter-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/splitter/ut/ut_splitter.cpp @@ -65,6 +70,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/columnshard/transactions/CMakeLists.darwin-arm64.txt b/ydb/core/tx/columnshard/transactions/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..1c1f0c7af617 --- /dev/null +++ b/ydb/core/tx/columnshard/transactions/CMakeLists.darwin-arm64.txt @@ -0,0 +1,23 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(operators) + +add_library(tx-columnshard-transactions) +target_compile_options(tx-columnshard-transactions PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(tx-columnshard-transactions PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-tablet_flat + core-tx-data_events +) +target_sources(tx-columnshard-transactions PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/transactions/tx_controller.cpp +) diff --git a/ydb/core/tx/columnshard/transactions/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/columnshard/transactions/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..1c1f0c7af617 --- /dev/null +++ b/ydb/core/tx/columnshard/transactions/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,23 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(operators) + +add_library(tx-columnshard-transactions) +target_compile_options(tx-columnshard-transactions PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(tx-columnshard-transactions PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-tablet_flat + core-tx-data_events +) +target_sources(tx-columnshard-transactions PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/transactions/tx_controller.cpp +) diff --git a/ydb/core/tx/columnshard/transactions/CMakeLists.linux-aarch64.txt b/ydb/core/tx/columnshard/transactions/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..f16f3e9b6702 --- /dev/null +++ b/ydb/core/tx/columnshard/transactions/CMakeLists.linux-aarch64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(operators) + +add_library(tx-columnshard-transactions) +target_compile_options(tx-columnshard-transactions PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(tx-columnshard-transactions PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-tablet_flat + core-tx-data_events +) +target_sources(tx-columnshard-transactions PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/transactions/tx_controller.cpp +) diff --git a/ydb/core/tx/columnshard/transactions/CMakeLists.linux-x86_64.txt b/ydb/core/tx/columnshard/transactions/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..f16f3e9b6702 --- /dev/null +++ b/ydb/core/tx/columnshard/transactions/CMakeLists.linux-x86_64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(operators) + +add_library(tx-columnshard-transactions) +target_compile_options(tx-columnshard-transactions PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(tx-columnshard-transactions PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-tablet_flat + core-tx-data_events +) +target_sources(tx-columnshard-transactions PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/transactions/tx_controller.cpp +) diff --git a/ydb/core/tx/columnshard/transactions/CMakeLists.txt b/ydb/core/tx/columnshard/transactions/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/tx/columnshard/transactions/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/tx/columnshard/transactions/CMakeLists.windows-x86_64.txt b/ydb/core/tx/columnshard/transactions/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..1cbf15564965 --- /dev/null +++ b/ydb/core/tx/columnshard/transactions/CMakeLists.windows-x86_64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(operators) + +add_library(tx-columnshard-transactions) +target_compile_options(tx-columnshard-transactions PRIVATE + -DKIKIMR_DISABLE_S3_OPS + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(tx-columnshard-transactions PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-tablet_flat + core-tx-data_events +) +target_sources(tx-columnshard-transactions PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/transactions/tx_controller.cpp +) diff --git a/ydb/core/tx/columnshard/transactions/operators/CMakeLists.darwin-arm64.txt b/ydb/core/tx/columnshard/transactions/operators/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..af66af6bed8f --- /dev/null +++ b/ydb/core/tx/columnshard/transactions/operators/CMakeLists.darwin-arm64.txt @@ -0,0 +1,27 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(columnshard-transactions-operators INTERFACE) +target_link_libraries(columnshard-transactions-operators INTERFACE + contrib-libs-cxxsupp + yutil + tx-columnshard-transactions +) + +add_global_library_for(columnshard-transactions-operators.global columnshard-transactions-operators) +target_link_libraries(columnshard-transactions-operators.global PUBLIC + contrib-libs-cxxsupp + yutil + tx-columnshard-transactions +) +target_sources(columnshard-transactions-operators.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/transactions/operators/schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/transactions/operators/long_tx_write.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/transactions/operators/ev_write.cpp +) diff --git a/ydb/core/tx/columnshard/transactions/operators/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/columnshard/transactions/operators/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..af66af6bed8f --- /dev/null +++ b/ydb/core/tx/columnshard/transactions/operators/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,27 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(columnshard-transactions-operators INTERFACE) +target_link_libraries(columnshard-transactions-operators INTERFACE + contrib-libs-cxxsupp + yutil + tx-columnshard-transactions +) + +add_global_library_for(columnshard-transactions-operators.global columnshard-transactions-operators) +target_link_libraries(columnshard-transactions-operators.global PUBLIC + contrib-libs-cxxsupp + yutil + tx-columnshard-transactions +) +target_sources(columnshard-transactions-operators.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/transactions/operators/schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/transactions/operators/long_tx_write.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/transactions/operators/ev_write.cpp +) diff --git a/ydb/core/tx/columnshard/transactions/operators/CMakeLists.linux-aarch64.txt b/ydb/core/tx/columnshard/transactions/operators/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..8a4995961026 --- /dev/null +++ b/ydb/core/tx/columnshard/transactions/operators/CMakeLists.linux-aarch64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(columnshard-transactions-operators INTERFACE) +target_link_libraries(columnshard-transactions-operators INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + tx-columnshard-transactions +) + +add_global_library_for(columnshard-transactions-operators.global columnshard-transactions-operators) +target_link_libraries(columnshard-transactions-operators.global PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + tx-columnshard-transactions +) +target_sources(columnshard-transactions-operators.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/transactions/operators/schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/transactions/operators/long_tx_write.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/transactions/operators/ev_write.cpp +) diff --git a/ydb/core/tx/columnshard/transactions/operators/CMakeLists.linux-x86_64.txt b/ydb/core/tx/columnshard/transactions/operators/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..8a4995961026 --- /dev/null +++ b/ydb/core/tx/columnshard/transactions/operators/CMakeLists.linux-x86_64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(columnshard-transactions-operators INTERFACE) +target_link_libraries(columnshard-transactions-operators INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + tx-columnshard-transactions +) + +add_global_library_for(columnshard-transactions-operators.global columnshard-transactions-operators) +target_link_libraries(columnshard-transactions-operators.global PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + tx-columnshard-transactions +) +target_sources(columnshard-transactions-operators.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/transactions/operators/schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/transactions/operators/long_tx_write.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/transactions/operators/ev_write.cpp +) diff --git a/ydb/core/tx/columnshard/transactions/operators/CMakeLists.txt b/ydb/core/tx/columnshard/transactions/operators/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/tx/columnshard/transactions/operators/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/tx/columnshard/transactions/operators/CMakeLists.windows-x86_64.txt b/ydb/core/tx/columnshard/transactions/operators/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..af66af6bed8f --- /dev/null +++ b/ydb/core/tx/columnshard/transactions/operators/CMakeLists.windows-x86_64.txt @@ -0,0 +1,27 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(columnshard-transactions-operators INTERFACE) +target_link_libraries(columnshard-transactions-operators INTERFACE + contrib-libs-cxxsupp + yutil + tx-columnshard-transactions +) + +add_global_library_for(columnshard-transactions-operators.global columnshard-transactions-operators) +target_link_libraries(columnshard-transactions-operators.global PUBLIC + contrib-libs-cxxsupp + yutil + tx-columnshard-transactions +) +target_sources(columnshard-transactions-operators.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/transactions/operators/schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/transactions/operators/long_tx_write.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/transactions/operators/ev_write.cpp +) diff --git a/ydb/core/tx/columnshard/ut_rw/CMakeLists.darwin-arm64.txt b/ydb/core/tx/columnshard/ut_rw/CMakeLists.darwin-arm64.txt index 737bdbf11b87..9a0a319dd72a 100644 --- a/ydb/core/tx/columnshard/ut_rw/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/columnshard/ut_rw/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-columnshard-ut_rw PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-columnshard-ut_rw PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard_ut_common.cpp @@ -67,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/columnshard/ut_rw/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/columnshard/ut_rw/CMakeLists.darwin-x86_64.txt index edb570ec7913..1085d2da8a91 100644 --- a/ydb/core/tx/columnshard/ut_rw/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/columnshard/ut_rw/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-columnshard-ut_rw PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-columnshard-ut_rw PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard_ut_common.cpp @@ -68,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/columnshard/ut_rw/CMakeLists.linux-aarch64.txt b/ydb/core/tx/columnshard/ut_rw/CMakeLists.linux-aarch64.txt index 3d90143420d2..8511ea73af71 100644 --- a/ydb/core/tx/columnshard/ut_rw/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/columnshard/ut_rw/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-columnshard-ut_rw PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-columnshard-ut_rw PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard_ut_common.cpp @@ -71,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/columnshard/ut_rw/CMakeLists.linux-x86_64.txt b/ydb/core/tx/columnshard/ut_rw/CMakeLists.linux-x86_64.txt index b9e15ace0951..34b7a7ca799f 100644 --- a/ydb/core/tx/columnshard/ut_rw/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/columnshard/ut_rw/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-columnshard-ut_rw PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-columnshard-ut_rw PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard_ut_common.cpp @@ -72,6 +69,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/columnshard/ut_rw/CMakeLists.windows-x86_64.txt b/ydb/core/tx/columnshard/ut_rw/CMakeLists.windows-x86_64.txt index 68c91949bc06..ccfd2efe9e4d 100644 --- a/ydb/core/tx/columnshard/ut_rw/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/columnshard/ut_rw/CMakeLists.windows-x86_64.txt @@ -61,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/columnshard/ut_schema/CMakeLists.darwin-arm64.txt b/ydb/core/tx/columnshard/ut_schema/CMakeLists.darwin-arm64.txt index 837f723bf9c4..236df899d978 100644 --- a/ydb/core/tx/columnshard/ut_schema/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/columnshard/ut_schema/CMakeLists.darwin-arm64.txt @@ -33,8 +33,6 @@ target_link_options(ydb-core-tx-columnshard-ut_schema PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-columnshard-ut_schema PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard_ut_common.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/columnshard/ut_schema/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/columnshard/ut_schema/CMakeLists.darwin-x86_64.txt index b939a28187e2..be286f288451 100644 --- a/ydb/core/tx/columnshard/ut_schema/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/columnshard/ut_schema/CMakeLists.darwin-x86_64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-columnshard-ut_schema PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-columnshard-ut_schema PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard_ut_common.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/columnshard/ut_schema/CMakeLists.linux-aarch64.txt b/ydb/core/tx/columnshard/ut_schema/CMakeLists.linux-aarch64.txt index 2bfe87b014bd..824131189ba2 100644 --- a/ydb/core/tx/columnshard/ut_schema/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/columnshard/ut_schema/CMakeLists.linux-aarch64.txt @@ -36,9 +36,6 @@ target_link_options(ydb-core-tx-columnshard-ut_schema PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-columnshard-ut_schema PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard_ut_common.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/columnshard/ut_schema/CMakeLists.linux-x86_64.txt b/ydb/core/tx/columnshard/ut_schema/CMakeLists.linux-x86_64.txt index c88400f82da3..202a72d24b75 100644 --- a/ydb/core/tx/columnshard/ut_schema/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/columnshard/ut_schema/CMakeLists.linux-x86_64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-columnshard-ut_schema PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-columnshard-ut_schema PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard_ut_common.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/columnshard/ut_schema/CMakeLists.windows-x86_64.txt b/ydb/core/tx/columnshard/ut_schema/CMakeLists.windows-x86_64.txt index ac67d068cd1b..385621f72a54 100644 --- a/ydb/core/tx/columnshard/ut_schema/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/columnshard/ut_schema/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/coordinator/CMakeLists.darwin-arm64.txt b/ydb/core/tx/coordinator/CMakeLists.darwin-arm64.txt index bd9fdf6266d8..ffa953fe5ccf 100644 --- a/ydb/core/tx/coordinator/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/coordinator/CMakeLists.darwin-arm64.txt @@ -30,6 +30,7 @@ target_link_libraries(core-tx-coordinator PUBLIC ydb-core-util ) target_sources(core-tx-coordinator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/coordinator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/coordinator_hooks.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/coordinator_impl.cpp diff --git a/ydb/core/tx/coordinator/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/coordinator/CMakeLists.darwin-x86_64.txt index bd9fdf6266d8..ffa953fe5ccf 100644 --- a/ydb/core/tx/coordinator/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/coordinator/CMakeLists.darwin-x86_64.txt @@ -30,6 +30,7 @@ target_link_libraries(core-tx-coordinator PUBLIC ydb-core-util ) target_sources(core-tx-coordinator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/coordinator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/coordinator_hooks.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/coordinator_impl.cpp diff --git a/ydb/core/tx/coordinator/CMakeLists.linux-aarch64.txt b/ydb/core/tx/coordinator/CMakeLists.linux-aarch64.txt index 455aa7c1601f..05eb4e1d128a 100644 --- a/ydb/core/tx/coordinator/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/coordinator/CMakeLists.linux-aarch64.txt @@ -31,6 +31,7 @@ target_link_libraries(core-tx-coordinator PUBLIC ydb-core-util ) target_sources(core-tx-coordinator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/coordinator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/coordinator_hooks.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/coordinator_impl.cpp diff --git a/ydb/core/tx/coordinator/CMakeLists.linux-x86_64.txt b/ydb/core/tx/coordinator/CMakeLists.linux-x86_64.txt index 455aa7c1601f..05eb4e1d128a 100644 --- a/ydb/core/tx/coordinator/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/coordinator/CMakeLists.linux-x86_64.txt @@ -31,6 +31,7 @@ target_link_libraries(core-tx-coordinator PUBLIC ydb-core-util ) target_sources(core-tx-coordinator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/coordinator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/coordinator_hooks.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/coordinator_impl.cpp diff --git a/ydb/core/tx/coordinator/CMakeLists.windows-x86_64.txt b/ydb/core/tx/coordinator/CMakeLists.windows-x86_64.txt index bd9fdf6266d8..ffa953fe5ccf 100644 --- a/ydb/core/tx/coordinator/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/coordinator/CMakeLists.windows-x86_64.txt @@ -30,6 +30,7 @@ target_link_libraries(core-tx-coordinator PUBLIC ydb-core-util ) target_sources(core-tx-coordinator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/defs.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/coordinator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/coordinator_hooks.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/coordinator_impl.cpp diff --git a/ydb/core/tx/coordinator/protos/CMakeLists.darwin-arm64.txt b/ydb/core/tx/coordinator/protos/CMakeLists.darwin-arm64.txt index 20d07d9e099a..c240c3d766b8 100644 --- a/ydb/core/tx/coordinator/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/coordinator/protos/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(tx-coordinator-protos PUBLIC target_proto_messages(tx-coordinator-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/protos/events.proto ) +target_sources(tx-coordinator-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/tx/coordinator/protos/events.pb.h +) target_proto_addincls(tx-coordinator-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/tx/coordinator/protos/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/coordinator/protos/CMakeLists.darwin-x86_64.txt index 20d07d9e099a..c240c3d766b8 100644 --- a/ydb/core/tx/coordinator/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/coordinator/protos/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(tx-coordinator-protos PUBLIC target_proto_messages(tx-coordinator-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/protos/events.proto ) +target_sources(tx-coordinator-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/tx/coordinator/protos/events.pb.h +) target_proto_addincls(tx-coordinator-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/tx/coordinator/protos/CMakeLists.linux-aarch64.txt b/ydb/core/tx/coordinator/protos/CMakeLists.linux-aarch64.txt index 363433566205..f52d9243c20b 100644 --- a/ydb/core/tx/coordinator/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/coordinator/protos/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(tx-coordinator-protos PUBLIC target_proto_messages(tx-coordinator-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/protos/events.proto ) +target_sources(tx-coordinator-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/tx/coordinator/protos/events.pb.h +) target_proto_addincls(tx-coordinator-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/tx/coordinator/protos/CMakeLists.linux-x86_64.txt b/ydb/core/tx/coordinator/protos/CMakeLists.linux-x86_64.txt index 363433566205..f52d9243c20b 100644 --- a/ydb/core/tx/coordinator/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/coordinator/protos/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(tx-coordinator-protos PUBLIC target_proto_messages(tx-coordinator-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/protos/events.proto ) +target_sources(tx-coordinator-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/tx/coordinator/protos/events.pb.h +) target_proto_addincls(tx-coordinator-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/tx/coordinator/protos/CMakeLists.windows-x86_64.txt b/ydb/core/tx/coordinator/protos/CMakeLists.windows-x86_64.txt index 20d07d9e099a..c240c3d766b8 100644 --- a/ydb/core/tx/coordinator/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/coordinator/protos/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(tx-coordinator-protos PUBLIC target_proto_messages(tx-coordinator-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/protos/events.proto ) +target_sources(tx-coordinator-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/tx/coordinator/protos/events.pb.h +) target_proto_addincls(tx-coordinator-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/tx/coordinator/ut/CMakeLists.darwin-arm64.txt b/ydb/core/tx/coordinator/ut/CMakeLists.darwin-arm64.txt index b9f36054e644..b8e1f5071802 100644 --- a/ydb/core/tx/coordinator/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/coordinator/ut/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-tx-coordinator-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-coordinator-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/coordinator_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/coordinator/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/coordinator/ut/CMakeLists.darwin-x86_64.txt index a59ad5a3c3bd..ef0fb278296a 100644 --- a/ydb/core/tx/coordinator/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/coordinator/ut/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-tx-coordinator-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-coordinator-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/coordinator_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/coordinator/ut/CMakeLists.linux-aarch64.txt b/ydb/core/tx/coordinator/ut/CMakeLists.linux-aarch64.txt index 73cda29bf525..ead58733ca90 100644 --- a/ydb/core/tx/coordinator/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/coordinator/ut/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-tx-coordinator-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-coordinator-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/coordinator_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/coordinator/ut/CMakeLists.linux-x86_64.txt b/ydb/core/tx/coordinator/ut/CMakeLists.linux-x86_64.txt index 94451cadef89..6aa42c3fda86 100644 --- a/ydb/core/tx/coordinator/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/coordinator/ut/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-tx-coordinator-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-coordinator-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/coordinator/coordinator_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/coordinator/ut/CMakeLists.windows-x86_64.txt b/ydb/core/tx/coordinator/ut/CMakeLists.windows-x86_64.txt index 032d24539fc1..ee6d0154938e 100644 --- a/ydb/core/tx/coordinator/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/coordinator/ut/CMakeLists.windows-x86_64.txt @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/CMakeLists.darwin-arm64.txt index 02077d6ae648..0ccb55b5d375 100644 --- a/ydb/core/tx/datashard/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/CMakeLists.darwin-arm64.txt @@ -34,6 +34,7 @@ add_subdirectory(ut_rs) add_subdirectory(ut_sequence) add_subdirectory(ut_snapshot) add_subdirectory(ut_stats) +add_subdirectory(ut_trace) add_subdirectory(ut_upload_rows) add_subdirectory(ut_volatile) add_subdirectory(ut_write) @@ -85,12 +86,6 @@ get_built_tool_path( tools/enum_parser/enum_parser enum_parser ) -get_built_tool_path( - TOOL_enum_parser_bin - TOOL_enum_parser_dependency - tools/enum_parser/enum_parser - enum_parser -) get_built_tool_path( TOOL_rescompiler_bin TOOL_rescompiler_dependency @@ -123,10 +118,11 @@ target_link_libraries(core-tx-datashard PUBLIC cpp-string_utils-quote ydb-core-actorlib_impl ydb-core-base + ydb-core-change_exchange ydb-core-engine core-engine-minikql ydb-core-formats - ydb-core-io_formats + core-io_formats-ydb_dump core-kqp-runtime core-persqueue-partition_key_range core-persqueue-writer @@ -148,6 +144,35 @@ target_link_libraries(core-tx-datashard PUBLIC ydb-library-chunks_limiter ) target_sources(core-tx-datashard PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard__engine_host.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_locks_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_locks.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_trans_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_outreadset.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_active_transaction.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_direct_transaction.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_failpoints.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_dep_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_pipeline.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_user_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_user_table.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_kqp_compute.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_kqp.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_read_operation.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_txs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/execution_unit.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/execution_unit_ctors.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/execution_unit_kind.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/export_iface.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/key_conflicts.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/operation.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/progress_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/read_table_scan.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/read_iterator.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/setup_sys_locks.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/alter_cdc_stream_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/alter_table_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/backup_restore_common.cpp @@ -173,8 +198,6 @@ target_sources(core-tx-datashard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender_async_index.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender_cdc_stream.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender_common_ops.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender_monitoring.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/check_commit_writes_tx_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/check_data_tx_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/check_distributed_erase_tx_unit.cpp @@ -280,9 +303,11 @@ target_sources(core-tx-datashard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/export_scan.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/finalize_build_index_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/finish_propose_unit.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/finish_propose_write_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/follower_edge.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/initiate_build_index_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/key_conflicts.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/key_validator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/load_and_wait_in_rs_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/load_tx_details_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/make_scan_snapshot_unit.cpp @@ -335,11 +360,6 @@ generate_enum_serilization(core-tx-datashard INCLUDE_HEADERS ydb/core/tx/datashard/change_exchange.h ) -generate_enum_serilization(core-tx-datashard - ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_record.h - INCLUDE_HEADERS - ydb/core/tx/datashard/change_record.h -) generate_enum_serilization(core-tx-datashard ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard.h INCLUDE_HEADERS @@ -396,10 +416,11 @@ target_link_libraries(core-tx-datashard.global PUBLIC cpp-string_utils-quote ydb-core-actorlib_impl ydb-core-base + ydb-core-change_exchange ydb-core-engine core-engine-minikql ydb-core-formats - ydb-core-io_formats + core-io_formats-ydb_dump core-kqp-runtime core-persqueue-partition_key_range core-persqueue-writer diff --git a/ydb/core/tx/datashard/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/CMakeLists.darwin-x86_64.txt index 02077d6ae648..0ccb55b5d375 100644 --- a/ydb/core/tx/datashard/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/CMakeLists.darwin-x86_64.txt @@ -34,6 +34,7 @@ add_subdirectory(ut_rs) add_subdirectory(ut_sequence) add_subdirectory(ut_snapshot) add_subdirectory(ut_stats) +add_subdirectory(ut_trace) add_subdirectory(ut_upload_rows) add_subdirectory(ut_volatile) add_subdirectory(ut_write) @@ -85,12 +86,6 @@ get_built_tool_path( tools/enum_parser/enum_parser enum_parser ) -get_built_tool_path( - TOOL_enum_parser_bin - TOOL_enum_parser_dependency - tools/enum_parser/enum_parser - enum_parser -) get_built_tool_path( TOOL_rescompiler_bin TOOL_rescompiler_dependency @@ -123,10 +118,11 @@ target_link_libraries(core-tx-datashard PUBLIC cpp-string_utils-quote ydb-core-actorlib_impl ydb-core-base + ydb-core-change_exchange ydb-core-engine core-engine-minikql ydb-core-formats - ydb-core-io_formats + core-io_formats-ydb_dump core-kqp-runtime core-persqueue-partition_key_range core-persqueue-writer @@ -148,6 +144,35 @@ target_link_libraries(core-tx-datashard PUBLIC ydb-library-chunks_limiter ) target_sources(core-tx-datashard PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard__engine_host.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_locks_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_locks.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_trans_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_outreadset.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_active_transaction.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_direct_transaction.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_failpoints.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_dep_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_pipeline.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_user_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_user_table.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_kqp_compute.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_kqp.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_read_operation.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_txs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/execution_unit.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/execution_unit_ctors.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/execution_unit_kind.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/export_iface.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/key_conflicts.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/operation.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/progress_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/read_table_scan.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/read_iterator.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/setup_sys_locks.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/alter_cdc_stream_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/alter_table_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/backup_restore_common.cpp @@ -173,8 +198,6 @@ target_sources(core-tx-datashard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender_async_index.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender_cdc_stream.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender_common_ops.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender_monitoring.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/check_commit_writes_tx_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/check_data_tx_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/check_distributed_erase_tx_unit.cpp @@ -280,9 +303,11 @@ target_sources(core-tx-datashard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/export_scan.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/finalize_build_index_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/finish_propose_unit.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/finish_propose_write_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/follower_edge.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/initiate_build_index_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/key_conflicts.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/key_validator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/load_and_wait_in_rs_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/load_tx_details_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/make_scan_snapshot_unit.cpp @@ -335,11 +360,6 @@ generate_enum_serilization(core-tx-datashard INCLUDE_HEADERS ydb/core/tx/datashard/change_exchange.h ) -generate_enum_serilization(core-tx-datashard - ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_record.h - INCLUDE_HEADERS - ydb/core/tx/datashard/change_record.h -) generate_enum_serilization(core-tx-datashard ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard.h INCLUDE_HEADERS @@ -396,10 +416,11 @@ target_link_libraries(core-tx-datashard.global PUBLIC cpp-string_utils-quote ydb-core-actorlib_impl ydb-core-base + ydb-core-change_exchange ydb-core-engine core-engine-minikql ydb-core-formats - ydb-core-io_formats + core-io_formats-ydb_dump core-kqp-runtime core-persqueue-partition_key_range core-persqueue-writer diff --git a/ydb/core/tx/datashard/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/CMakeLists.linux-aarch64.txt index bfda437b594c..a32eff50d7c4 100644 --- a/ydb/core/tx/datashard/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/CMakeLists.linux-aarch64.txt @@ -34,6 +34,7 @@ add_subdirectory(ut_rs) add_subdirectory(ut_sequence) add_subdirectory(ut_snapshot) add_subdirectory(ut_stats) +add_subdirectory(ut_trace) add_subdirectory(ut_upload_rows) add_subdirectory(ut_volatile) add_subdirectory(ut_write) @@ -85,12 +86,6 @@ get_built_tool_path( tools/enum_parser/enum_parser enum_parser ) -get_built_tool_path( - TOOL_enum_parser_bin - TOOL_enum_parser_dependency - tools/enum_parser/enum_parser - enum_parser -) get_built_tool_path( TOOL_rescompiler_bin TOOL_rescompiler_dependency @@ -124,10 +119,11 @@ target_link_libraries(core-tx-datashard PUBLIC cpp-string_utils-quote ydb-core-actorlib_impl ydb-core-base + ydb-core-change_exchange ydb-core-engine core-engine-minikql ydb-core-formats - ydb-core-io_formats + core-io_formats-ydb_dump core-kqp-runtime core-persqueue-partition_key_range core-persqueue-writer @@ -149,6 +145,35 @@ target_link_libraries(core-tx-datashard PUBLIC ydb-library-chunks_limiter ) target_sources(core-tx-datashard PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard__engine_host.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_locks_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_locks.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_trans_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_outreadset.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_active_transaction.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_direct_transaction.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_failpoints.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_dep_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_pipeline.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_user_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_user_table.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_kqp_compute.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_kqp.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_read_operation.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_txs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/execution_unit.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/execution_unit_ctors.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/execution_unit_kind.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/export_iface.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/key_conflicts.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/operation.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/progress_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/read_table_scan.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/read_iterator.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/setup_sys_locks.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/alter_cdc_stream_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/alter_table_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/backup_restore_common.cpp @@ -174,8 +199,6 @@ target_sources(core-tx-datashard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender_async_index.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender_cdc_stream.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender_common_ops.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender_monitoring.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/check_commit_writes_tx_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/check_data_tx_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/check_distributed_erase_tx_unit.cpp @@ -281,9 +304,11 @@ target_sources(core-tx-datashard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/export_scan.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/finalize_build_index_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/finish_propose_unit.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/finish_propose_write_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/follower_edge.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/initiate_build_index_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/key_conflicts.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/key_validator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/load_and_wait_in_rs_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/load_tx_details_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/make_scan_snapshot_unit.cpp @@ -336,11 +361,6 @@ generate_enum_serilization(core-tx-datashard INCLUDE_HEADERS ydb/core/tx/datashard/change_exchange.h ) -generate_enum_serilization(core-tx-datashard - ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_record.h - INCLUDE_HEADERS - ydb/core/tx/datashard/change_record.h -) generate_enum_serilization(core-tx-datashard ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard.h INCLUDE_HEADERS @@ -398,10 +418,11 @@ target_link_libraries(core-tx-datashard.global PUBLIC cpp-string_utils-quote ydb-core-actorlib_impl ydb-core-base + ydb-core-change_exchange ydb-core-engine core-engine-minikql ydb-core-formats - ydb-core-io_formats + core-io_formats-ydb_dump core-kqp-runtime core-persqueue-partition_key_range core-persqueue-writer diff --git a/ydb/core/tx/datashard/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/CMakeLists.linux-x86_64.txt index bfda437b594c..a32eff50d7c4 100644 --- a/ydb/core/tx/datashard/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/CMakeLists.linux-x86_64.txt @@ -34,6 +34,7 @@ add_subdirectory(ut_rs) add_subdirectory(ut_sequence) add_subdirectory(ut_snapshot) add_subdirectory(ut_stats) +add_subdirectory(ut_trace) add_subdirectory(ut_upload_rows) add_subdirectory(ut_volatile) add_subdirectory(ut_write) @@ -85,12 +86,6 @@ get_built_tool_path( tools/enum_parser/enum_parser enum_parser ) -get_built_tool_path( - TOOL_enum_parser_bin - TOOL_enum_parser_dependency - tools/enum_parser/enum_parser - enum_parser -) get_built_tool_path( TOOL_rescompiler_bin TOOL_rescompiler_dependency @@ -124,10 +119,11 @@ target_link_libraries(core-tx-datashard PUBLIC cpp-string_utils-quote ydb-core-actorlib_impl ydb-core-base + ydb-core-change_exchange ydb-core-engine core-engine-minikql ydb-core-formats - ydb-core-io_formats + core-io_formats-ydb_dump core-kqp-runtime core-persqueue-partition_key_range core-persqueue-writer @@ -149,6 +145,35 @@ target_link_libraries(core-tx-datashard PUBLIC ydb-library-chunks_limiter ) target_sources(core-tx-datashard PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard__engine_host.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_locks_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_locks.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_trans_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_outreadset.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_active_transaction.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_direct_transaction.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_failpoints.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_dep_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_pipeline.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_user_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_user_table.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_kqp_compute.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_kqp.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_read_operation.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_txs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/execution_unit.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/execution_unit_ctors.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/execution_unit_kind.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/export_iface.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/key_conflicts.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/operation.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/progress_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/read_table_scan.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/read_iterator.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/setup_sys_locks.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/alter_cdc_stream_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/alter_table_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/backup_restore_common.cpp @@ -174,8 +199,6 @@ target_sources(core-tx-datashard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender_async_index.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender_cdc_stream.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender_common_ops.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender_monitoring.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/check_commit_writes_tx_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/check_data_tx_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/check_distributed_erase_tx_unit.cpp @@ -281,9 +304,11 @@ target_sources(core-tx-datashard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/export_scan.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/finalize_build_index_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/finish_propose_unit.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/finish_propose_write_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/follower_edge.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/initiate_build_index_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/key_conflicts.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/key_validator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/load_and_wait_in_rs_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/load_tx_details_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/make_scan_snapshot_unit.cpp @@ -336,11 +361,6 @@ generate_enum_serilization(core-tx-datashard INCLUDE_HEADERS ydb/core/tx/datashard/change_exchange.h ) -generate_enum_serilization(core-tx-datashard - ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_record.h - INCLUDE_HEADERS - ydb/core/tx/datashard/change_record.h -) generate_enum_serilization(core-tx-datashard ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard.h INCLUDE_HEADERS @@ -398,10 +418,11 @@ target_link_libraries(core-tx-datashard.global PUBLIC cpp-string_utils-quote ydb-core-actorlib_impl ydb-core-base + ydb-core-change_exchange ydb-core-engine core-engine-minikql ydb-core-formats - ydb-core-io_formats + core-io_formats-ydb_dump core-kqp-runtime core-persqueue-partition_key_range core-persqueue-writer diff --git a/ydb/core/tx/datashard/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/CMakeLists.windows-x86_64.txt index f77a673de3d5..e9568610daf1 100644 --- a/ydb/core/tx/datashard/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/CMakeLists.windows-x86_64.txt @@ -34,6 +34,7 @@ add_subdirectory(ut_rs) add_subdirectory(ut_sequence) add_subdirectory(ut_snapshot) add_subdirectory(ut_stats) +add_subdirectory(ut_trace) add_subdirectory(ut_upload_rows) add_subdirectory(ut_volatile) add_subdirectory(ut_write) @@ -85,12 +86,6 @@ get_built_tool_path( tools/enum_parser/enum_parser enum_parser ) -get_built_tool_path( - TOOL_enum_parser_bin - TOOL_enum_parser_dependency - tools/enum_parser/enum_parser - enum_parser -) get_built_tool_path( TOOL_rescompiler_bin TOOL_rescompiler_dependency @@ -124,10 +119,11 @@ target_link_libraries(core-tx-datashard PUBLIC cpp-string_utils-quote ydb-core-actorlib_impl ydb-core-base + ydb-core-change_exchange ydb-core-engine core-engine-minikql ydb-core-formats - ydb-core-io_formats + core-io_formats-ydb_dump core-kqp-runtime core-persqueue-partition_key_range core-persqueue-writer @@ -149,6 +145,35 @@ target_link_libraries(core-tx-datashard PUBLIC ydb-library-chunks_limiter ) target_sources(core-tx-datashard PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard__engine_host.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_locks_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_locks.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_trans_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_outreadset.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_active_transaction.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_direct_transaction.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_failpoints.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_dep_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_pipeline.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_user_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_user_table.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_kqp_compute.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_kqp.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_read_operation.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_txs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/execution_unit.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/execution_unit_ctors.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/execution_unit_kind.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/export_iface.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/key_conflicts.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/operation.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/progress_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/read_table_scan.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/read_iterator.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/setup_sys_locks.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/alter_cdc_stream_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/alter_table_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/backup_restore_common.cpp @@ -174,8 +199,6 @@ target_sources(core-tx-datashard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender_async_index.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender_cdc_stream.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender_common_ops.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_sender_monitoring.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/check_commit_writes_tx_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/check_data_tx_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/check_distributed_erase_tx_unit.cpp @@ -281,9 +304,11 @@ target_sources(core-tx-datashard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/export_scan.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/finalize_build_index_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/finish_propose_unit.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/finish_propose_write_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/follower_edge.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/initiate_build_index_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/key_conflicts.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/key_validator.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/load_and_wait_in_rs_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/load_tx_details_unit.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/make_scan_snapshot_unit.cpp @@ -331,11 +356,6 @@ generate_enum_serilization(core-tx-datashard INCLUDE_HEADERS ydb/core/tx/datashard/change_exchange.h ) -generate_enum_serilization(core-tx-datashard - ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/change_record.h - INCLUDE_HEADERS - ydb/core/tx/datashard/change_record.h -) generate_enum_serilization(core-tx-datashard ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard.h INCLUDE_HEADERS @@ -393,10 +413,11 @@ target_link_libraries(core-tx-datashard.global PUBLIC cpp-string_utils-quote ydb-core-actorlib_impl ydb-core-base + ydb-core-change_exchange ydb-core-engine core-engine-minikql ydb-core-formats - ydb-core-io_formats + core-io_formats-ydb_dump core-kqp-runtime core-persqueue-partition_key_range core-persqueue-writer diff --git a/ydb/core/tx/datashard/ut_background_compaction/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_background_compaction/CMakeLists.darwin-arm64.txt index d307a249fc62..2eeb9e2017b2 100644 --- a/ydb/core/tx/datashard/ut_background_compaction/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_background_compaction/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_background_compaction PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_background_compaction PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_background_compaction.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_background_compaction/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_background_compaction/CMakeLists.darwin-x86_64.txt index 97b370f5a0b3..49ce3f6be1af 100644 --- a/ydb/core/tx/datashard/ut_background_compaction/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_background_compaction/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_background_compaction PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_background_compaction PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_background_compaction.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_background_compaction/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_background_compaction/CMakeLists.linux-aarch64.txt index e2c94c318373..a1c770f8e1d9 100644 --- a/ydb/core/tx/datashard/ut_background_compaction/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_background_compaction/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_background_compaction PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_background_compaction PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_background_compaction.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_background_compaction/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_background_compaction/CMakeLists.linux-x86_64.txt index cdbf022d6dd0..d5d9ce84d4af 100644 --- a/ydb/core/tx/datashard/ut_background_compaction/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_background_compaction/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_background_compaction PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_background_compaction PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_background_compaction.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_background_compaction/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_background_compaction/CMakeLists.windows-x86_64.txt index f8a1a5204bc3..2222c0c4f76b 100644 --- a/ydb/core/tx/datashard/ut_background_compaction/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_background_compaction/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_build_index/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_build_index/CMakeLists.darwin-arm64.txt index efdcb2a82ac5..9933ab2e3e7b 100644 --- a/ydb/core/tx/datashard/ut_build_index/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_build_index/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_build_index PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_build_index PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_build_index.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_build_index/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_build_index/CMakeLists.darwin-x86_64.txt index d94f2b640e91..e62e265a9970 100644 --- a/ydb/core/tx/datashard/ut_build_index/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_build_index/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_build_index PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_build_index PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_build_index.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_build_index/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_build_index/CMakeLists.linux-aarch64.txt index cad1e2c1e914..8ff865be659d 100644 --- a/ydb/core/tx/datashard/ut_build_index/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_build_index/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_build_index PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_build_index PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_build_index.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_build_index/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_build_index/CMakeLists.linux-x86_64.txt index 8f3ff5cc4926..e6fee890b2fd 100644 --- a/ydb/core/tx/datashard/ut_build_index/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_build_index/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_build_index PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_build_index PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_build_index.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_build_index/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_build_index/CMakeLists.windows-x86_64.txt index 554ea3efb78c..0c6dbcbe5406 100644 --- a/ydb/core/tx/datashard/ut_build_index/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_build_index/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_change_collector/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_change_collector/CMakeLists.darwin-arm64.txt index f026822e3c66..460a9de43d2c 100644 --- a/ydb/core/tx/datashard/ut_change_collector/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_change_collector/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_change_collector PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_change_collector PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_change_collector.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_change_collector/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_change_collector/CMakeLists.darwin-x86_64.txt index a294b5be41b7..83f36f724ed9 100644 --- a/ydb/core/tx/datashard/ut_change_collector/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_change_collector/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_change_collector PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_change_collector PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_change_collector.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_change_collector/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_change_collector/CMakeLists.linux-aarch64.txt index a1f58c31d5b3..8f9374ebdbac 100644 --- a/ydb/core/tx/datashard/ut_change_collector/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_change_collector/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_change_collector PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_change_collector PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_change_collector.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_change_collector/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_change_collector/CMakeLists.linux-x86_64.txt index efbbb5b8a9cd..53f4f591fba7 100644 --- a/ydb/core/tx/datashard/ut_change_collector/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_change_collector/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_change_collector PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_change_collector PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_change_collector.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_change_collector/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_change_collector/CMakeLists.windows-x86_64.txt index 457cc8393ec5..3030a20802d7 100644 --- a/ydb/core/tx/datashard/ut_change_collector/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_change_collector/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_change_exchange/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_change_exchange/CMakeLists.darwin-arm64.txt index 815a53bfd1ae..8b8ce5946724 100644 --- a/ydb/core/tx/datashard/ut_change_exchange/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_change_exchange/CMakeLists.darwin-arm64.txt @@ -37,8 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_change_exchange PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_change_exchange PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_change_exchange.cpp @@ -68,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_change_exchange/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_change_exchange/CMakeLists.darwin-x86_64.txt index 398673551ed0..9269cb495b99 100644 --- a/ydb/core/tx/datashard/ut_change_exchange/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_change_exchange/CMakeLists.darwin-x86_64.txt @@ -38,8 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_change_exchange PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_change_exchange PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_change_exchange.cpp @@ -69,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_change_exchange/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_change_exchange/CMakeLists.linux-aarch64.txt index 97103937998a..148100a2574c 100644 --- a/ydb/core/tx/datashard/ut_change_exchange/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_change_exchange/CMakeLists.linux-aarch64.txt @@ -40,9 +40,6 @@ target_link_options(ydb-core-tx-datashard-ut_change_exchange PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_change_exchange PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_change_exchange.cpp @@ -72,6 +69,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_change_exchange/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_change_exchange/CMakeLists.linux-x86_64.txt index 937bf9b9a6f5..0ca25690c7b9 100644 --- a/ydb/core/tx/datashard/ut_change_exchange/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_change_exchange/CMakeLists.linux-x86_64.txt @@ -41,9 +41,6 @@ target_link_options(ydb-core-tx-datashard-ut_change_exchange PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_change_exchange PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_change_exchange.cpp @@ -73,6 +70,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_change_exchange/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_change_exchange/CMakeLists.windows-x86_64.txt index acba1fbce12b..a7bcf14a3cda 100644 --- a/ydb/core/tx/datashard/ut_change_exchange/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_change_exchange/CMakeLists.windows-x86_64.txt @@ -62,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_common/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_common/CMakeLists.darwin-arm64.txt index 773aa90c43ee..fc5bca702ee5 100644 --- a/ydb/core/tx/datashard/ut_common/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_common/CMakeLists.darwin-arm64.txt @@ -18,5 +18,6 @@ target_link_libraries(tx-datashard-ut_common PUBLIC kqp-ut-common ) target_sources(tx-datashard-ut_common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/ut_common/datashard_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/ut_common/datashard_ut_common.cpp ) diff --git a/ydb/core/tx/datashard/ut_common/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_common/CMakeLists.darwin-x86_64.txt index 773aa90c43ee..fc5bca702ee5 100644 --- a/ydb/core/tx/datashard/ut_common/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_common/CMakeLists.darwin-x86_64.txt @@ -18,5 +18,6 @@ target_link_libraries(tx-datashard-ut_common PUBLIC kqp-ut-common ) target_sources(tx-datashard-ut_common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/ut_common/datashard_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/ut_common/datashard_ut_common.cpp ) diff --git a/ydb/core/tx/datashard/ut_common/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_common/CMakeLists.linux-aarch64.txt index 20d9a03406a7..56496b049d39 100644 --- a/ydb/core/tx/datashard/ut_common/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_common/CMakeLists.linux-aarch64.txt @@ -19,5 +19,6 @@ target_link_libraries(tx-datashard-ut_common PUBLIC kqp-ut-common ) target_sources(tx-datashard-ut_common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/ut_common/datashard_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/ut_common/datashard_ut_common.cpp ) diff --git a/ydb/core/tx/datashard/ut_common/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_common/CMakeLists.linux-x86_64.txt index 20d9a03406a7..56496b049d39 100644 --- a/ydb/core/tx/datashard/ut_common/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_common/CMakeLists.linux-x86_64.txt @@ -19,5 +19,6 @@ target_link_libraries(tx-datashard-ut_common PUBLIC kqp-ut-common ) target_sources(tx-datashard-ut_common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/ut_common/datashard_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/ut_common/datashard_ut_common.cpp ) diff --git a/ydb/core/tx/datashard/ut_common/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_common/CMakeLists.windows-x86_64.txt index 773aa90c43ee..fc5bca702ee5 100644 --- a/ydb/core/tx/datashard/ut_common/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_common/CMakeLists.windows-x86_64.txt @@ -18,5 +18,6 @@ target_link_libraries(tx-datashard-ut_common PUBLIC kqp-ut-common ) target_sources(tx-datashard-ut_common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/ut_common/datashard_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/ut_common/datashard_ut_common.cpp ) diff --git a/ydb/core/tx/datashard/ut_compaction/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_compaction/CMakeLists.darwin-arm64.txt index 5d3faa3b5d4b..1bcabfefc24a 100644 --- a/ydb/core/tx/datashard/ut_compaction/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_compaction/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_compaction PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_compaction PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_compaction.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_compaction/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_compaction/CMakeLists.darwin-x86_64.txt index 0ed7fc7bea67..731215793d47 100644 --- a/ydb/core/tx/datashard/ut_compaction/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_compaction/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_compaction PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_compaction PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_compaction.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_compaction/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_compaction/CMakeLists.linux-aarch64.txt index 04ee77c32525..cf01f5814cac 100644 --- a/ydb/core/tx/datashard/ut_compaction/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_compaction/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_compaction PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_compaction PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_compaction.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_compaction/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_compaction/CMakeLists.linux-x86_64.txt index 4f0ad0856e7f..755eed85090a 100644 --- a/ydb/core/tx/datashard/ut_compaction/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_compaction/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_compaction PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_compaction PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_compaction.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_compaction/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_compaction/CMakeLists.windows-x86_64.txt index 6e753185b271..3104b5ac854f 100644 --- a/ydb/core/tx/datashard/ut_compaction/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_compaction/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_erase_rows/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_erase_rows/CMakeLists.darwin-arm64.txt index 55cb9b48d61c..cf6161d86935 100644 --- a/ydb/core/tx/datashard/ut_erase_rows/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_erase_rows/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_erase_rows PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_erase_rows PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_erase_rows.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_erase_rows/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_erase_rows/CMakeLists.darwin-x86_64.txt index 2529a39824f6..dedafa296ab9 100644 --- a/ydb/core/tx/datashard/ut_erase_rows/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_erase_rows/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_erase_rows PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_erase_rows PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_erase_rows.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_erase_rows/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_erase_rows/CMakeLists.linux-aarch64.txt index 726d3e8d66fe..a7a8cfcedc74 100644 --- a/ydb/core/tx/datashard/ut_erase_rows/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_erase_rows/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_erase_rows PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_erase_rows PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_erase_rows.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_erase_rows/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_erase_rows/CMakeLists.linux-x86_64.txt index 81d84708c368..0b9c19379e0c 100644 --- a/ydb/core/tx/datashard/ut_erase_rows/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_erase_rows/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_erase_rows PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_erase_rows PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_erase_rows.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_erase_rows/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_erase_rows/CMakeLists.windows-x86_64.txt index 19c099356230..3551a35e3000 100644 --- a/ydb/core/tx/datashard/ut_erase_rows/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_erase_rows/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_followers/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_followers/CMakeLists.darwin-arm64.txt index 529db4e22405..781f4c495057 100644 --- a/ydb/core/tx/datashard/ut_followers/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_followers/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_followers PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_followers PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_followers.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_followers/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_followers/CMakeLists.darwin-x86_64.txt index 8dd8b9389b87..54241baaadc4 100644 --- a/ydb/core/tx/datashard/ut_followers/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_followers/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_followers PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_followers PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_followers.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_followers/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_followers/CMakeLists.linux-aarch64.txt index c4168379ab24..948c2c7127fd 100644 --- a/ydb/core/tx/datashard/ut_followers/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_followers/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_followers PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_followers PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_followers.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_followers/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_followers/CMakeLists.linux-x86_64.txt index cdb702199067..89a20f7d85ac 100644 --- a/ydb/core/tx/datashard/ut_followers/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_followers/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_followers PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_followers PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_followers.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_followers/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_followers/CMakeLists.windows-x86_64.txt index 38026f7aa0b5..fe0bc10a3e7f 100644 --- a/ydb/core/tx/datashard/ut_followers/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_followers/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_init/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_init/CMakeLists.darwin-arm64.txt index f9ba79047953..df367128c86d 100644 --- a/ydb/core/tx/datashard/ut_init/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_init/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_init PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_init PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_init.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_init/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_init/CMakeLists.darwin-x86_64.txt index f61001cb4f31..406b047c8017 100644 --- a/ydb/core/tx/datashard/ut_init/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_init/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_init PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_init PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_init.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_init/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_init/CMakeLists.linux-aarch64.txt index 9403c3868c15..127a2e46ebdd 100644 --- a/ydb/core/tx/datashard/ut_init/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_init/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_init PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_init PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_init.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_init/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_init/CMakeLists.linux-x86_64.txt index d8badfa873ff..4cebdab724c6 100644 --- a/ydb/core/tx/datashard/ut_init/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_init/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_init PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_init PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_init.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_init/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_init/CMakeLists.windows-x86_64.txt index ed67da876da4..bbdf5db23fa5 100644 --- a/ydb/core/tx/datashard/ut_init/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_init/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_keys/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_keys/CMakeLists.darwin-arm64.txt index dff0b516259d..1b5f07db1d63 100644 --- a/ydb/core/tx/datashard/ut_keys/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_keys/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_keys PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_keys PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_keys.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_keys/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_keys/CMakeLists.darwin-x86_64.txt index 69d3004eab48..7a3940e32c59 100644 --- a/ydb/core/tx/datashard/ut_keys/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_keys/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_keys PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_keys PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_keys.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_keys/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_keys/CMakeLists.linux-aarch64.txt index c129bcd3c987..db547f6ea9e4 100644 --- a/ydb/core/tx/datashard/ut_keys/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_keys/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_keys PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_keys PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_keys.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_keys/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_keys/CMakeLists.linux-x86_64.txt index b2f599106be4..97598da27e6e 100644 --- a/ydb/core/tx/datashard/ut_keys/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_keys/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_keys PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_keys PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_keys.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_keys/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_keys/CMakeLists.windows-x86_64.txt index 9f8b19214de8..2ba632427b09 100644 --- a/ydb/core/tx/datashard/ut_keys/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_keys/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_kqp/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_kqp/CMakeLists.darwin-arm64.txt index f61c7e666306..323e60a0dae5 100644 --- a/ydb/core/tx/datashard/ut_kqp/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_kqp/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_kqp PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_kqp PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_kqp.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_kqp/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_kqp/CMakeLists.darwin-x86_64.txt index 6522bfa0cb4b..db36ab9aec67 100644 --- a/ydb/core/tx/datashard/ut_kqp/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_kqp/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_kqp PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_kqp PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_kqp.cpp @@ -67,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_kqp/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_kqp/CMakeLists.linux-aarch64.txt index 12c982f061fa..efb1d4700e30 100644 --- a/ydb/core/tx/datashard/ut_kqp/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_kqp/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_kqp PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_kqp PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_kqp.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_kqp/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_kqp/CMakeLists.linux-x86_64.txt index f6bbe0cc031e..21c90c464adc 100644 --- a/ydb/core/tx/datashard/ut_kqp/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_kqp/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_kqp PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_kqp PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_kqp.cpp @@ -71,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_kqp/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_kqp/CMakeLists.windows-x86_64.txt index 15a05d62f367..4068546e929c 100644 --- a/ydb/core/tx/datashard/ut_kqp/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_kqp/CMakeLists.windows-x86_64.txt @@ -60,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_kqp_errors/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_kqp_errors/CMakeLists.darwin-arm64.txt index b6f3657f644f..c0675f45c8ce 100644 --- a/ydb/core/tx/datashard/ut_kqp_errors/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_kqp_errors/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_kqp_errors PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_kqp_errors PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_kqp_errors.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_kqp_errors/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_kqp_errors/CMakeLists.darwin-x86_64.txt index b5a8d290195d..c2f0c7cad85a 100644 --- a/ydb/core/tx/datashard/ut_kqp_errors/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_kqp_errors/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_kqp_errors PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_kqp_errors PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_kqp_errors.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_kqp_errors/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_kqp_errors/CMakeLists.linux-aarch64.txt index cb0734d034a8..46207473804a 100644 --- a/ydb/core/tx/datashard/ut_kqp_errors/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_kqp_errors/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_kqp_errors PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_kqp_errors PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_kqp_errors.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_kqp_errors/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_kqp_errors/CMakeLists.linux-x86_64.txt index 54052ffeda26..af73fff8287c 100644 --- a/ydb/core/tx/datashard/ut_kqp_errors/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_kqp_errors/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_kqp_errors PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_kqp_errors PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_kqp_errors.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_kqp_errors/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_kqp_errors/CMakeLists.windows-x86_64.txt index dd3c24d13311..3821b31bc666 100644 --- a/ydb/core/tx/datashard/ut_kqp_errors/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_kqp_errors/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_kqp_scan/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_kqp_scan/CMakeLists.darwin-arm64.txt index 289425f21b19..6bf768092a9e 100644 --- a/ydb/core/tx/datashard/ut_kqp_scan/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_kqp_scan/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_kqp_scan PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_kqp_scan PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_kqp_scan.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_kqp_scan/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_kqp_scan/CMakeLists.darwin-x86_64.txt index afbc6340312a..9629db5eba04 100644 --- a/ydb/core/tx/datashard/ut_kqp_scan/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_kqp_scan/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_kqp_scan PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_kqp_scan PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_kqp_scan.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_kqp_scan/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_kqp_scan/CMakeLists.linux-aarch64.txt index ec719c0c47b9..1f713a0d415c 100644 --- a/ydb/core/tx/datashard/ut_kqp_scan/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_kqp_scan/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_kqp_scan PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_kqp_scan PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_kqp_scan.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_kqp_scan/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_kqp_scan/CMakeLists.linux-x86_64.txt index a23a37eef6ec..af159f54f441 100644 --- a/ydb/core/tx/datashard/ut_kqp_scan/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_kqp_scan/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_kqp_scan PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_kqp_scan PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_kqp_scan.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_kqp_scan/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_kqp_scan/CMakeLists.windows-x86_64.txt index b712c5069225..21f32fe247b1 100644 --- a/ydb/core/tx/datashard/ut_kqp_scan/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_kqp_scan/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_locks/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_locks/CMakeLists.darwin-arm64.txt index 9ced346b42e0..567549dd0ff7 100644 --- a/ydb/core/tx/datashard/ut_locks/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_locks/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_locks PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_locks PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_locks.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_locks/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_locks/CMakeLists.darwin-x86_64.txt index a93e05b5e2ec..c69e20c2b062 100644 --- a/ydb/core/tx/datashard/ut_locks/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_locks/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_locks PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_locks PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_locks.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_locks/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_locks/CMakeLists.linux-aarch64.txt index dec4ec9ef72f..6c1a6637b827 100644 --- a/ydb/core/tx/datashard/ut_locks/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_locks/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_locks PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_locks PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_locks.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_locks/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_locks/CMakeLists.linux-x86_64.txt index a5813f190a5f..332c6881c04f 100644 --- a/ydb/core/tx/datashard/ut_locks/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_locks/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_locks PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_locks PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_locks.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_locks/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_locks/CMakeLists.windows-x86_64.txt index 33e0fe353d15..71dac22b9e02 100644 --- a/ydb/core/tx/datashard/ut_locks/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_locks/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_minikql/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_minikql/CMakeLists.darwin-arm64.txt index 1669c7d6462a..c5caee92bb3d 100644 --- a/ydb/core/tx/datashard/ut_minikql/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_minikql/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_minikql PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_minikql PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_minikql.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_minikql/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_minikql/CMakeLists.darwin-x86_64.txt index f2badd8b1799..0388b86476ae 100644 --- a/ydb/core/tx/datashard/ut_minikql/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_minikql/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_minikql PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_minikql PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_minikql.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_minikql/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_minikql/CMakeLists.linux-aarch64.txt index f994d8fa1c36..9da0259eaec3 100644 --- a/ydb/core/tx/datashard/ut_minikql/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_minikql/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_minikql PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_minikql PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_minikql.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_minikql/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_minikql/CMakeLists.linux-x86_64.txt index b6dd12d591f1..1d77618e782f 100644 --- a/ydb/core/tx/datashard/ut_minikql/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_minikql/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_minikql PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_minikql PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_minikql.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_minikql/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_minikql/CMakeLists.windows-x86_64.txt index d9a1eefb472b..660161eeaa49 100644 --- a/ydb/core/tx/datashard/ut_minikql/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_minikql/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_minstep/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_minstep/CMakeLists.darwin-arm64.txt index ab81530e0478..fe9c9383b230 100644 --- a/ydb/core/tx/datashard/ut_minstep/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_minstep/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_minstep PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_minstep PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_minstep.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_minstep/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_minstep/CMakeLists.darwin-x86_64.txt index 10c0f1c7c3dc..98e5e74cf55e 100644 --- a/ydb/core/tx/datashard/ut_minstep/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_minstep/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_minstep PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_minstep PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_minstep.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_minstep/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_minstep/CMakeLists.linux-aarch64.txt index f6a3170f4dea..9f31c294880c 100644 --- a/ydb/core/tx/datashard/ut_minstep/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_minstep/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_minstep PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_minstep PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_minstep.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_minstep/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_minstep/CMakeLists.linux-x86_64.txt index a78cfcc0bd27..65440eb2d6a6 100644 --- a/ydb/core/tx/datashard/ut_minstep/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_minstep/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_minstep PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_minstep PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_minstep.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_minstep/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_minstep/CMakeLists.windows-x86_64.txt index db7c86e808b6..293c085498dc 100644 --- a/ydb/core/tx/datashard/ut_minstep/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_minstep/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_order/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_order/CMakeLists.darwin-arm64.txt index cca65e2ce960..0e4fc8567b84 100644 --- a/ydb/core/tx/datashard/ut_order/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_order/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_order PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_order PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_order.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_order/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_order/CMakeLists.darwin-x86_64.txt index 513049b8daaf..82ea829f2226 100644 --- a/ydb/core/tx/datashard/ut_order/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_order/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_order PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_order PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_order.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_order/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_order/CMakeLists.linux-aarch64.txt index bd3a1f34364d..d8b519c47831 100644 --- a/ydb/core/tx/datashard/ut_order/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_order/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_order PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_order PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_order.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_order/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_order/CMakeLists.linux-x86_64.txt index 9e8524bd4578..bc386c7ade87 100644 --- a/ydb/core/tx/datashard/ut_order/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_order/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_order PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_order PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_order.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_order/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_order/CMakeLists.windows-x86_64.txt index 4658f34a6494..4cc6e71279e8 100644 --- a/ydb/core/tx/datashard/ut_order/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_order/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_range_avl_tree/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_range_avl_tree/CMakeLists.darwin-arm64.txt index e7d3955f53f9..d766fc8b6343 100644 --- a/ydb/core/tx/datashard/ut_range_avl_tree/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_range_avl_tree/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_range_avl_tree PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_range_avl_tree PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/range_avl_tree_ut.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_range_avl_tree/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_range_avl_tree/CMakeLists.darwin-x86_64.txt index 8bc223982387..0b9d23869933 100644 --- a/ydb/core/tx/datashard/ut_range_avl_tree/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_range_avl_tree/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_range_avl_tree PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_range_avl_tree PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/range_avl_tree_ut.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_range_avl_tree/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_range_avl_tree/CMakeLists.linux-aarch64.txt index 9cabb66c1eee..f051347a3192 100644 --- a/ydb/core/tx/datashard/ut_range_avl_tree/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_range_avl_tree/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_range_avl_tree PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_range_avl_tree PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/range_avl_tree_ut.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_range_avl_tree/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_range_avl_tree/CMakeLists.linux-x86_64.txt index 091e31789905..f187981aa005 100644 --- a/ydb/core/tx/datashard/ut_range_avl_tree/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_range_avl_tree/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_range_avl_tree PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_range_avl_tree PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/range_avl_tree_ut.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_range_avl_tree/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_range_avl_tree/CMakeLists.windows-x86_64.txt index 6329299a68d7..fc89ecc1e5cf 100644 --- a/ydb/core/tx/datashard/ut_range_avl_tree/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_range_avl_tree/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_range_ops/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_range_ops/CMakeLists.darwin-arm64.txt index 98b220052900..5b533846f369 100644 --- a/ydb/core/tx/datashard/ut_range_ops/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_range_ops/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_range_ops PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_range_ops PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_range_ops.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_range_ops/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_range_ops/CMakeLists.darwin-x86_64.txt index 97e2adfcf11a..4d8eab865410 100644 --- a/ydb/core/tx/datashard/ut_range_ops/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_range_ops/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_range_ops PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_range_ops PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_range_ops.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_range_ops/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_range_ops/CMakeLists.linux-aarch64.txt index 535320417eef..4afab54ee000 100644 --- a/ydb/core/tx/datashard/ut_range_ops/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_range_ops/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_range_ops PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_range_ops PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_range_ops.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_range_ops/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_range_ops/CMakeLists.linux-x86_64.txt index 7a3c1c1e8d09..fac306efab06 100644 --- a/ydb/core/tx/datashard/ut_range_ops/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_range_ops/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_range_ops PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_range_ops PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_range_ops.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_range_ops/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_range_ops/CMakeLists.windows-x86_64.txt index b0f9560f5c34..54ec0311de48 100644 --- a/ydb/core/tx/datashard/ut_range_ops/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_range_ops/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_range_treap/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_range_treap/CMakeLists.darwin-arm64.txt index dcf8838cd46f..bc7705dc6a7e 100644 --- a/ydb/core/tx/datashard/ut_range_treap/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_range_treap/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_range_treap PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_range_treap PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/range_treap_ut.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_range_treap/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_range_treap/CMakeLists.darwin-x86_64.txt index 89c959394de8..48cd4a563b02 100644 --- a/ydb/core/tx/datashard/ut_range_treap/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_range_treap/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_range_treap PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_range_treap PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/range_treap_ut.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_range_treap/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_range_treap/CMakeLists.linux-aarch64.txt index 10b1d8272c45..4288fbb3e39d 100644 --- a/ydb/core/tx/datashard/ut_range_treap/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_range_treap/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_range_treap PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_range_treap PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/range_treap_ut.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_range_treap/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_range_treap/CMakeLists.linux-x86_64.txt index ce18da096f0f..d42117cfbb70 100644 --- a/ydb/core/tx/datashard/ut_range_treap/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_range_treap/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_range_treap PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_range_treap PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/range_treap_ut.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_range_treap/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_range_treap/CMakeLists.windows-x86_64.txt index 66ad767b6592..305eaf27447c 100644 --- a/ydb/core/tx/datashard/ut_range_treap/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_range_treap/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_read_iterator/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_read_iterator/CMakeLists.darwin-arm64.txt index 222b8d26bb0d..7f474a4a6462 100644 --- a/ydb/core/tx/datashard/ut_read_iterator/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_read_iterator/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_read_iterator PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_read_iterator PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_read_iterator.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_read_iterator/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_read_iterator/CMakeLists.darwin-x86_64.txt index c667c8e5b20e..3e31333eb235 100644 --- a/ydb/core/tx/datashard/ut_read_iterator/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_read_iterator/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_read_iterator PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_read_iterator PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_read_iterator.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_read_iterator/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_read_iterator/CMakeLists.linux-aarch64.txt index 3eebce3873ff..2b3dac3281ee 100644 --- a/ydb/core/tx/datashard/ut_read_iterator/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_read_iterator/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_read_iterator PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_read_iterator PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_read_iterator.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_read_iterator/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_read_iterator/CMakeLists.linux-x86_64.txt index a35c7512809e..d6e75d03fa41 100644 --- a/ydb/core/tx/datashard/ut_read_iterator/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_read_iterator/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_read_iterator PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_read_iterator PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_read_iterator.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_read_iterator/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_read_iterator/CMakeLists.windows-x86_64.txt index fb85011ef83b..23cdcd4786f8 100644 --- a/ydb/core/tx/datashard/ut_read_iterator/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_read_iterator/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_read_table/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_read_table/CMakeLists.darwin-arm64.txt index 099e41a2cc5a..b2484df41b8d 100644 --- a/ydb/core/tx/datashard/ut_read_table/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_read_table/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_read_table PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_read_table PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_read_table.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_read_table/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_read_table/CMakeLists.darwin-x86_64.txt index 7652fcf9af31..cb44106a82a2 100644 --- a/ydb/core/tx/datashard/ut_read_table/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_read_table/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_read_table PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_read_table PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_read_table.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_read_table/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_read_table/CMakeLists.linux-aarch64.txt index 991958b30f09..c7e453b9873f 100644 --- a/ydb/core/tx/datashard/ut_read_table/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_read_table/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_read_table PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_read_table PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_read_table.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_read_table/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_read_table/CMakeLists.linux-x86_64.txt index b2600796b49b..29a629e8daa3 100644 --- a/ydb/core/tx/datashard/ut_read_table/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_read_table/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_read_table PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_read_table PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_read_table.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_read_table/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_read_table/CMakeLists.windows-x86_64.txt index 7aadb70c32d2..f06124181f5b 100644 --- a/ydb/core/tx/datashard/ut_read_table/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_read_table/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_reassign/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_reassign/CMakeLists.darwin-arm64.txt index ac8b74a1163c..5013df8ccd7a 100644 --- a/ydb/core/tx/datashard/ut_reassign/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_reassign/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_reassign PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_reassign PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_reassign.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_reassign/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_reassign/CMakeLists.darwin-x86_64.txt index 800338eee944..d5542a1b0bd8 100644 --- a/ydb/core/tx/datashard/ut_reassign/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_reassign/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_reassign PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_reassign PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_reassign.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_reassign/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_reassign/CMakeLists.linux-aarch64.txt index 11fafdeaef3d..5bc826d02e53 100644 --- a/ydb/core/tx/datashard/ut_reassign/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_reassign/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_reassign PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_reassign PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_reassign.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_reassign/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_reassign/CMakeLists.linux-x86_64.txt index fc828f0f2bc2..f0d7a2c349a6 100644 --- a/ydb/core/tx/datashard/ut_reassign/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_reassign/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_reassign PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_reassign PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_reassign.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_reassign/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_reassign/CMakeLists.windows-x86_64.txt index eeaa1bc7edf7..f8a0456962b9 100644 --- a/ydb/core/tx/datashard/ut_reassign/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_reassign/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_replication/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_replication/CMakeLists.darwin-arm64.txt index eebb17dd4ea7..af5d35c8d657 100644 --- a/ydb/core/tx/datashard/ut_replication/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_replication/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_replication PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_replication PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_replication.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_replication/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_replication/CMakeLists.darwin-x86_64.txt index 4ad0509c4ea9..b5b82e3514e4 100644 --- a/ydb/core/tx/datashard/ut_replication/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_replication/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_replication PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_replication PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_replication.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_replication/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_replication/CMakeLists.linux-aarch64.txt index 90ec39951631..58e93da46a80 100644 --- a/ydb/core/tx/datashard/ut_replication/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_replication/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_replication PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_replication PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_replication.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_replication/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_replication/CMakeLists.linux-x86_64.txt index bafcfa2da3b6..e6a53a56ff41 100644 --- a/ydb/core/tx/datashard/ut_replication/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_replication/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_replication PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_replication PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_replication.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_replication/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_replication/CMakeLists.windows-x86_64.txt index c979524668e1..9de835d84d12 100644 --- a/ydb/core/tx/datashard/ut_replication/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_replication/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_rs/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_rs/CMakeLists.darwin-arm64.txt index 38f169c237aa..c4ed0c491c88 100644 --- a/ydb/core/tx/datashard/ut_rs/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_rs/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_rs PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_rs PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_rs.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_rs/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_rs/CMakeLists.darwin-x86_64.txt index 4bed9467bef7..9ac330fbde0e 100644 --- a/ydb/core/tx/datashard/ut_rs/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_rs/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_rs PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_rs PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_rs.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_rs/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_rs/CMakeLists.linux-aarch64.txt index a2ede653b6fd..5c2cb61fb187 100644 --- a/ydb/core/tx/datashard/ut_rs/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_rs/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_rs PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_rs PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_rs.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_rs/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_rs/CMakeLists.linux-x86_64.txt index 4d21061c51d7..dca054990ab5 100644 --- a/ydb/core/tx/datashard/ut_rs/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_rs/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_rs PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_rs PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_rs.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_rs/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_rs/CMakeLists.windows-x86_64.txt index f02c3ee328e9..f39a73a51724 100644 --- a/ydb/core/tx/datashard/ut_rs/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_rs/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_sequence/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_sequence/CMakeLists.darwin-arm64.txt index 534574719227..750cf43b17b2 100644 --- a/ydb/core/tx/datashard/ut_sequence/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_sequence/CMakeLists.darwin-arm64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_sequence PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_sequence PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/ut_sequence/datashard_ut_sequence.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_sequence/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_sequence/CMakeLists.darwin-x86_64.txt index 9708a3ad1287..82edde5a8552 100644 --- a/ydb/core/tx/datashard/ut_sequence/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_sequence/CMakeLists.darwin-x86_64.txt @@ -36,8 +36,6 @@ target_link_options(ydb-core-tx-datashard-ut_sequence PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_sequence PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/ut_sequence/datashard_ut_sequence.cpp @@ -67,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_sequence/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_sequence/CMakeLists.linux-aarch64.txt index e91c55b8e1b2..8f2724b75c13 100644 --- a/ydb/core/tx/datashard/ut_sequence/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_sequence/CMakeLists.linux-aarch64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_sequence PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_sequence PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/ut_sequence/datashard_ut_sequence.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_sequence/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_sequence/CMakeLists.linux-x86_64.txt index d46b1156845d..fa5c81238648 100644 --- a/ydb/core/tx/datashard/ut_sequence/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_sequence/CMakeLists.linux-x86_64.txt @@ -39,9 +39,6 @@ target_link_options(ydb-core-tx-datashard-ut_sequence PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_sequence PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/ut_sequence/datashard_ut_sequence.cpp @@ -71,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_sequence/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_sequence/CMakeLists.windows-x86_64.txt index a47972c4efe4..3021ad647202 100644 --- a/ydb/core/tx/datashard/ut_sequence/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_sequence/CMakeLists.windows-x86_64.txt @@ -60,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_snapshot/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_snapshot/CMakeLists.darwin-arm64.txt index f390347dea6f..cbf6a853c75a 100644 --- a/ydb/core/tx/datashard/ut_snapshot/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_snapshot/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_snapshot PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_snapshot PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_snapshot.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_snapshot/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_snapshot/CMakeLists.darwin-x86_64.txt index 4c4dc8d3964d..f532bb344d84 100644 --- a/ydb/core/tx/datashard/ut_snapshot/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_snapshot/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_snapshot PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_snapshot PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_snapshot.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_snapshot/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_snapshot/CMakeLists.linux-aarch64.txt index e954529fad33..7fdf23ad9220 100644 --- a/ydb/core/tx/datashard/ut_snapshot/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_snapshot/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_snapshot PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_snapshot PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_snapshot.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_snapshot/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_snapshot/CMakeLists.linux-x86_64.txt index 4479ad2b1c29..6f89cf7f9adc 100644 --- a/ydb/core/tx/datashard/ut_snapshot/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_snapshot/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_snapshot PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_snapshot PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_snapshot.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_snapshot/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_snapshot/CMakeLists.windows-x86_64.txt index 27770f865ca3..eda018dc4e87 100644 --- a/ydb/core/tx/datashard/ut_snapshot/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_snapshot/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_stats/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_stats/CMakeLists.darwin-arm64.txt index bb0d48bfcf7f..3be752b9d1b7 100644 --- a/ydb/core/tx/datashard/ut_stats/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_stats/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_stats PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_stats PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_stats.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_stats/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_stats/CMakeLists.darwin-x86_64.txt index 7510211d98c8..f826a3f80406 100644 --- a/ydb/core/tx/datashard/ut_stats/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_stats/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_stats PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_stats PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_stats.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_stats/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_stats/CMakeLists.linux-aarch64.txt index 785c6913fcbd..f05d90fa4e5a 100644 --- a/ydb/core/tx/datashard/ut_stats/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_stats/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_stats PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_stats PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_stats.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_stats/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_stats/CMakeLists.linux-x86_64.txt index 21875d710b7a..baa2932ee622 100644 --- a/ydb/core/tx/datashard/ut_stats/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_stats/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_stats PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_stats PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_stats.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_stats/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_stats/CMakeLists.windows-x86_64.txt index cb09a13d3d32..44a7dcf9d212 100644 --- a/ydb/core/tx/datashard/ut_stats/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_stats/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_trace/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_trace/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..18a0f3ca7b55 --- /dev/null +++ b/ydb/core/tx/datashard/ut_trace/CMakeLists.darwin-arm64.txt @@ -0,0 +1,85 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-tx-datashard-ut_trace) +target_compile_options(ydb-core-tx-datashard-ut_trace PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-tx-datashard-ut_trace PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard +) +target_link_libraries(ydb-core-tx-datashard-ut_trace PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + core-tx-datashard + tx-datashard-ut_common + library-cpp-getopt + cpp-regex-pcre + library-cpp-svnversion + kqp-ut-common + core-testlib-default + ydb-core-tx + udf-service-exception_policy + public-lib-yson_value + cpp-client-ydb_result +) +target_link_options(ydb-core-tx-datashard-ut_trace PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-core-tx-datashard-ut_trace PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_trace.cpp +) +set_property( + TARGET + ydb-core-tx-datashard-ut_trace + PROPERTY + SPLIT_FACTOR + 5 +) +add_yunittest( + NAME + ydb-core-tx-datashard-ut_trace + TEST_TARGET + ydb-core-tx-datashard-ut_trace + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-tx-datashard-ut_trace + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-tx-datashard-ut_trace + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-tx-datashard-ut_trace + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-tx-datashard-ut_trace + system_allocator +) +vcs_info(ydb-core-tx-datashard-ut_trace) diff --git a/ydb/core/tx/datashard/ut_trace/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_trace/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..2b179af5ca25 --- /dev/null +++ b/ydb/core/tx/datashard/ut_trace/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,86 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-tx-datashard-ut_trace) +target_compile_options(ydb-core-tx-datashard-ut_trace PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-tx-datashard-ut_trace PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard +) +target_link_libraries(ydb-core-tx-datashard-ut_trace PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + core-tx-datashard + tx-datashard-ut_common + library-cpp-getopt + cpp-regex-pcre + library-cpp-svnversion + kqp-ut-common + core-testlib-default + ydb-core-tx + udf-service-exception_policy + public-lib-yson_value + cpp-client-ydb_result +) +target_link_options(ydb-core-tx-datashard-ut_trace PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-core-tx-datashard-ut_trace PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_trace.cpp +) +set_property( + TARGET + ydb-core-tx-datashard-ut_trace + PROPERTY + SPLIT_FACTOR + 5 +) +add_yunittest( + NAME + ydb-core-tx-datashard-ut_trace + TEST_TARGET + ydb-core-tx-datashard-ut_trace + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-tx-datashard-ut_trace + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-tx-datashard-ut_trace + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-tx-datashard-ut_trace + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-tx-datashard-ut_trace + system_allocator +) +vcs_info(ydb-core-tx-datashard-ut_trace) diff --git a/ydb/core/tx/datashard/ut_trace/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_trace/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..93d03774570a --- /dev/null +++ b/ydb/core/tx/datashard/ut_trace/CMakeLists.linux-aarch64.txt @@ -0,0 +1,88 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-tx-datashard-ut_trace) +target_compile_options(ydb-core-tx-datashard-ut_trace PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-tx-datashard-ut_trace PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard +) +target_link_libraries(ydb-core-tx-datashard-ut_trace PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + core-tx-datashard + tx-datashard-ut_common + library-cpp-getopt + cpp-regex-pcre + library-cpp-svnversion + kqp-ut-common + core-testlib-default + ydb-core-tx + udf-service-exception_policy + public-lib-yson_value + cpp-client-ydb_result +) +target_link_options(ydb-core-tx-datashard-ut_trace PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-core-tx-datashard-ut_trace PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_trace.cpp +) +set_property( + TARGET + ydb-core-tx-datashard-ut_trace + PROPERTY + SPLIT_FACTOR + 5 +) +add_yunittest( + NAME + ydb-core-tx-datashard-ut_trace + TEST_TARGET + ydb-core-tx-datashard-ut_trace + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-tx-datashard-ut_trace + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-tx-datashard-ut_trace + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-tx-datashard-ut_trace + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-tx-datashard-ut_trace + cpp-malloc-jemalloc +) +vcs_info(ydb-core-tx-datashard-ut_trace) diff --git a/ydb/core/tx/datashard/ut_trace/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_trace/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..3b9d3a8f1da6 --- /dev/null +++ b/ydb/core/tx/datashard/ut_trace/CMakeLists.linux-x86_64.txt @@ -0,0 +1,90 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-tx-datashard-ut_trace) +target_compile_options(ydb-core-tx-datashard-ut_trace PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-tx-datashard-ut_trace PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard +) +target_link_libraries(ydb-core-tx-datashard-ut_trace PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + core-tx-datashard + tx-datashard-ut_common + library-cpp-getopt + cpp-regex-pcre + library-cpp-svnversion + kqp-ut-common + core-testlib-default + ydb-core-tx + udf-service-exception_policy + public-lib-yson_value + cpp-client-ydb_result +) +target_link_options(ydb-core-tx-datashard-ut_trace PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-core-tx-datashard-ut_trace PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_trace.cpp +) +set_property( + TARGET + ydb-core-tx-datashard-ut_trace + PROPERTY + SPLIT_FACTOR + 5 +) +add_yunittest( + NAME + ydb-core-tx-datashard-ut_trace + TEST_TARGET + ydb-core-tx-datashard-ut_trace + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-tx-datashard-ut_trace + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-tx-datashard-ut_trace + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-tx-datashard-ut_trace + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-tx-datashard-ut_trace + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(ydb-core-tx-datashard-ut_trace) diff --git a/ydb/core/tx/datashard/ut_trace/CMakeLists.txt b/ydb/core/tx/datashard/ut_trace/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/tx/datashard/ut_trace/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/tx/datashard/ut_trace/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_trace/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..c75a7b7fdb31 --- /dev/null +++ b/ydb/core/tx/datashard/ut_trace/CMakeLists.windows-x86_64.txt @@ -0,0 +1,81 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-tx-datashard-ut_trace) +target_compile_options(ydb-core-tx-datashard-ut_trace PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-tx-datashard-ut_trace PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard +) +target_link_libraries(ydb-core-tx-datashard-ut_trace PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + core-tx-datashard + tx-datashard-ut_common + library-cpp-getopt + cpp-regex-pcre + library-cpp-svnversion + kqp-ut-common + core-testlib-default + ydb-core-tx + udf-service-exception_policy + public-lib-yson_value + cpp-client-ydb_result +) +target_sources(ydb-core-tx-datashard-ut_trace PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_trace.cpp +) +set_property( + TARGET + ydb-core-tx-datashard-ut_trace + PROPERTY + SPLIT_FACTOR + 5 +) +add_yunittest( + NAME + ydb-core-tx-datashard-ut_trace + TEST_TARGET + ydb-core-tx-datashard-ut_trace + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-tx-datashard-ut_trace + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-tx-datashard-ut_trace + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-tx-datashard-ut_trace + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-tx-datashard-ut_trace + system_allocator +) +vcs_info(ydb-core-tx-datashard-ut_trace) diff --git a/ydb/core/tx/datashard/ut_upload_rows/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_upload_rows/CMakeLists.darwin-arm64.txt index fe372e84dac5..77aa6aaefcbf 100644 --- a/ydb/core/tx/datashard/ut_upload_rows/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_upload_rows/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_upload_rows PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_upload_rows PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_upload_rows.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_upload_rows/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_upload_rows/CMakeLists.darwin-x86_64.txt index 907193f87e38..165879d4b62b 100644 --- a/ydb/core/tx/datashard/ut_upload_rows/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_upload_rows/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_upload_rows PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_upload_rows PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_upload_rows.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_upload_rows/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_upload_rows/CMakeLists.linux-aarch64.txt index 17111c30cfac..4868f639d46c 100644 --- a/ydb/core/tx/datashard/ut_upload_rows/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_upload_rows/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_upload_rows PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_upload_rows PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_upload_rows.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_upload_rows/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_upload_rows/CMakeLists.linux-x86_64.txt index 67a5f56d2b69..7ecaf7055591 100644 --- a/ydb/core/tx/datashard/ut_upload_rows/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_upload_rows/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_upload_rows PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_upload_rows PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_upload_rows.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_upload_rows/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_upload_rows/CMakeLists.windows-x86_64.txt index c832ae074d79..afd14f4b6573 100644 --- a/ydb/core/tx/datashard/ut_upload_rows/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_upload_rows/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_volatile/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_volatile/CMakeLists.darwin-arm64.txt index 95f34fced989..0fa19795dc9a 100644 --- a/ydb/core/tx/datashard/ut_volatile/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_volatile/CMakeLists.darwin-arm64.txt @@ -34,10 +34,9 @@ target_link_options(ydb-core-tx-datashard-ut_volatile PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_volatile PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_common_pq.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_common_pq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_volatile.cpp ) @@ -66,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_volatile/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_volatile/CMakeLists.darwin-x86_64.txt index 83abe519325a..f755ee63d0a1 100644 --- a/ydb/core/tx/datashard/ut_volatile/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_volatile/CMakeLists.darwin-x86_64.txt @@ -35,10 +35,9 @@ target_link_options(ydb-core-tx-datashard-ut_volatile PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_volatile PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_common_pq.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_common_pq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_volatile.cpp ) @@ -67,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_volatile/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_volatile/CMakeLists.linux-aarch64.txt index bbc6ee61f138..881ce28e4e0d 100644 --- a/ydb/core/tx/datashard/ut_volatile/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_volatile/CMakeLists.linux-aarch64.txt @@ -37,11 +37,9 @@ target_link_options(ydb-core-tx-datashard-ut_volatile PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_volatile PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_common_pq.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_common_pq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_volatile.cpp ) @@ -70,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_volatile/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_volatile/CMakeLists.linux-x86_64.txt index 1d28bccb6c20..ca5628fb8672 100644 --- a/ydb/core/tx/datashard/ut_volatile/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_volatile/CMakeLists.linux-x86_64.txt @@ -38,11 +38,9 @@ target_link_options(ydb-core-tx-datashard-ut_volatile PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_volatile PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_common_pq.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_common_pq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_volatile.cpp ) @@ -71,6 +69,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_volatile/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_volatile/CMakeLists.windows-x86_64.txt index 6943b540b636..6c302be7f261 100644 --- a/ydb/core/tx/datashard/ut_volatile/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_volatile/CMakeLists.windows-x86_64.txt @@ -32,6 +32,7 @@ target_link_libraries(ydb-core-tx-datashard-ut_volatile PUBLIC cpp-client-ydb_result ) target_sources(ydb-core-tx-datashard-ut_volatile PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_common_pq.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_common_pq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_volatile.cpp ) @@ -60,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_write/CMakeLists.darwin-arm64.txt b/ydb/core/tx/datashard/ut_write/CMakeLists.darwin-arm64.txt index ac06a0c7e13a..a48afff5efea 100644 --- a/ydb/core/tx/datashard/ut_write/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/datashard/ut_write/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-datashard-ut_write PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_write PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_write.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_write/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/datashard/ut_write/CMakeLists.darwin-x86_64.txt index c4ef06969424..649dcbe8df7e 100644 --- a/ydb/core/tx/datashard/ut_write/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/datashard/ut_write/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-core-tx-datashard-ut_write PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-datashard-ut_write PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_write.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_write/CMakeLists.linux-aarch64.txt b/ydb/core/tx/datashard/ut_write/CMakeLists.linux-aarch64.txt index 17b75fce13fc..089fd445796b 100644 --- a/ydb/core/tx/datashard/ut_write/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/datashard/ut_write/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-datashard-ut_write PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_write PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_write.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_write/CMakeLists.linux-x86_64.txt b/ydb/core/tx/datashard/ut_write/CMakeLists.linux-x86_64.txt index 45c988267d82..72962dbd1f7e 100644 --- a/ydb/core/tx/datashard/ut_write/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/datashard/ut_write/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-core-tx-datashard-ut_write PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-datashard-ut_write PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/datashard/datashard_ut_write.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/datashard/ut_write/CMakeLists.windows-x86_64.txt b/ydb/core/tx/datashard/ut_write/CMakeLists.windows-x86_64.txt index 99c673895213..193413ab5a46 100644 --- a/ydb/core/tx/datashard/ut_write/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/datashard/ut_write/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/long_tx_service/public/ut/CMakeLists.darwin-arm64.txt b/ydb/core/tx/long_tx_service/public/ut/CMakeLists.darwin-arm64.txt index 0af02ff7233e..dcdd40912348 100644 --- a/ydb/core/tx/long_tx_service/public/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/long_tx_service/public/ut/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-tx-long_tx_service-public-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-long_tx_service-public-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/long_tx_service/public/types_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/long_tx_service/public/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/long_tx_service/public/ut/CMakeLists.darwin-x86_64.txt index ca2308a9cd14..40d3ac86a3bd 100644 --- a/ydb/core/tx/long_tx_service/public/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/long_tx_service/public/ut/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-tx-long_tx_service-public-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-long_tx_service-public-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/long_tx_service/public/types_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/long_tx_service/public/ut/CMakeLists.linux-aarch64.txt b/ydb/core/tx/long_tx_service/public/ut/CMakeLists.linux-aarch64.txt index 6f91fee077f1..92fdb8e25677 100644 --- a/ydb/core/tx/long_tx_service/public/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/long_tx_service/public/ut/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-tx-long_tx_service-public-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-long_tx_service-public-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/long_tx_service/public/types_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/long_tx_service/public/ut/CMakeLists.linux-x86_64.txt b/ydb/core/tx/long_tx_service/public/ut/CMakeLists.linux-x86_64.txt index 95878b8443e8..3041fe4c94d2 100644 --- a/ydb/core/tx/long_tx_service/public/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/long_tx_service/public/ut/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-tx-long_tx_service-public-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-long_tx_service-public-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/long_tx_service/public/types_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/long_tx_service/public/ut/CMakeLists.windows-x86_64.txt b/ydb/core/tx/long_tx_service/public/ut/CMakeLists.windows-x86_64.txt index e801bef6eb11..7a02b8b5aa51 100644 --- a/ydb/core/tx/long_tx_service/public/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/long_tx_service/public/ut/CMakeLists.windows-x86_64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/long_tx_service/ut/CMakeLists.darwin-arm64.txt b/ydb/core/tx/long_tx_service/ut/CMakeLists.darwin-arm64.txt index 96a7425ee238..1f953f66ddd4 100644 --- a/ydb/core/tx/long_tx_service/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/long_tx_service/ut/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-tx-long_tx_service-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-long_tx_service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/long_tx_service/long_tx_service_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/long_tx_service/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/long_tx_service/ut/CMakeLists.darwin-x86_64.txt index 479349979f22..6a93bb59ac46 100644 --- a/ydb/core/tx/long_tx_service/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/long_tx_service/ut/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-tx-long_tx_service-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-long_tx_service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/long_tx_service/long_tx_service_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/long_tx_service/ut/CMakeLists.linux-aarch64.txt b/ydb/core/tx/long_tx_service/ut/CMakeLists.linux-aarch64.txt index a09594447c22..9c4c3f24c996 100644 --- a/ydb/core/tx/long_tx_service/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/long_tx_service/ut/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-tx-long_tx_service-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-long_tx_service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/long_tx_service/long_tx_service_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/long_tx_service/ut/CMakeLists.linux-x86_64.txt b/ydb/core/tx/long_tx_service/ut/CMakeLists.linux-x86_64.txt index cf03210ac12a..562301a24f4a 100644 --- a/ydb/core/tx/long_tx_service/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/long_tx_service/ut/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-tx-long_tx_service-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-long_tx_service-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/long_tx_service/long_tx_service_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/long_tx_service/ut/CMakeLists.windows-x86_64.txt b/ydb/core/tx/long_tx_service/ut/CMakeLists.windows-x86_64.txt index cda3f3a7887c..5083f999e6e1 100644 --- a/ydb/core/tx/long_tx_service/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/long_tx_service/ut/CMakeLists.windows-x86_64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/program/CMakeLists.darwin-arm64.txt b/ydb/core/tx/program/CMakeLists.darwin-arm64.txt index 89a5ca7f537b..fafdeeeab2ac 100644 --- a/ydb/core/tx/program/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/program/CMakeLists.darwin-arm64.txt @@ -17,7 +17,7 @@ target_link_libraries(core-tx-program PUBLIC core-formats-arrow ydb-core-protos ydb-core-tablet_flat - minikql-comp_nodes-llvm + yql-minikql-comp_nodes core-arrow_kernels-registry ) target_sources(core-tx-program PRIVATE diff --git a/ydb/core/tx/program/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/program/CMakeLists.darwin-x86_64.txt index 89a5ca7f537b..fafdeeeab2ac 100644 --- a/ydb/core/tx/program/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/program/CMakeLists.darwin-x86_64.txt @@ -17,7 +17,7 @@ target_link_libraries(core-tx-program PUBLIC core-formats-arrow ydb-core-protos ydb-core-tablet_flat - minikql-comp_nodes-llvm + yql-minikql-comp_nodes core-arrow_kernels-registry ) target_sources(core-tx-program PRIVATE diff --git a/ydb/core/tx/program/CMakeLists.linux-aarch64.txt b/ydb/core/tx/program/CMakeLists.linux-aarch64.txt index 1d4916663bb2..8f015ab56ea7 100644 --- a/ydb/core/tx/program/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/program/CMakeLists.linux-aarch64.txt @@ -18,7 +18,7 @@ target_link_libraries(core-tx-program PUBLIC core-formats-arrow ydb-core-protos ydb-core-tablet_flat - minikql-comp_nodes-llvm + yql-minikql-comp_nodes core-arrow_kernels-registry ) target_sources(core-tx-program PRIVATE diff --git a/ydb/core/tx/program/CMakeLists.linux-x86_64.txt b/ydb/core/tx/program/CMakeLists.linux-x86_64.txt index 1d4916663bb2..8f015ab56ea7 100644 --- a/ydb/core/tx/program/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/program/CMakeLists.linux-x86_64.txt @@ -18,7 +18,7 @@ target_link_libraries(core-tx-program PUBLIC core-formats-arrow ydb-core-protos ydb-core-tablet_flat - minikql-comp_nodes-llvm + yql-minikql-comp_nodes core-arrow_kernels-registry ) target_sources(core-tx-program PRIVATE diff --git a/ydb/core/tx/program/CMakeLists.windows-x86_64.txt b/ydb/core/tx/program/CMakeLists.windows-x86_64.txt index 89a5ca7f537b..fafdeeeab2ac 100644 --- a/ydb/core/tx/program/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/program/CMakeLists.windows-x86_64.txt @@ -17,7 +17,7 @@ target_link_libraries(core-tx-program PUBLIC core-formats-arrow ydb-core-protos ydb-core-tablet_flat - minikql-comp_nodes-llvm + yql-minikql-comp_nodes core-arrow_kernels-registry ) target_sources(core-tx-program PRIVATE diff --git a/ydb/core/tx/replication/CMakeLists.txt b/ydb/core/tx/replication/CMakeLists.txt index e8a77d31b80a..3e0e27658ccf 100644 --- a/ydb/core/tx/replication/CMakeLists.txt +++ b/ydb/core/tx/replication/CMakeLists.txt @@ -8,4 +8,5 @@ add_subdirectory(controller) add_subdirectory(service) +add_subdirectory(ut_helpers) add_subdirectory(ydb_proxy) diff --git a/ydb/core/tx/replication/service/CMakeLists.darwin-arm64.txt b/ydb/core/tx/replication/service/CMakeLists.darwin-arm64.txt index ce070b006e1f..4fa535b4626b 100644 --- a/ydb/core/tx/replication/service/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/replication/service/CMakeLists.darwin-arm64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(ut_topic_reader) add_library(tx-replication-service) target_compile_options(tx-replication-service PRIVATE @@ -15,7 +16,21 @@ target_link_libraries(tx-replication-service PUBLIC contrib-libs-cxxsupp yutil ydb-core-base + ydb-core-change_exchange + ydb-core-protos + ydb-core-scheme + ydb-core-scheme_types + ydb-core-tablet_flat + core-io_formats-cell_maker + tx-replication-ydb_proxy + library-actors-core + ydb-library-services + library-cpp-json ) target_sources(tx-replication-service PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/json_change_record.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/service.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/table_writer.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/topic_reader.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/worker.cpp ) diff --git a/ydb/core/tx/replication/service/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/replication/service/CMakeLists.darwin-x86_64.txt index ce070b006e1f..4fa535b4626b 100644 --- a/ydb/core/tx/replication/service/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/replication/service/CMakeLists.darwin-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(ut_topic_reader) add_library(tx-replication-service) target_compile_options(tx-replication-service PRIVATE @@ -15,7 +16,21 @@ target_link_libraries(tx-replication-service PUBLIC contrib-libs-cxxsupp yutil ydb-core-base + ydb-core-change_exchange + ydb-core-protos + ydb-core-scheme + ydb-core-scheme_types + ydb-core-tablet_flat + core-io_formats-cell_maker + tx-replication-ydb_proxy + library-actors-core + ydb-library-services + library-cpp-json ) target_sources(tx-replication-service PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/json_change_record.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/service.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/table_writer.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/topic_reader.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/worker.cpp ) diff --git a/ydb/core/tx/replication/service/CMakeLists.linux-aarch64.txt b/ydb/core/tx/replication/service/CMakeLists.linux-aarch64.txt index 68c0eddf13db..003848c34ae9 100644 --- a/ydb/core/tx/replication/service/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/replication/service/CMakeLists.linux-aarch64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(ut_topic_reader) add_library(tx-replication-service) target_compile_options(tx-replication-service PRIVATE @@ -16,7 +17,21 @@ target_link_libraries(tx-replication-service PUBLIC contrib-libs-cxxsupp yutil ydb-core-base + ydb-core-change_exchange + ydb-core-protos + ydb-core-scheme + ydb-core-scheme_types + ydb-core-tablet_flat + core-io_formats-cell_maker + tx-replication-ydb_proxy + library-actors-core + ydb-library-services + library-cpp-json ) target_sources(tx-replication-service PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/json_change_record.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/service.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/table_writer.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/topic_reader.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/worker.cpp ) diff --git a/ydb/core/tx/replication/service/CMakeLists.linux-x86_64.txt b/ydb/core/tx/replication/service/CMakeLists.linux-x86_64.txt index 68c0eddf13db..003848c34ae9 100644 --- a/ydb/core/tx/replication/service/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/replication/service/CMakeLists.linux-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(ut_topic_reader) add_library(tx-replication-service) target_compile_options(tx-replication-service PRIVATE @@ -16,7 +17,21 @@ target_link_libraries(tx-replication-service PUBLIC contrib-libs-cxxsupp yutil ydb-core-base + ydb-core-change_exchange + ydb-core-protos + ydb-core-scheme + ydb-core-scheme_types + ydb-core-tablet_flat + core-io_formats-cell_maker + tx-replication-ydb_proxy + library-actors-core + ydb-library-services + library-cpp-json ) target_sources(tx-replication-service PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/json_change_record.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/service.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/table_writer.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/topic_reader.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/worker.cpp ) diff --git a/ydb/core/tx/replication/service/CMakeLists.windows-x86_64.txt b/ydb/core/tx/replication/service/CMakeLists.windows-x86_64.txt index ce070b006e1f..4fa535b4626b 100644 --- a/ydb/core/tx/replication/service/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/replication/service/CMakeLists.windows-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(ut_topic_reader) add_library(tx-replication-service) target_compile_options(tx-replication-service PRIVATE @@ -15,7 +16,21 @@ target_link_libraries(tx-replication-service PUBLIC contrib-libs-cxxsupp yutil ydb-core-base + ydb-core-change_exchange + ydb-core-protos + ydb-core-scheme + ydb-core-scheme_types + ydb-core-tablet_flat + core-io_formats-cell_maker + tx-replication-ydb_proxy + library-actors-core + ydb-library-services + library-cpp-json ) target_sources(tx-replication-service PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/json_change_record.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/service.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/table_writer.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/topic_reader.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/worker.cpp ) diff --git a/ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.darwin-arm64.txt b/ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..f3085f78bcbd --- /dev/null +++ b/ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.darwin-arm64.txt @@ -0,0 +1,79 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-tx-replication-service-ut_topic_reader) +target_compile_options(ydb-core-tx-replication-service-ut_topic_reader PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-tx-replication-service-ut_topic_reader PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service +) +target_link_libraries(ydb-core-tx-replication-service-ut_topic_reader PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + tx-replication-service + tx-replication-ut_helpers + tx-replication-ydb_proxy + cpp-client-ydb_topic + cpp-testing-unittest +) +target_link_options(ydb-core-tx-replication-service-ut_topic_reader PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-core-tx-replication-service-ut_topic_reader PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/topic_reader_ut.cpp +) +set_property( + TARGET + ydb-core-tx-replication-service-ut_topic_reader + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-core-tx-replication-service-ut_topic_reader + TEST_TARGET + ydb-core-tx-replication-service-ut_topic_reader + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-tx-replication-service-ut_topic_reader + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-tx-replication-service-ut_topic_reader + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-tx-replication-service-ut_topic_reader + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-tx-replication-service-ut_topic_reader + system_allocator +) +vcs_info(ydb-core-tx-replication-service-ut_topic_reader) diff --git a/ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..ed0f9b741634 --- /dev/null +++ b/ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,80 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-tx-replication-service-ut_topic_reader) +target_compile_options(ydb-core-tx-replication-service-ut_topic_reader PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-tx-replication-service-ut_topic_reader PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service +) +target_link_libraries(ydb-core-tx-replication-service-ut_topic_reader PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + tx-replication-service + tx-replication-ut_helpers + tx-replication-ydb_proxy + cpp-client-ydb_topic + cpp-testing-unittest +) +target_link_options(ydb-core-tx-replication-service-ut_topic_reader PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-core-tx-replication-service-ut_topic_reader PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/topic_reader_ut.cpp +) +set_property( + TARGET + ydb-core-tx-replication-service-ut_topic_reader + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-core-tx-replication-service-ut_topic_reader + TEST_TARGET + ydb-core-tx-replication-service-ut_topic_reader + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-tx-replication-service-ut_topic_reader + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-tx-replication-service-ut_topic_reader + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-tx-replication-service-ut_topic_reader + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-tx-replication-service-ut_topic_reader + system_allocator +) +vcs_info(ydb-core-tx-replication-service-ut_topic_reader) diff --git a/ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.linux-aarch64.txt b/ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..d7c68ad220ad --- /dev/null +++ b/ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.linux-aarch64.txt @@ -0,0 +1,82 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-tx-replication-service-ut_topic_reader) +target_compile_options(ydb-core-tx-replication-service-ut_topic_reader PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-tx-replication-service-ut_topic_reader PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service +) +target_link_libraries(ydb-core-tx-replication-service-ut_topic_reader PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + tx-replication-service + tx-replication-ut_helpers + tx-replication-ydb_proxy + cpp-client-ydb_topic + cpp-testing-unittest +) +target_link_options(ydb-core-tx-replication-service-ut_topic_reader PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-core-tx-replication-service-ut_topic_reader PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/topic_reader_ut.cpp +) +set_property( + TARGET + ydb-core-tx-replication-service-ut_topic_reader + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-core-tx-replication-service-ut_topic_reader + TEST_TARGET + ydb-core-tx-replication-service-ut_topic_reader + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-tx-replication-service-ut_topic_reader + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-tx-replication-service-ut_topic_reader + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-tx-replication-service-ut_topic_reader + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-tx-replication-service-ut_topic_reader + cpp-malloc-jemalloc +) +vcs_info(ydb-core-tx-replication-service-ut_topic_reader) diff --git a/ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.linux-x86_64.txt b/ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..e34304aab046 --- /dev/null +++ b/ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.linux-x86_64.txt @@ -0,0 +1,84 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-tx-replication-service-ut_topic_reader) +target_compile_options(ydb-core-tx-replication-service-ut_topic_reader PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-tx-replication-service-ut_topic_reader PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service +) +target_link_libraries(ydb-core-tx-replication-service-ut_topic_reader PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + tx-replication-service + tx-replication-ut_helpers + tx-replication-ydb_proxy + cpp-client-ydb_topic + cpp-testing-unittest +) +target_link_options(ydb-core-tx-replication-service-ut_topic_reader PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-core-tx-replication-service-ut_topic_reader PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/topic_reader_ut.cpp +) +set_property( + TARGET + ydb-core-tx-replication-service-ut_topic_reader + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-core-tx-replication-service-ut_topic_reader + TEST_TARGET + ydb-core-tx-replication-service-ut_topic_reader + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-tx-replication-service-ut_topic_reader + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-tx-replication-service-ut_topic_reader + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-tx-replication-service-ut_topic_reader + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-tx-replication-service-ut_topic_reader + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(ydb-core-tx-replication-service-ut_topic_reader) diff --git a/ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.txt b/ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.windows-x86_64.txt b/ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..0499634bd6f5 --- /dev/null +++ b/ydb/core/tx/replication/service/ut_topic_reader/CMakeLists.windows-x86_64.txt @@ -0,0 +1,75 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-tx-replication-service-ut_topic_reader) +target_compile_options(ydb-core-tx-replication-service-ut_topic_reader PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-tx-replication-service-ut_topic_reader PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service +) +target_link_libraries(ydb-core-tx-replication-service-ut_topic_reader PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + tx-replication-service + tx-replication-ut_helpers + tx-replication-ydb_proxy + cpp-client-ydb_topic + cpp-testing-unittest +) +target_sources(ydb-core-tx-replication-service-ut_topic_reader PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/service/topic_reader_ut.cpp +) +set_property( + TARGET + ydb-core-tx-replication-service-ut_topic_reader + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-core-tx-replication-service-ut_topic_reader + TEST_TARGET + ydb-core-tx-replication-service-ut_topic_reader + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-tx-replication-service-ut_topic_reader + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-tx-replication-service-ut_topic_reader + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-tx-replication-service-ut_topic_reader + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-tx-replication-service-ut_topic_reader + system_allocator +) +vcs_info(ydb-core-tx-replication-service-ut_topic_reader) diff --git a/ydb/core/tx/replication/ut_helpers/CMakeLists.darwin-arm64.txt b/ydb/core/tx/replication/ut_helpers/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..71ca50befe61 --- /dev/null +++ b/ydb/core/tx/replication/ut_helpers/CMakeLists.darwin-arm64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(tx-replication-ut_helpers INTERFACE) +target_link_libraries(tx-replication-ut_helpers INTERFACE + contrib-libs-cxxsupp + yutil + ydb-core-base + ydb-core-protos + core-testlib-default + tx-replication-ydb_proxy + cpp-client-ydb_topic + cpp-testing-unittest +) +target_sources(tx-replication-ut_helpers INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/ut_helpers/test_env.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/ut_helpers/write_topic.h +) diff --git a/ydb/core/tx/replication/ut_helpers/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/replication/ut_helpers/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..71ca50befe61 --- /dev/null +++ b/ydb/core/tx/replication/ut_helpers/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(tx-replication-ut_helpers INTERFACE) +target_link_libraries(tx-replication-ut_helpers INTERFACE + contrib-libs-cxxsupp + yutil + ydb-core-base + ydb-core-protos + core-testlib-default + tx-replication-ydb_proxy + cpp-client-ydb_topic + cpp-testing-unittest +) +target_sources(tx-replication-ut_helpers INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/ut_helpers/test_env.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/ut_helpers/write_topic.h +) diff --git a/ydb/core/tx/replication/ut_helpers/CMakeLists.linux-aarch64.txt b/ydb/core/tx/replication/ut_helpers/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..df63b6f0514a --- /dev/null +++ b/ydb/core/tx/replication/ut_helpers/CMakeLists.linux-aarch64.txt @@ -0,0 +1,25 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(tx-replication-ut_helpers INTERFACE) +target_link_libraries(tx-replication-ut_helpers INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-base + ydb-core-protos + core-testlib-default + tx-replication-ydb_proxy + cpp-client-ydb_topic + cpp-testing-unittest +) +target_sources(tx-replication-ut_helpers INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/ut_helpers/test_env.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/ut_helpers/write_topic.h +) diff --git a/ydb/core/tx/replication/ut_helpers/CMakeLists.linux-x86_64.txt b/ydb/core/tx/replication/ut_helpers/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..df63b6f0514a --- /dev/null +++ b/ydb/core/tx/replication/ut_helpers/CMakeLists.linux-x86_64.txt @@ -0,0 +1,25 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(tx-replication-ut_helpers INTERFACE) +target_link_libraries(tx-replication-ut_helpers INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-base + ydb-core-protos + core-testlib-default + tx-replication-ydb_proxy + cpp-client-ydb_topic + cpp-testing-unittest +) +target_sources(tx-replication-ut_helpers INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/ut_helpers/test_env.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/ut_helpers/write_topic.h +) diff --git a/ydb/core/tx/replication/ut_helpers/CMakeLists.txt b/ydb/core/tx/replication/ut_helpers/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/tx/replication/ut_helpers/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/tx/replication/ut_helpers/CMakeLists.windows-x86_64.txt b/ydb/core/tx/replication/ut_helpers/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..71ca50befe61 --- /dev/null +++ b/ydb/core/tx/replication/ut_helpers/CMakeLists.windows-x86_64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(tx-replication-ut_helpers INTERFACE) +target_link_libraries(tx-replication-ut_helpers INTERFACE + contrib-libs-cxxsupp + yutil + ydb-core-base + ydb-core-protos + core-testlib-default + tx-replication-ydb_proxy + cpp-client-ydb_topic + cpp-testing-unittest +) +target_sources(tx-replication-ut_helpers INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/ut_helpers/test_env.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/ut_helpers/write_topic.h +) diff --git a/ydb/core/tx/replication/ydb_proxy/ut/CMakeLists.darwin-arm64.txt b/ydb/core/tx/replication/ydb_proxy/ut/CMakeLists.darwin-arm64.txt index 816747bdf68d..02eafccb8f1c 100644 --- a/ydb/core/tx/replication/ydb_proxy/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/replication/ydb_proxy/ut/CMakeLists.darwin-arm64.txt @@ -19,16 +19,14 @@ target_link_libraries(ydb-core-tx-replication-ydb_proxy-ut PUBLIC yutil cpp-testing-unittest_main tx-replication-ydb_proxy - cpp-testing-unittest - core-testlib-default + tx-replication-ut_helpers cpp-client-ydb_topic + cpp-testing-unittest ) target_link_options(ydb-core-tx-replication-ydb_proxy-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-replication-ydb_proxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/ydb_proxy/ydb_proxy_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/replication/ydb_proxy/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/replication/ydb_proxy/ut/CMakeLists.darwin-x86_64.txt index e24e8be7605d..2a7ef0d883e5 100644 --- a/ydb/core/tx/replication/ydb_proxy/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/replication/ydb_proxy/ut/CMakeLists.darwin-x86_64.txt @@ -20,16 +20,14 @@ target_link_libraries(ydb-core-tx-replication-ydb_proxy-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main tx-replication-ydb_proxy - cpp-testing-unittest - core-testlib-default + tx-replication-ut_helpers cpp-client-ydb_topic + cpp-testing-unittest ) target_link_options(ydb-core-tx-replication-ydb_proxy-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-replication-ydb_proxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/ydb_proxy/ydb_proxy_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/replication/ydb_proxy/ut/CMakeLists.linux-aarch64.txt b/ydb/core/tx/replication/ydb_proxy/ut/CMakeLists.linux-aarch64.txt index 33fd1e9dd6a9..d4c24fb7442c 100644 --- a/ydb/core/tx/replication/ydb_proxy/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/replication/ydb_proxy/ut/CMakeLists.linux-aarch64.txt @@ -20,9 +20,9 @@ target_link_libraries(ydb-core-tx-replication-ydb_proxy-ut PUBLIC yutil cpp-testing-unittest_main tx-replication-ydb_proxy - cpp-testing-unittest - core-testlib-default + tx-replication-ut_helpers cpp-client-ydb_topic + cpp-testing-unittest ) target_link_options(ydb-core-tx-replication-ydb_proxy-ut PRIVATE -ldl @@ -30,9 +30,6 @@ target_link_options(ydb-core-tx-replication-ydb_proxy-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-replication-ydb_proxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/ydb_proxy/ydb_proxy_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/replication/ydb_proxy/ut/CMakeLists.linux-x86_64.txt b/ydb/core/tx/replication/ydb_proxy/ut/CMakeLists.linux-x86_64.txt index e3ad8ee89c06..df7cfceecf1e 100644 --- a/ydb/core/tx/replication/ydb_proxy/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/replication/ydb_proxy/ut/CMakeLists.linux-x86_64.txt @@ -21,9 +21,9 @@ target_link_libraries(ydb-core-tx-replication-ydb_proxy-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main tx-replication-ydb_proxy - cpp-testing-unittest - core-testlib-default + tx-replication-ut_helpers cpp-client-ydb_topic + cpp-testing-unittest ) target_link_options(ydb-core-tx-replication-ydb_proxy-ut PRIVATE -ldl @@ -31,9 +31,6 @@ target_link_options(ydb-core-tx-replication-ydb_proxy-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-replication-ydb_proxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/ydb_proxy/ydb_proxy_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/replication/ydb_proxy/ut/CMakeLists.windows-x86_64.txt b/ydb/core/tx/replication/ydb_proxy/ut/CMakeLists.windows-x86_64.txt index a231dd3d2263..5ae32cefac60 100644 --- a/ydb/core/tx/replication/ydb_proxy/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/replication/ydb_proxy/ut/CMakeLists.windows-x86_64.txt @@ -20,9 +20,9 @@ target_link_libraries(ydb-core-tx-replication-ydb_proxy-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main tx-replication-ydb_proxy - cpp-testing-unittest - core-testlib-default + tx-replication-ut_helpers cpp-client-ydb_topic + cpp-testing-unittest ) target_sources(ydb-core-tx-replication-ydb_proxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/replication/ydb_proxy/ydb_proxy_ut.cpp @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_cache/CMakeLists.darwin-arm64.txt b/ydb/core/tx/scheme_board/ut_cache/CMakeLists.darwin-arm64.txt index 0a2718840e49..4a0ce51f436a 100644 --- a/ydb/core/tx/scheme_board/ut_cache/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/scheme_board/ut_cache/CMakeLists.darwin-arm64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-tx-scheme_board-ut_cache PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-scheme_board-ut_cache PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/cache_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_cache/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/scheme_board/ut_cache/CMakeLists.darwin-x86_64.txt index f79a62dc2d41..ed39a75f9086 100644 --- a/ydb/core/tx/scheme_board/ut_cache/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/scheme_board/ut_cache/CMakeLists.darwin-x86_64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-core-tx-scheme_board-ut_cache PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-scheme_board-ut_cache PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/cache_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_cache/CMakeLists.linux-aarch64.txt b/ydb/core/tx/scheme_board/ut_cache/CMakeLists.linux-aarch64.txt index 6a0fb344befb..3a293ccd403b 100644 --- a/ydb/core/tx/scheme_board/ut_cache/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/scheme_board/ut_cache/CMakeLists.linux-aarch64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-tx-scheme_board-ut_cache PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-scheme_board-ut_cache PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/cache_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_cache/CMakeLists.linux-x86_64.txt b/ydb/core/tx/scheme_board/ut_cache/CMakeLists.linux-x86_64.txt index e95f35346e28..b183a154f071 100644 --- a/ydb/core/tx/scheme_board/ut_cache/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/scheme_board/ut_cache/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-core-tx-scheme_board-ut_cache PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-scheme_board-ut_cache PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/cache_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_cache/CMakeLists.windows-x86_64.txt b/ydb/core/tx/scheme_board/ut_cache/CMakeLists.windows-x86_64.txt index cfa76751d7f2..22eef0cf93f7 100644 --- a/ydb/core/tx/scheme_board/ut_cache/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/scheme_board/ut_cache/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_double_indexed/CMakeLists.darwin-arm64.txt b/ydb/core/tx/scheme_board/ut_double_indexed/CMakeLists.darwin-arm64.txt index 71bb08aa2256..40c9cbbbe0cd 100644 --- a/ydb/core/tx/scheme_board/ut_double_indexed/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/scheme_board/ut_double_indexed/CMakeLists.darwin-arm64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-core-tx-scheme_board-ut_double_indexed PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-scheme_board-ut_double_indexed PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/double_indexed_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_double_indexed/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/scheme_board/ut_double_indexed/CMakeLists.darwin-x86_64.txt index 7dc173161a35..1d857fdb8aa9 100644 --- a/ydb/core/tx/scheme_board/ut_double_indexed/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/scheme_board/ut_double_indexed/CMakeLists.darwin-x86_64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-tx-scheme_board-ut_double_indexed PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-scheme_board-ut_double_indexed PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/double_indexed_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_double_indexed/CMakeLists.linux-aarch64.txt b/ydb/core/tx/scheme_board/ut_double_indexed/CMakeLists.linux-aarch64.txt index 5ca6b2c14915..eabed24e232c 100644 --- a/ydb/core/tx/scheme_board/ut_double_indexed/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/scheme_board/ut_double_indexed/CMakeLists.linux-aarch64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-core-tx-scheme_board-ut_double_indexed PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-scheme_board-ut_double_indexed PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/double_indexed_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_double_indexed/CMakeLists.linux-x86_64.txt b/ydb/core/tx/scheme_board/ut_double_indexed/CMakeLists.linux-x86_64.txt index f935b441ae49..a13eedb65281 100644 --- a/ydb/core/tx/scheme_board/ut_double_indexed/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/scheme_board/ut_double_indexed/CMakeLists.linux-x86_64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-tx-scheme_board-ut_double_indexed PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-scheme_board-ut_double_indexed PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/double_indexed_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_double_indexed/CMakeLists.windows-x86_64.txt b/ydb/core/tx/scheme_board/ut_double_indexed/CMakeLists.windows-x86_64.txt index 6b12030ffb69..76582f715144 100644 --- a/ydb/core/tx/scheme_board/ut_double_indexed/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/scheme_board/ut_double_indexed/CMakeLists.windows-x86_64.txt @@ -49,6 +49,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_monitoring/CMakeLists.darwin-arm64.txt b/ydb/core/tx/scheme_board/ut_monitoring/CMakeLists.darwin-arm64.txt index 235fefbbabeb..3cd1d6322fcd 100644 --- a/ydb/core/tx/scheme_board/ut_monitoring/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/scheme_board/ut_monitoring/CMakeLists.darwin-arm64.txt @@ -22,13 +22,12 @@ target_link_libraries(ydb-core-tx-scheme_board-ut_monitoring PUBLIC library-actors-core cpp-testing-unittest testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-core-tx-scheme_board-ut_monitoring PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-scheme_board-ut_monitoring PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/monitoring_ut.cpp @@ -59,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_monitoring/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/scheme_board/ut_monitoring/CMakeLists.darwin-x86_64.txt index 3eed54a7e0a4..461d04c39e76 100644 --- a/ydb/core/tx/scheme_board/ut_monitoring/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/scheme_board/ut_monitoring/CMakeLists.darwin-x86_64.txt @@ -23,13 +23,12 @@ target_link_libraries(ydb-core-tx-scheme_board-ut_monitoring PUBLIC library-actors-core cpp-testing-unittest testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-core-tx-scheme_board-ut_monitoring PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-scheme_board-ut_monitoring PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/monitoring_ut.cpp @@ -60,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_monitoring/CMakeLists.linux-aarch64.txt b/ydb/core/tx/scheme_board/ut_monitoring/CMakeLists.linux-aarch64.txt index 2d6453716c6b..7d42d9276db2 100644 --- a/ydb/core/tx/scheme_board/ut_monitoring/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/scheme_board/ut_monitoring/CMakeLists.linux-aarch64.txt @@ -23,6 +23,7 @@ target_link_libraries(ydb-core-tx-scheme_board-ut_monitoring PUBLIC library-actors-core cpp-testing-unittest testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-core-tx-scheme_board-ut_monitoring PRIVATE -ldl @@ -30,9 +31,6 @@ target_link_options(ydb-core-tx-scheme_board-ut_monitoring PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-scheme_board-ut_monitoring PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/monitoring_ut.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_monitoring/CMakeLists.linux-x86_64.txt b/ydb/core/tx/scheme_board/ut_monitoring/CMakeLists.linux-x86_64.txt index e29a4ef5ac27..138391ef50d4 100644 --- a/ydb/core/tx/scheme_board/ut_monitoring/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/scheme_board/ut_monitoring/CMakeLists.linux-x86_64.txt @@ -24,6 +24,7 @@ target_link_libraries(ydb-core-tx-scheme_board-ut_monitoring PUBLIC library-actors-core cpp-testing-unittest testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-core-tx-scheme_board-ut_monitoring PRIVATE -ldl @@ -31,9 +32,6 @@ target_link_options(ydb-core-tx-scheme_board-ut_monitoring PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-scheme_board-ut_monitoring PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/monitoring_ut.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_monitoring/CMakeLists.windows-x86_64.txt b/ydb/core/tx/scheme_board/ut_monitoring/CMakeLists.windows-x86_64.txt index 926a0abb569b..5404a8404204 100644 --- a/ydb/core/tx/scheme_board/ut_monitoring/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/scheme_board/ut_monitoring/CMakeLists.windows-x86_64.txt @@ -23,6 +23,7 @@ target_link_libraries(ydb-core-tx-scheme_board-ut_monitoring PUBLIC library-actors-core cpp-testing-unittest testlib-basics-default + minikql-comp_nodes-llvm14 ) target_sources(ydb-core-tx-scheme_board-ut_monitoring PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/monitoring_ut.cpp @@ -53,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_populator/CMakeLists.darwin-arm64.txt b/ydb/core/tx/scheme_board/ut_populator/CMakeLists.darwin-arm64.txt index 57814d52fbf1..d638f89c7aec 100644 --- a/ydb/core/tx/scheme_board/ut_populator/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/scheme_board/ut_populator/CMakeLists.darwin-arm64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-core-tx-scheme_board-ut_populator PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-scheme_board-ut_populator PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/populator_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_populator/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/scheme_board/ut_populator/CMakeLists.darwin-x86_64.txt index 3173958e67f0..51885e2d5109 100644 --- a/ydb/core/tx/scheme_board/ut_populator/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/scheme_board/ut_populator/CMakeLists.darwin-x86_64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-tx-scheme_board-ut_populator PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-scheme_board-ut_populator PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/populator_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_populator/CMakeLists.linux-aarch64.txt b/ydb/core/tx/scheme_board/ut_populator/CMakeLists.linux-aarch64.txt index 067f78030b70..984f6a5f5e0a 100644 --- a/ydb/core/tx/scheme_board/ut_populator/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/scheme_board/ut_populator/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-core-tx-scheme_board-ut_populator PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-scheme_board-ut_populator PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/populator_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_populator/CMakeLists.linux-x86_64.txt b/ydb/core/tx/scheme_board/ut_populator/CMakeLists.linux-x86_64.txt index 42561a3ca002..66a36bb74ec0 100644 --- a/ydb/core/tx/scheme_board/ut_populator/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/scheme_board/ut_populator/CMakeLists.linux-x86_64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-tx-scheme_board-ut_populator PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-scheme_board-ut_populator PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/populator_ut.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_populator/CMakeLists.windows-x86_64.txt b/ydb/core/tx/scheme_board/ut_populator/CMakeLists.windows-x86_64.txt index 5aa756da24f0..fdef9400d9d6 100644 --- a/ydb/core/tx/scheme_board/ut_populator/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/scheme_board/ut_populator/CMakeLists.windows-x86_64.txt @@ -55,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_replica/CMakeLists.darwin-arm64.txt b/ydb/core/tx/scheme_board/ut_replica/CMakeLists.darwin-arm64.txt index efb45bac82f5..36db22a0c8cb 100644 --- a/ydb/core/tx/scheme_board/ut_replica/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/scheme_board/ut_replica/CMakeLists.darwin-arm64.txt @@ -20,14 +20,13 @@ target_link_libraries(ydb-core-tx-scheme_board-ut_replica PUBLIC cpp-testing-unittest_main core-tx-scheme_board cpp-testing-unittest + minikql-comp_nodes-llvm14 testlib-basics-default ) target_link_options(ydb-core-tx-scheme_board-ut_replica PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-scheme_board-ut_replica PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/replica_ut.cpp @@ -58,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_replica/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/scheme_board/ut_replica/CMakeLists.darwin-x86_64.txt index 603831ede7ac..ac9619ccb632 100644 --- a/ydb/core/tx/scheme_board/ut_replica/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/scheme_board/ut_replica/CMakeLists.darwin-x86_64.txt @@ -21,14 +21,13 @@ target_link_libraries(ydb-core-tx-scheme_board-ut_replica PUBLIC cpp-testing-unittest_main core-tx-scheme_board cpp-testing-unittest + minikql-comp_nodes-llvm14 testlib-basics-default ) target_link_options(ydb-core-tx-scheme_board-ut_replica PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-scheme_board-ut_replica PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/replica_ut.cpp @@ -59,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_replica/CMakeLists.linux-aarch64.txt b/ydb/core/tx/scheme_board/ut_replica/CMakeLists.linux-aarch64.txt index d732dc234578..747851de5fa8 100644 --- a/ydb/core/tx/scheme_board/ut_replica/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/scheme_board/ut_replica/CMakeLists.linux-aarch64.txt @@ -21,6 +21,7 @@ target_link_libraries(ydb-core-tx-scheme_board-ut_replica PUBLIC cpp-testing-unittest_main core-tx-scheme_board cpp-testing-unittest + minikql-comp_nodes-llvm14 testlib-basics-default ) target_link_options(ydb-core-tx-scheme_board-ut_replica PRIVATE @@ -29,9 +30,6 @@ target_link_options(ydb-core-tx-scheme_board-ut_replica PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-scheme_board-ut_replica PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/replica_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_replica/CMakeLists.linux-x86_64.txt b/ydb/core/tx/scheme_board/ut_replica/CMakeLists.linux-x86_64.txt index 0072087b8b6b..2c210740ed42 100644 --- a/ydb/core/tx/scheme_board/ut_replica/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/scheme_board/ut_replica/CMakeLists.linux-x86_64.txt @@ -22,6 +22,7 @@ target_link_libraries(ydb-core-tx-scheme_board-ut_replica PUBLIC cpp-testing-unittest_main core-tx-scheme_board cpp-testing-unittest + minikql-comp_nodes-llvm14 testlib-basics-default ) target_link_options(ydb-core-tx-scheme_board-ut_replica PRIVATE @@ -30,9 +31,6 @@ target_link_options(ydb-core-tx-scheme_board-ut_replica PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-scheme_board-ut_replica PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/replica_ut.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_replica/CMakeLists.windows-x86_64.txt b/ydb/core/tx/scheme_board/ut_replica/CMakeLists.windows-x86_64.txt index 307a52d7fa12..74579ebfec57 100644 --- a/ydb/core/tx/scheme_board/ut_replica/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/scheme_board/ut_replica/CMakeLists.windows-x86_64.txt @@ -21,6 +21,7 @@ target_link_libraries(ydb-core-tx-scheme_board-ut_replica PUBLIC cpp-testing-unittest_main core-tx-scheme_board cpp-testing-unittest + minikql-comp_nodes-llvm14 testlib-basics-default ) target_sources(ydb-core-tx-scheme_board-ut_replica PRIVATE @@ -52,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_subscriber/CMakeLists.darwin-arm64.txt b/ydb/core/tx/scheme_board/ut_subscriber/CMakeLists.darwin-arm64.txt index 795ba979ad14..b7f8a0af4a68 100644 --- a/ydb/core/tx/scheme_board/ut_subscriber/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/scheme_board/ut_subscriber/CMakeLists.darwin-arm64.txt @@ -22,13 +22,12 @@ target_link_libraries(ydb-core-tx-scheme_board-ut_subscriber PUBLIC library-actors-interconnect cpp-testing-unittest testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-core-tx-scheme_board-ut_subscriber PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-scheme_board-ut_subscriber PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/subscriber_ut.cpp @@ -59,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_subscriber/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/scheme_board/ut_subscriber/CMakeLists.darwin-x86_64.txt index b766c09e7a2b..875cd002eb29 100644 --- a/ydb/core/tx/scheme_board/ut_subscriber/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/scheme_board/ut_subscriber/CMakeLists.darwin-x86_64.txt @@ -23,13 +23,12 @@ target_link_libraries(ydb-core-tx-scheme_board-ut_subscriber PUBLIC library-actors-interconnect cpp-testing-unittest testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-core-tx-scheme_board-ut_subscriber PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-scheme_board-ut_subscriber PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/subscriber_ut.cpp @@ -60,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_subscriber/CMakeLists.linux-aarch64.txt b/ydb/core/tx/scheme_board/ut_subscriber/CMakeLists.linux-aarch64.txt index 300f8b4808f9..000db2280abd 100644 --- a/ydb/core/tx/scheme_board/ut_subscriber/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/scheme_board/ut_subscriber/CMakeLists.linux-aarch64.txt @@ -23,6 +23,7 @@ target_link_libraries(ydb-core-tx-scheme_board-ut_subscriber PUBLIC library-actors-interconnect cpp-testing-unittest testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-core-tx-scheme_board-ut_subscriber PRIVATE -ldl @@ -30,9 +31,6 @@ target_link_options(ydb-core-tx-scheme_board-ut_subscriber PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-scheme_board-ut_subscriber PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/subscriber_ut.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_subscriber/CMakeLists.linux-x86_64.txt b/ydb/core/tx/scheme_board/ut_subscriber/CMakeLists.linux-x86_64.txt index f59caa182079..42477466e0e6 100644 --- a/ydb/core/tx/scheme_board/ut_subscriber/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/scheme_board/ut_subscriber/CMakeLists.linux-x86_64.txt @@ -24,6 +24,7 @@ target_link_libraries(ydb-core-tx-scheme_board-ut_subscriber PUBLIC library-actors-interconnect cpp-testing-unittest testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-core-tx-scheme_board-ut_subscriber PRIVATE -ldl @@ -31,9 +32,6 @@ target_link_options(ydb-core-tx-scheme_board-ut_subscriber PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-scheme_board-ut_subscriber PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/subscriber_ut.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/scheme_board/ut_subscriber/CMakeLists.windows-x86_64.txt b/ydb/core/tx/scheme_board/ut_subscriber/CMakeLists.windows-x86_64.txt index 9e74a6092ea6..3b97217c2d65 100644 --- a/ydb/core/tx/scheme_board/ut_subscriber/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/scheme_board/ut_subscriber/CMakeLists.windows-x86_64.txt @@ -23,6 +23,7 @@ target_link_libraries(ydb-core-tx-scheme_board-ut_subscriber PUBLIC library-actors-interconnect cpp-testing-unittest testlib-basics-default + minikql-comp_nodes-llvm14 ) target_sources(ydb-core-tx-scheme_board-ut_subscriber PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/subscriber_ut.cpp @@ -53,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/CMakeLists.darwin-arm64.txt index 591fa2ff4f24..9593e617a016 100644 --- a/ydb/core/tx/schemeshard/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/CMakeLists.darwin-arm64.txt @@ -6,7 +6,9 @@ # original buildsystem will not be accepted. +add_subdirectory(olap) add_subdirectory(ut_auditsettings) +add_subdirectory(ut_background_cleaning) add_subdirectory(ut_backup) add_subdirectory(ut_base) add_subdirectory(ut_base_reboots) @@ -111,6 +113,7 @@ target_link_libraries(core-tx-schemeshard PUBLIC ydb-core-tablet_flat ydb-core-tx core-tx-datashard + tx-schemeshard-olap core-tx-scheme_board core-tx-tx_allocator_client ydb-core-util @@ -124,7 +127,27 @@ target_link_libraries(core-tx-schemeshard PUBLIC ydb-services-bg_tasks ) target_sources(core-tx-schemeshard PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_side_effects.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common_subdomain.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_part.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_domain_links.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_effective_acl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_info_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path_element.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_svp_migration.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_tx_infly.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_user_attr_limits.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_utils.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/operation_queue_timer.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__background_cleaning.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__borrowed_compaction.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__compaction.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__clean_pathes.cpp @@ -148,13 +171,13 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_memory_changes.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_db_changes.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_bsv.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_external_data_source.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_external_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_extsubdomain.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_fs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_index.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_kesus.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_login.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_olap_store.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_olap_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_pq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_solomon.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_subdomain.cpp @@ -163,6 +186,8 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_assign_bsv.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_cancel_tx.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common_external_data_source.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common_external_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_consistent_copy_tables.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_copy_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_backup.cpp @@ -175,8 +200,6 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_indexed_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_kesus.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_lock.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_olap_store.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_olap_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_pq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_replication.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_restore.cpp @@ -194,8 +217,6 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_indexed_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_kesus.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_lock.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_olap_store.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_olap_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_pq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_replication.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_sequence.cpp @@ -243,7 +264,6 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_effective_acl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_identificators.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_info_types.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_olap_types.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path_describer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path_element.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path.cpp diff --git a/ydb/core/tx/schemeshard/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/CMakeLists.darwin-x86_64.txt index 591fa2ff4f24..9593e617a016 100644 --- a/ydb/core/tx/schemeshard/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/CMakeLists.darwin-x86_64.txt @@ -6,7 +6,9 @@ # original buildsystem will not be accepted. +add_subdirectory(olap) add_subdirectory(ut_auditsettings) +add_subdirectory(ut_background_cleaning) add_subdirectory(ut_backup) add_subdirectory(ut_base) add_subdirectory(ut_base_reboots) @@ -111,6 +113,7 @@ target_link_libraries(core-tx-schemeshard PUBLIC ydb-core-tablet_flat ydb-core-tx core-tx-datashard + tx-schemeshard-olap core-tx-scheme_board core-tx-tx_allocator_client ydb-core-util @@ -124,7 +127,27 @@ target_link_libraries(core-tx-schemeshard PUBLIC ydb-services-bg_tasks ) target_sources(core-tx-schemeshard PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_side_effects.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common_subdomain.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_part.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_domain_links.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_effective_acl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_info_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path_element.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_svp_migration.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_tx_infly.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_user_attr_limits.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_utils.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/operation_queue_timer.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__background_cleaning.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__borrowed_compaction.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__compaction.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__clean_pathes.cpp @@ -148,13 +171,13 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_memory_changes.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_db_changes.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_bsv.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_external_data_source.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_external_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_extsubdomain.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_fs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_index.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_kesus.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_login.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_olap_store.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_olap_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_pq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_solomon.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_subdomain.cpp @@ -163,6 +186,8 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_assign_bsv.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_cancel_tx.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common_external_data_source.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common_external_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_consistent_copy_tables.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_copy_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_backup.cpp @@ -175,8 +200,6 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_indexed_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_kesus.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_lock.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_olap_store.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_olap_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_pq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_replication.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_restore.cpp @@ -194,8 +217,6 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_indexed_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_kesus.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_lock.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_olap_store.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_olap_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_pq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_replication.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_sequence.cpp @@ -243,7 +264,6 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_effective_acl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_identificators.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_info_types.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_olap_types.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path_describer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path_element.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path.cpp diff --git a/ydb/core/tx/schemeshard/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/CMakeLists.linux-aarch64.txt index 72a0c87e54ce..d948f0a058a6 100644 --- a/ydb/core/tx/schemeshard/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/CMakeLists.linux-aarch64.txt @@ -6,7 +6,9 @@ # original buildsystem will not be accepted. +add_subdirectory(olap) add_subdirectory(ut_auditsettings) +add_subdirectory(ut_background_cleaning) add_subdirectory(ut_backup) add_subdirectory(ut_base) add_subdirectory(ut_base_reboots) @@ -112,6 +114,7 @@ target_link_libraries(core-tx-schemeshard PUBLIC ydb-core-tablet_flat ydb-core-tx core-tx-datashard + tx-schemeshard-olap core-tx-scheme_board core-tx-tx_allocator_client ydb-core-util @@ -125,7 +128,27 @@ target_link_libraries(core-tx-schemeshard PUBLIC ydb-services-bg_tasks ) target_sources(core-tx-schemeshard PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_side_effects.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common_subdomain.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_part.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_domain_links.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_effective_acl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_info_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path_element.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_svp_migration.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_tx_infly.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_user_attr_limits.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_utils.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/operation_queue_timer.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__background_cleaning.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__borrowed_compaction.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__compaction.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__clean_pathes.cpp @@ -149,13 +172,13 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_memory_changes.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_db_changes.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_bsv.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_external_data_source.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_external_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_extsubdomain.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_fs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_index.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_kesus.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_login.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_olap_store.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_olap_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_pq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_solomon.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_subdomain.cpp @@ -164,6 +187,8 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_assign_bsv.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_cancel_tx.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common_external_data_source.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common_external_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_consistent_copy_tables.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_copy_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_backup.cpp @@ -176,8 +201,6 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_indexed_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_kesus.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_lock.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_olap_store.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_olap_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_pq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_replication.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_restore.cpp @@ -195,8 +218,6 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_indexed_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_kesus.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_lock.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_olap_store.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_olap_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_pq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_replication.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_sequence.cpp @@ -244,7 +265,6 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_effective_acl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_identificators.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_info_types.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_olap_types.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path_describer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path_element.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path.cpp diff --git a/ydb/core/tx/schemeshard/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/CMakeLists.linux-x86_64.txt index 72a0c87e54ce..d948f0a058a6 100644 --- a/ydb/core/tx/schemeshard/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/CMakeLists.linux-x86_64.txt @@ -6,7 +6,9 @@ # original buildsystem will not be accepted. +add_subdirectory(olap) add_subdirectory(ut_auditsettings) +add_subdirectory(ut_background_cleaning) add_subdirectory(ut_backup) add_subdirectory(ut_base) add_subdirectory(ut_base_reboots) @@ -112,6 +114,7 @@ target_link_libraries(core-tx-schemeshard PUBLIC ydb-core-tablet_flat ydb-core-tx core-tx-datashard + tx-schemeshard-olap core-tx-scheme_board core-tx-tx_allocator_client ydb-core-util @@ -125,7 +128,27 @@ target_link_libraries(core-tx-schemeshard PUBLIC ydb-services-bg_tasks ) target_sources(core-tx-schemeshard PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_side_effects.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common_subdomain.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_part.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_domain_links.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_effective_acl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_info_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path_element.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_svp_migration.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_tx_infly.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_user_attr_limits.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_utils.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/operation_queue_timer.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__background_cleaning.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__borrowed_compaction.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__compaction.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__clean_pathes.cpp @@ -149,13 +172,13 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_memory_changes.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_db_changes.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_bsv.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_external_data_source.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_external_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_extsubdomain.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_fs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_index.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_kesus.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_login.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_olap_store.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_olap_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_pq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_solomon.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_subdomain.cpp @@ -164,6 +187,8 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_assign_bsv.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_cancel_tx.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common_external_data_source.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common_external_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_consistent_copy_tables.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_copy_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_backup.cpp @@ -176,8 +201,6 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_indexed_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_kesus.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_lock.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_olap_store.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_olap_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_pq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_replication.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_restore.cpp @@ -195,8 +218,6 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_indexed_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_kesus.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_lock.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_olap_store.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_olap_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_pq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_replication.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_sequence.cpp @@ -244,7 +265,6 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_effective_acl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_identificators.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_info_types.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_olap_types.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path_describer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path_element.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path.cpp diff --git a/ydb/core/tx/schemeshard/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/CMakeLists.windows-x86_64.txt index 9030a1fb941f..4cebc8ac2a46 100644 --- a/ydb/core/tx/schemeshard/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/CMakeLists.windows-x86_64.txt @@ -6,7 +6,9 @@ # original buildsystem will not be accepted. +add_subdirectory(olap) add_subdirectory(ut_auditsettings) +add_subdirectory(ut_background_cleaning) add_subdirectory(ut_backup) add_subdirectory(ut_base) add_subdirectory(ut_base_reboots) @@ -111,6 +113,7 @@ target_link_libraries(core-tx-schemeshard PUBLIC ydb-core-tablet_flat ydb-core-tx core-tx-datashard + tx-schemeshard-olap core-tx-scheme_board core-tx-tx_allocator_client ydb-core-util @@ -124,7 +127,27 @@ target_link_libraries(core-tx-schemeshard PUBLIC ydb-services-bg_tasks ) target_sources(core-tx-schemeshard PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_side_effects.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common_subdomain.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_part.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_impl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_domain_links.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_effective_acl.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_info_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path_element.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_schema.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_svp_migration.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_tx_infly.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_types.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_user_attr_limits.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_utils.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/operation_queue_timer.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__background_cleaning.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__borrowed_compaction.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__compaction.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__clean_pathes.cpp @@ -148,13 +171,13 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_memory_changes.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_db_changes.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_bsv.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_external_data_source.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_external_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_extsubdomain.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_fs.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_index.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_kesus.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_login.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_olap_store.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_olap_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_pq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_solomon.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_alter_subdomain.cpp @@ -163,6 +186,8 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_assign_bsv.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_cancel_tx.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common_external_data_source.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_common_external_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_consistent_copy_tables.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_copy_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_backup.cpp @@ -175,8 +200,6 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_indexed_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_kesus.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_lock.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_olap_store.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_olap_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_pq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_replication.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_create_restore.cpp @@ -194,8 +217,6 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_indexed_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_kesus.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_lock.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_olap_store.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_olap_table.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_pq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_replication.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard__operation_drop_sequence.cpp @@ -243,7 +264,6 @@ target_sources(core-tx-schemeshard PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_effective_acl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_identificators.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_info_types.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_olap_types.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path_describer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path_element.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/schemeshard_path.cpp diff --git a/ydb/core/tx/schemeshard/olap/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/olap/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..1e38f462ca9a --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/CMakeLists.darwin-arm64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(columns) +add_subdirectory(common) +add_subdirectory(indexes) +add_subdirectory(operations) +add_subdirectory(schema) + +add_library(tx-schemeshard-olap INTERFACE) +target_link_libraries(tx-schemeshard-olap INTERFACE + contrib-libs-cxxsupp + yutil + schemeshard-olap-columns + schemeshard-olap-indexes + schemeshard-olap-schema + schemeshard-olap-common + schemeshard-olap-operations +) diff --git a/ydb/core/tx/schemeshard/olap/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/olap/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..1e38f462ca9a --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(columns) +add_subdirectory(common) +add_subdirectory(indexes) +add_subdirectory(operations) +add_subdirectory(schema) + +add_library(tx-schemeshard-olap INTERFACE) +target_link_libraries(tx-schemeshard-olap INTERFACE + contrib-libs-cxxsupp + yutil + schemeshard-olap-columns + schemeshard-olap-indexes + schemeshard-olap-schema + schemeshard-olap-common + schemeshard-olap-operations +) diff --git a/ydb/core/tx/schemeshard/olap/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/olap/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..74efd072c757 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/CMakeLists.linux-aarch64.txt @@ -0,0 +1,25 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(columns) +add_subdirectory(common) +add_subdirectory(indexes) +add_subdirectory(operations) +add_subdirectory(schema) + +add_library(tx-schemeshard-olap INTERFACE) +target_link_libraries(tx-schemeshard-olap INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + schemeshard-olap-columns + schemeshard-olap-indexes + schemeshard-olap-schema + schemeshard-olap-common + schemeshard-olap-operations +) diff --git a/ydb/core/tx/schemeshard/olap/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/olap/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..74efd072c757 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/CMakeLists.linux-x86_64.txt @@ -0,0 +1,25 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(columns) +add_subdirectory(common) +add_subdirectory(indexes) +add_subdirectory(operations) +add_subdirectory(schema) + +add_library(tx-schemeshard-olap INTERFACE) +target_link_libraries(tx-schemeshard-olap INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + schemeshard-olap-columns + schemeshard-olap-indexes + schemeshard-olap-schema + schemeshard-olap-common + schemeshard-olap-operations +) diff --git a/ydb/core/tx/schemeshard/olap/CMakeLists.txt b/ydb/core/tx/schemeshard/olap/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/tx/schemeshard/olap/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/olap/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..1e38f462ca9a --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/CMakeLists.windows-x86_64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(columns) +add_subdirectory(common) +add_subdirectory(indexes) +add_subdirectory(operations) +add_subdirectory(schema) + +add_library(tx-schemeshard-olap INTERFACE) +target_link_libraries(tx-schemeshard-olap INTERFACE + contrib-libs-cxxsupp + yutil + schemeshard-olap-columns + schemeshard-olap-indexes + schemeshard-olap-schema + schemeshard-olap-common + schemeshard-olap-operations +) diff --git a/ydb/core/tx/schemeshard/olap/columns/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/olap/columns/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..963388f7d8d6 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/columns/CMakeLists.darwin-arm64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-columns) +target_compile_options(schemeshard-olap-columns PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(schemeshard-olap-columns PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-protos + formats-arrow-dictionary + formats-arrow-compression +) +target_sources(schemeshard-olap-columns PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/columns/schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/columns/update.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/columns/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/olap/columns/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..963388f7d8d6 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/columns/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-columns) +target_compile_options(schemeshard-olap-columns PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(schemeshard-olap-columns PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-protos + formats-arrow-dictionary + formats-arrow-compression +) +target_sources(schemeshard-olap-columns PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/columns/schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/columns/update.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/columns/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/olap/columns/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..456af1fdedae --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/columns/CMakeLists.linux-aarch64.txt @@ -0,0 +1,25 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-columns) +target_compile_options(schemeshard-olap-columns PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(schemeshard-olap-columns PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-protos + formats-arrow-dictionary + formats-arrow-compression +) +target_sources(schemeshard-olap-columns PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/columns/schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/columns/update.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/columns/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/olap/columns/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..456af1fdedae --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/columns/CMakeLists.linux-x86_64.txt @@ -0,0 +1,25 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-columns) +target_compile_options(schemeshard-olap-columns PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(schemeshard-olap-columns PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-core-protos + formats-arrow-dictionary + formats-arrow-compression +) +target_sources(schemeshard-olap-columns PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/columns/schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/columns/update.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/columns/CMakeLists.txt b/ydb/core/tx/schemeshard/olap/columns/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/columns/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/tx/schemeshard/olap/columns/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/olap/columns/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..963388f7d8d6 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/columns/CMakeLists.windows-x86_64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-columns) +target_compile_options(schemeshard-olap-columns PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(schemeshard-olap-columns PUBLIC + contrib-libs-cxxsupp + yutil + ydb-core-protos + formats-arrow-dictionary + formats-arrow-compression +) +target_sources(schemeshard-olap-columns PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/columns/schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/columns/update.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/common/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/olap/common/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..3bb00a761514 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/common/CMakeLists.darwin-arm64.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-common) +target_link_libraries(schemeshard-olap-common PUBLIC + contrib-libs-cxxsupp + yutil + ydb-library-ydb_issue + ydb-core-base +) +target_sources(schemeshard-olap-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/common/common.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/common/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/olap/common/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..3bb00a761514 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/common/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-common) +target_link_libraries(schemeshard-olap-common PUBLIC + contrib-libs-cxxsupp + yutil + ydb-library-ydb_issue + ydb-core-base +) +target_sources(schemeshard-olap-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/common/common.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/common/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/olap/common/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..fc818621b3bf --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/common/CMakeLists.linux-aarch64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-common) +target_link_libraries(schemeshard-olap-common PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-library-ydb_issue + ydb-core-base +) +target_sources(schemeshard-olap-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/common/common.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/common/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/olap/common/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..fc818621b3bf --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/common/CMakeLists.linux-x86_64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-common) +target_link_libraries(schemeshard-olap-common PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + ydb-library-ydb_issue + ydb-core-base +) +target_sources(schemeshard-olap-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/common/common.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/common/CMakeLists.txt b/ydb/core/tx/schemeshard/olap/common/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/common/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/tx/schemeshard/olap/common/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/olap/common/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..3bb00a761514 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/common/CMakeLists.windows-x86_64.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-common) +target_link_libraries(schemeshard-olap-common PUBLIC + contrib-libs-cxxsupp + yutil + ydb-library-ydb_issue + ydb-core-base +) +target_sources(schemeshard-olap-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/common/common.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/indexes/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/olap/indexes/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..0a16697caea7 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/indexes/CMakeLists.darwin-arm64.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-indexes) +target_link_libraries(schemeshard-olap-indexes PUBLIC + contrib-libs-cxxsupp + yutil + services-bg_tasks-abstract +) +target_sources(schemeshard-olap-indexes PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/indexes/schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/indexes/update.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/indexes/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/olap/indexes/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..0a16697caea7 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/indexes/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-indexes) +target_link_libraries(schemeshard-olap-indexes PUBLIC + contrib-libs-cxxsupp + yutil + services-bg_tasks-abstract +) +target_sources(schemeshard-olap-indexes PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/indexes/schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/indexes/update.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/indexes/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/olap/indexes/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..269cb67d4bcf --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/indexes/CMakeLists.linux-aarch64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-indexes) +target_link_libraries(schemeshard-olap-indexes PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + services-bg_tasks-abstract +) +target_sources(schemeshard-olap-indexes PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/indexes/schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/indexes/update.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/indexes/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/olap/indexes/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..269cb67d4bcf --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/indexes/CMakeLists.linux-x86_64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-indexes) +target_link_libraries(schemeshard-olap-indexes PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + services-bg_tasks-abstract +) +target_sources(schemeshard-olap-indexes PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/indexes/schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/indexes/update.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/indexes/CMakeLists.txt b/ydb/core/tx/schemeshard/olap/indexes/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/indexes/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/tx/schemeshard/olap/indexes/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/olap/indexes/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..0a16697caea7 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/indexes/CMakeLists.windows-x86_64.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-indexes) +target_link_libraries(schemeshard-olap-indexes PUBLIC + contrib-libs-cxxsupp + yutil + services-bg_tasks-abstract +) +target_sources(schemeshard-olap-indexes PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/indexes/schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/indexes/update.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/operations/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/olap/operations/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..8f53c31cd6e2 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/operations/CMakeLists.darwin-arm64.txt @@ -0,0 +1,27 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-operations) +target_compile_options(schemeshard-olap-operations PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(schemeshard-olap-operations PUBLIC + contrib-libs-cxxsupp + yutil + core-mind-hive + ydb-services-bg_tasks +) +target_sources(schemeshard-olap-operations PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/create_table.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/drop_table.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/alter_table.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/create_store.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/drop_store.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/alter_store.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/operations/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/olap/operations/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..8f53c31cd6e2 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/operations/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,27 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-operations) +target_compile_options(schemeshard-olap-operations PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(schemeshard-olap-operations PUBLIC + contrib-libs-cxxsupp + yutil + core-mind-hive + ydb-services-bg_tasks +) +target_sources(schemeshard-olap-operations PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/create_table.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/drop_table.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/alter_table.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/create_store.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/drop_store.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/alter_store.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/operations/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/olap/operations/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..8e8e3067b101 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/operations/CMakeLists.linux-aarch64.txt @@ -0,0 +1,28 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-operations) +target_compile_options(schemeshard-olap-operations PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(schemeshard-olap-operations PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + core-mind-hive + ydb-services-bg_tasks +) +target_sources(schemeshard-olap-operations PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/create_table.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/drop_table.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/alter_table.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/create_store.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/drop_store.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/alter_store.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/operations/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/olap/operations/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..8e8e3067b101 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/operations/CMakeLists.linux-x86_64.txt @@ -0,0 +1,28 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-operations) +target_compile_options(schemeshard-olap-operations PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(schemeshard-olap-operations PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + core-mind-hive + ydb-services-bg_tasks +) +target_sources(schemeshard-olap-operations PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/create_table.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/drop_table.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/alter_table.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/create_store.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/drop_store.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/alter_store.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/operations/CMakeLists.txt b/ydb/core/tx/schemeshard/olap/operations/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/operations/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/tx/schemeshard/olap/operations/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/olap/operations/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..8f53c31cd6e2 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/operations/CMakeLists.windows-x86_64.txt @@ -0,0 +1,27 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-operations) +target_compile_options(schemeshard-olap-operations PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(schemeshard-olap-operations PUBLIC + contrib-libs-cxxsupp + yutil + core-mind-hive + ydb-services-bg_tasks +) +target_sources(schemeshard-olap-operations PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/create_table.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/drop_table.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/alter_table.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/create_store.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/drop_store.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/operations/alter_store.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/schema/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/olap/schema/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..66983fce5a67 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/schema/CMakeLists.darwin-arm64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-schema) +target_link_libraries(schemeshard-olap-schema PUBLIC + contrib-libs-cxxsupp + yutil + schemeshard-olap-columns + schemeshard-olap-indexes +) +target_sources(schemeshard-olap-schema PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/schema/schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/schema/update.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/schema/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/olap/schema/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..66983fce5a67 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/schema/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-schema) +target_link_libraries(schemeshard-olap-schema PUBLIC + contrib-libs-cxxsupp + yutil + schemeshard-olap-columns + schemeshard-olap-indexes +) +target_sources(schemeshard-olap-schema PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/schema/schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/schema/update.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/schema/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/olap/schema/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..286ee995be67 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/schema/CMakeLists.linux-aarch64.txt @@ -0,0 +1,21 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-schema) +target_link_libraries(schemeshard-olap-schema PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + schemeshard-olap-columns + schemeshard-olap-indexes +) +target_sources(schemeshard-olap-schema PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/schema/schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/schema/update.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/schema/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/olap/schema/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..286ee995be67 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/schema/CMakeLists.linux-x86_64.txt @@ -0,0 +1,21 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-schema) +target_link_libraries(schemeshard-olap-schema PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + schemeshard-olap-columns + schemeshard-olap-indexes +) +target_sources(schemeshard-olap-schema PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/schema/schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/schema/update.cpp +) diff --git a/ydb/core/tx/schemeshard/olap/schema/CMakeLists.txt b/ydb/core/tx/schemeshard/olap/schema/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/schema/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/tx/schemeshard/olap/schema/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/olap/schema/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..66983fce5a67 --- /dev/null +++ b/ydb/core/tx/schemeshard/olap/schema/CMakeLists.windows-x86_64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(schemeshard-olap-schema) +target_link_libraries(schemeshard-olap-schema PUBLIC + contrib-libs-cxxsupp + yutil + schemeshard-olap-columns + schemeshard-olap-indexes +) +target_sources(schemeshard-olap-schema PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/schema/schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/schema/update.cpp +) diff --git a/ydb/core/tx/schemeshard/ut_auditsettings/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_auditsettings/CMakeLists.darwin-arm64.txt index eea28d51c324..0c0949ef886f 100644 --- a/ydb/core/tx/schemeshard/ut_auditsettings/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_auditsettings/CMakeLists.darwin-arm64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_auditsettings PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_auditsettings PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_auditsettings/ut_auditsettings.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_auditsettings/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_auditsettings/CMakeLists.darwin-x86_64.txt index d6cb0d84152b..0eb8a4d7985d 100644 --- a/ydb/core/tx/schemeshard/ut_auditsettings/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_auditsettings/CMakeLists.darwin-x86_64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_auditsettings PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_auditsettings PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_auditsettings/ut_auditsettings.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_auditsettings/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_auditsettings/CMakeLists.linux-aarch64.txt index d89d67228255..fd285a877183 100644 --- a/ydb/core/tx/schemeshard/ut_auditsettings/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_auditsettings/CMakeLists.linux-aarch64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_auditsettings PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_auditsettings PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_auditsettings/ut_auditsettings.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_auditsettings/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_auditsettings/CMakeLists.linux-x86_64.txt index b152b4143daa..d2cce26df866 100644 --- a/ydb/core/tx/schemeshard/ut_auditsettings/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_auditsettings/CMakeLists.linux-x86_64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_auditsettings PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_auditsettings PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_auditsettings/ut_auditsettings.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_auditsettings/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_auditsettings/CMakeLists.windows-x86_64.txt index deae92b8dddc..b7830941e110 100644 --- a/ydb/core/tx/schemeshard/ut_auditsettings/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_auditsettings/CMakeLists.windows-x86_64.txt @@ -55,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..6b3d24565107 --- /dev/null +++ b/ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.darwin-arm64.txt @@ -0,0 +1,82 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-tx-schemeshard-ut_background_cleaning) +target_compile_options(ydb-core-tx-schemeshard-ut_background_cleaning PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-tx-schemeshard-ut_background_cleaning PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard +) +target_link_libraries(ydb-core-tx-schemeshard-ut_background_cleaning PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + core-tx-schemeshard + library-cpp-getopt + cpp-regex-pcre + core-testlib-default + ydb-core-tx + tx-schemeshard-ut_helpers + core-wrappers-ut_helpers + ydb-core-base +) +target_link_options(ydb-core-tx-schemeshard-ut_background_cleaning PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-core-tx-schemeshard-ut_background_cleaning PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_background_cleaning/ut_background_cleaning.cpp +) +set_property( + TARGET + ydb-core-tx-schemeshard-ut_background_cleaning + PROPERTY + SPLIT_FACTOR + 3 +) +add_yunittest( + NAME + ydb-core-tx-schemeshard-ut_background_cleaning + TEST_TARGET + ydb-core-tx-schemeshard-ut_background_cleaning + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-tx-schemeshard-ut_background_cleaning + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-tx-schemeshard-ut_background_cleaning + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-tx-schemeshard-ut_background_cleaning + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-tx-schemeshard-ut_background_cleaning + system_allocator +) +vcs_info(ydb-core-tx-schemeshard-ut_background_cleaning) diff --git a/ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..61de724ca733 --- /dev/null +++ b/ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,83 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-tx-schemeshard-ut_background_cleaning) +target_compile_options(ydb-core-tx-schemeshard-ut_background_cleaning PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-tx-schemeshard-ut_background_cleaning PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard +) +target_link_libraries(ydb-core-tx-schemeshard-ut_background_cleaning PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + core-tx-schemeshard + library-cpp-getopt + cpp-regex-pcre + core-testlib-default + ydb-core-tx + tx-schemeshard-ut_helpers + core-wrappers-ut_helpers + ydb-core-base +) +target_link_options(ydb-core-tx-schemeshard-ut_background_cleaning PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-core-tx-schemeshard-ut_background_cleaning PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_background_cleaning/ut_background_cleaning.cpp +) +set_property( + TARGET + ydb-core-tx-schemeshard-ut_background_cleaning + PROPERTY + SPLIT_FACTOR + 3 +) +add_yunittest( + NAME + ydb-core-tx-schemeshard-ut_background_cleaning + TEST_TARGET + ydb-core-tx-schemeshard-ut_background_cleaning + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-tx-schemeshard-ut_background_cleaning + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-tx-schemeshard-ut_background_cleaning + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-tx-schemeshard-ut_background_cleaning + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-tx-schemeshard-ut_background_cleaning + system_allocator +) +vcs_info(ydb-core-tx-schemeshard-ut_background_cleaning) diff --git a/ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..3f65843d279b --- /dev/null +++ b/ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.linux-aarch64.txt @@ -0,0 +1,85 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-tx-schemeshard-ut_background_cleaning) +target_compile_options(ydb-core-tx-schemeshard-ut_background_cleaning PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-tx-schemeshard-ut_background_cleaning PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard +) +target_link_libraries(ydb-core-tx-schemeshard-ut_background_cleaning PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + core-tx-schemeshard + library-cpp-getopt + cpp-regex-pcre + core-testlib-default + ydb-core-tx + tx-schemeshard-ut_helpers + core-wrappers-ut_helpers + ydb-core-base +) +target_link_options(ydb-core-tx-schemeshard-ut_background_cleaning PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-core-tx-schemeshard-ut_background_cleaning PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_background_cleaning/ut_background_cleaning.cpp +) +set_property( + TARGET + ydb-core-tx-schemeshard-ut_background_cleaning + PROPERTY + SPLIT_FACTOR + 3 +) +add_yunittest( + NAME + ydb-core-tx-schemeshard-ut_background_cleaning + TEST_TARGET + ydb-core-tx-schemeshard-ut_background_cleaning + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-tx-schemeshard-ut_background_cleaning + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-tx-schemeshard-ut_background_cleaning + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-tx-schemeshard-ut_background_cleaning + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-tx-schemeshard-ut_background_cleaning + cpp-malloc-jemalloc +) +vcs_info(ydb-core-tx-schemeshard-ut_background_cleaning) diff --git a/ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..a826fa852bf2 --- /dev/null +++ b/ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.linux-x86_64.txt @@ -0,0 +1,87 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-tx-schemeshard-ut_background_cleaning) +target_compile_options(ydb-core-tx-schemeshard-ut_background_cleaning PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-tx-schemeshard-ut_background_cleaning PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard +) +target_link_libraries(ydb-core-tx-schemeshard-ut_background_cleaning PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + core-tx-schemeshard + library-cpp-getopt + cpp-regex-pcre + core-testlib-default + ydb-core-tx + tx-schemeshard-ut_helpers + core-wrappers-ut_helpers + ydb-core-base +) +target_link_options(ydb-core-tx-schemeshard-ut_background_cleaning PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-core-tx-schemeshard-ut_background_cleaning PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_background_cleaning/ut_background_cleaning.cpp +) +set_property( + TARGET + ydb-core-tx-schemeshard-ut_background_cleaning + PROPERTY + SPLIT_FACTOR + 3 +) +add_yunittest( + NAME + ydb-core-tx-schemeshard-ut_background_cleaning + TEST_TARGET + ydb-core-tx-schemeshard-ut_background_cleaning + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-tx-schemeshard-ut_background_cleaning + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-tx-schemeshard-ut_background_cleaning + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-tx-schemeshard-ut_background_cleaning + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-tx-schemeshard-ut_background_cleaning + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(ydb-core-tx-schemeshard-ut_background_cleaning) diff --git a/ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.txt b/ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..b6eda18277f3 --- /dev/null +++ b/ydb/core/tx/schemeshard/ut_background_cleaning/CMakeLists.windows-x86_64.txt @@ -0,0 +1,78 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-core-tx-schemeshard-ut_background_cleaning) +target_compile_options(ydb-core-tx-schemeshard-ut_background_cleaning PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-core-tx-schemeshard-ut_background_cleaning PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard +) +target_link_libraries(ydb-core-tx-schemeshard-ut_background_cleaning PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + core-tx-schemeshard + library-cpp-getopt + cpp-regex-pcre + core-testlib-default + ydb-core-tx + tx-schemeshard-ut_helpers + core-wrappers-ut_helpers + ydb-core-base +) +target_sources(ydb-core-tx-schemeshard-ut_background_cleaning PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_background_cleaning/ut_background_cleaning.cpp +) +set_property( + TARGET + ydb-core-tx-schemeshard-ut_background_cleaning + PROPERTY + SPLIT_FACTOR + 3 +) +add_yunittest( + NAME + ydb-core-tx-schemeshard-ut_background_cleaning + TEST_TARGET + ydb-core-tx-schemeshard-ut_background_cleaning + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-core-tx-schemeshard-ut_background_cleaning + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-core-tx-schemeshard-ut_background_cleaning + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-core-tx-schemeshard-ut_background_cleaning + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-core-tx-schemeshard-ut_background_cleaning + system_allocator +) +vcs_info(ydb-core-tx-schemeshard-ut_background_cleaning) diff --git a/ydb/core/tx/schemeshard/ut_backup/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_backup/CMakeLists.darwin-arm64.txt index 10a744410ce2..4e4c55a86cda 100644 --- a/ydb/core/tx/schemeshard/ut_backup/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_backup/CMakeLists.darwin-arm64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_backup PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_backup PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_backup/ut_backup.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_backup/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_backup/CMakeLists.darwin-x86_64.txt index c0e416f9e259..e19a937d7807 100644 --- a/ydb/core/tx/schemeshard/ut_backup/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_backup/CMakeLists.darwin-x86_64.txt @@ -33,8 +33,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_backup PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_backup PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_backup/ut_backup.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_backup/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_backup/CMakeLists.linux-aarch64.txt index cfd13a84a12f..a82fe047d045 100644 --- a/ydb/core/tx/schemeshard/ut_backup/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_backup/CMakeLists.linux-aarch64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_backup PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_backup PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_backup/ut_backup.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_backup/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_backup/CMakeLists.linux-x86_64.txt index cb86ed4385aa..35110403cd9d 100644 --- a/ydb/core/tx/schemeshard/ut_backup/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_backup/CMakeLists.linux-x86_64.txt @@ -36,9 +36,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_backup PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_backup PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_backup/ut_backup.cpp @@ -68,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_backup/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_backup/CMakeLists.windows-x86_64.txt index ddc5251d828d..167e38b1e535 100644 --- a/ydb/core/tx/schemeshard/ut_backup/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_backup/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_base/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_base/CMakeLists.darwin-arm64.txt index 7dab7ff10e53..7c214de06136 100644 --- a/ydb/core/tx/schemeshard/ut_base/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_base/CMakeLists.darwin-arm64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_base PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_base PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_base/ut_base.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_base/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_base/CMakeLists.darwin-x86_64.txt index 5f7f530d9039..185c6f616b60 100644 --- a/ydb/core/tx/schemeshard/ut_base/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_base/CMakeLists.darwin-x86_64.txt @@ -33,8 +33,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_base PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_base PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_base/ut_base.cpp @@ -67,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_base/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_base/CMakeLists.linux-aarch64.txt index 8e895f64fc79..a197341e90c6 100644 --- a/ydb/core/tx/schemeshard/ut_base/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_base/CMakeLists.linux-aarch64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_base PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_base PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_base/ut_base.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_base/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_base/CMakeLists.linux-x86_64.txt index 321ed8352ef9..3083bd62524d 100644 --- a/ydb/core/tx/schemeshard/ut_base/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_base/CMakeLists.linux-x86_64.txt @@ -36,9 +36,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_base PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_base PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_base/ut_base.cpp @@ -71,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_base/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_base/CMakeLists.windows-x86_64.txt index 88db1730ccd7..160da0dd8214 100644 --- a/ydb/core/tx/schemeshard/ut_base/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_base/CMakeLists.windows-x86_64.txt @@ -60,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_base_reboots/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_base_reboots/CMakeLists.darwin-arm64.txt index cbfec446cb82..abfff533c0d8 100644 --- a/ydb/core/tx/schemeshard/ut_base_reboots/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_base_reboots/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_base_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_base_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_base_reboots/ut_base_reboots.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_base_reboots/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_base_reboots/CMakeLists.darwin-x86_64.txt index b2b2b95f9183..e5b4d7615502 100644 --- a/ydb/core/tx/schemeshard/ut_base_reboots/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_base_reboots/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_base_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_base_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_base_reboots/ut_base_reboots.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_base_reboots/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_base_reboots/CMakeLists.linux-aarch64.txt index 1d3fa15ed159..c38ea608e67b 100644 --- a/ydb/core/tx/schemeshard/ut_base_reboots/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_base_reboots/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_base_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_base_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_base_reboots/ut_base_reboots.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_base_reboots/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_base_reboots/CMakeLists.linux-x86_64.txt index 96c7a12d54cb..6080d173ddef 100644 --- a/ydb/core/tx/schemeshard/ut_base_reboots/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_base_reboots/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_base_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_base_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_base_reboots/ut_base_reboots.cpp @@ -68,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_base_reboots/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_base_reboots/CMakeLists.windows-x86_64.txt index 4280ac7a17a7..2f748c4ad932 100644 --- a/ydb/core/tx/schemeshard/ut_base_reboots/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_base_reboots/CMakeLists.windows-x86_64.txt @@ -57,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_bsvolume/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_bsvolume/CMakeLists.darwin-arm64.txt index 5182c7ddf7b8..118eb24c2968 100644 --- a/ydb/core/tx/schemeshard/ut_bsvolume/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_bsvolume/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_bsvolume PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_bsvolume PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_bsvolume/ut_bsvolume.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_bsvolume/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_bsvolume/CMakeLists.darwin-x86_64.txt index e977234deadc..4b88124aed6f 100644 --- a/ydb/core/tx/schemeshard/ut_bsvolume/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_bsvolume/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_bsvolume PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_bsvolume PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_bsvolume/ut_bsvolume.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_bsvolume/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_bsvolume/CMakeLists.linux-aarch64.txt index 03f4a2753ed4..4331151222ef 100644 --- a/ydb/core/tx/schemeshard/ut_bsvolume/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_bsvolume/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_bsvolume PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_bsvolume PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_bsvolume/ut_bsvolume.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_bsvolume/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_bsvolume/CMakeLists.linux-x86_64.txt index 8fa4eaba593f..f5b2dd03ba48 100644 --- a/ydb/core/tx/schemeshard/ut_bsvolume/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_bsvolume/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_bsvolume PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_bsvolume PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_bsvolume/ut_bsvolume.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_bsvolume/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_bsvolume/CMakeLists.windows-x86_64.txt index 3e057cdb9139..9dceb899b8a2 100644 --- a/ydb/core/tx/schemeshard/ut_bsvolume/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_bsvolume/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_bsvolume_reboots/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_bsvolume_reboots/CMakeLists.darwin-arm64.txt index f789a7200e3e..463fd0af688c 100644 --- a/ydb/core/tx/schemeshard/ut_bsvolume_reboots/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_bsvolume_reboots/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_bsvolume_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_bsvolume_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_bsvolume_reboots/ut_bsvolume_reboots.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_bsvolume_reboots/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_bsvolume_reboots/CMakeLists.darwin-x86_64.txt index 0e2f73a0462d..de0f2e1fe9a6 100644 --- a/ydb/core/tx/schemeshard/ut_bsvolume_reboots/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_bsvolume_reboots/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_bsvolume_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_bsvolume_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_bsvolume_reboots/ut_bsvolume_reboots.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_bsvolume_reboots/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_bsvolume_reboots/CMakeLists.linux-aarch64.txt index e9af99390155..f9c419a4c924 100644 --- a/ydb/core/tx/schemeshard/ut_bsvolume_reboots/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_bsvolume_reboots/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_bsvolume_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_bsvolume_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_bsvolume_reboots/ut_bsvolume_reboots.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_bsvolume_reboots/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_bsvolume_reboots/CMakeLists.linux-x86_64.txt index 3c6eb5007188..2f9ac70daa4c 100644 --- a/ydb/core/tx/schemeshard/ut_bsvolume_reboots/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_bsvolume_reboots/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_bsvolume_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_bsvolume_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_bsvolume_reboots/ut_bsvolume_reboots.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_bsvolume_reboots/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_bsvolume_reboots/CMakeLists.windows-x86_64.txt index 72b6ce4e08ab..f1a80929c2b1 100644 --- a/ydb/core/tx/schemeshard/ut_bsvolume_reboots/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_bsvolume_reboots/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_cdc_stream/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_cdc_stream/CMakeLists.darwin-arm64.txt index 7c52b7fe73c9..79efcc7a410f 100644 --- a/ydb/core/tx/schemeshard/ut_cdc_stream/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_cdc_stream/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_cdc_stream PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_cdc_stream PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_cdc_stream/ut_cdc_stream.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_cdc_stream/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_cdc_stream/CMakeLists.darwin-x86_64.txt index 5dda4e327e93..77e83655a15e 100644 --- a/ydb/core/tx/schemeshard/ut_cdc_stream/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_cdc_stream/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_cdc_stream PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_cdc_stream PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_cdc_stream/ut_cdc_stream.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_cdc_stream/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_cdc_stream/CMakeLists.linux-aarch64.txt index d5b175938ae7..39d786783182 100644 --- a/ydb/core/tx/schemeshard/ut_cdc_stream/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_cdc_stream/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_cdc_stream PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_cdc_stream PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_cdc_stream/ut_cdc_stream.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_cdc_stream/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_cdc_stream/CMakeLists.linux-x86_64.txt index 02d285d75780..c9a3a90dde7a 100644 --- a/ydb/core/tx/schemeshard/ut_cdc_stream/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_cdc_stream/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_cdc_stream PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_cdc_stream PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_cdc_stream/ut_cdc_stream.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_cdc_stream/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_cdc_stream/CMakeLists.windows-x86_64.txt index 6d5148f44614..224dfdc0870b 100644 --- a/ydb/core/tx/schemeshard/ut_cdc_stream/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_cdc_stream/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/CMakeLists.darwin-arm64.txt index b7e2d76dcd34..510b86e08521 100644 --- a/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_cdc_stream_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_cdc_stream_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/ut_cdc_stream_reboots.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/CMakeLists.darwin-x86_64.txt index a6a0ffefaf9e..04ee484e865a 100644 --- a/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_cdc_stream_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_cdc_stream_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/ut_cdc_stream_reboots.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/CMakeLists.linux-aarch64.txt index 0bd0ddcee68d..3cb9e06a643e 100644 --- a/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_cdc_stream_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_cdc_stream_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/ut_cdc_stream_reboots.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/CMakeLists.linux-x86_64.txt index 5d8315b40829..689ce7022f71 100644 --- a/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_cdc_stream_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_cdc_stream_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/ut_cdc_stream_reboots.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/CMakeLists.windows-x86_64.txt index e34c578449db..02fdaaaa766c 100644 --- a/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_cdc_stream_reboots/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_column_build/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_column_build/CMakeLists.darwin-arm64.txt index 704be592363f..6f3487abfb65 100644 --- a/ydb/core/tx/schemeshard/ut_column_build/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_column_build/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_column_build PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_column_build PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_column_build/ut_column_build.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_column_build/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_column_build/CMakeLists.darwin-x86_64.txt index cbb1cb24fe7d..9249f206a56f 100644 --- a/ydb/core/tx/schemeshard/ut_column_build/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_column_build/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_column_build PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_column_build PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_column_build/ut_column_build.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_column_build/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_column_build/CMakeLists.linux-aarch64.txt index 557f2dcbbb2f..7ba4919b92b7 100644 --- a/ydb/core/tx/schemeshard/ut_column_build/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_column_build/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_column_build PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_column_build PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_column_build/ut_column_build.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_column_build/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_column_build/CMakeLists.linux-x86_64.txt index 33c7cbbf2ae5..132dbd35ff22 100644 --- a/ydb/core/tx/schemeshard/ut_column_build/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_column_build/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_column_build PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_column_build PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_column_build/ut_column_build.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_column_build/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_column_build/CMakeLists.windows-x86_64.txt index 8c045b2320e5..8f08f75fef64 100644 --- a/ydb/core/tx/schemeshard/ut_column_build/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_column_build/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_compaction/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_compaction/CMakeLists.darwin-arm64.txt index ac5b00d7bb57..3828c88e68f7 100644 --- a/ydb/core/tx/schemeshard/ut_compaction/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_compaction/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_compaction PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_compaction PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_compaction/ut_compaction.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_compaction/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_compaction/CMakeLists.darwin-x86_64.txt index 3311baf5b09e..4f219b90693f 100644 --- a/ydb/core/tx/schemeshard/ut_compaction/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_compaction/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_compaction PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_compaction PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_compaction/ut_compaction.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_compaction/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_compaction/CMakeLists.linux-aarch64.txt index 1465ace9df9a..9b1bdb5b0ca4 100644 --- a/ydb/core/tx/schemeshard/ut_compaction/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_compaction/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_compaction PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_compaction PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_compaction/ut_compaction.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_compaction/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_compaction/CMakeLists.linux-x86_64.txt index 27806492c1b6..4fd1efb3cfab 100644 --- a/ydb/core/tx/schemeshard/ut_compaction/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_compaction/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_compaction PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_compaction PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_compaction/ut_compaction.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_compaction/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_compaction/CMakeLists.windows-x86_64.txt index ccdea764942a..804aacbeda07 100644 --- a/ydb/core/tx/schemeshard/ut_compaction/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_compaction/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_export/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_export/CMakeLists.darwin-arm64.txt index acf8dd9196ec..4e0740d4fe3f 100644 --- a/ydb/core/tx/schemeshard/ut_export/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_export/CMakeLists.darwin-arm64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_export PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_export PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_export/ut_export.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_export/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_export/CMakeLists.darwin-x86_64.txt index de70c7f29eac..f2dd708769bc 100644 --- a/ydb/core/tx/schemeshard/ut_export/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_export/CMakeLists.darwin-x86_64.txt @@ -33,8 +33,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_export PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_export PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_export/ut_export.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_export/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_export/CMakeLists.linux-aarch64.txt index 7eb20adaf78d..9d3122eba35d 100644 --- a/ydb/core/tx/schemeshard/ut_export/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_export/CMakeLists.linux-aarch64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_export PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_export PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_export/ut_export.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_export/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_export/CMakeLists.linux-x86_64.txt index 6add7105d78e..d39f4e5ac31a 100644 --- a/ydb/core/tx/schemeshard/ut_export/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_export/CMakeLists.linux-x86_64.txt @@ -36,9 +36,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_export PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_export PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_export/ut_export.cpp @@ -68,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_export/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_export/CMakeLists.windows-x86_64.txt index 91ceb9a79237..daf953e8b6a0 100644 --- a/ydb/core/tx/schemeshard/ut_export/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_export/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_export_reboots_s3/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_export_reboots_s3/CMakeLists.darwin-arm64.txt index 2eaf6913cb13..5bf9e792d697 100644 --- a/ydb/core/tx/schemeshard/ut_export_reboots_s3/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_export_reboots_s3/CMakeLists.darwin-arm64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_export_reboots_s3 PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_export_reboots_s3 PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_export_reboots_s3/ut_export_reboots_s3.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_export_reboots_s3/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_export_reboots_s3/CMakeLists.darwin-x86_64.txt index e1bcfec7030d..dfb423bf3894 100644 --- a/ydb/core/tx/schemeshard/ut_export_reboots_s3/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_export_reboots_s3/CMakeLists.darwin-x86_64.txt @@ -33,8 +33,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_export_reboots_s3 PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_export_reboots_s3 PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_export_reboots_s3/ut_export_reboots_s3.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_export_reboots_s3/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_export_reboots_s3/CMakeLists.linux-aarch64.txt index 0e62fec24ddc..383aeffdd82f 100644 --- a/ydb/core/tx/schemeshard/ut_export_reboots_s3/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_export_reboots_s3/CMakeLists.linux-aarch64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_export_reboots_s3 PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_export_reboots_s3 PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_export_reboots_s3/ut_export_reboots_s3.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_export_reboots_s3/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_export_reboots_s3/CMakeLists.linux-x86_64.txt index 9c1e5843669c..357336099db4 100644 --- a/ydb/core/tx/schemeshard/ut_export_reboots_s3/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_export_reboots_s3/CMakeLists.linux-x86_64.txt @@ -36,9 +36,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_export_reboots_s3 PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_export_reboots_s3 PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_export_reboots_s3/ut_export_reboots_s3.cpp @@ -68,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_export_reboots_s3/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_export_reboots_s3/CMakeLists.windows-x86_64.txt index ae2ef497ce89..ec3c0557e159 100644 --- a/ydb/core/tx/schemeshard/ut_export_reboots_s3/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_export_reboots_s3/CMakeLists.windows-x86_64.txt @@ -57,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_external_data_source/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_external_data_source/CMakeLists.darwin-arm64.txt index 4883ce1ba759..a2e835b91b17 100644 --- a/ydb/core/tx/schemeshard/ut_external_data_source/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_external_data_source/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_external_data_source PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_external_data_source PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_external_data_source/ut_external_data_source.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_external_data_source/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_external_data_source/CMakeLists.darwin-x86_64.txt index efaffb803927..2f146c2dd53b 100644 --- a/ydb/core/tx/schemeshard/ut_external_data_source/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_external_data_source/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_external_data_source PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_external_data_source PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_external_data_source/ut_external_data_source.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_external_data_source/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_external_data_source/CMakeLists.linux-aarch64.txt index 6fc88cf0ac32..c1b1339438c2 100644 --- a/ydb/core/tx/schemeshard/ut_external_data_source/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_external_data_source/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_external_data_source PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_external_data_source PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_external_data_source/ut_external_data_source.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_external_data_source/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_external_data_source/CMakeLists.linux-x86_64.txt index e26cf8c14178..85553e8bd334 100644 --- a/ydb/core/tx/schemeshard/ut_external_data_source/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_external_data_source/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_external_data_source PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_external_data_source PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_external_data_source/ut_external_data_source.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_external_data_source/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_external_data_source/CMakeLists.windows-x86_64.txt index d0d5b6077142..21af3d0a0051 100644 --- a/ydb/core/tx/schemeshard/ut_external_data_source/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_external_data_source/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_external_data_source_reboots/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_external_data_source_reboots/CMakeLists.darwin-arm64.txt index 5e764990fe10..1de7eb1a35fc 100644 --- a/ydb/core/tx/schemeshard/ut_external_data_source_reboots/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_external_data_source_reboots/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(schemeshard-ut_external_data_source_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(schemeshard-ut_external_data_source_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_external_data_source_reboots/ut_external_data_source_reboots.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_external_data_source_reboots/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_external_data_source_reboots/CMakeLists.darwin-x86_64.txt index a5dd89e6b5a8..cbd5912045b5 100644 --- a/ydb/core/tx/schemeshard/ut_external_data_source_reboots/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_external_data_source_reboots/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(schemeshard-ut_external_data_source_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(schemeshard-ut_external_data_source_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_external_data_source_reboots/ut_external_data_source_reboots.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_external_data_source_reboots/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_external_data_source_reboots/CMakeLists.linux-aarch64.txt index 4df53a8214fd..43aa2c9e6518 100644 --- a/ydb/core/tx/schemeshard/ut_external_data_source_reboots/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_external_data_source_reboots/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(schemeshard-ut_external_data_source_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(schemeshard-ut_external_data_source_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_external_data_source_reboots/ut_external_data_source_reboots.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_external_data_source_reboots/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_external_data_source_reboots/CMakeLists.linux-x86_64.txt index 2580674124a0..daa96db0e753 100644 --- a/ydb/core/tx/schemeshard/ut_external_data_source_reboots/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_external_data_source_reboots/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(schemeshard-ut_external_data_source_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(schemeshard-ut_external_data_source_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_external_data_source_reboots/ut_external_data_source_reboots.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_external_data_source_reboots/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_external_data_source_reboots/CMakeLists.windows-x86_64.txt index 828c7c0bd1e9..d79a7aeaac3c 100644 --- a/ydb/core/tx/schemeshard/ut_external_data_source_reboots/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_external_data_source_reboots/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_external_table/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_external_table/CMakeLists.darwin-arm64.txt index bee4fca124b5..81e49b606d9e 100644 --- a/ydb/core/tx/schemeshard/ut_external_table/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_external_table/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_external_table PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_external_table PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_external_table/ut_external_table.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_external_table/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_external_table/CMakeLists.darwin-x86_64.txt index 87394ae85008..191c36d0c6c7 100644 --- a/ydb/core/tx/schemeshard/ut_external_table/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_external_table/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_external_table PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_external_table PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_external_table/ut_external_table.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_external_table/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_external_table/CMakeLists.linux-aarch64.txt index a45d238f54e8..70eab607ec32 100644 --- a/ydb/core/tx/schemeshard/ut_external_table/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_external_table/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_external_table PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_external_table PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_external_table/ut_external_table.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_external_table/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_external_table/CMakeLists.linux-x86_64.txt index 5e2acf0f5af1..23d097870de2 100644 --- a/ydb/core/tx/schemeshard/ut_external_table/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_external_table/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_external_table PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_external_table PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_external_table/ut_external_table.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_external_table/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_external_table/CMakeLists.windows-x86_64.txt index 586578d76ba5..45643bbc20b1 100644 --- a/ydb/core/tx/schemeshard/ut_external_table/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_external_table/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_external_table_reboots/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_external_table_reboots/CMakeLists.darwin-arm64.txt index fdae871723d2..aabe54e9c667 100644 --- a/ydb/core/tx/schemeshard/ut_external_table_reboots/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_external_table_reboots/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_external_table_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_external_table_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_external_table_reboots/ut_external_table_reboots.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_external_table_reboots/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_external_table_reboots/CMakeLists.darwin-x86_64.txt index 00871644449f..419f84f26c6a 100644 --- a/ydb/core/tx/schemeshard/ut_external_table_reboots/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_external_table_reboots/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_external_table_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_external_table_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_external_table_reboots/ut_external_table_reboots.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_external_table_reboots/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_external_table_reboots/CMakeLists.linux-aarch64.txt index a02e1c0fee35..d437ae9ca2b5 100644 --- a/ydb/core/tx/schemeshard/ut_external_table_reboots/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_external_table_reboots/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_external_table_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_external_table_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_external_table_reboots/ut_external_table_reboots.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_external_table_reboots/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_external_table_reboots/CMakeLists.linux-x86_64.txt index 073cdcddb386..540fd6f074d7 100644 --- a/ydb/core/tx/schemeshard/ut_external_table_reboots/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_external_table_reboots/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_external_table_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_external_table_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_external_table_reboots/ut_external_table_reboots.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_external_table_reboots/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_external_table_reboots/CMakeLists.windows-x86_64.txt index 494349edca90..3fc43ac5a0bc 100644 --- a/ydb/core/tx/schemeshard/ut_external_table_reboots/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_external_table_reboots/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_extsubdomain/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_extsubdomain/CMakeLists.darwin-arm64.txt index 97f0bd3f25aa..470a97f9c857 100644 --- a/ydb/core/tx/schemeshard/ut_extsubdomain/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_extsubdomain/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_extsubdomain PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_extsubdomain PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_extsubdomain/ut_extsubdomain.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_extsubdomain/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_extsubdomain/CMakeLists.darwin-x86_64.txt index e6f9907b62c7..4ac31768ae17 100644 --- a/ydb/core/tx/schemeshard/ut_extsubdomain/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_extsubdomain/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_extsubdomain PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_extsubdomain PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_extsubdomain/ut_extsubdomain.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_extsubdomain/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_extsubdomain/CMakeLists.linux-aarch64.txt index c16d168c926e..76e6b7573277 100644 --- a/ydb/core/tx/schemeshard/ut_extsubdomain/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_extsubdomain/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_extsubdomain PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_extsubdomain PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_extsubdomain/ut_extsubdomain.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_extsubdomain/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_extsubdomain/CMakeLists.linux-x86_64.txt index d418989d9955..cf64cc9cdcaa 100644 --- a/ydb/core/tx/schemeshard/ut_extsubdomain/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_extsubdomain/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_extsubdomain PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_extsubdomain PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_extsubdomain/ut_extsubdomain.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_extsubdomain/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_extsubdomain/CMakeLists.windows-x86_64.txt index 2bb0a7846e5b..3cffe0917b50 100644 --- a/ydb/core/tx/schemeshard/ut_extsubdomain/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_extsubdomain/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/CMakeLists.darwin-arm64.txt index faf66f6902da..00625a4ecf88 100644 --- a/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_extsubdomain_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_extsubdomain_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/ut_extsubdomain_reboots.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/CMakeLists.darwin-x86_64.txt index 3473d8c04535..66c788aa1552 100644 --- a/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_extsubdomain_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_extsubdomain_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/ut_extsubdomain_reboots.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/CMakeLists.linux-aarch64.txt index 2b0286251ed3..6a039440c22f 100644 --- a/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_extsubdomain_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_extsubdomain_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/ut_extsubdomain_reboots.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/CMakeLists.linux-x86_64.txt index 804834ccc030..9a7967a2f484 100644 --- a/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_extsubdomain_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_extsubdomain_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/ut_extsubdomain_reboots.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/CMakeLists.windows-x86_64.txt index e00734e21bbf..e04b45076a7c 100644 --- a/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_extsubdomain_reboots/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_filestore_reboots/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_filestore_reboots/CMakeLists.darwin-arm64.txt index 3381a4c27ebd..415f67db3afc 100644 --- a/ydb/core/tx/schemeshard/ut_filestore_reboots/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_filestore_reboots/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_filestore_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_filestore_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_filestore_reboots/ut_filestore_reboots.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_filestore_reboots/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_filestore_reboots/CMakeLists.darwin-x86_64.txt index 60f76fb012c3..2035eb21dec1 100644 --- a/ydb/core/tx/schemeshard/ut_filestore_reboots/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_filestore_reboots/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_filestore_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_filestore_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_filestore_reboots/ut_filestore_reboots.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_filestore_reboots/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_filestore_reboots/CMakeLists.linux-aarch64.txt index e1ae38fab840..2434f6d3f4f8 100644 --- a/ydb/core/tx/schemeshard/ut_filestore_reboots/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_filestore_reboots/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_filestore_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_filestore_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_filestore_reboots/ut_filestore_reboots.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_filestore_reboots/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_filestore_reboots/CMakeLists.linux-x86_64.txt index 1b9e37497536..f7e970d7c833 100644 --- a/ydb/core/tx/schemeshard/ut_filestore_reboots/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_filestore_reboots/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_filestore_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_filestore_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_filestore_reboots/ut_filestore_reboots.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_filestore_reboots/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_filestore_reboots/CMakeLists.windows-x86_64.txt index a3aeefb475ce..b4c3f25902bd 100644 --- a/ydb/core/tx/schemeshard/ut_filestore_reboots/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_filestore_reboots/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_helpers/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_helpers/CMakeLists.darwin-arm64.txt index 38616cf23871..5cd277b09def 100644 --- a/ydb/core/tx/schemeshard/ut_helpers/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_helpers/CMakeLists.darwin-arm64.txt @@ -37,6 +37,10 @@ target_link_libraries(tx-schemeshard-ut_helpers PUBLIC cpp-client-ydb_driver ) target_sources(tx-schemeshard-ut_helpers PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/ls_checks.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/test_env.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/test_with_reboots.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/export_reboots_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/failing_mtpq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/helpers.cpp diff --git a/ydb/core/tx/schemeshard/ut_helpers/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_helpers/CMakeLists.darwin-x86_64.txt index 38616cf23871..5cd277b09def 100644 --- a/ydb/core/tx/schemeshard/ut_helpers/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_helpers/CMakeLists.darwin-x86_64.txt @@ -37,6 +37,10 @@ target_link_libraries(tx-schemeshard-ut_helpers PUBLIC cpp-client-ydb_driver ) target_sources(tx-schemeshard-ut_helpers PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/ls_checks.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/test_env.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/test_with_reboots.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/export_reboots_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/failing_mtpq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/helpers.cpp diff --git a/ydb/core/tx/schemeshard/ut_helpers/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_helpers/CMakeLists.linux-aarch64.txt index 44d0922fc3b9..217dd4a2ea04 100644 --- a/ydb/core/tx/schemeshard/ut_helpers/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_helpers/CMakeLists.linux-aarch64.txt @@ -38,6 +38,10 @@ target_link_libraries(tx-schemeshard-ut_helpers PUBLIC cpp-client-ydb_driver ) target_sources(tx-schemeshard-ut_helpers PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/ls_checks.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/test_env.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/test_with_reboots.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/export_reboots_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/failing_mtpq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/helpers.cpp diff --git a/ydb/core/tx/schemeshard/ut_helpers/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_helpers/CMakeLists.linux-x86_64.txt index 44d0922fc3b9..217dd4a2ea04 100644 --- a/ydb/core/tx/schemeshard/ut_helpers/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_helpers/CMakeLists.linux-x86_64.txt @@ -38,6 +38,10 @@ target_link_libraries(tx-schemeshard-ut_helpers PUBLIC cpp-client-ydb_driver ) target_sources(tx-schemeshard-ut_helpers PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/ls_checks.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/test_env.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/test_with_reboots.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/export_reboots_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/failing_mtpq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/helpers.cpp diff --git a/ydb/core/tx/schemeshard/ut_helpers/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_helpers/CMakeLists.windows-x86_64.txt index 38616cf23871..5cd277b09def 100644 --- a/ydb/core/tx/schemeshard/ut_helpers/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_helpers/CMakeLists.windows-x86_64.txt @@ -37,6 +37,10 @@ target_link_libraries(tx-schemeshard-ut_helpers PUBLIC cpp-client-ydb_driver ) target_sources(tx-schemeshard-ut_helpers PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/helpers.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/ls_checks.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/test_env.h + ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/test_with_reboots.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/export_reboots_common.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/failing_mtpq.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_helpers/helpers.cpp diff --git a/ydb/core/tx/schemeshard/ut_index/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_index/CMakeLists.darwin-arm64.txt index db8d953141ba..b464cffb9e80 100644 --- a/ydb/core/tx/schemeshard/ut_index/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_index/CMakeLists.darwin-arm64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_index PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_index PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_index/ut_async_index.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_index/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_index/CMakeLists.darwin-x86_64.txt index 25dd3208e6ae..f8338d32686c 100644 --- a/ydb/core/tx/schemeshard/ut_index/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_index/CMakeLists.darwin-x86_64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_index PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_index PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_index/ut_async_index.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_index/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_index/CMakeLists.linux-aarch64.txt index 82f6e361e3fd..895f526d9ba7 100644 --- a/ydb/core/tx/schemeshard/ut_index/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_index/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_index PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_index PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_index/ut_async_index.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_index/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_index/CMakeLists.linux-x86_64.txt index c6109f3e8700..7303e178a074 100644 --- a/ydb/core/tx/schemeshard/ut_index/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_index/CMakeLists.linux-x86_64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_index PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_index PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_index/ut_async_index.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_index/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_index/CMakeLists.windows-x86_64.txt index 18569c8744ac..74520764ca3b 100644 --- a/ydb/core/tx/schemeshard/ut_index/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_index/CMakeLists.windows-x86_64.txt @@ -55,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_index_build/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_index_build/CMakeLists.darwin-arm64.txt index dd28b658eeae..8f283086a5c4 100644 --- a/ydb/core/tx/schemeshard/ut_index_build/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_index_build/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_index_build PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_index_build PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_index_build/ut_index_build.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_index_build/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_index_build/CMakeLists.darwin-x86_64.txt index 6d6687904c24..9db005e979b1 100644 --- a/ydb/core/tx/schemeshard/ut_index_build/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_index_build/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_index_build PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_index_build PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_index_build/ut_index_build.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_index_build/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_index_build/CMakeLists.linux-aarch64.txt index 264dd7455b33..a6f667991212 100644 --- a/ydb/core/tx/schemeshard/ut_index_build/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_index_build/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_index_build PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_index_build PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_index_build/ut_index_build.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_index_build/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_index_build/CMakeLists.linux-x86_64.txt index 3ff2eba8f5b6..45af51a82500 100644 --- a/ydb/core/tx/schemeshard/ut_index_build/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_index_build/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_index_build PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_index_build PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_index_build/ut_index_build.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_index_build/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_index_build/CMakeLists.windows-x86_64.txt index 39683caa7113..2dad6e89c7b8 100644 --- a/ydb/core/tx/schemeshard/ut_index_build/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_index_build/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_index_build_reboots/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_index_build_reboots/CMakeLists.darwin-arm64.txt index b796c1745b4b..51cfad95747d 100644 --- a/ydb/core/tx/schemeshard/ut_index_build_reboots/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_index_build_reboots/CMakeLists.darwin-arm64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_index_build_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_index_build_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_index_build_reboots/ut_index_build_reboots.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_index_build_reboots/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_index_build_reboots/CMakeLists.darwin-x86_64.txt index 06448129123e..82897449e5de 100644 --- a/ydb/core/tx/schemeshard/ut_index_build_reboots/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_index_build_reboots/CMakeLists.darwin-x86_64.txt @@ -33,8 +33,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_index_build_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_index_build_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_index_build_reboots/ut_index_build_reboots.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_index_build_reboots/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_index_build_reboots/CMakeLists.linux-aarch64.txt index 0efe88590476..09596cf73a1f 100644 --- a/ydb/core/tx/schemeshard/ut_index_build_reboots/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_index_build_reboots/CMakeLists.linux-aarch64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_index_build_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_index_build_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_index_build_reboots/ut_index_build_reboots.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_index_build_reboots/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_index_build_reboots/CMakeLists.linux-x86_64.txt index b53d2c3424ba..9d7f9b0eb6e9 100644 --- a/ydb/core/tx/schemeshard/ut_index_build_reboots/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_index_build_reboots/CMakeLists.linux-x86_64.txt @@ -36,9 +36,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_index_build_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_index_build_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_index_build_reboots/ut_index_build_reboots.cpp @@ -68,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_index_build_reboots/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_index_build_reboots/CMakeLists.windows-x86_64.txt index eff4241561a5..d5823e855daa 100644 --- a/ydb/core/tx/schemeshard/ut_index_build_reboots/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_index_build_reboots/CMakeLists.windows-x86_64.txt @@ -57,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_login/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_login/CMakeLists.darwin-arm64.txt index 148554edd5a2..a6ea932a6ac6 100644 --- a/ydb/core/tx/schemeshard/ut_login/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_login/CMakeLists.darwin-arm64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_login PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_login PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_login/ut_login.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_login/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_login/CMakeLists.darwin-x86_64.txt index c8c7106917dd..8932faa4eb38 100644 --- a/ydb/core/tx/schemeshard/ut_login/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_login/CMakeLists.darwin-x86_64.txt @@ -33,8 +33,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_login PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_login PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_login/ut_login.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_login/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_login/CMakeLists.linux-aarch64.txt index 6356a995163b..48ea23e250f1 100644 --- a/ydb/core/tx/schemeshard/ut_login/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_login/CMakeLists.linux-aarch64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_login PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_login PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_login/ut_login.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_login/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_login/CMakeLists.linux-x86_64.txt index d4796fdb4e25..81e697072873 100644 --- a/ydb/core/tx/schemeshard/ut_login/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_login/CMakeLists.linux-x86_64.txt @@ -36,9 +36,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_login PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_login PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_login/ut_login.cpp @@ -68,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_login/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_login/CMakeLists.windows-x86_64.txt index ff885b8fb774..14057ef0d479 100644 --- a/ydb/core/tx/schemeshard/ut_login/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_login/CMakeLists.windows-x86_64.txt @@ -57,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_move/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_move/CMakeLists.darwin-arm64.txt index ea64b6828650..4bd8a4d1192e 100644 --- a/ydb/core/tx/schemeshard/ut_move/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_move/CMakeLists.darwin-arm64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_move PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_move PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_move/ut_move.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_move/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_move/CMakeLists.darwin-x86_64.txt index b4da03e27aaa..235fee279446 100644 --- a/ydb/core/tx/schemeshard/ut_move/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_move/CMakeLists.darwin-x86_64.txt @@ -33,8 +33,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_move PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_move PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_move/ut_move.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_move/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_move/CMakeLists.linux-aarch64.txt index 825a07b2d320..7620bb6ab26e 100644 --- a/ydb/core/tx/schemeshard/ut_move/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_move/CMakeLists.linux-aarch64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_move PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_move PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_move/ut_move.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_move/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_move/CMakeLists.linux-x86_64.txt index c21e17328780..92d6e88d89a6 100644 --- a/ydb/core/tx/schemeshard/ut_move/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_move/CMakeLists.linux-x86_64.txt @@ -36,9 +36,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_move PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_move PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_move/ut_move.cpp @@ -68,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_move/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_move/CMakeLists.windows-x86_64.txt index 62a6648ddba2..369c417dbd32 100644 --- a/ydb/core/tx/schemeshard/ut_move/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_move/CMakeLists.windows-x86_64.txt @@ -57,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_move_reboots/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_move_reboots/CMakeLists.darwin-arm64.txt index f2e20f58aa5d..436c41a94185 100644 --- a/ydb/core/tx/schemeshard/ut_move_reboots/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_move_reboots/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_move_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_move_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_move_reboots/ut_move_reboots.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_move_reboots/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_move_reboots/CMakeLists.darwin-x86_64.txt index 25b954f36f7b..90ee258e14ec 100644 --- a/ydb/core/tx/schemeshard/ut_move_reboots/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_move_reboots/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_move_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_move_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_move_reboots/ut_move_reboots.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_move_reboots/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_move_reboots/CMakeLists.linux-aarch64.txt index 1c678b692cca..d30bbf0b199a 100644 --- a/ydb/core/tx/schemeshard/ut_move_reboots/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_move_reboots/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_move_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_move_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_move_reboots/ut_move_reboots.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_move_reboots/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_move_reboots/CMakeLists.linux-x86_64.txt index ec4f146e2a42..2a4a25b2b4fc 100644 --- a/ydb/core/tx/schemeshard/ut_move_reboots/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_move_reboots/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_move_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_move_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_move_reboots/ut_move_reboots.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_move_reboots/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_move_reboots/CMakeLists.windows-x86_64.txt index e40377a5a626..ea866f445347 100644 --- a/ydb/core/tx/schemeshard/ut_move_reboots/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_move_reboots/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_olap/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_olap/CMakeLists.darwin-arm64.txt index 6041abae61cd..de583a7225cf 100644 --- a/ydb/core/tx/schemeshard/ut_olap/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_olap/CMakeLists.darwin-arm64.txt @@ -33,8 +33,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_olap PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_olap PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_olap/ut_olap.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_olap/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_olap/CMakeLists.darwin-x86_64.txt index e65df2b0e91c..59b0f4da89ca 100644 --- a/ydb/core/tx/schemeshard/ut_olap/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_olap/CMakeLists.darwin-x86_64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_olap PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_olap PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_olap/ut_olap.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_olap/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_olap/CMakeLists.linux-aarch64.txt index c55935dc5916..ce8068e254db 100644 --- a/ydb/core/tx/schemeshard/ut_olap/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_olap/CMakeLists.linux-aarch64.txt @@ -36,9 +36,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_olap PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_olap PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_olap/ut_olap.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_olap/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_olap/CMakeLists.linux-x86_64.txt index 03a4ed5f2bcf..8572460e3df7 100644 --- a/ydb/core/tx/schemeshard/ut_olap/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_olap/CMakeLists.linux-x86_64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_olap PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_olap PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_olap/ut_olap.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_olap/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_olap/CMakeLists.windows-x86_64.txt index 026b3548b525..3a0b115039e0 100644 --- a/ydb/core/tx/schemeshard/ut_olap/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_olap/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_olap_reboots/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_olap_reboots/CMakeLists.darwin-arm64.txt index f0d7a0b5043c..ee697b9a3877 100644 --- a/ydb/core/tx/schemeshard/ut_olap_reboots/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_olap_reboots/CMakeLists.darwin-arm64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_olap_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_olap_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_olap_reboots/ut_olap_reboots.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_olap_reboots/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_olap_reboots/CMakeLists.darwin-x86_64.txt index 5aec8a43a858..52e95b1329ef 100644 --- a/ydb/core/tx/schemeshard/ut_olap_reboots/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_olap_reboots/CMakeLists.darwin-x86_64.txt @@ -33,8 +33,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_olap_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_olap_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_olap_reboots/ut_olap_reboots.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_olap_reboots/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_olap_reboots/CMakeLists.linux-aarch64.txt index bb5fd4d6b5d8..176e9e8ea0b5 100644 --- a/ydb/core/tx/schemeshard/ut_olap_reboots/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_olap_reboots/CMakeLists.linux-aarch64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_olap_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_olap_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_olap_reboots/ut_olap_reboots.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_olap_reboots/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_olap_reboots/CMakeLists.linux-x86_64.txt index 3d20c735c685..74cfe254dee0 100644 --- a/ydb/core/tx/schemeshard/ut_olap_reboots/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_olap_reboots/CMakeLists.linux-x86_64.txt @@ -36,9 +36,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_olap_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_olap_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_olap_reboots/ut_olap_reboots.cpp @@ -68,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_olap_reboots/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_olap_reboots/CMakeLists.windows-x86_64.txt index 10032ad387bd..1036d26d78da 100644 --- a/ydb/core/tx/schemeshard/ut_olap_reboots/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_olap_reboots/CMakeLists.windows-x86_64.txt @@ -57,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_pq_reboots/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_pq_reboots/CMakeLists.darwin-arm64.txt index 36486be38b70..a09cf3539642 100644 --- a/ydb/core/tx/schemeshard/ut_pq_reboots/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_pq_reboots/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_pq_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_pq_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_pq_reboots/ut_pq_reboots.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_pq_reboots/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_pq_reboots/CMakeLists.darwin-x86_64.txt index e31b79f06e5e..ce6615ebb388 100644 --- a/ydb/core/tx/schemeshard/ut_pq_reboots/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_pq_reboots/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_pq_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_pq_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_pq_reboots/ut_pq_reboots.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_pq_reboots/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_pq_reboots/CMakeLists.linux-aarch64.txt index 809b286497ee..ba50c70526fd 100644 --- a/ydb/core/tx/schemeshard/ut_pq_reboots/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_pq_reboots/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_pq_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_pq_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_pq_reboots/ut_pq_reboots.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_pq_reboots/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_pq_reboots/CMakeLists.linux-x86_64.txt index e55199b0dc96..87aba9212bf6 100644 --- a/ydb/core/tx/schemeshard/ut_pq_reboots/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_pq_reboots/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_pq_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_pq_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_pq_reboots/ut_pq_reboots.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_pq_reboots/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_pq_reboots/CMakeLists.windows-x86_64.txt index b2e0f721256c..9a36bfce4547 100644 --- a/ydb/core/tx/schemeshard/ut_pq_reboots/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_pq_reboots/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_reboots/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_reboots/CMakeLists.darwin-arm64.txt index d5433330cf50..7ba7e3b57407 100644 --- a/ydb/core/tx/schemeshard/ut_reboots/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_reboots/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_reboots/ut_reboots.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_reboots/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_reboots/CMakeLists.darwin-x86_64.txt index 6a2226b4a381..110caed64bc1 100644 --- a/ydb/core/tx/schemeshard/ut_reboots/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_reboots/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_reboots/ut_reboots.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_reboots/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_reboots/CMakeLists.linux-aarch64.txt index f9b214bb756c..bb7ffff40428 100644 --- a/ydb/core/tx/schemeshard/ut_reboots/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_reboots/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_reboots/ut_reboots.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_reboots/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_reboots/CMakeLists.linux-x86_64.txt index 39d66fd17ca4..f9aab3e2a573 100644 --- a/ydb/core/tx/schemeshard/ut_reboots/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_reboots/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_reboots/ut_reboots.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_reboots/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_reboots/CMakeLists.windows-x86_64.txt index 394383cb205b..877c76846b23 100644 --- a/ydb/core/tx/schemeshard/ut_reboots/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_reboots/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_replication/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_replication/CMakeLists.darwin-arm64.txt index 6e9bc137e7b8..fc9178e17e0e 100644 --- a/ydb/core/tx/schemeshard/ut_replication/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_replication/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_replication PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_replication PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_replication/ut_replication.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_replication/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_replication/CMakeLists.darwin-x86_64.txt index 4573bcfc8aa8..52798b3f6996 100644 --- a/ydb/core/tx/schemeshard/ut_replication/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_replication/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_replication PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_replication PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_replication/ut_replication.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_replication/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_replication/CMakeLists.linux-aarch64.txt index 379bf52b2387..02ea0831aeb2 100644 --- a/ydb/core/tx/schemeshard/ut_replication/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_replication/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_replication PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_replication PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_replication/ut_replication.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_replication/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_replication/CMakeLists.linux-x86_64.txt index 12396fd1b62f..2c7f2b01052c 100644 --- a/ydb/core/tx/schemeshard/ut_replication/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_replication/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_replication PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_replication PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_replication/ut_replication.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_replication/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_replication/CMakeLists.windows-x86_64.txt index a4d35444a609..c4c09dd22481 100644 --- a/ydb/core/tx/schemeshard/ut_replication/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_replication/CMakeLists.windows-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_replication_reboots/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_replication_reboots/CMakeLists.darwin-arm64.txt index 3b40c0b46586..442f9f5efe29 100644 --- a/ydb/core/tx/schemeshard/ut_replication_reboots/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_replication_reboots/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_replication_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_replication_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_replication_reboots/ut_replication_reboots.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_replication_reboots/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_replication_reboots/CMakeLists.darwin-x86_64.txt index b2fc233d151d..9c18d9eac35c 100644 --- a/ydb/core/tx/schemeshard/ut_replication_reboots/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_replication_reboots/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_replication_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_replication_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_replication_reboots/ut_replication_reboots.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_replication_reboots/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_replication_reboots/CMakeLists.linux-aarch64.txt index e54922c36c3e..4de324dd4350 100644 --- a/ydb/core/tx/schemeshard/ut_replication_reboots/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_replication_reboots/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_replication_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_replication_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_replication_reboots/ut_replication_reboots.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_replication_reboots/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_replication_reboots/CMakeLists.linux-x86_64.txt index d69748bcf754..7bb69f7c1999 100644 --- a/ydb/core/tx/schemeshard/ut_replication_reboots/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_replication_reboots/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_replication_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_replication_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_replication_reboots/ut_replication_reboots.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_replication_reboots/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_replication_reboots/CMakeLists.windows-x86_64.txt index 8b938ee2e13a..0c54f561cb0b 100644 --- a/ydb/core/tx/schemeshard/ut_replication_reboots/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_replication_reboots/CMakeLists.windows-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_restore/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_restore/CMakeLists.darwin-arm64.txt index a4ca5be662dd..601981a1983d 100644 --- a/ydb/core/tx/schemeshard/ut_restore/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_restore/CMakeLists.darwin-arm64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_restore PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_restore PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_restore/ut_restore.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_restore/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_restore/CMakeLists.darwin-x86_64.txt index 135c2b299b4c..790f4aa275f1 100644 --- a/ydb/core/tx/schemeshard/ut_restore/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_restore/CMakeLists.darwin-x86_64.txt @@ -33,8 +33,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_restore PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_restore PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_restore/ut_restore.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_restore/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_restore/CMakeLists.linux-aarch64.txt index 965050bb1145..a9e20b670d04 100644 --- a/ydb/core/tx/schemeshard/ut_restore/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_restore/CMakeLists.linux-aarch64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_restore PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_restore PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_restore/ut_restore.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_restore/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_restore/CMakeLists.linux-x86_64.txt index 41f372da7a6c..a1cbb8c372d3 100644 --- a/ydb/core/tx/schemeshard/ut_restore/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_restore/CMakeLists.linux-x86_64.txt @@ -36,9 +36,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_restore PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_restore PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_restore/ut_restore.cpp @@ -68,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_restore/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_restore/CMakeLists.windows-x86_64.txt index a4e53b2a9855..231a7e1c8e20 100644 --- a/ydb/core/tx/schemeshard/ut_restore/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_restore/CMakeLists.windows-x86_64.txt @@ -57,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_rtmr/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_rtmr/CMakeLists.darwin-arm64.txt index 1cec7b5f2c44..61f0412b1d9d 100644 --- a/ydb/core/tx/schemeshard/ut_rtmr/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_rtmr/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_rtmr PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_rtmr PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_rtmr/ut_rtmr.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_rtmr/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_rtmr/CMakeLists.darwin-x86_64.txt index 48c9fa3fb264..67397097ad83 100644 --- a/ydb/core/tx/schemeshard/ut_rtmr/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_rtmr/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_rtmr PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_rtmr PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_rtmr/ut_rtmr.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_rtmr/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_rtmr/CMakeLists.linux-aarch64.txt index ec8187234499..f28225aaf333 100644 --- a/ydb/core/tx/schemeshard/ut_rtmr/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_rtmr/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_rtmr PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_rtmr PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_rtmr/ut_rtmr.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_rtmr/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_rtmr/CMakeLists.linux-x86_64.txt index 8a6237c2aa0d..cffdfeff718a 100644 --- a/ydb/core/tx/schemeshard/ut_rtmr/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_rtmr/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_rtmr PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_rtmr PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_rtmr/ut_rtmr.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_rtmr/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_rtmr/CMakeLists.windows-x86_64.txt index 37cc2af750ac..4979fd434435 100644 --- a/ydb/core/tx/schemeshard/ut_rtmr/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_rtmr/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_rtmr_reboots/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_rtmr_reboots/CMakeLists.darwin-arm64.txt index aa816b856de6..104d15c80a96 100644 --- a/ydb/core/tx/schemeshard/ut_rtmr_reboots/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_rtmr_reboots/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_rtmr_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_rtmr_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_rtmr_reboots/ut_rtmr_reboots.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_rtmr_reboots/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_rtmr_reboots/CMakeLists.darwin-x86_64.txt index 2f1c7933bf7f..0b8bb1a0c9f1 100644 --- a/ydb/core/tx/schemeshard/ut_rtmr_reboots/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_rtmr_reboots/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_rtmr_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_rtmr_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_rtmr_reboots/ut_rtmr_reboots.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_rtmr_reboots/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_rtmr_reboots/CMakeLists.linux-aarch64.txt index 025790101990..ead1400b2d0f 100644 --- a/ydb/core/tx/schemeshard/ut_rtmr_reboots/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_rtmr_reboots/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_rtmr_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_rtmr_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_rtmr_reboots/ut_rtmr_reboots.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_rtmr_reboots/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_rtmr_reboots/CMakeLists.linux-x86_64.txt index 12373ee41661..117297669691 100644 --- a/ydb/core/tx/schemeshard/ut_rtmr_reboots/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_rtmr_reboots/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_rtmr_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_rtmr_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_rtmr_reboots/ut_rtmr_reboots.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_rtmr_reboots/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_rtmr_reboots/CMakeLists.windows-x86_64.txt index 49112db67440..77107e26ad22 100644 --- a/ydb/core/tx/schemeshard/ut_rtmr_reboots/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_rtmr_reboots/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_ru_calculator/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_ru_calculator/CMakeLists.darwin-arm64.txt index 228c3cc0ec32..8591fcb8a7f0 100644 --- a/ydb/core/tx/schemeshard/ut_ru_calculator/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_ru_calculator/CMakeLists.darwin-arm64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_ru_calculator PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_ru_calculator PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_ru_calculator/ut_ru_calculator.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_ru_calculator/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_ru_calculator/CMakeLists.darwin-x86_64.txt index 962a30d4cb36..3b499e283b2b 100644 --- a/ydb/core/tx/schemeshard/ut_ru_calculator/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_ru_calculator/CMakeLists.darwin-x86_64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_ru_calculator PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_ru_calculator PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_ru_calculator/ut_ru_calculator.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_ru_calculator/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_ru_calculator/CMakeLists.linux-aarch64.txt index 468c66ff4b14..12eed342e444 100644 --- a/ydb/core/tx/schemeshard/ut_ru_calculator/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_ru_calculator/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_ru_calculator PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_ru_calculator PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_ru_calculator/ut_ru_calculator.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_ru_calculator/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_ru_calculator/CMakeLists.linux-x86_64.txt index 02e0aa735bba..f1464aa51c6b 100644 --- a/ydb/core/tx/schemeshard/ut_ru_calculator/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_ru_calculator/CMakeLists.linux-x86_64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_ru_calculator PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_ru_calculator PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_ru_calculator/ut_ru_calculator.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_ru_calculator/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_ru_calculator/CMakeLists.windows-x86_64.txt index 0df1b1a95625..174ab11898c1 100644 --- a/ydb/core/tx/schemeshard/ut_ru_calculator/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_ru_calculator/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_sequence/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_sequence/CMakeLists.darwin-arm64.txt index 98bcb28af9df..2a66a50354de 100644 --- a/ydb/core/tx/schemeshard/ut_sequence/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_sequence/CMakeLists.darwin-arm64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_sequence PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_sequence PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_sequence/ut_sequence.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_sequence/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_sequence/CMakeLists.darwin-x86_64.txt index bdaab8f0698f..f1c0ae1d6003 100644 --- a/ydb/core/tx/schemeshard/ut_sequence/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_sequence/CMakeLists.darwin-x86_64.txt @@ -33,8 +33,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_sequence PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_sequence PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_sequence/ut_sequence.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_sequence/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_sequence/CMakeLists.linux-aarch64.txt index 4aef4b35684d..35c531f001e0 100644 --- a/ydb/core/tx/schemeshard/ut_sequence/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_sequence/CMakeLists.linux-aarch64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_sequence PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_sequence PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_sequence/ut_sequence.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_sequence/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_sequence/CMakeLists.linux-x86_64.txt index 5d0c03b6dae3..708503284f87 100644 --- a/ydb/core/tx/schemeshard/ut_sequence/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_sequence/CMakeLists.linux-x86_64.txt @@ -36,9 +36,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_sequence PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_sequence PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_sequence/ut_sequence.cpp @@ -68,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_sequence/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_sequence/CMakeLists.windows-x86_64.txt index d0e31d6a0dd6..68cb9c89b879 100644 --- a/ydb/core/tx/schemeshard/ut_sequence/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_sequence/CMakeLists.windows-x86_64.txt @@ -57,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_sequence_reboots/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_sequence_reboots/CMakeLists.darwin-arm64.txt index 8f2d82f09f71..c2a11a4c854f 100644 --- a/ydb/core/tx/schemeshard/ut_sequence_reboots/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_sequence_reboots/CMakeLists.darwin-arm64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_sequence_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_sequence_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_sequence_reboots/ut_sequence_reboots.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_sequence_reboots/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_sequence_reboots/CMakeLists.darwin-x86_64.txt index dbe3e93e3139..d02ce964c083 100644 --- a/ydb/core/tx/schemeshard/ut_sequence_reboots/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_sequence_reboots/CMakeLists.darwin-x86_64.txt @@ -33,8 +33,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_sequence_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_sequence_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_sequence_reboots/ut_sequence_reboots.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_sequence_reboots/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_sequence_reboots/CMakeLists.linux-aarch64.txt index 59bd5e3162d0..15684a727349 100644 --- a/ydb/core/tx/schemeshard/ut_sequence_reboots/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_sequence_reboots/CMakeLists.linux-aarch64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_sequence_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_sequence_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_sequence_reboots/ut_sequence_reboots.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_sequence_reboots/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_sequence_reboots/CMakeLists.linux-x86_64.txt index 9546d23b22d9..dd2c8f08d4c3 100644 --- a/ydb/core/tx/schemeshard/ut_sequence_reboots/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_sequence_reboots/CMakeLists.linux-x86_64.txt @@ -36,9 +36,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_sequence_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_sequence_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_sequence_reboots/ut_sequence_reboots.cpp @@ -68,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_sequence_reboots/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_sequence_reboots/CMakeLists.windows-x86_64.txt index 16638ec57c4a..48a947f393f4 100644 --- a/ydb/core/tx/schemeshard/ut_sequence_reboots/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_sequence_reboots/CMakeLists.windows-x86_64.txt @@ -57,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_serverless/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_serverless/CMakeLists.darwin-arm64.txt index d44a06573451..44ab7b5d9602 100644 --- a/ydb/core/tx/schemeshard/ut_serverless/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_serverless/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_serverless PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_serverless PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_serverless/ut_serverless.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_serverless/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_serverless/CMakeLists.darwin-x86_64.txt index ad19c0800c2b..d83bd545d965 100644 --- a/ydb/core/tx/schemeshard/ut_serverless/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_serverless/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_serverless PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_serverless PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_serverless/ut_serverless.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_serverless/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_serverless/CMakeLists.linux-aarch64.txt index 8b8631e4f378..7d8edc4c7254 100644 --- a/ydb/core/tx/schemeshard/ut_serverless/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_serverless/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_serverless PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_serverless PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_serverless/ut_serverless.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_serverless/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_serverless/CMakeLists.linux-x86_64.txt index 86a42c0d8cbf..85cdc8102e92 100644 --- a/ydb/core/tx/schemeshard/ut_serverless/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_serverless/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_serverless PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_serverless PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_serverless/ut_serverless.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_serverless/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_serverless/CMakeLists.windows-x86_64.txt index 1bef091afb8d..803cb79d33cf 100644 --- a/ydb/core/tx/schemeshard/ut_serverless/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_serverless/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_serverless_reboots/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_serverless_reboots/CMakeLists.darwin-arm64.txt index 7fa8a9462f2c..c11ba802b7fc 100644 --- a/ydb/core/tx/schemeshard/ut_serverless_reboots/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_serverless_reboots/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_serverless_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_serverless_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_serverless_reboots/ut_serverless_reboots.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_serverless_reboots/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_serverless_reboots/CMakeLists.darwin-x86_64.txt index 6862513ea34e..867c90d7096f 100644 --- a/ydb/core/tx/schemeshard/ut_serverless_reboots/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_serverless_reboots/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_serverless_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_serverless_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_serverless_reboots/ut_serverless_reboots.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_serverless_reboots/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_serverless_reboots/CMakeLists.linux-aarch64.txt index 36858a5a8a42..4288bde7067d 100644 --- a/ydb/core/tx/schemeshard/ut_serverless_reboots/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_serverless_reboots/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_serverless_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_serverless_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_serverless_reboots/ut_serverless_reboots.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_serverless_reboots/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_serverless_reboots/CMakeLists.linux-x86_64.txt index cfaa780864cc..457f940e71b3 100644 --- a/ydb/core/tx/schemeshard/ut_serverless_reboots/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_serverless_reboots/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_serverless_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_serverless_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_serverless_reboots/ut_serverless_reboots.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_serverless_reboots/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_serverless_reboots/CMakeLists.windows-x86_64.txt index 9836cd321f7c..740ef0f6ceec 100644 --- a/ydb/core/tx/schemeshard/ut_serverless_reboots/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_serverless_reboots/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_split_merge/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_split_merge/CMakeLists.darwin-arm64.txt index d12ed5a3f1d0..e5f68882ddf6 100644 --- a/ydb/core/tx/schemeshard/ut_split_merge/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_split_merge/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_split_merge PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_split_merge PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_split_merge/ut_split_merge.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_split_merge/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_split_merge/CMakeLists.darwin-x86_64.txt index 3da13e83de40..121cd0cb9c88 100644 --- a/ydb/core/tx/schemeshard/ut_split_merge/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_split_merge/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_split_merge PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_split_merge PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_split_merge/ut_split_merge.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_split_merge/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_split_merge/CMakeLists.linux-aarch64.txt index fdd8b41a6ae0..f43f6389ceec 100644 --- a/ydb/core/tx/schemeshard/ut_split_merge/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_split_merge/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_split_merge PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_split_merge PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_split_merge/ut_split_merge.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_split_merge/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_split_merge/CMakeLists.linux-x86_64.txt index 0239c347c65d..879146961b6a 100644 --- a/ydb/core/tx/schemeshard/ut_split_merge/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_split_merge/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_split_merge PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_split_merge PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_split_merge/ut_split_merge.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_split_merge/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_split_merge/CMakeLists.windows-x86_64.txt index e8f8600bb9c4..95ec2d37ab21 100644 --- a/ydb/core/tx/schemeshard/ut_split_merge/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_split_merge/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_split_merge_reboots/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_split_merge_reboots/CMakeLists.darwin-arm64.txt index 64d703acd816..e8bb29c83171 100644 --- a/ydb/core/tx/schemeshard/ut_split_merge_reboots/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_split_merge_reboots/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_split_merge_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_split_merge_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_split_merge_reboots/ut_split_merge_reboots.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_split_merge_reboots/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_split_merge_reboots/CMakeLists.darwin-x86_64.txt index 919b33e94a1a..a90037c36ca2 100644 --- a/ydb/core/tx/schemeshard/ut_split_merge_reboots/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_split_merge_reboots/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_split_merge_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_split_merge_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_split_merge_reboots/ut_split_merge_reboots.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_split_merge_reboots/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_split_merge_reboots/CMakeLists.linux-aarch64.txt index 677a817d31e9..f2bf291b3f85 100644 --- a/ydb/core/tx/schemeshard/ut_split_merge_reboots/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_split_merge_reboots/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_split_merge_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_split_merge_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_split_merge_reboots/ut_split_merge_reboots.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_split_merge_reboots/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_split_merge_reboots/CMakeLists.linux-x86_64.txt index b882f857f836..a716284f0121 100644 --- a/ydb/core/tx/schemeshard/ut_split_merge_reboots/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_split_merge_reboots/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_split_merge_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_split_merge_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_split_merge_reboots/ut_split_merge_reboots.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_split_merge_reboots/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_split_merge_reboots/CMakeLists.windows-x86_64.txt index ccc2b392580f..dfd9be10d729 100644 --- a/ydb/core/tx/schemeshard/ut_split_merge_reboots/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_split_merge_reboots/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_stats/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_stats/CMakeLists.darwin-arm64.txt index 7c10e2e61803..ecb644b9b3c8 100644 --- a/ydb/core/tx/schemeshard/ut_stats/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_stats/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_stats PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_stats PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_stats/ut_stats.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_stats/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_stats/CMakeLists.darwin-x86_64.txt index c9884411ddd5..b21608ca5635 100644 --- a/ydb/core/tx/schemeshard/ut_stats/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_stats/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_stats PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_stats PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_stats/ut_stats.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_stats/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_stats/CMakeLists.linux-aarch64.txt index d6bbf763a3df..85e3234b05ea 100644 --- a/ydb/core/tx/schemeshard/ut_stats/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_stats/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_stats PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_stats PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_stats/ut_stats.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_stats/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_stats/CMakeLists.linux-x86_64.txt index 65fe40cc98d6..4274567e8864 100644 --- a/ydb/core/tx/schemeshard/ut_stats/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_stats/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_stats PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_stats PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_stats/ut_stats.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_stats/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_stats/CMakeLists.windows-x86_64.txt index faa6d3e7d4f9..14150068c5b2 100644 --- a/ydb/core/tx/schemeshard/ut_stats/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_stats/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_subdomain/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_subdomain/CMakeLists.darwin-arm64.txt index 85f9adc3b92e..65435cd266d8 100644 --- a/ydb/core/tx/schemeshard/ut_subdomain/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_subdomain/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_subdomain PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_subdomain PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_subdomain/ut_subdomain.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_subdomain/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_subdomain/CMakeLists.darwin-x86_64.txt index 49cf2eba94e4..001f772345d0 100644 --- a/ydb/core/tx/schemeshard/ut_subdomain/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_subdomain/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_subdomain PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_subdomain PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_subdomain/ut_subdomain.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_subdomain/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_subdomain/CMakeLists.linux-aarch64.txt index 5b24ec33e77e..cfc1a5506a33 100644 --- a/ydb/core/tx/schemeshard/ut_subdomain/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_subdomain/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_subdomain PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_subdomain PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_subdomain/ut_subdomain.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_subdomain/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_subdomain/CMakeLists.linux-x86_64.txt index db0f79f48b1c..368505fe3a39 100644 --- a/ydb/core/tx/schemeshard/ut_subdomain/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_subdomain/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_subdomain PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_subdomain PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_subdomain/ut_subdomain.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_subdomain/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_subdomain/CMakeLists.windows-x86_64.txt index 944e7a94c5a1..d90adddd0d14 100644 --- a/ydb/core/tx/schemeshard/ut_subdomain/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_subdomain/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_subdomain_reboots/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_subdomain_reboots/CMakeLists.darwin-arm64.txt index 114c72c5b6ae..522fa9174e60 100644 --- a/ydb/core/tx/schemeshard/ut_subdomain_reboots/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_subdomain_reboots/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_subdomain_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_subdomain_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_subdomain_reboots/ut_subdomain_reboots.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_subdomain_reboots/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_subdomain_reboots/CMakeLists.darwin-x86_64.txt index 1b55bd6d4e07..1b6cfcb223c2 100644 --- a/ydb/core/tx/schemeshard/ut_subdomain_reboots/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_subdomain_reboots/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_subdomain_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_subdomain_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_subdomain_reboots/ut_subdomain_reboots.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_subdomain_reboots/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_subdomain_reboots/CMakeLists.linux-aarch64.txt index 92edcc81bb99..2afef50cb88b 100644 --- a/ydb/core/tx/schemeshard/ut_subdomain_reboots/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_subdomain_reboots/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_subdomain_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_subdomain_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_subdomain_reboots/ut_subdomain_reboots.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_subdomain_reboots/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_subdomain_reboots/CMakeLists.linux-x86_64.txt index c434e147977a..19d0c4a04ea5 100644 --- a/ydb/core/tx/schemeshard/ut_subdomain_reboots/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_subdomain_reboots/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_subdomain_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_subdomain_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_subdomain_reboots/ut_subdomain_reboots.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_subdomain_reboots/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_subdomain_reboots/CMakeLists.windows-x86_64.txt index b35a20cff7c7..7ecea8f233c0 100644 --- a/ydb/core/tx/schemeshard/ut_subdomain_reboots/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_subdomain_reboots/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_topic_splitmerge/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_topic_splitmerge/CMakeLists.darwin-arm64.txt index 329bbba1cccf..940619e9f305 100644 --- a/ydb/core/tx/schemeshard/ut_topic_splitmerge/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_topic_splitmerge/CMakeLists.darwin-arm64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_topic_splitmerge PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_topic_splitmerge PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_topic_splitmerge/ut_topic_splitmerge.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_topic_splitmerge/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_topic_splitmerge/CMakeLists.darwin-x86_64.txt index a73fe9a8a5cc..18866ae1bb90 100644 --- a/ydb/core/tx/schemeshard/ut_topic_splitmerge/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_topic_splitmerge/CMakeLists.darwin-x86_64.txt @@ -33,8 +33,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_topic_splitmerge PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_topic_splitmerge PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_topic_splitmerge/ut_topic_splitmerge.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_topic_splitmerge/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_topic_splitmerge/CMakeLists.linux-aarch64.txt index 24cc09d92f41..0f666a99ff32 100644 --- a/ydb/core/tx/schemeshard/ut_topic_splitmerge/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_topic_splitmerge/CMakeLists.linux-aarch64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_topic_splitmerge PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_topic_splitmerge PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_topic_splitmerge/ut_topic_splitmerge.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_topic_splitmerge/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_topic_splitmerge/CMakeLists.linux-x86_64.txt index d546519beae0..9f8ba6b111e1 100644 --- a/ydb/core/tx/schemeshard/ut_topic_splitmerge/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_topic_splitmerge/CMakeLists.linux-x86_64.txt @@ -36,9 +36,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_topic_splitmerge PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_topic_splitmerge PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_topic_splitmerge/ut_topic_splitmerge.cpp @@ -68,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_topic_splitmerge/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_topic_splitmerge/CMakeLists.windows-x86_64.txt index c0d3bd8cdc0a..89e640111306 100644 --- a/ydb/core/tx/schemeshard/ut_topic_splitmerge/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_topic_splitmerge/CMakeLists.windows-x86_64.txt @@ -57,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_ttl/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_ttl/CMakeLists.darwin-arm64.txt index 8e602bf9939a..62ff983b0bc7 100644 --- a/ydb/core/tx/schemeshard/ut_ttl/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_ttl/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_ttl PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_ttl PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_ttl/ut_ttl.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_ttl/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_ttl/CMakeLists.darwin-x86_64.txt index e9e69878f2dc..c0fbf5c314b4 100644 --- a/ydb/core/tx/schemeshard/ut_ttl/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_ttl/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_ttl PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_ttl PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_ttl/ut_ttl.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_ttl/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_ttl/CMakeLists.linux-aarch64.txt index c7e7c5a263c9..0deea1701683 100644 --- a/ydb/core/tx/schemeshard/ut_ttl/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_ttl/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_ttl PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_ttl PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_ttl/ut_ttl.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_ttl/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_ttl/CMakeLists.linux-x86_64.txt index 0de2d74b9a5d..31be7de334e6 100644 --- a/ydb/core/tx/schemeshard/ut_ttl/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_ttl/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_ttl PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_ttl PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_ttl/ut_ttl.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_ttl/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_ttl/CMakeLists.windows-x86_64.txt index 72e26c488adc..2631ef61dd5a 100644 --- a/ydb/core/tx/schemeshard/ut_ttl/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_ttl/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_user_attributes/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_user_attributes/CMakeLists.darwin-arm64.txt index 70e47bf17c57..d1e72288323f 100644 --- a/ydb/core/tx/schemeshard/ut_user_attributes/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_user_attributes/CMakeLists.darwin-arm64.txt @@ -41,8 +41,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_user_attributes PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_user_attributes PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_user_attributes/ut_user_attributes.cpp @@ -72,6 +70,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_user_attributes/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_user_attributes/CMakeLists.darwin-x86_64.txt index 97ac58c11299..f4c115071a5f 100644 --- a/ydb/core/tx/schemeshard/ut_user_attributes/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_user_attributes/CMakeLists.darwin-x86_64.txt @@ -42,8 +42,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_user_attributes PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_user_attributes PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_user_attributes/ut_user_attributes.cpp @@ -73,6 +71,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_user_attributes/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_user_attributes/CMakeLists.linux-aarch64.txt index 78ea6fce040b..6a6f046a2af5 100644 --- a/ydb/core/tx/schemeshard/ut_user_attributes/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_user_attributes/CMakeLists.linux-aarch64.txt @@ -44,9 +44,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_user_attributes PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_user_attributes PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_user_attributes/ut_user_attributes.cpp @@ -76,6 +73,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_user_attributes/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_user_attributes/CMakeLists.linux-x86_64.txt index 293b90ebdbb6..682429197fa9 100644 --- a/ydb/core/tx/schemeshard/ut_user_attributes/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_user_attributes/CMakeLists.linux-x86_64.txt @@ -45,9 +45,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_user_attributes PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_user_attributes PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_user_attributes/ut_user_attributes.cpp @@ -77,6 +74,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_user_attributes/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_user_attributes/CMakeLists.windows-x86_64.txt index 5277810f948c..8e6ed3d7b404 100644 --- a/ydb/core/tx/schemeshard/ut_user_attributes/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_user_attributes/CMakeLists.windows-x86_64.txt @@ -66,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_user_attributes_reboots/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_user_attributes_reboots/CMakeLists.darwin-arm64.txt index 5b711530d9b8..cfdb829cbb10 100644 --- a/ydb/core/tx/schemeshard/ut_user_attributes_reboots/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_user_attributes_reboots/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(core-tx-schemeshard-ut_user_attributes_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(core-tx-schemeshard-ut_user_attributes_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_user_attributes_reboots/ut_user_attributes_reboots.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_user_attributes_reboots/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_user_attributes_reboots/CMakeLists.darwin-x86_64.txt index b8c626c2cf47..424d9c1089a7 100644 --- a/ydb/core/tx/schemeshard/ut_user_attributes_reboots/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_user_attributes_reboots/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(core-tx-schemeshard-ut_user_attributes_reboots PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(core-tx-schemeshard-ut_user_attributes_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_user_attributes_reboots/ut_user_attributes_reboots.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_user_attributes_reboots/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_user_attributes_reboots/CMakeLists.linux-aarch64.txt index 4cd905e56ca3..17bf4b5cf719 100644 --- a/ydb/core/tx/schemeshard/ut_user_attributes_reboots/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_user_attributes_reboots/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(core-tx-schemeshard-ut_user_attributes_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(core-tx-schemeshard-ut_user_attributes_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_user_attributes_reboots/ut_user_attributes_reboots.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_user_attributes_reboots/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_user_attributes_reboots/CMakeLists.linux-x86_64.txt index 84ac775ea0c0..e72ba8d10d86 100644 --- a/ydb/core/tx/schemeshard/ut_user_attributes_reboots/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_user_attributes_reboots/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(core-tx-schemeshard-ut_user_attributes_reboots PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(core-tx-schemeshard-ut_user_attributes_reboots PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_user_attributes_reboots/ut_user_attributes_reboots.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_user_attributes_reboots/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_user_attributes_reboots/CMakeLists.windows-x86_64.txt index d9ff9652ae1a..69a835d2826d 100644 --- a/ydb/core/tx/schemeshard/ut_user_attributes_reboots/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_user_attributes_reboots/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_view/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/ut_view/CMakeLists.darwin-arm64.txt index 7e06068f4131..b117715359f9 100644 --- a/ydb/core/tx/schemeshard/ut_view/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/ut_view/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_view PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_view PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_view/ut_view.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_view/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/ut_view/CMakeLists.darwin-x86_64.txt index 8eb92da86e6f..d17431bafebc 100644 --- a/ydb/core/tx/schemeshard/ut_view/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_view/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_view PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-schemeshard-ut_view PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_view/ut_view.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_view/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/ut_view/CMakeLists.linux-aarch64.txt index b9b34dd82d26..f1f75f02a73c 100644 --- a/ydb/core/tx/schemeshard/ut_view/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/ut_view/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_view PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_view PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_view/ut_view.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_view/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/ut_view/CMakeLists.linux-x86_64.txt index 95c47a1a51f5..83ff4f4c818e 100644 --- a/ydb/core/tx/schemeshard/ut_view/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_view/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-tx-schemeshard-ut_view PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-schemeshard-ut_view PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/ut_view/ut_view.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/schemeshard/ut_view/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/ut_view/CMakeLists.windows-x86_64.txt index 7ffd4960f538..b4d55beb8bc5 100644 --- a/ydb/core/tx/schemeshard/ut_view/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/ut_view/CMakeLists.windows-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/sequenceproxy/ut/CMakeLists.darwin-arm64.txt b/ydb/core/tx/sequenceproxy/ut/CMakeLists.darwin-arm64.txt index 21d825c2885a..f1c7f8a1f51f 100644 --- a/ydb/core/tx/sequenceproxy/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/sequenceproxy/ut/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-tx-sequenceproxy-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-sequenceproxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/sequenceproxy/sequenceproxy_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/sequenceproxy/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/sequenceproxy/ut/CMakeLists.darwin-x86_64.txt index 9c2ea8246b9c..a8b211b92577 100644 --- a/ydb/core/tx/sequenceproxy/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/sequenceproxy/ut/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-tx-sequenceproxy-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-sequenceproxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/sequenceproxy/sequenceproxy_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/sequenceproxy/ut/CMakeLists.linux-aarch64.txt b/ydb/core/tx/sequenceproxy/ut/CMakeLists.linux-aarch64.txt index 81e438ff5b5b..cfff8a1bdd6c 100644 --- a/ydb/core/tx/sequenceproxy/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/sequenceproxy/ut/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-tx-sequenceproxy-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-sequenceproxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/sequenceproxy/sequenceproxy_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/sequenceproxy/ut/CMakeLists.linux-x86_64.txt b/ydb/core/tx/sequenceproxy/ut/CMakeLists.linux-x86_64.txt index 7e4b25d89754..3e9108248846 100644 --- a/ydb/core/tx/sequenceproxy/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/sequenceproxy/ut/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-tx-sequenceproxy-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-sequenceproxy-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/sequenceproxy/sequenceproxy_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/sequenceproxy/ut/CMakeLists.windows-x86_64.txt b/ydb/core/tx/sequenceproxy/ut/CMakeLists.windows-x86_64.txt index c932a83084c6..164d1320add9 100644 --- a/ydb/core/tx/sequenceproxy/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/sequenceproxy/ut/CMakeLists.windows-x86_64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/sequenceshard/public/ut/CMakeLists.darwin-arm64.txt b/ydb/core/tx/sequenceshard/public/ut/CMakeLists.darwin-arm64.txt index 0dd66cbcf6bb..a5ece63d3a7d 100644 --- a/ydb/core/tx/sequenceshard/public/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/sequenceshard/public/ut/CMakeLists.darwin-arm64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-core-tx-sequenceshard-public-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) set_property( TARGET @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/sequenceshard/public/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/sequenceshard/public/ut/CMakeLists.darwin-x86_64.txt index cb1e814151df..4552f627981a 100644 --- a/ydb/core/tx/sequenceshard/public/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/sequenceshard/public/ut/CMakeLists.darwin-x86_64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-tx-sequenceshard-public-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) set_property( TARGET @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/sequenceshard/public/ut/CMakeLists.linux-aarch64.txt b/ydb/core/tx/sequenceshard/public/ut/CMakeLists.linux-aarch64.txt index d85d286e150f..bd2102359563 100644 --- a/ydb/core/tx/sequenceshard/public/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/sequenceshard/public/ut/CMakeLists.linux-aarch64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-core-tx-sequenceshard-public-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) set_property( TARGET @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/sequenceshard/public/ut/CMakeLists.linux-x86_64.txt b/ydb/core/tx/sequenceshard/public/ut/CMakeLists.linux-x86_64.txt index 84972832d829..88b0d6cc521c 100644 --- a/ydb/core/tx/sequenceshard/public/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/sequenceshard/public/ut/CMakeLists.linux-x86_64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-tx-sequenceshard-public-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) set_property( TARGET @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/sequenceshard/public/ut/CMakeLists.windows-x86_64.txt b/ydb/core/tx/sequenceshard/public/ut/CMakeLists.windows-x86_64.txt index f8365a617512..101ff6d76edd 100644 --- a/ydb/core/tx/sequenceshard/public/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/sequenceshard/public/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/sequenceshard/ut/CMakeLists.darwin-arm64.txt b/ydb/core/tx/sequenceshard/ut/CMakeLists.darwin-arm64.txt index b5fd8462d863..7db37a9816c3 100644 --- a/ydb/core/tx/sequenceshard/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/sequenceshard/ut/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-tx-sequenceshard-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-sequenceshard-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/sequenceshard/ut_helpers.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/sequenceshard/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/sequenceshard/ut/CMakeLists.darwin-x86_64.txt index c79a0a012033..fb4f6a437056 100644 --- a/ydb/core/tx/sequenceshard/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/sequenceshard/ut/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-tx-sequenceshard-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-sequenceshard-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/sequenceshard/ut_helpers.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/sequenceshard/ut/CMakeLists.linux-aarch64.txt b/ydb/core/tx/sequenceshard/ut/CMakeLists.linux-aarch64.txt index e71b14634544..14a637bc58ee 100644 --- a/ydb/core/tx/sequenceshard/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/sequenceshard/ut/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-tx-sequenceshard-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-sequenceshard-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/sequenceshard/ut_helpers.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/sequenceshard/ut/CMakeLists.linux-x86_64.txt b/ydb/core/tx/sequenceshard/ut/CMakeLists.linux-x86_64.txt index 8aa707b6fdc1..3bba81bb9e84 100644 --- a/ydb/core/tx/sequenceshard/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/sequenceshard/ut/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-tx-sequenceshard-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-sequenceshard-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/sequenceshard/ut_helpers.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/sequenceshard/ut/CMakeLists.windows-x86_64.txt b/ydb/core/tx/sequenceshard/ut/CMakeLists.windows-x86_64.txt index 94123b62e85c..9b326f2cb1c8 100644 --- a/ydb/core/tx/sequenceshard/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/sequenceshard/ut/CMakeLists.windows-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/sharding/ut/CMakeLists.darwin-arm64.txt b/ydb/core/tx/sharding/ut/CMakeLists.darwin-arm64.txt index 046aac03ce16..1421b16a01cd 100644 --- a/ydb/core/tx/sharding/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/sharding/ut/CMakeLists.darwin-arm64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-tx-sharding-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-sharding-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/sharding/ut/ut_sharding.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/sharding/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/sharding/ut/CMakeLists.darwin-x86_64.txt index b8c1bfbc1a71..4bb02638bc17 100644 --- a/ydb/core/tx/sharding/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/sharding/ut/CMakeLists.darwin-x86_64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-sharding-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-sharding-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/sharding/ut/ut_sharding.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/sharding/ut/CMakeLists.linux-aarch64.txt b/ydb/core/tx/sharding/ut/CMakeLists.linux-aarch64.txt index 9a364474c2f8..bd5d4b196a0e 100644 --- a/ydb/core/tx/sharding/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/sharding/ut/CMakeLists.linux-aarch64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-tx-sharding-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-sharding-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/sharding/ut/ut_sharding.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/sharding/ut/CMakeLists.linux-x86_64.txt b/ydb/core/tx/sharding/ut/CMakeLists.linux-x86_64.txt index 7c58afe940ae..cbb9f9d83a97 100644 --- a/ydb/core/tx/sharding/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/sharding/ut/CMakeLists.linux-x86_64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-sharding-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-sharding-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/sharding/ut/ut_sharding.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/sharding/ut/CMakeLists.windows-x86_64.txt b/ydb/core/tx/sharding/ut/CMakeLists.windows-x86_64.txt index 8f1ac9b3ef08..c818d2578202 100644 --- a/ydb/core/tx/sharding/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/sharding/ut/CMakeLists.windows-x86_64.txt @@ -55,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tiering/ut/CMakeLists.darwin-arm64.txt b/ydb/core/tx/tiering/ut/CMakeLists.darwin-arm64.txt index 62f730fdbb1f..a28c6388b196 100644 --- a/ydb/core/tx/tiering/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/tiering/ut/CMakeLists.darwin-arm64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-core-tx-tiering-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-tiering-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/tiering/ut/ut_tiers.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tiering/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/tiering/ut/CMakeLists.darwin-x86_64.txt index b356a3f7fff3..ad87af702af5 100644 --- a/ydb/core/tx/tiering/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/tiering/ut/CMakeLists.darwin-x86_64.txt @@ -33,8 +33,6 @@ target_link_options(ydb-core-tx-tiering-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-tiering-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/tiering/ut/ut_tiers.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tiering/ut/CMakeLists.linux-aarch64.txt b/ydb/core/tx/tiering/ut/CMakeLists.linux-aarch64.txt index 13efb9449aac..8fba1b49f346 100644 --- a/ydb/core/tx/tiering/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/tiering/ut/CMakeLists.linux-aarch64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-core-tx-tiering-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-tiering-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/tiering/ut/ut_tiers.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tiering/ut/CMakeLists.linux-x86_64.txt b/ydb/core/tx/tiering/ut/CMakeLists.linux-x86_64.txt index 7585efb53af0..372f97a21143 100644 --- a/ydb/core/tx/tiering/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/tiering/ut/CMakeLists.linux-x86_64.txt @@ -36,9 +36,6 @@ target_link_options(ydb-core-tx-tiering-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-tiering-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/tiering/ut/ut_tiers.cpp @@ -68,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tiering/ut/CMakeLists.windows-x86_64.txt b/ydb/core/tx/tiering/ut/CMakeLists.windows-x86_64.txt index fef0d0a3a070..3add3dd0a5a6 100644 --- a/ydb/core/tx/tiering/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/tiering/ut/CMakeLists.windows-x86_64.txt @@ -57,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/time_cast/ut/CMakeLists.darwin-arm64.txt b/ydb/core/tx/time_cast/ut/CMakeLists.darwin-arm64.txt index 07e19102ac63..5860973cbd66 100644 --- a/ydb/core/tx/time_cast/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/time_cast/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-tx-time_cast-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-time_cast-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/time_cast/time_cast_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/time_cast/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/time_cast/ut/CMakeLists.darwin-x86_64.txt index 3ed229a30efa..fea26f9d0df7 100644 --- a/ydb/core/tx/time_cast/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/time_cast/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-tx-time_cast-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-time_cast-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/time_cast/time_cast_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/time_cast/ut/CMakeLists.linux-aarch64.txt b/ydb/core/tx/time_cast/ut/CMakeLists.linux-aarch64.txt index 9193473d1f50..e8a9f4807a63 100644 --- a/ydb/core/tx/time_cast/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/time_cast/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-tx-time_cast-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-time_cast-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/time_cast/time_cast_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/time_cast/ut/CMakeLists.linux-x86_64.txt b/ydb/core/tx/time_cast/ut/CMakeLists.linux-x86_64.txt index 87fcf99ca4aa..0430e18fd662 100644 --- a/ydb/core/tx/time_cast/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/time_cast/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-tx-time_cast-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-time_cast-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/time_cast/time_cast_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/time_cast/ut/CMakeLists.windows-x86_64.txt b/ydb/core/tx/time_cast/ut/CMakeLists.windows-x86_64.txt index f188fcc8f6f7..783a05e86af4 100644 --- a/ydb/core/tx/time_cast/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/time_cast/ut/CMakeLists.windows-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_allocator/ut/CMakeLists.darwin-arm64.txt b/ydb/core/tx/tx_allocator/ut/CMakeLists.darwin-arm64.txt index c42d2076a35a..8c848ef2242f 100644 --- a/ydb/core/tx/tx_allocator/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/tx_allocator/ut/CMakeLists.darwin-arm64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-tx-tx_allocator-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-tx_allocator-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_allocator/txallocator_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_allocator/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/tx_allocator/ut/CMakeLists.darwin-x86_64.txt index 39de8b58662a..cc9e8ad7ad2f 100644 --- a/ydb/core/tx/tx_allocator/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/tx_allocator/ut/CMakeLists.darwin-x86_64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-core-tx-tx_allocator-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-tx_allocator-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_allocator/txallocator_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_allocator/ut/CMakeLists.linux-aarch64.txt b/ydb/core/tx/tx_allocator/ut/CMakeLists.linux-aarch64.txt index 5f59430cc042..8a7893abf760 100644 --- a/ydb/core/tx/tx_allocator/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/tx_allocator/ut/CMakeLists.linux-aarch64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-tx-tx_allocator-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-tx_allocator-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_allocator/txallocator_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_allocator/ut/CMakeLists.linux-x86_64.txt b/ydb/core/tx/tx_allocator/ut/CMakeLists.linux-x86_64.txt index 26453439db74..563751174c4b 100644 --- a/ydb/core/tx/tx_allocator/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/tx_allocator/ut/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-core-tx-tx_allocator-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-tx_allocator-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_allocator/txallocator_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_allocator/ut/CMakeLists.windows-x86_64.txt b/ydb/core/tx/tx_allocator/ut/CMakeLists.windows-x86_64.txt index e7626912192b..f0ba02c01f4d 100644 --- a/ydb/core/tx/tx_allocator/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/tx_allocator/ut/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_allocator_client/ut/CMakeLists.darwin-arm64.txt b/ydb/core/tx/tx_allocator_client/ut/CMakeLists.darwin-arm64.txt index 1a8e04b2e070..c56f1e063feb 100644 --- a/ydb/core/tx/tx_allocator_client/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/tx_allocator_client/ut/CMakeLists.darwin-arm64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-core-tx-tx_allocator_client-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-tx_allocator_client-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_allocator_client/actor_client_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_allocator_client/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/tx_allocator_client/ut/CMakeLists.darwin-x86_64.txt index b7f2bdc5bd7b..27748f9746f4 100644 --- a/ydb/core/tx/tx_allocator_client/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/tx_allocator_client/ut/CMakeLists.darwin-x86_64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-core-tx-tx_allocator_client-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-tx_allocator_client-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_allocator_client/actor_client_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_allocator_client/ut/CMakeLists.linux-aarch64.txt b/ydb/core/tx/tx_allocator_client/ut/CMakeLists.linux-aarch64.txt index 7d07dd295f1b..7aba602acde7 100644 --- a/ydb/core/tx/tx_allocator_client/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/tx_allocator_client/ut/CMakeLists.linux-aarch64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-core-tx-tx_allocator_client-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-tx_allocator_client-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_allocator_client/actor_client_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_allocator_client/ut/CMakeLists.linux-x86_64.txt b/ydb/core/tx/tx_allocator_client/ut/CMakeLists.linux-x86_64.txt index 3d37c35895ec..4785f9b2dfa9 100644 --- a/ydb/core/tx/tx_allocator_client/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/tx_allocator_client/ut/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-core-tx-tx_allocator_client-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-tx_allocator_client-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_allocator_client/actor_client_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_allocator_client/ut/CMakeLists.windows-x86_64.txt b/ydb/core/tx/tx_allocator_client/ut/CMakeLists.windows-x86_64.txt index e92d0283780f..21d0691858c4 100644 --- a/ydb/core/tx/tx_allocator_client/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/tx_allocator_client/ut/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_proxy/CMakeLists.darwin-arm64.txt b/ydb/core/tx/tx_proxy/CMakeLists.darwin-arm64.txt index d9bbec6ac45e..af20842557bc 100644 --- a/ydb/core/tx/tx_proxy/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/tx_proxy/CMakeLists.darwin-arm64.txt @@ -36,7 +36,7 @@ target_link_libraries(core-tx-tx_proxy PUBLIC ydb-core-engine ydb-core-formats ydb-core-grpc_services - ydb-core-io_formats + core-io_formats-arrow ydb-core-protos ydb-core-scheme core-sys_view-common diff --git a/ydb/core/tx/tx_proxy/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/tx_proxy/CMakeLists.darwin-x86_64.txt index d9bbec6ac45e..af20842557bc 100644 --- a/ydb/core/tx/tx_proxy/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/tx_proxy/CMakeLists.darwin-x86_64.txt @@ -36,7 +36,7 @@ target_link_libraries(core-tx-tx_proxy PUBLIC ydb-core-engine ydb-core-formats ydb-core-grpc_services - ydb-core-io_formats + core-io_formats-arrow ydb-core-protos ydb-core-scheme core-sys_view-common diff --git a/ydb/core/tx/tx_proxy/CMakeLists.linux-aarch64.txt b/ydb/core/tx/tx_proxy/CMakeLists.linux-aarch64.txt index 341b92e2bfbc..4069d9761c2b 100644 --- a/ydb/core/tx/tx_proxy/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/tx_proxy/CMakeLists.linux-aarch64.txt @@ -37,7 +37,7 @@ target_link_libraries(core-tx-tx_proxy PUBLIC ydb-core-engine ydb-core-formats ydb-core-grpc_services - ydb-core-io_formats + core-io_formats-arrow ydb-core-protos ydb-core-scheme core-sys_view-common diff --git a/ydb/core/tx/tx_proxy/CMakeLists.linux-x86_64.txt b/ydb/core/tx/tx_proxy/CMakeLists.linux-x86_64.txt index 341b92e2bfbc..4069d9761c2b 100644 --- a/ydb/core/tx/tx_proxy/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/tx_proxy/CMakeLists.linux-x86_64.txt @@ -37,7 +37,7 @@ target_link_libraries(core-tx-tx_proxy PUBLIC ydb-core-engine ydb-core-formats ydb-core-grpc_services - ydb-core-io_formats + core-io_formats-arrow ydb-core-protos ydb-core-scheme core-sys_view-common diff --git a/ydb/core/tx/tx_proxy/CMakeLists.windows-x86_64.txt b/ydb/core/tx/tx_proxy/CMakeLists.windows-x86_64.txt index d9bbec6ac45e..af20842557bc 100644 --- a/ydb/core/tx/tx_proxy/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/tx_proxy/CMakeLists.windows-x86_64.txt @@ -36,7 +36,7 @@ target_link_libraries(core-tx-tx_proxy PUBLIC ydb-core-engine ydb-core-formats ydb-core-grpc_services - ydb-core-io_formats + core-io_formats-arrow ydb-core-protos ydb-core-scheme core-sys_view-common diff --git a/ydb/core/tx/tx_proxy/ut_base_tenant/CMakeLists.darwin-arm64.txt b/ydb/core/tx/tx_proxy/ut_base_tenant/CMakeLists.darwin-arm64.txt index 500a6612d346..257a7e60cfa8 100644 --- a/ydb/core/tx/tx_proxy/ut_base_tenant/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/tx_proxy/ut_base_tenant/CMakeLists.darwin-arm64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-tx-tx_proxy-ut_base_tenant PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-tx_proxy-ut_base_tenant PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_proxy/ut_base_tenant/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/tx_proxy/ut_base_tenant/CMakeLists.darwin-x86_64.txt index 3a69bcd0acf4..a80f5649a406 100644 --- a/ydb/core/tx/tx_proxy/ut_base_tenant/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/tx_proxy/ut_base_tenant/CMakeLists.darwin-x86_64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-tx_proxy-ut_base_tenant PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-tx_proxy-ut_base_tenant PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_proxy/ut_base_tenant/CMakeLists.linux-aarch64.txt b/ydb/core/tx/tx_proxy/ut_base_tenant/CMakeLists.linux-aarch64.txt index 92d6fb8a6b36..a24173e797cd 100644 --- a/ydb/core/tx/tx_proxy/ut_base_tenant/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/tx_proxy/ut_base_tenant/CMakeLists.linux-aarch64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-tx-tx_proxy-ut_base_tenant PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-tx_proxy-ut_base_tenant PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_proxy/ut_base_tenant/CMakeLists.linux-x86_64.txt b/ydb/core/tx/tx_proxy/ut_base_tenant/CMakeLists.linux-x86_64.txt index f791d47190ca..1aeabd48a473 100644 --- a/ydb/core/tx/tx_proxy/ut_base_tenant/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/tx_proxy/ut_base_tenant/CMakeLists.linux-x86_64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-tx_proxy-ut_base_tenant PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-tx_proxy-ut_base_tenant PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_proxy/ut_base_tenant/CMakeLists.windows-x86_64.txt b/ydb/core/tx/tx_proxy/ut_base_tenant/CMakeLists.windows-x86_64.txt index 2b013325b5cd..c2febe7da379 100644 --- a/ydb/core/tx/tx_proxy/ut_base_tenant/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/tx_proxy/ut_base_tenant/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_proxy/ut_encrypted_storage/CMakeLists.darwin-arm64.txt b/ydb/core/tx/tx_proxy/ut_encrypted_storage/CMakeLists.darwin-arm64.txt index f96c5dd76dbb..1dbaef9c586e 100644 --- a/ydb/core/tx/tx_proxy/ut_encrypted_storage/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/tx_proxy/ut_encrypted_storage/CMakeLists.darwin-arm64.txt @@ -30,10 +30,9 @@ target_link_options(ydb-core-tx-tx_proxy-ut_encrypted_storage PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-tx_proxy-ut_encrypted_storage PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut_helpers.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/encrypted_storage_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut_helpers.cpp ) @@ -62,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_proxy/ut_encrypted_storage/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/tx_proxy/ut_encrypted_storage/CMakeLists.darwin-x86_64.txt index b80a8a92a1fe..11ac68c7afbe 100644 --- a/ydb/core/tx/tx_proxy/ut_encrypted_storage/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/tx_proxy/ut_encrypted_storage/CMakeLists.darwin-x86_64.txt @@ -31,10 +31,9 @@ target_link_options(ydb-core-tx-tx_proxy-ut_encrypted_storage PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-tx_proxy-ut_encrypted_storage PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut_helpers.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/encrypted_storage_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut_helpers.cpp ) @@ -63,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_proxy/ut_encrypted_storage/CMakeLists.linux-aarch64.txt b/ydb/core/tx/tx_proxy/ut_encrypted_storage/CMakeLists.linux-aarch64.txt index 6452eceee810..117396e0e156 100644 --- a/ydb/core/tx/tx_proxy/ut_encrypted_storage/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/tx_proxy/ut_encrypted_storage/CMakeLists.linux-aarch64.txt @@ -33,11 +33,9 @@ target_link_options(ydb-core-tx-tx_proxy-ut_encrypted_storage PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-tx_proxy-ut_encrypted_storage PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut_helpers.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/encrypted_storage_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut_helpers.cpp ) @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_proxy/ut_encrypted_storage/CMakeLists.linux-x86_64.txt b/ydb/core/tx/tx_proxy/ut_encrypted_storage/CMakeLists.linux-x86_64.txt index 2d8ad642f0cd..21296d8e907d 100644 --- a/ydb/core/tx/tx_proxy/ut_encrypted_storage/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/tx_proxy/ut_encrypted_storage/CMakeLists.linux-x86_64.txt @@ -34,11 +34,9 @@ target_link_options(ydb-core-tx-tx_proxy-ut_encrypted_storage PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-tx_proxy-ut_encrypted_storage PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut_helpers.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/encrypted_storage_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut_helpers.cpp ) @@ -67,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_proxy/ut_encrypted_storage/CMakeLists.windows-x86_64.txt b/ydb/core/tx/tx_proxy/ut_encrypted_storage/CMakeLists.windows-x86_64.txt index 53525cc960a8..b54ac2d3332c 100644 --- a/ydb/core/tx/tx_proxy/ut_encrypted_storage/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/tx_proxy/ut_encrypted_storage/CMakeLists.windows-x86_64.txt @@ -28,6 +28,7 @@ target_link_libraries(ydb-core-tx-tx_proxy-ut_encrypted_storage PUBLIC udf-service-exception_policy ) target_sources(ydb-core-tx-tx_proxy-ut_encrypted_storage PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut_helpers.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/encrypted_storage_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut_helpers.cpp ) @@ -56,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_proxy/ut_ext_tenant/CMakeLists.darwin-arm64.txt b/ydb/core/tx/tx_proxy/ut_ext_tenant/CMakeLists.darwin-arm64.txt index 86c8ed558a7d..e3883e532ae5 100644 --- a/ydb/core/tx/tx_proxy/ut_ext_tenant/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/tx_proxy/ut_ext_tenant/CMakeLists.darwin-arm64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-core-tx-tx_proxy-ut_ext_tenant PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-tx_proxy-ut_ext_tenant PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ext_tenant_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_proxy/ut_ext_tenant/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/tx_proxy/ut_ext_tenant/CMakeLists.darwin-x86_64.txt index dd5c709211ae..b33b3c2aefd3 100644 --- a/ydb/core/tx/tx_proxy/ut_ext_tenant/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/tx_proxy/ut_ext_tenant/CMakeLists.darwin-x86_64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-core-tx-tx_proxy-ut_ext_tenant PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-tx_proxy-ut_ext_tenant PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ext_tenant_ut.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_proxy/ut_ext_tenant/CMakeLists.linux-aarch64.txt b/ydb/core/tx/tx_proxy/ut_ext_tenant/CMakeLists.linux-aarch64.txt index c78f697182a5..cc5c012e2ecd 100644 --- a/ydb/core/tx/tx_proxy/ut_ext_tenant/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/tx_proxy/ut_ext_tenant/CMakeLists.linux-aarch64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-core-tx-tx_proxy-ut_ext_tenant PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-tx_proxy-ut_ext_tenant PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ext_tenant_ut.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_proxy/ut_ext_tenant/CMakeLists.linux-x86_64.txt b/ydb/core/tx/tx_proxy/ut_ext_tenant/CMakeLists.linux-x86_64.txt index c87569c4ecd1..c28dd447c1fc 100644 --- a/ydb/core/tx/tx_proxy/ut_ext_tenant/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/tx_proxy/ut_ext_tenant/CMakeLists.linux-x86_64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-core-tx-tx_proxy-ut_ext_tenant PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-tx_proxy-ut_ext_tenant PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ext_tenant_ut.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_proxy/ut_ext_tenant/CMakeLists.windows-x86_64.txt b/ydb/core/tx/tx_proxy/ut_ext_tenant/CMakeLists.windows-x86_64.txt index c1dfda882512..6caa96b67a4e 100644 --- a/ydb/core/tx/tx_proxy/ut_ext_tenant/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/tx_proxy/ut_ext_tenant/CMakeLists.windows-x86_64.txt @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_proxy/ut_storage_tenant/CMakeLists.darwin-arm64.txt b/ydb/core/tx/tx_proxy/ut_storage_tenant/CMakeLists.darwin-arm64.txt index 88772be63fe6..8115358076bb 100644 --- a/ydb/core/tx/tx_proxy/ut_storage_tenant/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/tx_proxy/ut_storage_tenant/CMakeLists.darwin-arm64.txt @@ -31,10 +31,9 @@ target_link_options(ydb-core-tx-tx_proxy-ut_storage_tenant PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-tx_proxy-ut_storage_tenant PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut_helpers.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/storage_tenant_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut_helpers.cpp ) @@ -63,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_proxy/ut_storage_tenant/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/tx_proxy/ut_storage_tenant/CMakeLists.darwin-x86_64.txt index 10f1d6d52c2f..2e43de528f3e 100644 --- a/ydb/core/tx/tx_proxy/ut_storage_tenant/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/tx_proxy/ut_storage_tenant/CMakeLists.darwin-x86_64.txt @@ -32,10 +32,9 @@ target_link_options(ydb-core-tx-tx_proxy-ut_storage_tenant PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-tx-tx_proxy-ut_storage_tenant PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut_helpers.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/storage_tenant_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut_helpers.cpp ) @@ -64,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_proxy/ut_storage_tenant/CMakeLists.linux-aarch64.txt b/ydb/core/tx/tx_proxy/ut_storage_tenant/CMakeLists.linux-aarch64.txt index 52d6050d9599..b36094042e76 100644 --- a/ydb/core/tx/tx_proxy/ut_storage_tenant/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/tx_proxy/ut_storage_tenant/CMakeLists.linux-aarch64.txt @@ -34,11 +34,9 @@ target_link_options(ydb-core-tx-tx_proxy-ut_storage_tenant PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-tx_proxy-ut_storage_tenant PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut_helpers.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/storage_tenant_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut_helpers.cpp ) @@ -67,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_proxy/ut_storage_tenant/CMakeLists.linux-x86_64.txt b/ydb/core/tx/tx_proxy/ut_storage_tenant/CMakeLists.linux-x86_64.txt index fa09bcf88790..936395fdf9bb 100644 --- a/ydb/core/tx/tx_proxy/ut_storage_tenant/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/tx_proxy/ut_storage_tenant/CMakeLists.linux-x86_64.txt @@ -35,11 +35,9 @@ target_link_options(ydb-core-tx-tx_proxy-ut_storage_tenant PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-tx-tx_proxy-ut_storage_tenant PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut_helpers.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/storage_tenant_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut_helpers.cpp ) @@ -68,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/tx/tx_proxy/ut_storage_tenant/CMakeLists.windows-x86_64.txt b/ydb/core/tx/tx_proxy/ut_storage_tenant/CMakeLists.windows-x86_64.txt index 5dafcadd84a9..caf293e73746 100644 --- a/ydb/core/tx/tx_proxy/ut_storage_tenant/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/tx_proxy/ut_storage_tenant/CMakeLists.windows-x86_64.txt @@ -29,6 +29,7 @@ target_link_libraries(ydb-core-tx-tx_proxy-ut_storage_tenant PUBLIC udf-service-exception_policy ) target_sources(ydb-core-tx-tx_proxy-ut_storage_tenant PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut_helpers.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/storage_tenant_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/tx_proxy/proxy_ut_helpers.cpp ) @@ -57,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/util/CMakeLists.darwin-arm64.txt b/ydb/core/util/CMakeLists.darwin-arm64.txt index 6756018979c7..ce3bf134ef71 100644 --- a/ydb/core/util/CMakeLists.darwin-arm64.txt +++ b/ydb/core/util/CMakeLists.darwin-arm64.txt @@ -29,6 +29,44 @@ target_link_libraries(ydb-core-util PUBLIC ydb-library-yverify_stream ) target_sources(ydb-core-util PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/util/activeactors.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/cache_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/circular_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/concurrent_rw_hash.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/console.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/count_min_sketch.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/counted_leaky_bucket.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/event_priority_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/failure_injection.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/format.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/fragmented_buffer.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/hyperlog_counter.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/interval_set.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/intrusive_fixed_hash_set.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/intrusive_heap.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/intrusive_stack.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/log_priority_mute_checker.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/memory_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/operation_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/pb.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/proto_duration.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/queue_inplace.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/queue_oneone_inplace.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/simple_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/single_thread_ic_mock.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/stlog.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/templates.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/testactorsys.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/text.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/token_bucket.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/throughput_meter.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/tuples.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/type_alias.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/ulid.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/ui64id.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/wildcard.h ${CMAKE_SOURCE_DIR}/ydb/core/util/address_classifier.cpp ${CMAKE_SOURCE_DIR}/ydb/core/util/backoff.cpp ${CMAKE_SOURCE_DIR}/ydb/core/util/cache.cpp diff --git a/ydb/core/util/CMakeLists.darwin-x86_64.txt b/ydb/core/util/CMakeLists.darwin-x86_64.txt index 6756018979c7..ce3bf134ef71 100644 --- a/ydb/core/util/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/util/CMakeLists.darwin-x86_64.txt @@ -29,6 +29,44 @@ target_link_libraries(ydb-core-util PUBLIC ydb-library-yverify_stream ) target_sources(ydb-core-util PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/util/activeactors.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/cache_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/circular_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/concurrent_rw_hash.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/console.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/count_min_sketch.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/counted_leaky_bucket.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/event_priority_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/failure_injection.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/format.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/fragmented_buffer.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/hyperlog_counter.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/interval_set.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/intrusive_fixed_hash_set.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/intrusive_heap.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/intrusive_stack.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/log_priority_mute_checker.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/memory_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/operation_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/pb.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/proto_duration.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/queue_inplace.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/queue_oneone_inplace.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/simple_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/single_thread_ic_mock.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/stlog.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/templates.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/testactorsys.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/text.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/token_bucket.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/throughput_meter.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/tuples.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/type_alias.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/ulid.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/ui64id.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/wildcard.h ${CMAKE_SOURCE_DIR}/ydb/core/util/address_classifier.cpp ${CMAKE_SOURCE_DIR}/ydb/core/util/backoff.cpp ${CMAKE_SOURCE_DIR}/ydb/core/util/cache.cpp diff --git a/ydb/core/util/CMakeLists.linux-aarch64.txt b/ydb/core/util/CMakeLists.linux-aarch64.txt index 9b3bbcf86e89..47d4734b32f4 100644 --- a/ydb/core/util/CMakeLists.linux-aarch64.txt +++ b/ydb/core/util/CMakeLists.linux-aarch64.txt @@ -30,6 +30,44 @@ target_link_libraries(ydb-core-util PUBLIC ydb-library-yverify_stream ) target_sources(ydb-core-util PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/util/activeactors.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/cache_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/circular_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/concurrent_rw_hash.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/console.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/count_min_sketch.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/counted_leaky_bucket.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/event_priority_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/failure_injection.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/format.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/fragmented_buffer.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/hyperlog_counter.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/interval_set.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/intrusive_fixed_hash_set.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/intrusive_heap.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/intrusive_stack.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/log_priority_mute_checker.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/memory_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/operation_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/pb.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/proto_duration.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/queue_inplace.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/queue_oneone_inplace.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/simple_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/single_thread_ic_mock.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/stlog.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/templates.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/testactorsys.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/text.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/token_bucket.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/throughput_meter.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/tuples.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/type_alias.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/ulid.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/ui64id.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/wildcard.h ${CMAKE_SOURCE_DIR}/ydb/core/util/address_classifier.cpp ${CMAKE_SOURCE_DIR}/ydb/core/util/backoff.cpp ${CMAKE_SOURCE_DIR}/ydb/core/util/cache.cpp diff --git a/ydb/core/util/CMakeLists.linux-x86_64.txt b/ydb/core/util/CMakeLists.linux-x86_64.txt index 9b3bbcf86e89..47d4734b32f4 100644 --- a/ydb/core/util/CMakeLists.linux-x86_64.txt +++ b/ydb/core/util/CMakeLists.linux-x86_64.txt @@ -30,6 +30,44 @@ target_link_libraries(ydb-core-util PUBLIC ydb-library-yverify_stream ) target_sources(ydb-core-util PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/util/activeactors.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/cache_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/circular_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/concurrent_rw_hash.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/console.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/count_min_sketch.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/counted_leaky_bucket.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/event_priority_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/failure_injection.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/format.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/fragmented_buffer.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/hyperlog_counter.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/interval_set.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/intrusive_fixed_hash_set.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/intrusive_heap.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/intrusive_stack.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/log_priority_mute_checker.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/memory_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/operation_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/pb.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/proto_duration.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/queue_inplace.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/queue_oneone_inplace.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/simple_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/single_thread_ic_mock.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/stlog.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/templates.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/testactorsys.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/text.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/token_bucket.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/throughput_meter.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/tuples.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/type_alias.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/ulid.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/ui64id.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/wildcard.h ${CMAKE_SOURCE_DIR}/ydb/core/util/address_classifier.cpp ${CMAKE_SOURCE_DIR}/ydb/core/util/backoff.cpp ${CMAKE_SOURCE_DIR}/ydb/core/util/cache.cpp diff --git a/ydb/core/util/CMakeLists.windows-x86_64.txt b/ydb/core/util/CMakeLists.windows-x86_64.txt index 6756018979c7..ce3bf134ef71 100644 --- a/ydb/core/util/CMakeLists.windows-x86_64.txt +++ b/ydb/core/util/CMakeLists.windows-x86_64.txt @@ -29,6 +29,44 @@ target_link_libraries(ydb-core-util PUBLIC ydb-library-yverify_stream ) target_sources(ydb-core-util PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/util/activeactors.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/cache_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/circular_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/concurrent_rw_hash.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/console.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/count_min_sketch.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/counted_leaky_bucket.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/defs.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/event_priority_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/failure_injection.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/format.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/fragmented_buffer.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/hyperlog_counter.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/interval_set.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/intrusive_fixed_hash_set.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/intrusive_heap.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/intrusive_stack.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/log_priority_mute_checker.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/memory_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/operation_queue.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/pb.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/proto_duration.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/queue_inplace.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/queue_oneone_inplace.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/simple_cache.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/single_thread_ic_mock.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/stlog.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/templates.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/testactorsys.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/text.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/token_bucket.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/throughput_meter.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/tuples.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/type_alias.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/ulid.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/ui64id.h + ${CMAKE_SOURCE_DIR}/ydb/core/util/wildcard.h ${CMAKE_SOURCE_DIR}/ydb/core/util/address_classifier.cpp ${CMAKE_SOURCE_DIR}/ydb/core/util/backoff.cpp ${CMAKE_SOURCE_DIR}/ydb/core/util/cache.cpp diff --git a/ydb/core/util/btree_benchmark/CMakeLists.darwin-arm64.txt b/ydb/core/util/btree_benchmark/CMakeLists.darwin-arm64.txt index 050a44fa4aa0..d193e2c58376 100644 --- a/ydb/core/util/btree_benchmark/CMakeLists.darwin-arm64.txt +++ b/ydb/core/util/btree_benchmark/CMakeLists.darwin-arm64.txt @@ -19,8 +19,6 @@ target_link_options(btree_benchmark PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(btree_benchmark PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/util/btree_benchmark/main.cpp diff --git a/ydb/core/util/btree_benchmark/CMakeLists.darwin-x86_64.txt b/ydb/core/util/btree_benchmark/CMakeLists.darwin-x86_64.txt index 32796e4d1812..c3299eaf5faf 100644 --- a/ydb/core/util/btree_benchmark/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/util/btree_benchmark/CMakeLists.darwin-x86_64.txt @@ -20,8 +20,6 @@ target_link_options(btree_benchmark PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(btree_benchmark PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/util/btree_benchmark/main.cpp diff --git a/ydb/core/util/btree_benchmark/CMakeLists.linux-aarch64.txt b/ydb/core/util/btree_benchmark/CMakeLists.linux-aarch64.txt index 85d4487f73ca..8bc330a77a74 100644 --- a/ydb/core/util/btree_benchmark/CMakeLists.linux-aarch64.txt +++ b/ydb/core/util/btree_benchmark/CMakeLists.linux-aarch64.txt @@ -22,9 +22,6 @@ target_link_options(btree_benchmark PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(btree_benchmark PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/util/btree_benchmark/main.cpp diff --git a/ydb/core/util/btree_benchmark/CMakeLists.linux-x86_64.txt b/ydb/core/util/btree_benchmark/CMakeLists.linux-x86_64.txt index d54bd142739a..ff6a27923702 100644 --- a/ydb/core/util/btree_benchmark/CMakeLists.linux-x86_64.txt +++ b/ydb/core/util/btree_benchmark/CMakeLists.linux-x86_64.txt @@ -23,9 +23,6 @@ target_link_options(btree_benchmark PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(btree_benchmark PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/util/btree_benchmark/main.cpp diff --git a/ydb/core/util/ut/CMakeLists.darwin-arm64.txt b/ydb/core/util/ut/CMakeLists.darwin-arm64.txt index c7cd3e7dc653..1c49731bb155 100644 --- a/ydb/core/util/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/util/ut/CMakeLists.darwin-arm64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-core-util-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-util-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/util/address_classifier_ut.cpp @@ -86,6 +84,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/util/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/util/ut/CMakeLists.darwin-x86_64.txt index c7fa9985f51b..f16b3f84e729 100644 --- a/ydb/core/util/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/util/ut/CMakeLists.darwin-x86_64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-util-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-util-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/util/address_classifier_ut.cpp @@ -87,6 +85,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/util/ut/CMakeLists.linux-aarch64.txt b/ydb/core/util/ut/CMakeLists.linux-aarch64.txt index cbebb39f6ab4..c878a31c745f 100644 --- a/ydb/core/util/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/util/ut/CMakeLists.linux-aarch64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-core-util-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-util-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/util/address_classifier_ut.cpp @@ -90,6 +87,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/util/ut/CMakeLists.linux-x86_64.txt b/ydb/core/util/ut/CMakeLists.linux-x86_64.txt index daf463609d0f..c4cc83ed0b0c 100644 --- a/ydb/core/util/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/util/ut/CMakeLists.linux-x86_64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-util-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-util-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/util/address_classifier_ut.cpp @@ -91,6 +88,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/util/ut/CMakeLists.windows-x86_64.txt b/ydb/core/util/ut/CMakeLists.windows-x86_64.txt index 500f855b30ff..91f72d7ccb52 100644 --- a/ydb/core/util/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/util/ut/CMakeLists.windows-x86_64.txt @@ -80,6 +80,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/viewer/CMakeLists.darwin-arm64.txt b/ydb/core/viewer/CMakeLists.darwin-arm64.txt index 98e7e67ed639..67ded5fa00b9 100644 --- a/ydb/core/viewer/CMakeLists.darwin-arm64.txt +++ b/ydb/core/viewer/CMakeLists.darwin-arm64.txt @@ -33,6 +33,7 @@ target_link_libraries(ydb-core-viewer PUBLIC core-blobstorage-base blobstorage-vdisk-common core-client-server + core-graph-api ydb-core-grpc_services core-grpc_services-local_rpc ydb-core-health_check @@ -52,6 +53,56 @@ target_link_libraries(ydb-core-viewer PUBLIC cpp-client-ydb_types ) target_sources(ydb-core-viewer PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/browse_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/browse_pq.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/browse.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/counters_hosts.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_acl.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_blobindexstat.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_browse.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_bscontrollerinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_bsgroupinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_cluster.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_compute.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_content.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_describe.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_local_rpc.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_getblob.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_graph.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_healthcheck.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_hiveinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_hotkeys.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_labeledcounters.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_metainfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_netinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_nodeinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_nodelist.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_nodes.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_pdiskinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_query.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_render.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_storage.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_sysinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_tabletcounters.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_tabletinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_tenants.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_tenantinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_topicinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_pqconsumerinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_vdisk_req.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_vdiskinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_vdiskstat.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_wb_req.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_whoami.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/log.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/viewer_request.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/viewer.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/wb_aggregate.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/wb_filter.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/wb_group.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/wb_merge.h ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_handlers_vdisk.cpp ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_handlers_viewer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/viewer/viewer_request.cpp @@ -79,6 +130,7 @@ target_link_libraries(ydb-core-viewer.global PUBLIC core-blobstorage-base blobstorage-vdisk-common core-client-server + core-graph-api ydb-core-grpc_services core-grpc_services-local_rpc ydb-core-health_check diff --git a/ydb/core/viewer/CMakeLists.darwin-x86_64.txt b/ydb/core/viewer/CMakeLists.darwin-x86_64.txt index 98e7e67ed639..67ded5fa00b9 100644 --- a/ydb/core/viewer/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/viewer/CMakeLists.darwin-x86_64.txt @@ -33,6 +33,7 @@ target_link_libraries(ydb-core-viewer PUBLIC core-blobstorage-base blobstorage-vdisk-common core-client-server + core-graph-api ydb-core-grpc_services core-grpc_services-local_rpc ydb-core-health_check @@ -52,6 +53,56 @@ target_link_libraries(ydb-core-viewer PUBLIC cpp-client-ydb_types ) target_sources(ydb-core-viewer PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/browse_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/browse_pq.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/browse.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/counters_hosts.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_acl.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_blobindexstat.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_browse.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_bscontrollerinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_bsgroupinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_cluster.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_compute.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_content.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_describe.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_local_rpc.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_getblob.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_graph.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_healthcheck.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_hiveinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_hotkeys.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_labeledcounters.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_metainfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_netinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_nodeinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_nodelist.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_nodes.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_pdiskinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_query.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_render.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_storage.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_sysinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_tabletcounters.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_tabletinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_tenants.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_tenantinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_topicinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_pqconsumerinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_vdisk_req.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_vdiskinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_vdiskstat.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_wb_req.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_whoami.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/log.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/viewer_request.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/viewer.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/wb_aggregate.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/wb_filter.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/wb_group.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/wb_merge.h ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_handlers_vdisk.cpp ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_handlers_viewer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/viewer/viewer_request.cpp @@ -79,6 +130,7 @@ target_link_libraries(ydb-core-viewer.global PUBLIC core-blobstorage-base blobstorage-vdisk-common core-client-server + core-graph-api ydb-core-grpc_services core-grpc_services-local_rpc ydb-core-health_check diff --git a/ydb/core/viewer/CMakeLists.linux-aarch64.txt b/ydb/core/viewer/CMakeLists.linux-aarch64.txt index d55b6b86b858..2ce409ce05eb 100644 --- a/ydb/core/viewer/CMakeLists.linux-aarch64.txt +++ b/ydb/core/viewer/CMakeLists.linux-aarch64.txt @@ -34,6 +34,7 @@ target_link_libraries(ydb-core-viewer PUBLIC core-blobstorage-base blobstorage-vdisk-common core-client-server + core-graph-api ydb-core-grpc_services core-grpc_services-local_rpc ydb-core-health_check @@ -53,6 +54,56 @@ target_link_libraries(ydb-core-viewer PUBLIC cpp-client-ydb_types ) target_sources(ydb-core-viewer PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/browse_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/browse_pq.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/browse.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/counters_hosts.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_acl.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_blobindexstat.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_browse.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_bscontrollerinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_bsgroupinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_cluster.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_compute.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_content.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_describe.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_local_rpc.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_getblob.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_graph.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_healthcheck.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_hiveinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_hotkeys.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_labeledcounters.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_metainfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_netinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_nodeinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_nodelist.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_nodes.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_pdiskinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_query.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_render.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_storage.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_sysinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_tabletcounters.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_tabletinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_tenants.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_tenantinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_topicinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_pqconsumerinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_vdisk_req.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_vdiskinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_vdiskstat.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_wb_req.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_whoami.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/log.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/viewer_request.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/viewer.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/wb_aggregate.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/wb_filter.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/wb_group.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/wb_merge.h ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_handlers_vdisk.cpp ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_handlers_viewer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/viewer/viewer_request.cpp @@ -81,6 +132,7 @@ target_link_libraries(ydb-core-viewer.global PUBLIC core-blobstorage-base blobstorage-vdisk-common core-client-server + core-graph-api ydb-core-grpc_services core-grpc_services-local_rpc ydb-core-health_check diff --git a/ydb/core/viewer/CMakeLists.linux-x86_64.txt b/ydb/core/viewer/CMakeLists.linux-x86_64.txt index d55b6b86b858..2ce409ce05eb 100644 --- a/ydb/core/viewer/CMakeLists.linux-x86_64.txt +++ b/ydb/core/viewer/CMakeLists.linux-x86_64.txt @@ -34,6 +34,7 @@ target_link_libraries(ydb-core-viewer PUBLIC core-blobstorage-base blobstorage-vdisk-common core-client-server + core-graph-api ydb-core-grpc_services core-grpc_services-local_rpc ydb-core-health_check @@ -53,6 +54,56 @@ target_link_libraries(ydb-core-viewer PUBLIC cpp-client-ydb_types ) target_sources(ydb-core-viewer PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/browse_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/browse_pq.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/browse.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/counters_hosts.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_acl.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_blobindexstat.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_browse.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_bscontrollerinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_bsgroupinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_cluster.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_compute.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_content.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_describe.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_local_rpc.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_getblob.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_graph.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_healthcheck.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_hiveinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_hotkeys.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_labeledcounters.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_metainfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_netinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_nodeinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_nodelist.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_nodes.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_pdiskinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_query.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_render.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_storage.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_sysinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_tabletcounters.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_tabletinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_tenants.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_tenantinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_topicinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_pqconsumerinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_vdisk_req.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_vdiskinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_vdiskstat.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_wb_req.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_whoami.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/log.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/viewer_request.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/viewer.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/wb_aggregate.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/wb_filter.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/wb_group.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/wb_merge.h ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_handlers_vdisk.cpp ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_handlers_viewer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/viewer/viewer_request.cpp @@ -81,6 +132,7 @@ target_link_libraries(ydb-core-viewer.global PUBLIC core-blobstorage-base blobstorage-vdisk-common core-client-server + core-graph-api ydb-core-grpc_services core-grpc_services-local_rpc ydb-core-health_check diff --git a/ydb/core/viewer/CMakeLists.windows-x86_64.txt b/ydb/core/viewer/CMakeLists.windows-x86_64.txt index 98e7e67ed639..67ded5fa00b9 100644 --- a/ydb/core/viewer/CMakeLists.windows-x86_64.txt +++ b/ydb/core/viewer/CMakeLists.windows-x86_64.txt @@ -33,6 +33,7 @@ target_link_libraries(ydb-core-viewer PUBLIC core-blobstorage-base blobstorage-vdisk-common core-client-server + core-graph-api ydb-core-grpc_services core-grpc_services-local_rpc ydb-core-health_check @@ -52,6 +53,56 @@ target_link_libraries(ydb-core-viewer PUBLIC cpp-client-ydb_types ) target_sources(ydb-core-viewer PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/browse_db.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/browse_pq.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/browse.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/counters_hosts.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_acl.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_blobindexstat.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_browse.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_bscontrollerinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_bsgroupinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_cluster.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_compute.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_config.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_content.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_counters.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_describe.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_local_rpc.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_getblob.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_graph.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_healthcheck.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_hiveinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_hotkeys.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_labeledcounters.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_metainfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_netinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_nodeinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_nodelist.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_nodes.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_pdiskinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_query.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_render.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_storage.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_sysinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_tabletcounters.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_tabletinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_tenants.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_tenantinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_topicinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_pqconsumerinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_vdisk_req.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_vdiskinfo.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_vdiskstat.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_wb_req.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_whoami.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/log.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/viewer_request.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/viewer.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/wb_aggregate.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/wb_filter.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/wb_group.h + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/wb_merge.h ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_handlers_vdisk.cpp ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json_handlers_viewer.cpp ${CMAKE_SOURCE_DIR}/ydb/core/viewer/viewer_request.cpp @@ -79,6 +130,7 @@ target_link_libraries(ydb-core-viewer.global PUBLIC core-blobstorage-base blobstorage-vdisk-common core-client-server + core-graph-api ydb-core-grpc_services core-grpc_services-local_rpc ydb-core-health_check diff --git a/ydb/core/viewer/json/CMakeLists.darwin-arm64.txt b/ydb/core/viewer/json/CMakeLists.darwin-arm64.txt index 6c8ae852b499..b4f48a0702da 100644 --- a/ydb/core/viewer/json/CMakeLists.darwin-arm64.txt +++ b/ydb/core/viewer/json/CMakeLists.darwin-arm64.txt @@ -16,5 +16,6 @@ target_link_libraries(core-viewer-json PUBLIC core-viewer-protos ) target_sources(core-viewer-json PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json/json.h ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json/json.cpp ) diff --git a/ydb/core/viewer/json/CMakeLists.darwin-x86_64.txt b/ydb/core/viewer/json/CMakeLists.darwin-x86_64.txt index 6c8ae852b499..b4f48a0702da 100644 --- a/ydb/core/viewer/json/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/viewer/json/CMakeLists.darwin-x86_64.txt @@ -16,5 +16,6 @@ target_link_libraries(core-viewer-json PUBLIC core-viewer-protos ) target_sources(core-viewer-json PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json/json.h ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json/json.cpp ) diff --git a/ydb/core/viewer/json/CMakeLists.linux-aarch64.txt b/ydb/core/viewer/json/CMakeLists.linux-aarch64.txt index d9c7f4535953..e4b8fdea691c 100644 --- a/ydb/core/viewer/json/CMakeLists.linux-aarch64.txt +++ b/ydb/core/viewer/json/CMakeLists.linux-aarch64.txt @@ -17,5 +17,6 @@ target_link_libraries(core-viewer-json PUBLIC core-viewer-protos ) target_sources(core-viewer-json PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json/json.h ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json/json.cpp ) diff --git a/ydb/core/viewer/json/CMakeLists.linux-x86_64.txt b/ydb/core/viewer/json/CMakeLists.linux-x86_64.txt index d9c7f4535953..e4b8fdea691c 100644 --- a/ydb/core/viewer/json/CMakeLists.linux-x86_64.txt +++ b/ydb/core/viewer/json/CMakeLists.linux-x86_64.txt @@ -17,5 +17,6 @@ target_link_libraries(core-viewer-json PUBLIC core-viewer-protos ) target_sources(core-viewer-json PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json/json.h ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json/json.cpp ) diff --git a/ydb/core/viewer/json/CMakeLists.windows-x86_64.txt b/ydb/core/viewer/json/CMakeLists.windows-x86_64.txt index 6c8ae852b499..b4f48a0702da 100644 --- a/ydb/core/viewer/json/CMakeLists.windows-x86_64.txt +++ b/ydb/core/viewer/json/CMakeLists.windows-x86_64.txt @@ -16,5 +16,6 @@ target_link_libraries(core-viewer-json PUBLIC core-viewer-protos ) target_sources(core-viewer-json PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json/json.h ${CMAKE_SOURCE_DIR}/ydb/core/viewer/json/json.cpp ) diff --git a/ydb/core/viewer/protos/CMakeLists.darwin-arm64.txt b/ydb/core/viewer/protos/CMakeLists.darwin-arm64.txt index 9928b65a1d79..b90ba880f370 100644 --- a/ydb/core/viewer/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/core/viewer/protos/CMakeLists.darwin-arm64.txt @@ -29,6 +29,9 @@ target_link_libraries(core-viewer-protos PUBLIC target_proto_messages(core-viewer-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/viewer/protos/viewer.proto ) +target_sources(core-viewer-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/viewer/protos/viewer.pb.h +) target_proto_addincls(core-viewer-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/viewer/protos/CMakeLists.darwin-x86_64.txt b/ydb/core/viewer/protos/CMakeLists.darwin-x86_64.txt index 9928b65a1d79..b90ba880f370 100644 --- a/ydb/core/viewer/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/viewer/protos/CMakeLists.darwin-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(core-viewer-protos PUBLIC target_proto_messages(core-viewer-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/viewer/protos/viewer.proto ) +target_sources(core-viewer-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/viewer/protos/viewer.pb.h +) target_proto_addincls(core-viewer-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/viewer/protos/CMakeLists.linux-aarch64.txt b/ydb/core/viewer/protos/CMakeLists.linux-aarch64.txt index c7fe09bce363..8f2ceafae135 100644 --- a/ydb/core/viewer/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/core/viewer/protos/CMakeLists.linux-aarch64.txt @@ -30,6 +30,9 @@ target_link_libraries(core-viewer-protos PUBLIC target_proto_messages(core-viewer-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/viewer/protos/viewer.proto ) +target_sources(core-viewer-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/viewer/protos/viewer.pb.h +) target_proto_addincls(core-viewer-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/viewer/protos/CMakeLists.linux-x86_64.txt b/ydb/core/viewer/protos/CMakeLists.linux-x86_64.txt index c7fe09bce363..8f2ceafae135 100644 --- a/ydb/core/viewer/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/core/viewer/protos/CMakeLists.linux-x86_64.txt @@ -30,6 +30,9 @@ target_link_libraries(core-viewer-protos PUBLIC target_proto_messages(core-viewer-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/viewer/protos/viewer.proto ) +target_sources(core-viewer-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/viewer/protos/viewer.pb.h +) target_proto_addincls(core-viewer-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/viewer/protos/CMakeLists.windows-x86_64.txt b/ydb/core/viewer/protos/CMakeLists.windows-x86_64.txt index 9928b65a1d79..b90ba880f370 100644 --- a/ydb/core/viewer/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/core/viewer/protos/CMakeLists.windows-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(core-viewer-protos PUBLIC target_proto_messages(core-viewer-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/viewer/protos/viewer.proto ) +target_sources(core-viewer-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/viewer/protos/viewer.pb.h +) target_proto_addincls(core-viewer-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/viewer/ut/CMakeLists.darwin-arm64.txt b/ydb/core/viewer/ut/CMakeLists.darwin-arm64.txt index 9d90a2c34433..27cd76b84b93 100644 --- a/ydb/core/viewer/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/viewer/ut/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-core-viewer-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-viewer-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/viewer/viewer_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/viewer/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/viewer/ut/CMakeLists.darwin-x86_64.txt index af1da2c045ea..16e116e0777d 100644 --- a/ydb/core/viewer/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/viewer/ut/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-viewer-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-viewer-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/viewer/viewer_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/viewer/ut/CMakeLists.linux-aarch64.txt b/ydb/core/viewer/ut/CMakeLists.linux-aarch64.txt index eba7834f9690..3863c33d6646 100644 --- a/ydb/core/viewer/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/viewer/ut/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-core-viewer-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-viewer-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/viewer/viewer_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/viewer/ut/CMakeLists.linux-x86_64.txt b/ydb/core/viewer/ut/CMakeLists.linux-x86_64.txt index 5303204d4f0f..11beb0461b1c 100644 --- a/ydb/core/viewer/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/viewer/ut/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-viewer-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-viewer-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/viewer/viewer_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/viewer/ut/CMakeLists.windows-x86_64.txt b/ydb/core/viewer/ut/CMakeLists.windows-x86_64.txt index 57213c4074ab..e2062ad1d105 100644 --- a/ydb/core/viewer/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/viewer/ut/CMakeLists.windows-x86_64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/wrappers/ut/CMakeLists.darwin-arm64.txt b/ydb/core/wrappers/ut/CMakeLists.darwin-arm64.txt index e71e9f85c201..5c81cf092818 100644 --- a/ydb/core/wrappers/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/wrappers/ut/CMakeLists.darwin-arm64.txt @@ -24,14 +24,13 @@ target_link_libraries(ydb-core-wrappers-ut PUBLIC cpp-testing-unittest ydb-core-protos testlib-basics-default + minikql-comp_nodes-llvm14 core-wrappers-ut_helpers ) target_link_options(ydb-core-wrappers-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-wrappers-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/wrappers/s3_wrapper_ut.cpp @@ -61,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/wrappers/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/wrappers/ut/CMakeLists.darwin-x86_64.txt index feea9aa33191..c98d3a32807d 100644 --- a/ydb/core/wrappers/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/wrappers/ut/CMakeLists.darwin-x86_64.txt @@ -25,14 +25,13 @@ target_link_libraries(ydb-core-wrappers-ut PUBLIC cpp-testing-unittest ydb-core-protos testlib-basics-default + minikql-comp_nodes-llvm14 core-wrappers-ut_helpers ) target_link_options(ydb-core-wrappers-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-wrappers-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/wrappers/s3_wrapper_ut.cpp @@ -62,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/wrappers/ut/CMakeLists.linux-aarch64.txt b/ydb/core/wrappers/ut/CMakeLists.linux-aarch64.txt index 992e329050ff..e515299a2c51 100644 --- a/ydb/core/wrappers/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/wrappers/ut/CMakeLists.linux-aarch64.txt @@ -25,6 +25,7 @@ target_link_libraries(ydb-core-wrappers-ut PUBLIC cpp-testing-unittest ydb-core-protos testlib-basics-default + minikql-comp_nodes-llvm14 core-wrappers-ut_helpers ) target_link_options(ydb-core-wrappers-ut PRIVATE @@ -33,9 +34,6 @@ target_link_options(ydb-core-wrappers-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-wrappers-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/wrappers/s3_wrapper_ut.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/wrappers/ut/CMakeLists.linux-x86_64.txt b/ydb/core/wrappers/ut/CMakeLists.linux-x86_64.txt index 9f6600034beb..a616e191b232 100644 --- a/ydb/core/wrappers/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/wrappers/ut/CMakeLists.linux-x86_64.txt @@ -26,6 +26,7 @@ target_link_libraries(ydb-core-wrappers-ut PUBLIC cpp-testing-unittest ydb-core-protos testlib-basics-default + minikql-comp_nodes-llvm14 core-wrappers-ut_helpers ) target_link_options(ydb-core-wrappers-ut PRIVATE @@ -34,9 +35,6 @@ target_link_options(ydb-core-wrappers-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-wrappers-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/wrappers/s3_wrapper_ut.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/wrappers/ut/CMakeLists.windows-x86_64.txt b/ydb/core/wrappers/ut/CMakeLists.windows-x86_64.txt index c6502dd978a8..85e0d563974b 100644 --- a/ydb/core/wrappers/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/wrappers/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ydb_convert/ut/CMakeLists.darwin-arm64.txt b/ydb/core/ydb_convert/ut/CMakeLists.darwin-arm64.txt index a4bd6b7a02e9..951acb6e1174 100644 --- a/ydb/core/ydb_convert/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/ydb_convert/ut/CMakeLists.darwin-arm64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-core-ydb_convert-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-ydb_convert-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ydb_convert/compression_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ydb_convert/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/ydb_convert/ut/CMakeLists.darwin-x86_64.txt index f555033f702f..c174f3670bcf 100644 --- a/ydb/core/ydb_convert/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/ydb_convert/ut/CMakeLists.darwin-x86_64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-core-ydb_convert-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-ydb_convert-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ydb_convert/compression_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ydb_convert/ut/CMakeLists.linux-aarch64.txt b/ydb/core/ydb_convert/ut/CMakeLists.linux-aarch64.txt index 41329355c027..becdd9b1f64c 100644 --- a/ydb/core/ydb_convert/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/ydb_convert/ut/CMakeLists.linux-aarch64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-core-ydb_convert-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-ydb_convert-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ydb_convert/compression_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ydb_convert/ut/CMakeLists.linux-x86_64.txt b/ydb/core/ydb_convert/ut/CMakeLists.linux-x86_64.txt index ae8f89f9058b..309697e05ff0 100644 --- a/ydb/core/ydb_convert/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/ydb_convert/ut/CMakeLists.linux-x86_64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-core-ydb_convert-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-ydb_convert-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ydb_convert/compression_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ydb_convert/ut/CMakeLists.windows-x86_64.txt b/ydb/core/ydb_convert/ut/CMakeLists.windows-x86_64.txt index 4737a057f111..c93b69a60767 100644 --- a/ydb/core/ydb_convert/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/ydb_convert/ut/CMakeLists.windows-x86_64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/actor/ut/CMakeLists.darwin-arm64.txt b/ydb/core/ymq/actor/ut/CMakeLists.darwin-arm64.txt index aeb10ec91fdc..7b906e309d31 100644 --- a/ydb/core/ymq/actor/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/ymq/actor/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-core-ymq-actor-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-ymq-actor-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/actor/ut/attributes_md5_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/actor/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/ymq/actor/ut/CMakeLists.darwin-x86_64.txt index 28a755ddc05e..fd7a972e669b 100644 --- a/ydb/core/ymq/actor/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/ymq/actor/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-core-ymq-actor-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-ymq-actor-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/actor/ut/attributes_md5_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/actor/ut/CMakeLists.linux-aarch64.txt b/ydb/core/ymq/actor/ut/CMakeLists.linux-aarch64.txt index 37acb96ee36a..a63c7d25c221 100644 --- a/ydb/core/ymq/actor/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/ymq/actor/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-core-ymq-actor-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-ymq-actor-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/actor/ut/attributes_md5_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/actor/ut/CMakeLists.linux-x86_64.txt b/ydb/core/ymq/actor/ut/CMakeLists.linux-x86_64.txt index 34b58c8220f2..9aa9fe052c65 100644 --- a/ydb/core/ymq/actor/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/ymq/actor/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-core-ymq-actor-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-ymq-actor-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/actor/ut/attributes_md5_ut.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/actor/ut/CMakeLists.windows-x86_64.txt b/ydb/core/ymq/actor/ut/CMakeLists.windows-x86_64.txt index d615cb56e723..799c1b50de4d 100644 --- a/ydb/core/ymq/actor/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/ymq/actor/ut/CMakeLists.windows-x86_64.txt @@ -55,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/actor/yc_search_ut/CMakeLists.darwin-arm64.txt b/ydb/core/ymq/actor/yc_search_ut/CMakeLists.darwin-arm64.txt index 03abbfb802cc..e29be46e8dc6 100644 --- a/ydb/core/ymq/actor/yc_search_ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/ymq/actor/yc_search_ut/CMakeLists.darwin-arm64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-core-ymq-actor-yc_search_ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-ymq-actor-yc_search_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/actor/yc_search_ut/index_events_processor_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/actor/yc_search_ut/CMakeLists.darwin-x86_64.txt b/ydb/core/ymq/actor/yc_search_ut/CMakeLists.darwin-x86_64.txt index a63cf5f38b5f..eb0f91952af1 100644 --- a/ydb/core/ymq/actor/yc_search_ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/ymq/actor/yc_search_ut/CMakeLists.darwin-x86_64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-core-ymq-actor-yc_search_ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-ymq-actor-yc_search_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/actor/yc_search_ut/index_events_processor_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/actor/yc_search_ut/CMakeLists.linux-aarch64.txt b/ydb/core/ymq/actor/yc_search_ut/CMakeLists.linux-aarch64.txt index 4a78e903cd33..e1c453987cb8 100644 --- a/ydb/core/ymq/actor/yc_search_ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/ymq/actor/yc_search_ut/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-core-ymq-actor-yc_search_ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-ymq-actor-yc_search_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/actor/yc_search_ut/index_events_processor_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/actor/yc_search_ut/CMakeLists.linux-x86_64.txt b/ydb/core/ymq/actor/yc_search_ut/CMakeLists.linux-x86_64.txt index c1a30c4bffec..d8440ef66e67 100644 --- a/ydb/core/ymq/actor/yc_search_ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/ymq/actor/yc_search_ut/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-core-ymq-actor-yc_search_ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-ymq-actor-yc_search_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/actor/yc_search_ut/index_events_processor_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/actor/yc_search_ut/CMakeLists.windows-x86_64.txt b/ydb/core/ymq/actor/yc_search_ut/CMakeLists.windows-x86_64.txt index 208c4d89fa7e..dab52968fe0c 100644 --- a/ydb/core/ymq/actor/yc_search_ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/ymq/actor/yc_search_ut/CMakeLists.windows-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/base/CMakeLists.darwin-arm64.txt b/ydb/core/ymq/base/CMakeLists.darwin-arm64.txt index 3ddb1bd7253d..5735e6dc32bb 100644 --- a/ydb/core/ymq/base/CMakeLists.darwin-arm64.txt +++ b/ydb/core/ymq/base/CMakeLists.darwin-arm64.txt @@ -44,6 +44,7 @@ target_link_libraries(core-ymq-base PUBLIC public-lib-scheme_types ) target_sources(core-ymq-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/events_writer_iface.h ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/acl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/action.cpp ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/counters.cpp diff --git a/ydb/core/ymq/base/CMakeLists.darwin-x86_64.txt b/ydb/core/ymq/base/CMakeLists.darwin-x86_64.txt index 3ddb1bd7253d..5735e6dc32bb 100644 --- a/ydb/core/ymq/base/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/ymq/base/CMakeLists.darwin-x86_64.txt @@ -44,6 +44,7 @@ target_link_libraries(core-ymq-base PUBLIC public-lib-scheme_types ) target_sources(core-ymq-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/events_writer_iface.h ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/acl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/action.cpp ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/counters.cpp diff --git a/ydb/core/ymq/base/CMakeLists.linux-aarch64.txt b/ydb/core/ymq/base/CMakeLists.linux-aarch64.txt index 4f9bc2b6d93e..68e3d22f3dec 100644 --- a/ydb/core/ymq/base/CMakeLists.linux-aarch64.txt +++ b/ydb/core/ymq/base/CMakeLists.linux-aarch64.txt @@ -45,6 +45,7 @@ target_link_libraries(core-ymq-base PUBLIC public-lib-scheme_types ) target_sources(core-ymq-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/events_writer_iface.h ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/acl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/action.cpp ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/counters.cpp diff --git a/ydb/core/ymq/base/CMakeLists.linux-x86_64.txt b/ydb/core/ymq/base/CMakeLists.linux-x86_64.txt index 4f9bc2b6d93e..68e3d22f3dec 100644 --- a/ydb/core/ymq/base/CMakeLists.linux-x86_64.txt +++ b/ydb/core/ymq/base/CMakeLists.linux-x86_64.txt @@ -45,6 +45,7 @@ target_link_libraries(core-ymq-base PUBLIC public-lib-scheme_types ) target_sources(core-ymq-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/events_writer_iface.h ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/acl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/action.cpp ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/counters.cpp diff --git a/ydb/core/ymq/base/CMakeLists.windows-x86_64.txt b/ydb/core/ymq/base/CMakeLists.windows-x86_64.txt index 3ddb1bd7253d..5735e6dc32bb 100644 --- a/ydb/core/ymq/base/CMakeLists.windows-x86_64.txt +++ b/ydb/core/ymq/base/CMakeLists.windows-x86_64.txt @@ -44,6 +44,7 @@ target_link_libraries(core-ymq-base PUBLIC public-lib-scheme_types ) target_sources(core-ymq-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/events_writer_iface.h ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/acl.cpp ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/action.cpp ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/counters.cpp diff --git a/ydb/core/ymq/base/ut/CMakeLists.darwin-arm64.txt b/ydb/core/ymq/base/ut/CMakeLists.darwin-arm64.txt index 3c52b2d2204f..e9a3adac7461 100644 --- a/ydb/core/ymq/base/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/ymq/base/ut/CMakeLists.darwin-arm64.txt @@ -19,8 +19,6 @@ target_link_options(ydb-core-ymq-base-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-ymq-base-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/ut/action_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/base/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/ymq/base/ut/CMakeLists.darwin-x86_64.txt index 908dcf9d0e75..24b58556a934 100644 --- a/ydb/core/ymq/base/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/ymq/base/ut/CMakeLists.darwin-x86_64.txt @@ -20,8 +20,6 @@ target_link_options(ydb-core-ymq-base-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-ymq-base-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/ut/action_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/base/ut/CMakeLists.linux-aarch64.txt b/ydb/core/ymq/base/ut/CMakeLists.linux-aarch64.txt index 3cfaba190fca..04814a1f560b 100644 --- a/ydb/core/ymq/base/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/ymq/base/ut/CMakeLists.linux-aarch64.txt @@ -22,9 +22,6 @@ target_link_options(ydb-core-ymq-base-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-ymq-base-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/ut/action_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/base/ut/CMakeLists.linux-x86_64.txt b/ydb/core/ymq/base/ut/CMakeLists.linux-x86_64.txt index 6d5983633fb2..2b2f4d4abaa3 100644 --- a/ydb/core/ymq/base/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/ymq/base/ut/CMakeLists.linux-x86_64.txt @@ -23,9 +23,6 @@ target_link_options(ydb-core-ymq-base-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-ymq-base-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/base/ut/action_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/base/ut/CMakeLists.windows-x86_64.txt b/ydb/core/ymq/base/ut/CMakeLists.windows-x86_64.txt index fe10fdab8ea8..1fe40d67404f 100644 --- a/ydb/core/ymq/base/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/ymq/base/ut/CMakeLists.windows-x86_64.txt @@ -49,6 +49,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/client/bin/CMakeLists.darwin-arm64.txt b/ydb/core/ymq/client/bin/CMakeLists.darwin-arm64.txt index f7bb00de924a..e9b52fbae24c 100644 --- a/ydb/core/ymq/client/bin/CMakeLists.darwin-arm64.txt +++ b/ydb/core/ymq/client/bin/CMakeLists.darwin-arm64.txt @@ -19,8 +19,6 @@ target_link_options(sqs PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(sqs PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/client/bin/main.cpp diff --git a/ydb/core/ymq/client/bin/CMakeLists.darwin-x86_64.txt b/ydb/core/ymq/client/bin/CMakeLists.darwin-x86_64.txt index a2810b4b2f9e..1ea590548005 100644 --- a/ydb/core/ymq/client/bin/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/ymq/client/bin/CMakeLists.darwin-x86_64.txt @@ -20,8 +20,6 @@ target_link_options(sqs PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(sqs PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/client/bin/main.cpp diff --git a/ydb/core/ymq/client/bin/CMakeLists.linux-aarch64.txt b/ydb/core/ymq/client/bin/CMakeLists.linux-aarch64.txt index 02904ecbfba9..1216e72178b0 100644 --- a/ydb/core/ymq/client/bin/CMakeLists.linux-aarch64.txt +++ b/ydb/core/ymq/client/bin/CMakeLists.linux-aarch64.txt @@ -22,9 +22,6 @@ target_link_options(sqs PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(sqs PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/client/bin/main.cpp diff --git a/ydb/core/ymq/client/bin/CMakeLists.linux-x86_64.txt b/ydb/core/ymq/client/bin/CMakeLists.linux-x86_64.txt index 768a4762861e..0e9867411f4a 100644 --- a/ydb/core/ymq/client/bin/CMakeLists.linux-x86_64.txt +++ b/ydb/core/ymq/client/bin/CMakeLists.linux-x86_64.txt @@ -23,9 +23,6 @@ target_link_options(sqs PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(sqs PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/client/bin/main.cpp diff --git a/ydb/core/ymq/http/ut/CMakeLists.darwin-arm64.txt b/ydb/core/ymq/http/ut/CMakeLists.darwin-arm64.txt index 5ab62098a5ba..213560c39a38 100644 --- a/ydb/core/ymq/http/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/ymq/http/ut/CMakeLists.darwin-arm64.txt @@ -20,8 +20,6 @@ target_link_options(ydb-core-ymq-http-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-ymq-http-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/http/ut/xml_builder_ut.cpp @@ -51,6 +49,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/http/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/ymq/http/ut/CMakeLists.darwin-x86_64.txt index fedc91397e7c..14784d3249af 100644 --- a/ydb/core/ymq/http/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/ymq/http/ut/CMakeLists.darwin-x86_64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-core-ymq-http-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-ymq-http-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/http/ut/xml_builder_ut.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/http/ut/CMakeLists.linux-aarch64.txt b/ydb/core/ymq/http/ut/CMakeLists.linux-aarch64.txt index afdca5e83a2d..bf078a2a4e0b 100644 --- a/ydb/core/ymq/http/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/ymq/http/ut/CMakeLists.linux-aarch64.txt @@ -23,9 +23,6 @@ target_link_options(ydb-core-ymq-http-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-ymq-http-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/http/ut/xml_builder_ut.cpp @@ -55,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/http/ut/CMakeLists.linux-x86_64.txt b/ydb/core/ymq/http/ut/CMakeLists.linux-x86_64.txt index 1d3ff48fa3dc..2994b52321ef 100644 --- a/ydb/core/ymq/http/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/ymq/http/ut/CMakeLists.linux-x86_64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-core-ymq-http-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-ymq-http-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/http/ut/xml_builder_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/http/ut/CMakeLists.windows-x86_64.txt b/ydb/core/ymq/http/ut/CMakeLists.windows-x86_64.txt index da699adb6b7b..c590f5b6486e 100644 --- a/ydb/core/ymq/http/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/ymq/http/ut/CMakeLists.windows-x86_64.txt @@ -45,6 +45,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/proto/CMakeLists.darwin-arm64.txt b/ydb/core/ymq/proto/CMakeLists.darwin-arm64.txt index 187b3709ebf8..23a3156706b0 100644 --- a/ydb/core/ymq/proto/CMakeLists.darwin-arm64.txt +++ b/ydb/core/ymq/proto/CMakeLists.darwin-arm64.txt @@ -42,6 +42,10 @@ target_proto_messages(core-ymq-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/proto/events.proto ${CMAKE_SOURCE_DIR}/ydb/core/ymq/proto/records.proto ) +target_sources(core-ymq-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/ymq/proto/events.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/ymq/proto/records.pb.h +) target_proto_addincls(core-ymq-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/ymq/proto/CMakeLists.darwin-x86_64.txt b/ydb/core/ymq/proto/CMakeLists.darwin-x86_64.txt index 187b3709ebf8..23a3156706b0 100644 --- a/ydb/core/ymq/proto/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/ymq/proto/CMakeLists.darwin-x86_64.txt @@ -42,6 +42,10 @@ target_proto_messages(core-ymq-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/proto/events.proto ${CMAKE_SOURCE_DIR}/ydb/core/ymq/proto/records.proto ) +target_sources(core-ymq-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/ymq/proto/events.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/ymq/proto/records.pb.h +) target_proto_addincls(core-ymq-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/ymq/proto/CMakeLists.linux-aarch64.txt b/ydb/core/ymq/proto/CMakeLists.linux-aarch64.txt index ddf57faa3fb8..daf7e5faa954 100644 --- a/ydb/core/ymq/proto/CMakeLists.linux-aarch64.txt +++ b/ydb/core/ymq/proto/CMakeLists.linux-aarch64.txt @@ -43,6 +43,10 @@ target_proto_messages(core-ymq-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/proto/events.proto ${CMAKE_SOURCE_DIR}/ydb/core/ymq/proto/records.proto ) +target_sources(core-ymq-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/ymq/proto/events.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/ymq/proto/records.pb.h +) target_proto_addincls(core-ymq-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/ymq/proto/CMakeLists.linux-x86_64.txt b/ydb/core/ymq/proto/CMakeLists.linux-x86_64.txt index ddf57faa3fb8..daf7e5faa954 100644 --- a/ydb/core/ymq/proto/CMakeLists.linux-x86_64.txt +++ b/ydb/core/ymq/proto/CMakeLists.linux-x86_64.txt @@ -43,6 +43,10 @@ target_proto_messages(core-ymq-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/proto/events.proto ${CMAKE_SOURCE_DIR}/ydb/core/ymq/proto/records.proto ) +target_sources(core-ymq-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/ymq/proto/events.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/ymq/proto/records.pb.h +) target_proto_addincls(core-ymq-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/ymq/proto/CMakeLists.windows-x86_64.txt b/ydb/core/ymq/proto/CMakeLists.windows-x86_64.txt index 187b3709ebf8..23a3156706b0 100644 --- a/ydb/core/ymq/proto/CMakeLists.windows-x86_64.txt +++ b/ydb/core/ymq/proto/CMakeLists.windows-x86_64.txt @@ -42,6 +42,10 @@ target_proto_messages(core-ymq-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/proto/events.proto ${CMAKE_SOURCE_DIR}/ydb/core/ymq/proto/records.proto ) +target_sources(core-ymq-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/ymq/proto/events.pb.h + ${CMAKE_BINARY_DIR}/ydb/core/ymq/proto/records.pb.h +) target_proto_addincls(core-ymq-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/core/ymq/ut/CMakeLists.darwin-arm64.txt b/ydb/core/ymq/ut/CMakeLists.darwin-arm64.txt index dd630e396cc5..e0273ee60630 100644 --- a/ydb/core/ymq/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/ymq/ut/CMakeLists.darwin-arm64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-core-ymq-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-ymq-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/ut/queue_id_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/ymq/ut/CMakeLists.darwin-x86_64.txt index 2663304588c2..e21aad2e413b 100644 --- a/ydb/core/ymq/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/ymq/ut/CMakeLists.darwin-x86_64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-core-ymq-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-core-ymq-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/ut/queue_id_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/ut/CMakeLists.linux-aarch64.txt b/ydb/core/ymq/ut/CMakeLists.linux-aarch64.txt index 416c7da4881e..4bd4343a988e 100644 --- a/ydb/core/ymq/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/ymq/ut/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-core-ymq-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-ymq-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/ut/queue_id_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/ut/CMakeLists.linux-x86_64.txt b/ydb/core/ymq/ut/CMakeLists.linux-x86_64.txt index e94f43220686..5d6822644ad7 100644 --- a/ydb/core/ymq/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/ymq/ut/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-core-ymq-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-core-ymq-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/ymq/ut/queue_id_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/ymq/ut/CMakeLists.windows-x86_64.txt b/ydb/core/ymq/ut/CMakeLists.windows-x86_64.txt index 0eb56d33b956..d6e78f0a25da 100644 --- a/ydb/core/ymq/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/ymq/ut/CMakeLists.windows-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/core/yql_testlib/CMakeLists.darwin-arm64.txt b/ydb/core/yql_testlib/CMakeLists.darwin-arm64.txt index 0c60bab274bb..cd6bc9bbcc9a 100644 --- a/ydb/core/yql_testlib/CMakeLists.darwin-arm64.txt +++ b/ydb/core/yql_testlib/CMakeLists.darwin-arm64.txt @@ -36,5 +36,6 @@ target_link_libraries(ydb-core-yql_testlib PUBLIC providers-common-udf_resolve ) target_sources(ydb-core-yql_testlib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/yql_testlib/yql_testlib.h ${CMAKE_SOURCE_DIR}/ydb/core/yql_testlib/yql_testlib.cpp ) diff --git a/ydb/core/yql_testlib/CMakeLists.darwin-x86_64.txt b/ydb/core/yql_testlib/CMakeLists.darwin-x86_64.txt index 0c60bab274bb..cd6bc9bbcc9a 100644 --- a/ydb/core/yql_testlib/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/yql_testlib/CMakeLists.darwin-x86_64.txt @@ -36,5 +36,6 @@ target_link_libraries(ydb-core-yql_testlib PUBLIC providers-common-udf_resolve ) target_sources(ydb-core-yql_testlib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/yql_testlib/yql_testlib.h ${CMAKE_SOURCE_DIR}/ydb/core/yql_testlib/yql_testlib.cpp ) diff --git a/ydb/core/yql_testlib/CMakeLists.linux-aarch64.txt b/ydb/core/yql_testlib/CMakeLists.linux-aarch64.txt index 5e23e5d64e2c..9a856970dbc4 100644 --- a/ydb/core/yql_testlib/CMakeLists.linux-aarch64.txt +++ b/ydb/core/yql_testlib/CMakeLists.linux-aarch64.txt @@ -37,5 +37,6 @@ target_link_libraries(ydb-core-yql_testlib PUBLIC providers-common-udf_resolve ) target_sources(ydb-core-yql_testlib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/yql_testlib/yql_testlib.h ${CMAKE_SOURCE_DIR}/ydb/core/yql_testlib/yql_testlib.cpp ) diff --git a/ydb/core/yql_testlib/CMakeLists.linux-x86_64.txt b/ydb/core/yql_testlib/CMakeLists.linux-x86_64.txt index 5e23e5d64e2c..9a856970dbc4 100644 --- a/ydb/core/yql_testlib/CMakeLists.linux-x86_64.txt +++ b/ydb/core/yql_testlib/CMakeLists.linux-x86_64.txt @@ -37,5 +37,6 @@ target_link_libraries(ydb-core-yql_testlib PUBLIC providers-common-udf_resolve ) target_sources(ydb-core-yql_testlib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/yql_testlib/yql_testlib.h ${CMAKE_SOURCE_DIR}/ydb/core/yql_testlib/yql_testlib.cpp ) diff --git a/ydb/core/yql_testlib/CMakeLists.windows-x86_64.txt b/ydb/core/yql_testlib/CMakeLists.windows-x86_64.txt index 0c60bab274bb..cd6bc9bbcc9a 100644 --- a/ydb/core/yql_testlib/CMakeLists.windows-x86_64.txt +++ b/ydb/core/yql_testlib/CMakeLists.windows-x86_64.txt @@ -36,5 +36,6 @@ target_link_libraries(ydb-core-yql_testlib PUBLIC providers-common-udf_resolve ) target_sources(ydb-core-yql_testlib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/yql_testlib/yql_testlib.h ${CMAKE_SOURCE_DIR}/ydb/core/yql_testlib/yql_testlib.cpp ) diff --git a/ydb/library/CMakeLists.txt b/ydb/library/CMakeLists.txt index 9bcf016a7b5f..6ce0b87bd8aa 100644 --- a/ydb/library/CMakeLists.txt +++ b/ydb/library/CMakeLists.txt @@ -11,6 +11,7 @@ add_subdirectory(aclib) add_subdirectory(actors) add_subdirectory(arrow_clickhouse) add_subdirectory(arrow_kernels) +add_subdirectory(arrow_parquet) add_subdirectory(backup) add_subdirectory(binary_json) add_subdirectory(chunks_limiter) diff --git a/ydb/library/accessor/CMakeLists.darwin-arm64.txt b/ydb/library/accessor/CMakeLists.darwin-arm64.txt index c2a284076f84..9b03fdbf606d 100644 --- a/ydb/library/accessor/CMakeLists.darwin-arm64.txt +++ b/ydb/library/accessor/CMakeLists.darwin-arm64.txt @@ -11,7 +11,9 @@ add_library(ydb-library-accessor) target_link_libraries(ydb-library-accessor PUBLIC contrib-libs-cxxsupp yutil + library-actors-core ) target_sources(ydb-library-accessor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/accessor/accessor.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/accessor/validator.cpp ) diff --git a/ydb/library/accessor/CMakeLists.darwin-x86_64.txt b/ydb/library/accessor/CMakeLists.darwin-x86_64.txt index c2a284076f84..9b03fdbf606d 100644 --- a/ydb/library/accessor/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/accessor/CMakeLists.darwin-x86_64.txt @@ -11,7 +11,9 @@ add_library(ydb-library-accessor) target_link_libraries(ydb-library-accessor PUBLIC contrib-libs-cxxsupp yutil + library-actors-core ) target_sources(ydb-library-accessor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/accessor/accessor.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/accessor/validator.cpp ) diff --git a/ydb/library/accessor/CMakeLists.linux-aarch64.txt b/ydb/library/accessor/CMakeLists.linux-aarch64.txt index d233360f6a17..87967ba851cd 100644 --- a/ydb/library/accessor/CMakeLists.linux-aarch64.txt +++ b/ydb/library/accessor/CMakeLists.linux-aarch64.txt @@ -12,7 +12,9 @@ target_link_libraries(ydb-library-accessor PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + library-actors-core ) target_sources(ydb-library-accessor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/accessor/accessor.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/accessor/validator.cpp ) diff --git a/ydb/library/accessor/CMakeLists.linux-x86_64.txt b/ydb/library/accessor/CMakeLists.linux-x86_64.txt index d233360f6a17..87967ba851cd 100644 --- a/ydb/library/accessor/CMakeLists.linux-x86_64.txt +++ b/ydb/library/accessor/CMakeLists.linux-x86_64.txt @@ -12,7 +12,9 @@ target_link_libraries(ydb-library-accessor PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + library-actors-core ) target_sources(ydb-library-accessor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/accessor/accessor.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/accessor/validator.cpp ) diff --git a/ydb/library/accessor/CMakeLists.windows-x86_64.txt b/ydb/library/accessor/CMakeLists.windows-x86_64.txt index c2a284076f84..9b03fdbf606d 100644 --- a/ydb/library/accessor/CMakeLists.windows-x86_64.txt +++ b/ydb/library/accessor/CMakeLists.windows-x86_64.txt @@ -11,7 +11,9 @@ add_library(ydb-library-accessor) target_link_libraries(ydb-library-accessor PUBLIC contrib-libs-cxxsupp yutil + library-actors-core ) target_sources(ydb-library-accessor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/accessor/accessor.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/accessor/validator.cpp ) diff --git a/ydb/library/aclib/CMakeLists.darwin-arm64.txt b/ydb/library/aclib/CMakeLists.darwin-arm64.txt index 336127fc2684..8c7633a7f452 100644 --- a/ydb/library/aclib/CMakeLists.darwin-arm64.txt +++ b/ydb/library/aclib/CMakeLists.darwin-arm64.txt @@ -18,5 +18,6 @@ target_link_libraries(ydb-library-aclib PUBLIC library-aclib-protos ) target_sources(ydb-library-aclib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/aclib/aclib.h ${CMAKE_SOURCE_DIR}/ydb/library/aclib/aclib.cpp ) diff --git a/ydb/library/aclib/CMakeLists.darwin-x86_64.txt b/ydb/library/aclib/CMakeLists.darwin-x86_64.txt index 336127fc2684..8c7633a7f452 100644 --- a/ydb/library/aclib/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/aclib/CMakeLists.darwin-x86_64.txt @@ -18,5 +18,6 @@ target_link_libraries(ydb-library-aclib PUBLIC library-aclib-protos ) target_sources(ydb-library-aclib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/aclib/aclib.h ${CMAKE_SOURCE_DIR}/ydb/library/aclib/aclib.cpp ) diff --git a/ydb/library/aclib/CMakeLists.linux-aarch64.txt b/ydb/library/aclib/CMakeLists.linux-aarch64.txt index 148291a94bfe..188748cc86e0 100644 --- a/ydb/library/aclib/CMakeLists.linux-aarch64.txt +++ b/ydb/library/aclib/CMakeLists.linux-aarch64.txt @@ -19,5 +19,6 @@ target_link_libraries(ydb-library-aclib PUBLIC library-aclib-protos ) target_sources(ydb-library-aclib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/aclib/aclib.h ${CMAKE_SOURCE_DIR}/ydb/library/aclib/aclib.cpp ) diff --git a/ydb/library/aclib/CMakeLists.linux-x86_64.txt b/ydb/library/aclib/CMakeLists.linux-x86_64.txt index 148291a94bfe..188748cc86e0 100644 --- a/ydb/library/aclib/CMakeLists.linux-x86_64.txt +++ b/ydb/library/aclib/CMakeLists.linux-x86_64.txt @@ -19,5 +19,6 @@ target_link_libraries(ydb-library-aclib PUBLIC library-aclib-protos ) target_sources(ydb-library-aclib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/aclib/aclib.h ${CMAKE_SOURCE_DIR}/ydb/library/aclib/aclib.cpp ) diff --git a/ydb/library/aclib/CMakeLists.windows-x86_64.txt b/ydb/library/aclib/CMakeLists.windows-x86_64.txt index 336127fc2684..8c7633a7f452 100644 --- a/ydb/library/aclib/CMakeLists.windows-x86_64.txt +++ b/ydb/library/aclib/CMakeLists.windows-x86_64.txt @@ -18,5 +18,6 @@ target_link_libraries(ydb-library-aclib PUBLIC library-aclib-protos ) target_sources(ydb-library-aclib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/aclib/aclib.h ${CMAKE_SOURCE_DIR}/ydb/library/aclib/aclib.cpp ) diff --git a/ydb/library/aclib/protos/CMakeLists.darwin-arm64.txt b/ydb/library/aclib/protos/CMakeLists.darwin-arm64.txt index d23f61eba431..8a0eaad714b9 100644 --- a/ydb/library/aclib/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/library/aclib/protos/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(library-aclib-protos PUBLIC target_proto_messages(library-aclib-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/aclib/protos/aclib.proto ) +target_sources(library-aclib-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/aclib/protos/aclib.pb.h +) target_proto_addincls(library-aclib-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/aclib/protos/CMakeLists.darwin-x86_64.txt b/ydb/library/aclib/protos/CMakeLists.darwin-x86_64.txt index d23f61eba431..8a0eaad714b9 100644 --- a/ydb/library/aclib/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/aclib/protos/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(library-aclib-protos PUBLIC target_proto_messages(library-aclib-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/aclib/protos/aclib.proto ) +target_sources(library-aclib-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/aclib/protos/aclib.pb.h +) target_proto_addincls(library-aclib-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/aclib/protos/CMakeLists.linux-aarch64.txt b/ydb/library/aclib/protos/CMakeLists.linux-aarch64.txt index 361dd6900710..d32e6b04dad1 100644 --- a/ydb/library/aclib/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/library/aclib/protos/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(library-aclib-protos PUBLIC target_proto_messages(library-aclib-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/aclib/protos/aclib.proto ) +target_sources(library-aclib-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/aclib/protos/aclib.pb.h +) target_proto_addincls(library-aclib-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/aclib/protos/CMakeLists.linux-x86_64.txt b/ydb/library/aclib/protos/CMakeLists.linux-x86_64.txt index 361dd6900710..d32e6b04dad1 100644 --- a/ydb/library/aclib/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/library/aclib/protos/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(library-aclib-protos PUBLIC target_proto_messages(library-aclib-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/aclib/protos/aclib.proto ) +target_sources(library-aclib-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/aclib/protos/aclib.pb.h +) target_proto_addincls(library-aclib-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/aclib/protos/CMakeLists.windows-x86_64.txt b/ydb/library/aclib/protos/CMakeLists.windows-x86_64.txt index d23f61eba431..8a0eaad714b9 100644 --- a/ydb/library/aclib/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/library/aclib/protos/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(library-aclib-protos PUBLIC target_proto_messages(library-aclib-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/aclib/protos/aclib.proto ) +target_sources(library-aclib-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/aclib/protos/aclib.pb.h +) target_proto_addincls(library-aclib-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/aclib/ut/CMakeLists.darwin-arm64.txt b/ydb/library/aclib/ut/CMakeLists.darwin-arm64.txt index 12f0fd0a474c..eb3a31bd6ddd 100644 --- a/ydb/library/aclib/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/aclib/ut/CMakeLists.darwin-arm64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/aclib/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/aclib/ut/CMakeLists.darwin-x86_64.txt index 855e04c0cfca..fc161a0aab05 100644 --- a/ydb/library/aclib/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/aclib/ut/CMakeLists.darwin-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/aclib/ut/CMakeLists.linux-aarch64.txt b/ydb/library/aclib/ut/CMakeLists.linux-aarch64.txt index 922aea54e61f..3e1e5dd3d1b9 100644 --- a/ydb/library/aclib/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/aclib/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-aclib-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-aclib-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/aclib/aclib_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/aclib/ut/CMakeLists.linux-x86_64.txt b/ydb/library/aclib/ut/CMakeLists.linux-x86_64.txt index 8f4c41ddf71b..cce8f4614065 100644 --- a/ydb/library/aclib/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/aclib/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-aclib-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-aclib-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/aclib/aclib_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/aclib/ut/CMakeLists.windows-x86_64.txt b/ydb/library/aclib/ut/CMakeLists.windows-x86_64.txt index bdb59fb4acd4..20b7b8847951 100644 --- a/ydb/library/aclib/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/aclib/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/core/CMakeLists.darwin-arm64.txt b/ydb/library/actors/core/CMakeLists.darwin-arm64.txt index f85da8cdc686..bed6b44e2682 100644 --- a/ydb/library/actors/core/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/core/CMakeLists.darwin-arm64.txt @@ -47,6 +47,52 @@ target_link_libraries(library-actors-core PUBLIC cpp-threading-future ) target_sources(library-actors-core PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor_coroutine.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actorid.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actorsystem.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/ask.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/buffer.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/callstack.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/config.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/cpu_manager.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/cpu_state.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/event.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/event_local.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/event_pb.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/events.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executelater.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_base.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_basic.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_io.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_shared.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_thread.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/harmonizer.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/hfunc.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/interconnect.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/invoke.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/io_dispatcher.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/lease.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/log.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/log_settings.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/log_buffer.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/log_metrics.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mailbox.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mailbox_queue_revolving.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mailbox_queue_simple.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mon.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mon_stats.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/monotonic.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/monotonic_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/worker_context.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/probes.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/process_stats.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/scheduler_actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/scheduler_basic.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/scheduler_cookie.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/scheduler_queue.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/servicemap.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor_bootstrapped.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor_coroutine.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor.cpp @@ -65,6 +111,7 @@ target_sources(library-actors-core PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_base.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_basic.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_io.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_shared.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_thread.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/harmonizer.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/interconnect.cpp diff --git a/ydb/library/actors/core/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/core/CMakeLists.darwin-x86_64.txt index f85da8cdc686..bed6b44e2682 100644 --- a/ydb/library/actors/core/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/core/CMakeLists.darwin-x86_64.txt @@ -47,6 +47,52 @@ target_link_libraries(library-actors-core PUBLIC cpp-threading-future ) target_sources(library-actors-core PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor_coroutine.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actorid.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actorsystem.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/ask.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/buffer.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/callstack.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/config.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/cpu_manager.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/cpu_state.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/event.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/event_local.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/event_pb.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/events.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executelater.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_base.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_basic.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_io.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_shared.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_thread.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/harmonizer.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/hfunc.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/interconnect.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/invoke.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/io_dispatcher.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/lease.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/log.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/log_settings.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/log_buffer.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/log_metrics.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mailbox.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mailbox_queue_revolving.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mailbox_queue_simple.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mon.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mon_stats.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/monotonic.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/monotonic_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/worker_context.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/probes.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/process_stats.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/scheduler_actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/scheduler_basic.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/scheduler_cookie.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/scheduler_queue.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/servicemap.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor_bootstrapped.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor_coroutine.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor.cpp @@ -65,6 +111,7 @@ target_sources(library-actors-core PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_base.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_basic.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_io.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_shared.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_thread.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/harmonizer.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/interconnect.cpp diff --git a/ydb/library/actors/core/CMakeLists.linux-aarch64.txt b/ydb/library/actors/core/CMakeLists.linux-aarch64.txt index cf33f599690b..7d123876753f 100644 --- a/ydb/library/actors/core/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/core/CMakeLists.linux-aarch64.txt @@ -48,6 +48,52 @@ target_link_libraries(library-actors-core PUBLIC cpp-threading-future ) target_sources(library-actors-core PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor_coroutine.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actorid.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actorsystem.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/ask.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/buffer.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/callstack.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/config.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/cpu_manager.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/cpu_state.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/event.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/event_local.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/event_pb.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/events.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executelater.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_base.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_basic.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_io.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_shared.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_thread.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/harmonizer.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/hfunc.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/interconnect.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/invoke.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/io_dispatcher.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/lease.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/log.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/log_settings.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/log_buffer.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/log_metrics.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mailbox.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mailbox_queue_revolving.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mailbox_queue_simple.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mon.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mon_stats.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/monotonic.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/monotonic_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/worker_context.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/probes.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/process_stats.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/scheduler_actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/scheduler_basic.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/scheduler_cookie.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/scheduler_queue.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/servicemap.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor_bootstrapped.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor_coroutine.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor.cpp @@ -66,6 +112,7 @@ target_sources(library-actors-core PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_base.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_basic.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_io.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_shared.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_thread.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/harmonizer.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/interconnect.cpp diff --git a/ydb/library/actors/core/CMakeLists.linux-x86_64.txt b/ydb/library/actors/core/CMakeLists.linux-x86_64.txt index cf33f599690b..7d123876753f 100644 --- a/ydb/library/actors/core/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/core/CMakeLists.linux-x86_64.txt @@ -48,6 +48,52 @@ target_link_libraries(library-actors-core PUBLIC cpp-threading-future ) target_sources(library-actors-core PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor_coroutine.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actorid.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actorsystem.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/ask.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/buffer.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/callstack.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/config.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/cpu_manager.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/cpu_state.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/event.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/event_local.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/event_pb.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/events.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executelater.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_base.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_basic.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_io.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_shared.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_thread.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/harmonizer.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/hfunc.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/interconnect.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/invoke.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/io_dispatcher.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/lease.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/log.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/log_settings.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/log_buffer.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/log_metrics.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mailbox.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mailbox_queue_revolving.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mailbox_queue_simple.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mon.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mon_stats.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/monotonic.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/monotonic_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/worker_context.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/probes.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/process_stats.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/scheduler_actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/scheduler_basic.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/scheduler_cookie.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/scheduler_queue.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/servicemap.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor_bootstrapped.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor_coroutine.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor.cpp @@ -66,6 +112,7 @@ target_sources(library-actors-core PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_base.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_basic.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_io.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_shared.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_thread.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/harmonizer.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/interconnect.cpp diff --git a/ydb/library/actors/core/CMakeLists.windows-x86_64.txt b/ydb/library/actors/core/CMakeLists.windows-x86_64.txt index f85da8cdc686..bed6b44e2682 100644 --- a/ydb/library/actors/core/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/core/CMakeLists.windows-x86_64.txt @@ -47,6 +47,52 @@ target_link_libraries(library-actors-core PUBLIC cpp-threading-future ) target_sources(library-actors-core PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor_coroutine.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actorid.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actorsystem.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/ask.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/buffer.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/callstack.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/config.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/cpu_manager.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/cpu_state.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/event.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/event_local.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/event_pb.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/events.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executelater.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_base.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_basic.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_io.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_shared.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_thread.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/harmonizer.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/hfunc.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/interconnect.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/invoke.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/io_dispatcher.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/lease.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/log.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/log_settings.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/log_buffer.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/log_metrics.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mailbox.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mailbox_queue_revolving.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mailbox_queue_simple.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mon.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/mon_stats.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/monotonic.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/monotonic_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/worker_context.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/probes.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/process_stats.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/scheduler_actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/scheduler_basic.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/scheduler_cookie.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/scheduler_queue.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/servicemap.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor_bootstrapped.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor_coroutine.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor.cpp @@ -65,6 +111,7 @@ target_sources(library-actors-core PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_base.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_basic.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_io.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_pool_shared.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/executor_thread.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/harmonizer.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/interconnect.cpp diff --git a/ydb/library/actors/core/ut/CMakeLists.darwin-arm64.txt b/ydb/library/actors/core/ut/CMakeLists.darwin-arm64.txt index 98e9cdcae187..5d6267159019 100644 --- a/ydb/library/actors/core/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/core/ut/CMakeLists.darwin-arm64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-library-actors-core-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-core-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor_coroutine_ut.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/core/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/core/ut/CMakeLists.darwin-x86_64.txt index d20fbe3e959e..e1315d1a38df 100644 --- a/ydb/library/actors/core/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/core/ut/CMakeLists.darwin-x86_64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-library-actors-core-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-core-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor_coroutine_ut.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/core/ut/CMakeLists.linux-aarch64.txt b/ydb/library/actors/core/ut/CMakeLists.linux-aarch64.txt index e47e5555b121..f928be9953d2 100644 --- a/ydb/library/actors/core/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/core/ut/CMakeLists.linux-aarch64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-library-actors-core-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-core-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor_coroutine_ut.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/core/ut/CMakeLists.linux-x86_64.txt b/ydb/library/actors/core/ut/CMakeLists.linux-x86_64.txt index 4610ee7de376..e7052e1054e7 100644 --- a/ydb/library/actors/core/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/core/ut/CMakeLists.linux-x86_64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-library-actors-core-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-core-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/actor_coroutine_ut.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/core/ut/CMakeLists.windows-x86_64.txt b/ydb/library/actors/core/ut/CMakeLists.windows-x86_64.txt index c3834bf41d99..b4a9d14743ad 100644 --- a/ydb/library/actors/core/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/core/ut/CMakeLists.windows-x86_64.txt @@ -59,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/core/ut_fat/CMakeLists.darwin-arm64.txt b/ydb/library/actors/core/ut_fat/CMakeLists.darwin-arm64.txt index 3450db8c63b4..fa9fc3d9978d 100644 --- a/ydb/library/actors/core/ut_fat/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/core/ut_fat/CMakeLists.darwin-arm64.txt @@ -18,8 +18,6 @@ target_link_options(ydb-library-actors-core-ut_fat PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-core-ut_fat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/ut_fat/actor_benchmark.cpp @@ -49,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/core/ut_fat/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/core/ut_fat/CMakeLists.darwin-x86_64.txt index 52d1619cea94..313a27f66543 100644 --- a/ydb/library/actors/core/ut_fat/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/core/ut_fat/CMakeLists.darwin-x86_64.txt @@ -19,8 +19,6 @@ target_link_options(ydb-library-actors-core-ut_fat PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-core-ut_fat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/ut_fat/actor_benchmark.cpp @@ -50,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/core/ut_fat/CMakeLists.linux-aarch64.txt b/ydb/library/actors/core/ut_fat/CMakeLists.linux-aarch64.txt index 1efe7c22852d..895941c0c6ff 100644 --- a/ydb/library/actors/core/ut_fat/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/core/ut_fat/CMakeLists.linux-aarch64.txt @@ -21,9 +21,6 @@ target_link_options(ydb-library-actors-core-ut_fat PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-core-ut_fat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/ut_fat/actor_benchmark.cpp @@ -53,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/core/ut_fat/CMakeLists.linux-x86_64.txt b/ydb/library/actors/core/ut_fat/CMakeLists.linux-x86_64.txt index 1163a0cc02c6..d46c551f8ae3 100644 --- a/ydb/library/actors/core/ut_fat/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/core/ut_fat/CMakeLists.linux-x86_64.txt @@ -22,9 +22,6 @@ target_link_options(ydb-library-actors-core-ut_fat PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-core-ut_fat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/core/ut_fat/actor_benchmark.cpp @@ -54,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/core/ut_fat/CMakeLists.windows-x86_64.txt b/ydb/library/actors/core/ut_fat/CMakeLists.windows-x86_64.txt index d700cdd9e068..37d94c013664 100644 --- a/ydb/library/actors/core/ut_fat/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/core/ut_fat/CMakeLists.windows-x86_64.txt @@ -43,6 +43,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/cppcoro/CMakeLists.darwin-arm64.txt b/ydb/library/actors/cppcoro/CMakeLists.darwin-arm64.txt index 8e2847d70bed..e285be748e39 100644 --- a/ydb/library/actors/cppcoro/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/cppcoro/CMakeLists.darwin-arm64.txt @@ -16,6 +16,11 @@ target_link_libraries(library-actors-cppcoro PUBLIC library-actors-core ) target_sources(library-actors-cppcoro PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/await_callback.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_group.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_result.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/await_callback.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_group.cpp diff --git a/ydb/library/actors/cppcoro/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/cppcoro/CMakeLists.darwin-x86_64.txt index 8e2847d70bed..e285be748e39 100644 --- a/ydb/library/actors/cppcoro/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/cppcoro/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,11 @@ target_link_libraries(library-actors-cppcoro PUBLIC library-actors-core ) target_sources(library-actors-cppcoro PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/await_callback.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_group.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_result.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/await_callback.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_group.cpp diff --git a/ydb/library/actors/cppcoro/CMakeLists.linux-aarch64.txt b/ydb/library/actors/cppcoro/CMakeLists.linux-aarch64.txt index 1e8318081352..99586f910a63 100644 --- a/ydb/library/actors/cppcoro/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/cppcoro/CMakeLists.linux-aarch64.txt @@ -17,6 +17,11 @@ target_link_libraries(library-actors-cppcoro PUBLIC library-actors-core ) target_sources(library-actors-cppcoro PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/await_callback.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_group.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_result.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/await_callback.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_group.cpp diff --git a/ydb/library/actors/cppcoro/CMakeLists.linux-x86_64.txt b/ydb/library/actors/cppcoro/CMakeLists.linux-x86_64.txt index 1e8318081352..99586f910a63 100644 --- a/ydb/library/actors/cppcoro/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/cppcoro/CMakeLists.linux-x86_64.txt @@ -17,6 +17,11 @@ target_link_libraries(library-actors-cppcoro PUBLIC library-actors-core ) target_sources(library-actors-cppcoro PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/await_callback.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_group.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_result.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/await_callback.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_group.cpp diff --git a/ydb/library/actors/cppcoro/CMakeLists.windows-x86_64.txt b/ydb/library/actors/cppcoro/CMakeLists.windows-x86_64.txt index 8e2847d70bed..e285be748e39 100644 --- a/ydb/library/actors/cppcoro/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/cppcoro/CMakeLists.windows-x86_64.txt @@ -16,6 +16,11 @@ target_link_libraries(library-actors-cppcoro PUBLIC library-actors-core ) target_sources(library-actors-cppcoro PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/await_callback.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_group.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_result.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/await_callback.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_group.cpp diff --git a/ydb/library/actors/cppcoro/corobenchmark/CMakeLists.darwin-arm64.txt b/ydb/library/actors/cppcoro/corobenchmark/CMakeLists.darwin-arm64.txt index c4ae691e512a..fdb3ecdeab98 100644 --- a/ydb/library/actors/cppcoro/corobenchmark/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/cppcoro/corobenchmark/CMakeLists.darwin-arm64.txt @@ -18,8 +18,6 @@ target_link_options(corobenchmark PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(corobenchmark PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/corobenchmark/main.cpp diff --git a/ydb/library/actors/cppcoro/corobenchmark/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/cppcoro/corobenchmark/CMakeLists.darwin-x86_64.txt index ffebcc68c85d..43b001c7e60f 100644 --- a/ydb/library/actors/cppcoro/corobenchmark/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/cppcoro/corobenchmark/CMakeLists.darwin-x86_64.txt @@ -19,8 +19,6 @@ target_link_options(corobenchmark PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(corobenchmark PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/corobenchmark/main.cpp diff --git a/ydb/library/actors/cppcoro/corobenchmark/CMakeLists.linux-aarch64.txt b/ydb/library/actors/cppcoro/corobenchmark/CMakeLists.linux-aarch64.txt index 8ae4d8260172..7aced2478d30 100644 --- a/ydb/library/actors/cppcoro/corobenchmark/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/cppcoro/corobenchmark/CMakeLists.linux-aarch64.txt @@ -21,9 +21,6 @@ target_link_options(corobenchmark PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(corobenchmark PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/corobenchmark/main.cpp diff --git a/ydb/library/actors/cppcoro/corobenchmark/CMakeLists.linux-x86_64.txt b/ydb/library/actors/cppcoro/corobenchmark/CMakeLists.linux-x86_64.txt index 7160c3cdfea0..618191ed382c 100644 --- a/ydb/library/actors/cppcoro/corobenchmark/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/cppcoro/corobenchmark/CMakeLists.linux-x86_64.txt @@ -22,9 +22,6 @@ target_link_options(corobenchmark PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(corobenchmark PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/corobenchmark/main.cpp diff --git a/ydb/library/actors/cppcoro/ut/CMakeLists.darwin-arm64.txt b/ydb/library/actors/cppcoro/ut/CMakeLists.darwin-arm64.txt index c277a4b75b41..2653f3babf12 100644 --- a/ydb/library/actors/cppcoro/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/cppcoro/ut/CMakeLists.darwin-arm64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-library-actors-cppcoro-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-cppcoro-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/cppcoro/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/cppcoro/ut/CMakeLists.darwin-x86_64.txt index 4166f6544519..a4350c824b6d 100644 --- a/ydb/library/actors/cppcoro/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/cppcoro/ut/CMakeLists.darwin-x86_64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-library-actors-cppcoro-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-cppcoro-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/cppcoro/ut/CMakeLists.linux-aarch64.txt b/ydb/library/actors/cppcoro/ut/CMakeLists.linux-aarch64.txt index a91773f80ff5..c0eaf56798c9 100644 --- a/ydb/library/actors/cppcoro/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/cppcoro/ut/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-actors-cppcoro-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-cppcoro-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/cppcoro/ut/CMakeLists.linux-x86_64.txt b/ydb/library/actors/cppcoro/ut/CMakeLists.linux-x86_64.txt index 41f3d81b2d88..d3a88c1cf3fa 100644 --- a/ydb/library/actors/cppcoro/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/cppcoro/ut/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-library-actors-cppcoro-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-cppcoro-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/cppcoro/task_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/cppcoro/ut/CMakeLists.windows-x86_64.txt b/ydb/library/actors/cppcoro/ut/CMakeLists.windows-x86_64.txt index ddb5bbb146ce..ca6c42192bf0 100644 --- a/ydb/library/actors/cppcoro/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/cppcoro/ut/CMakeLists.windows-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/dnscachelib/CMakeLists.darwin-arm64.txt b/ydb/library/actors/dnscachelib/CMakeLists.darwin-arm64.txt index fcddde2933f4..42ee0776d453 100644 --- a/ydb/library/actors/dnscachelib/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/dnscachelib/CMakeLists.darwin-arm64.txt @@ -16,6 +16,9 @@ target_link_libraries(library-actors-dnscachelib PUBLIC cpp-deprecated-atomic ) target_sources(library-actors-dnscachelib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/dnscache.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/probes.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/timekeeper.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/dnscache.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/probes.cpp ) diff --git a/ydb/library/actors/dnscachelib/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/dnscachelib/CMakeLists.darwin-x86_64.txt index fcddde2933f4..42ee0776d453 100644 --- a/ydb/library/actors/dnscachelib/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/dnscachelib/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(library-actors-dnscachelib PUBLIC cpp-deprecated-atomic ) target_sources(library-actors-dnscachelib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/dnscache.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/probes.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/timekeeper.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/dnscache.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/probes.cpp ) diff --git a/ydb/library/actors/dnscachelib/CMakeLists.linux-aarch64.txt b/ydb/library/actors/dnscachelib/CMakeLists.linux-aarch64.txt index b13cb452aa7d..74e673c6e5f9 100644 --- a/ydb/library/actors/dnscachelib/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/dnscachelib/CMakeLists.linux-aarch64.txt @@ -17,6 +17,9 @@ target_link_libraries(library-actors-dnscachelib PUBLIC cpp-deprecated-atomic ) target_sources(library-actors-dnscachelib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/dnscache.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/probes.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/timekeeper.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/dnscache.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/probes.cpp ) diff --git a/ydb/library/actors/dnscachelib/CMakeLists.linux-x86_64.txt b/ydb/library/actors/dnscachelib/CMakeLists.linux-x86_64.txt index b13cb452aa7d..74e673c6e5f9 100644 --- a/ydb/library/actors/dnscachelib/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/dnscachelib/CMakeLists.linux-x86_64.txt @@ -17,6 +17,9 @@ target_link_libraries(library-actors-dnscachelib PUBLIC cpp-deprecated-atomic ) target_sources(library-actors-dnscachelib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/dnscache.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/probes.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/timekeeper.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/dnscache.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/probes.cpp ) diff --git a/ydb/library/actors/dnscachelib/CMakeLists.windows-x86_64.txt b/ydb/library/actors/dnscachelib/CMakeLists.windows-x86_64.txt index fcddde2933f4..42ee0776d453 100644 --- a/ydb/library/actors/dnscachelib/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/dnscachelib/CMakeLists.windows-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(library-actors-dnscachelib PUBLIC cpp-deprecated-atomic ) target_sources(library-actors-dnscachelib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/dnscache.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/probes.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/timekeeper.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/dnscache.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnscachelib/probes.cpp ) diff --git a/ydb/library/actors/dnsresolver/ut/CMakeLists.darwin-arm64.txt b/ydb/library/actors/dnsresolver/ut/CMakeLists.darwin-arm64.txt index d39e015be606..ac763ec4e631 100644 --- a/ydb/library/actors/dnsresolver/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/dnsresolver/ut/CMakeLists.darwin-arm64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-library-actors-dnsresolver-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-dnsresolver-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnsresolver/dnsresolver_caching_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/dnsresolver/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/dnsresolver/ut/CMakeLists.darwin-x86_64.txt index 0ec77485fafd..6d33a8c648f6 100644 --- a/ydb/library/actors/dnsresolver/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/dnsresolver/ut/CMakeLists.darwin-x86_64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-library-actors-dnsresolver-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-dnsresolver-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnsresolver/dnsresolver_caching_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/dnsresolver/ut/CMakeLists.linux-aarch64.txt b/ydb/library/actors/dnsresolver/ut/CMakeLists.linux-aarch64.txt index f0ef871fd6c0..56994f876d6e 100644 --- a/ydb/library/actors/dnsresolver/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/dnsresolver/ut/CMakeLists.linux-aarch64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-library-actors-dnsresolver-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-dnsresolver-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnsresolver/dnsresolver_caching_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/dnsresolver/ut/CMakeLists.linux-x86_64.txt b/ydb/library/actors/dnsresolver/ut/CMakeLists.linux-x86_64.txt index 28de710f265e..a18251d2aa96 100644 --- a/ydb/library/actors/dnsresolver/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/dnsresolver/ut/CMakeLists.linux-x86_64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-library-actors-dnsresolver-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-dnsresolver-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/dnsresolver/dnsresolver_caching_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/dnsresolver/ut/CMakeLists.windows-x86_64.txt b/ydb/library/actors/dnsresolver/ut/CMakeLists.windows-x86_64.txt index e604ef5b8839..ad5cb5f59f32 100644 --- a/ydb/library/actors/dnsresolver/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/dnsresolver/ut/CMakeLists.windows-x86_64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/examples/01_ping_pong/CMakeLists.darwin-arm64.txt b/ydb/library/actors/examples/01_ping_pong/CMakeLists.darwin-arm64.txt index 9d2cf5c7006f..5febec3a3e75 100644 --- a/ydb/library/actors/examples/01_ping_pong/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/examples/01_ping_pong/CMakeLists.darwin-arm64.txt @@ -17,8 +17,6 @@ target_link_options(example_01_ping_pong PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(example_01_ping_pong PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/01_ping_pong/main.cpp diff --git a/ydb/library/actors/examples/01_ping_pong/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/examples/01_ping_pong/CMakeLists.darwin-x86_64.txt index bb175a877ac1..38ead4accfaf 100644 --- a/ydb/library/actors/examples/01_ping_pong/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/examples/01_ping_pong/CMakeLists.darwin-x86_64.txt @@ -18,8 +18,6 @@ target_link_options(example_01_ping_pong PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(example_01_ping_pong PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/01_ping_pong/main.cpp diff --git a/ydb/library/actors/examples/01_ping_pong/CMakeLists.linux-aarch64.txt b/ydb/library/actors/examples/01_ping_pong/CMakeLists.linux-aarch64.txt index 73dc0b020d3d..53fc09152e71 100644 --- a/ydb/library/actors/examples/01_ping_pong/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/examples/01_ping_pong/CMakeLists.linux-aarch64.txt @@ -20,9 +20,6 @@ target_link_options(example_01_ping_pong PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(example_01_ping_pong PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/01_ping_pong/main.cpp diff --git a/ydb/library/actors/examples/01_ping_pong/CMakeLists.linux-x86_64.txt b/ydb/library/actors/examples/01_ping_pong/CMakeLists.linux-x86_64.txt index f30012ff4164..0e22d5ba9338 100644 --- a/ydb/library/actors/examples/01_ping_pong/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/examples/01_ping_pong/CMakeLists.linux-x86_64.txt @@ -21,9 +21,6 @@ target_link_options(example_01_ping_pong PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(example_01_ping_pong PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/01_ping_pong/main.cpp diff --git a/ydb/library/actors/examples/02_discovery/CMakeLists.darwin-arm64.txt b/ydb/library/actors/examples/02_discovery/CMakeLists.darwin-arm64.txt index c5783b9062ea..c0bebf5fe10d 100644 --- a/ydb/library/actors/examples/02_discovery/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/examples/02_discovery/CMakeLists.darwin-arm64.txt @@ -33,13 +33,13 @@ target_link_options(example_02_discovery PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_proto_messages(example_02_discovery PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/protocol.proto ) target_sources(example_02_discovery PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/actors/examples/02_discovery/protocol.pb.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/services.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/endpoint.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/lookup.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/main.cpp diff --git a/ydb/library/actors/examples/02_discovery/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/examples/02_discovery/CMakeLists.darwin-x86_64.txt index 51c6fb244644..ae8f57c3b6a6 100644 --- a/ydb/library/actors/examples/02_discovery/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/examples/02_discovery/CMakeLists.darwin-x86_64.txt @@ -34,13 +34,13 @@ target_link_options(example_02_discovery PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_proto_messages(example_02_discovery PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/protocol.proto ) target_sources(example_02_discovery PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/actors/examples/02_discovery/protocol.pb.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/services.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/endpoint.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/lookup.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/main.cpp diff --git a/ydb/library/actors/examples/02_discovery/CMakeLists.linux-aarch64.txt b/ydb/library/actors/examples/02_discovery/CMakeLists.linux-aarch64.txt index 457698edeac8..092a75dbb4b2 100644 --- a/ydb/library/actors/examples/02_discovery/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/examples/02_discovery/CMakeLists.linux-aarch64.txt @@ -36,14 +36,13 @@ target_link_options(example_02_discovery PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_proto_messages(example_02_discovery PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/protocol.proto ) target_sources(example_02_discovery PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/actors/examples/02_discovery/protocol.pb.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/services.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/endpoint.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/lookup.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/main.cpp diff --git a/ydb/library/actors/examples/02_discovery/CMakeLists.linux-x86_64.txt b/ydb/library/actors/examples/02_discovery/CMakeLists.linux-x86_64.txt index 2efa983d1464..a151b0bf68e5 100644 --- a/ydb/library/actors/examples/02_discovery/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/examples/02_discovery/CMakeLists.linux-x86_64.txt @@ -37,14 +37,13 @@ target_link_options(example_02_discovery PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_proto_messages(example_02_discovery PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/protocol.proto ) target_sources(example_02_discovery PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/actors/examples/02_discovery/protocol.pb.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/services.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/endpoint.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/lookup.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/main.cpp diff --git a/ydb/library/actors/examples/02_discovery/CMakeLists.windows-x86_64.txt b/ydb/library/actors/examples/02_discovery/CMakeLists.windows-x86_64.txt index e8a950fdf724..cd095b21a41a 100644 --- a/ydb/library/actors/examples/02_discovery/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/examples/02_discovery/CMakeLists.windows-x86_64.txt @@ -34,6 +34,8 @@ target_proto_messages(example_02_discovery PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/protocol.proto ) target_sources(example_02_discovery PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/actors/examples/02_discovery/protocol.pb.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/services.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/endpoint.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/lookup.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/examples/02_discovery/main.cpp diff --git a/ydb/library/actors/helpers/CMakeLists.darwin-arm64.txt b/ydb/library/actors/helpers/CMakeLists.darwin-arm64.txt index 4392ee98f617..4763c9f2d44c 100644 --- a/ydb/library/actors/helpers/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/helpers/CMakeLists.darwin-arm64.txt @@ -16,6 +16,10 @@ target_link_libraries(library-actors-helpers PUBLIC cpp-monlib-dynamic_counters ) target_sources(library-actors-helpers PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/activeactors.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/flow_controlled_queue.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/future_callback.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/mon_histogram_helper.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/activeactors.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/flow_controlled_queue.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/selfping_actor.cpp diff --git a/ydb/library/actors/helpers/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/helpers/CMakeLists.darwin-x86_64.txt index 4392ee98f617..4763c9f2d44c 100644 --- a/ydb/library/actors/helpers/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/helpers/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,10 @@ target_link_libraries(library-actors-helpers PUBLIC cpp-monlib-dynamic_counters ) target_sources(library-actors-helpers PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/activeactors.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/flow_controlled_queue.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/future_callback.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/mon_histogram_helper.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/activeactors.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/flow_controlled_queue.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/selfping_actor.cpp diff --git a/ydb/library/actors/helpers/CMakeLists.linux-aarch64.txt b/ydb/library/actors/helpers/CMakeLists.linux-aarch64.txt index b9a2080232a9..f7146c5fdafd 100644 --- a/ydb/library/actors/helpers/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/helpers/CMakeLists.linux-aarch64.txt @@ -17,6 +17,10 @@ target_link_libraries(library-actors-helpers PUBLIC cpp-monlib-dynamic_counters ) target_sources(library-actors-helpers PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/activeactors.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/flow_controlled_queue.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/future_callback.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/mon_histogram_helper.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/activeactors.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/flow_controlled_queue.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/selfping_actor.cpp diff --git a/ydb/library/actors/helpers/CMakeLists.linux-x86_64.txt b/ydb/library/actors/helpers/CMakeLists.linux-x86_64.txt index b9a2080232a9..f7146c5fdafd 100644 --- a/ydb/library/actors/helpers/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/helpers/CMakeLists.linux-x86_64.txt @@ -17,6 +17,10 @@ target_link_libraries(library-actors-helpers PUBLIC cpp-monlib-dynamic_counters ) target_sources(library-actors-helpers PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/activeactors.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/flow_controlled_queue.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/future_callback.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/mon_histogram_helper.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/activeactors.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/flow_controlled_queue.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/selfping_actor.cpp diff --git a/ydb/library/actors/helpers/CMakeLists.windows-x86_64.txt b/ydb/library/actors/helpers/CMakeLists.windows-x86_64.txt index 4392ee98f617..4763c9f2d44c 100644 --- a/ydb/library/actors/helpers/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/helpers/CMakeLists.windows-x86_64.txt @@ -16,6 +16,10 @@ target_link_libraries(library-actors-helpers PUBLIC cpp-monlib-dynamic_counters ) target_sources(library-actors-helpers PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/activeactors.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/flow_controlled_queue.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/future_callback.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/mon_histogram_helper.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/activeactors.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/flow_controlled_queue.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/selfping_actor.cpp diff --git a/ydb/library/actors/helpers/ut/CMakeLists.darwin-arm64.txt b/ydb/library/actors/helpers/ut/CMakeLists.darwin-arm64.txt index eb490e93de8c..6c4b931d3bca 100644 --- a/ydb/library/actors/helpers/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/helpers/ut/CMakeLists.darwin-arm64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-library-actors-helpers-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-helpers-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/selfping_actor_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/helpers/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/helpers/ut/CMakeLists.darwin-x86_64.txt index 613b811455a9..fac30b41f02a 100644 --- a/ydb/library/actors/helpers/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/helpers/ut/CMakeLists.darwin-x86_64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-library-actors-helpers-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-helpers-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/selfping_actor_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/helpers/ut/CMakeLists.linux-aarch64.txt b/ydb/library/actors/helpers/ut/CMakeLists.linux-aarch64.txt index 7ad8585da62b..3719601a58f9 100644 --- a/ydb/library/actors/helpers/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/helpers/ut/CMakeLists.linux-aarch64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-library-actors-helpers-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-helpers-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/selfping_actor_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/helpers/ut/CMakeLists.linux-x86_64.txt b/ydb/library/actors/helpers/ut/CMakeLists.linux-x86_64.txt index 937dab9a4735..bf2640b06cc5 100644 --- a/ydb/library/actors/helpers/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/helpers/ut/CMakeLists.linux-x86_64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-library-actors-helpers-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-helpers-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/helpers/selfping_actor_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/helpers/ut/CMakeLists.windows-x86_64.txt b/ydb/library/actors/helpers/ut/CMakeLists.windows-x86_64.txt index e50e89233281..d5051a95c4b4 100644 --- a/ydb/library/actors/helpers/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/helpers/ut/CMakeLists.windows-x86_64.txt @@ -49,6 +49,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/http/CMakeLists.darwin-arm64.txt b/ydb/library/actors/http/CMakeLists.darwin-arm64.txt index c1852d9c0e9c..d36ec68dd34d 100644 --- a/ydb/library/actors/http/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/http/CMakeLists.darwin-arm64.txt @@ -21,6 +21,14 @@ target_link_libraries(library-actors-http PUBLIC cpp-string_utils-quote ) target_sources(library-actors-http PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_config.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy_sock_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy_sock64.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy_ssl.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_static.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_cache.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_compress.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy_acceptor.cpp diff --git a/ydb/library/actors/http/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/http/CMakeLists.darwin-x86_64.txt index c1852d9c0e9c..d36ec68dd34d 100644 --- a/ydb/library/actors/http/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/http/CMakeLists.darwin-x86_64.txt @@ -21,6 +21,14 @@ target_link_libraries(library-actors-http PUBLIC cpp-string_utils-quote ) target_sources(library-actors-http PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_config.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy_sock_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy_sock64.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy_ssl.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_static.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_cache.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_compress.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy_acceptor.cpp diff --git a/ydb/library/actors/http/CMakeLists.linux-aarch64.txt b/ydb/library/actors/http/CMakeLists.linux-aarch64.txt index eb987fc90c56..fb7fcdd71562 100644 --- a/ydb/library/actors/http/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/http/CMakeLists.linux-aarch64.txt @@ -22,6 +22,14 @@ target_link_libraries(library-actors-http PUBLIC cpp-string_utils-quote ) target_sources(library-actors-http PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_config.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy_sock_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy_sock64.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy_ssl.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_static.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_cache.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_compress.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy_acceptor.cpp diff --git a/ydb/library/actors/http/CMakeLists.linux-x86_64.txt b/ydb/library/actors/http/CMakeLists.linux-x86_64.txt index eb987fc90c56..fb7fcdd71562 100644 --- a/ydb/library/actors/http/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/http/CMakeLists.linux-x86_64.txt @@ -22,6 +22,14 @@ target_link_libraries(library-actors-http PUBLIC cpp-string_utils-quote ) target_sources(library-actors-http PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_config.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy_sock_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy_sock64.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy_ssl.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_static.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_cache.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_compress.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy_acceptor.cpp diff --git a/ydb/library/actors/http/CMakeLists.windows-x86_64.txt b/ydb/library/actors/http/CMakeLists.windows-x86_64.txt index c1852d9c0e9c..d36ec68dd34d 100644 --- a/ydb/library/actors/http/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/http/CMakeLists.windows-x86_64.txt @@ -21,6 +21,14 @@ target_link_libraries(library-actors-http PUBLIC cpp-string_utils-quote ) target_sources(library-actors-http PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_config.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy_sock_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy_sock64.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy_ssl.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_static.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_cache.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_compress.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_proxy_acceptor.cpp diff --git a/ydb/library/actors/http/ut/CMakeLists.darwin-arm64.txt b/ydb/library/actors/http/ut/CMakeLists.darwin-arm64.txt index 42ca8a551d6c..0f1327072e97 100644 --- a/ydb/library/actors/http/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/http/ut/CMakeLists.darwin-arm64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-library-actors-http-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-http-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/http/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/http/ut/CMakeLists.darwin-x86_64.txt index a7563e08fd07..b6ad7bb0912b 100644 --- a/ydb/library/actors/http/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/http/ut/CMakeLists.darwin-x86_64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-library-actors-http-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-http-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/http/ut/CMakeLists.linux-aarch64.txt b/ydb/library/actors/http/ut/CMakeLists.linux-aarch64.txt index b8acf5c26114..c63f888cb136 100644 --- a/ydb/library/actors/http/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/http/ut/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-actors-http-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-http-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/http/ut/CMakeLists.linux-x86_64.txt b/ydb/library/actors/http/ut/CMakeLists.linux-x86_64.txt index e33b1f6c2043..fa2a737ca377 100644 --- a/ydb/library/actors/http/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/http/ut/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-library-actors-http-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-http-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/http/http_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/http/ut/CMakeLists.windows-x86_64.txt b/ydb/library/actors/http/ut/CMakeLists.windows-x86_64.txt index f1adc52bda7c..7725614237a6 100644 --- a/ydb/library/actors/http/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/http/ut/CMakeLists.windows-x86_64.txt @@ -44,6 +44,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/interconnect/CMakeLists.darwin-arm64.txt b/ydb/library/actors/interconnect/CMakeLists.darwin-arm64.txt index aa0d0be89c18..339fd1bcd0b5 100644 --- a/ydb/library/actors/interconnect/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/interconnect/CMakeLists.darwin-arm64.txt @@ -37,6 +37,34 @@ target_link_libraries(library-actors-interconnect PUBLIC library-cpp-packedtypes ) target_sources(library-actors-interconnect PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/channel_scheduler.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/event_filter.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/event_holder_pool.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/events_local.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_address.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_channel.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_common.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_handshake.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_mon.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_proxy_wrapper.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_stream.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_tcp_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_tcp_server.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_tcp_session.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/load.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/logging.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/packet.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller_actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller_tcp.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller_tcp_unit.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller_tcp_unit_select.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/profiler.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/slowpoke_actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/types.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/watchdog_timer.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_address.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_channel.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_counters.cpp diff --git a/ydb/library/actors/interconnect/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/interconnect/CMakeLists.darwin-x86_64.txt index aa0d0be89c18..339fd1bcd0b5 100644 --- a/ydb/library/actors/interconnect/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/interconnect/CMakeLists.darwin-x86_64.txt @@ -37,6 +37,34 @@ target_link_libraries(library-actors-interconnect PUBLIC library-cpp-packedtypes ) target_sources(library-actors-interconnect PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/channel_scheduler.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/event_filter.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/event_holder_pool.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/events_local.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_address.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_channel.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_common.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_handshake.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_mon.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_proxy_wrapper.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_stream.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_tcp_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_tcp_server.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_tcp_session.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/load.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/logging.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/packet.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller_actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller_tcp.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller_tcp_unit.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller_tcp_unit_select.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/profiler.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/slowpoke_actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/types.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/watchdog_timer.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_address.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_channel.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_counters.cpp diff --git a/ydb/library/actors/interconnect/CMakeLists.linux-aarch64.txt b/ydb/library/actors/interconnect/CMakeLists.linux-aarch64.txt index 0d7462732caa..ae615cacfbac 100644 --- a/ydb/library/actors/interconnect/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/interconnect/CMakeLists.linux-aarch64.txt @@ -38,6 +38,35 @@ target_link_libraries(library-actors-interconnect PUBLIC library-cpp-packedtypes ) target_sources(library-actors-interconnect PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/channel_scheduler.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/event_filter.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/event_holder_pool.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/events_local.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_address.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_channel.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_common.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_handshake.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_mon.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_proxy_wrapper.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_stream.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_tcp_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_tcp_server.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_tcp_session.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/load.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/logging.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/packet.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller_actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller_tcp.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller_tcp_unit.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller_tcp_unit_select.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/profiler.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/slowpoke_actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/types.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/watchdog_timer.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller_tcp_unit_epoll.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_address.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_channel.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_counters.cpp diff --git a/ydb/library/actors/interconnect/CMakeLists.linux-x86_64.txt b/ydb/library/actors/interconnect/CMakeLists.linux-x86_64.txt index 0d7462732caa..ae615cacfbac 100644 --- a/ydb/library/actors/interconnect/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/interconnect/CMakeLists.linux-x86_64.txt @@ -38,6 +38,35 @@ target_link_libraries(library-actors-interconnect PUBLIC library-cpp-packedtypes ) target_sources(library-actors-interconnect PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/channel_scheduler.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/event_filter.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/event_holder_pool.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/events_local.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_address.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_channel.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_common.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_handshake.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_mon.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_proxy_wrapper.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_stream.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_tcp_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_tcp_server.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_tcp_session.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/load.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/logging.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/packet.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller_actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller_tcp.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller_tcp_unit.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller_tcp_unit_select.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/profiler.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/slowpoke_actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/types.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/watchdog_timer.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller_tcp_unit_epoll.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_address.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_channel.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_counters.cpp diff --git a/ydb/library/actors/interconnect/CMakeLists.windows-x86_64.txt b/ydb/library/actors/interconnect/CMakeLists.windows-x86_64.txt index aa0d0be89c18..339fd1bcd0b5 100644 --- a/ydb/library/actors/interconnect/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/interconnect/CMakeLists.windows-x86_64.txt @@ -37,6 +37,34 @@ target_link_libraries(library-actors-interconnect PUBLIC library-cpp-packedtypes ) target_sources(library-actors-interconnect PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/channel_scheduler.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/event_filter.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/event_holder_pool.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/events_local.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_address.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_channel.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_common.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_handshake.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_mon.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_proxy_wrapper.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_stream.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_tcp_proxy.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_tcp_server.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_tcp_session.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/load.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/logging.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/packet.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller_actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller_tcp.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller_tcp_unit.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/poller_tcp_unit_select.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/profiler.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/slowpoke_actor.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/types.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/watchdog_timer.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_address.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_channel.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/interconnect_counters.cpp diff --git a/ydb/library/actors/interconnect/mock/CMakeLists.darwin-arm64.txt b/ydb/library/actors/interconnect/mock/CMakeLists.darwin-arm64.txt index 9f23da53a954..7f29976d3b1a 100644 --- a/ydb/library/actors/interconnect/mock/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/interconnect/mock/CMakeLists.darwin-arm64.txt @@ -14,5 +14,6 @@ target_link_libraries(actors-interconnect-mock PUBLIC library-actors-interconnect ) target_sources(actors-interconnect-mock PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/mock/ic_mock.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/mock/ic_mock.cpp ) diff --git a/ydb/library/actors/interconnect/mock/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/interconnect/mock/CMakeLists.darwin-x86_64.txt index 9f23da53a954..7f29976d3b1a 100644 --- a/ydb/library/actors/interconnect/mock/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/interconnect/mock/CMakeLists.darwin-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(actors-interconnect-mock PUBLIC library-actors-interconnect ) target_sources(actors-interconnect-mock PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/mock/ic_mock.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/mock/ic_mock.cpp ) diff --git a/ydb/library/actors/interconnect/mock/CMakeLists.linux-aarch64.txt b/ydb/library/actors/interconnect/mock/CMakeLists.linux-aarch64.txt index cc540810a79e..c9c6c31ae3d2 100644 --- a/ydb/library/actors/interconnect/mock/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/interconnect/mock/CMakeLists.linux-aarch64.txt @@ -15,5 +15,6 @@ target_link_libraries(actors-interconnect-mock PUBLIC library-actors-interconnect ) target_sources(actors-interconnect-mock PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/mock/ic_mock.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/mock/ic_mock.cpp ) diff --git a/ydb/library/actors/interconnect/mock/CMakeLists.linux-x86_64.txt b/ydb/library/actors/interconnect/mock/CMakeLists.linux-x86_64.txt index cc540810a79e..c9c6c31ae3d2 100644 --- a/ydb/library/actors/interconnect/mock/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/interconnect/mock/CMakeLists.linux-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(actors-interconnect-mock PUBLIC library-actors-interconnect ) target_sources(actors-interconnect-mock PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/mock/ic_mock.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/mock/ic_mock.cpp ) diff --git a/ydb/library/actors/interconnect/mock/CMakeLists.windows-x86_64.txt b/ydb/library/actors/interconnect/mock/CMakeLists.windows-x86_64.txt index 9f23da53a954..7f29976d3b1a 100644 --- a/ydb/library/actors/interconnect/mock/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/interconnect/mock/CMakeLists.windows-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(actors-interconnect-mock PUBLIC library-actors-interconnect ) target_sources(actors-interconnect-mock PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/mock/ic_mock.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/mock/ic_mock.cpp ) diff --git a/ydb/library/actors/interconnect/ut/CMakeLists.darwin-arm64.txt b/ydb/library/actors/interconnect/ut/CMakeLists.darwin-arm64.txt index b8d9f5448f2c..72524fbcc7b6 100644 --- a/ydb/library/actors/interconnect/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/interconnect/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-library-actors-interconnect-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-interconnect-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/channel_scheduler_ut.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/interconnect/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/interconnect/ut/CMakeLists.darwin-x86_64.txt index 86b4d1f2cca7..1aa7f2e13171 100644 --- a/ydb/library/actors/interconnect/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/interconnect/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-library-actors-interconnect-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-interconnect-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/channel_scheduler_ut.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/interconnect/ut/CMakeLists.linux-aarch64.txt b/ydb/library/actors/interconnect/ut/CMakeLists.linux-aarch64.txt index 279a83d646d1..a1913a79dc16 100644 --- a/ydb/library/actors/interconnect/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/interconnect/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-library-actors-interconnect-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-interconnect-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/channel_scheduler_ut.cpp @@ -68,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/interconnect/ut/CMakeLists.linux-x86_64.txt b/ydb/library/actors/interconnect/ut/CMakeLists.linux-x86_64.txt index 183c47e61bc5..72f1328ffa55 100644 --- a/ydb/library/actors/interconnect/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/interconnect/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-library-actors-interconnect-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-interconnect-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/channel_scheduler_ut.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/interconnect/ut/CMakeLists.windows-x86_64.txt b/ydb/library/actors/interconnect/ut/CMakeLists.windows-x86_64.txt index a9e78893c496..fcaf598ff809 100644 --- a/ydb/library/actors/interconnect/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/interconnect/ut/CMakeLists.windows-x86_64.txt @@ -58,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/interconnect/ut/lib/CMakeLists.darwin-arm64.txt b/ydb/library/actors/interconnect/ut/lib/CMakeLists.darwin-arm64.txt index a6a86ac09baa..513a65b518a5 100644 --- a/ydb/library/actors/interconnect/ut/lib/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/interconnect/ut/lib/CMakeLists.darwin-arm64.txt @@ -12,3 +12,9 @@ target_link_libraries(interconnect-ut-lib INTERFACE contrib-libs-cxxsupp yutil ) +target_sources(interconnect-ut-lib INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/lib/node.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/lib/test_events.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/lib/test_actors.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/lib/ic_test_cluster.h +) diff --git a/ydb/library/actors/interconnect/ut/lib/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/interconnect/ut/lib/CMakeLists.darwin-x86_64.txt index a6a86ac09baa..513a65b518a5 100644 --- a/ydb/library/actors/interconnect/ut/lib/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/interconnect/ut/lib/CMakeLists.darwin-x86_64.txt @@ -12,3 +12,9 @@ target_link_libraries(interconnect-ut-lib INTERFACE contrib-libs-cxxsupp yutil ) +target_sources(interconnect-ut-lib INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/lib/node.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/lib/test_events.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/lib/test_actors.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/lib/ic_test_cluster.h +) diff --git a/ydb/library/actors/interconnect/ut/lib/CMakeLists.linux-aarch64.txt b/ydb/library/actors/interconnect/ut/lib/CMakeLists.linux-aarch64.txt index b20c3b0de902..bed00d033442 100644 --- a/ydb/library/actors/interconnect/ut/lib/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/interconnect/ut/lib/CMakeLists.linux-aarch64.txt @@ -13,3 +13,9 @@ target_link_libraries(interconnect-ut-lib INTERFACE contrib-libs-cxxsupp yutil ) +target_sources(interconnect-ut-lib INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/lib/node.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/lib/test_events.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/lib/test_actors.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/lib/ic_test_cluster.h +) diff --git a/ydb/library/actors/interconnect/ut/lib/CMakeLists.linux-x86_64.txt b/ydb/library/actors/interconnect/ut/lib/CMakeLists.linux-x86_64.txt index b20c3b0de902..bed00d033442 100644 --- a/ydb/library/actors/interconnect/ut/lib/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/interconnect/ut/lib/CMakeLists.linux-x86_64.txt @@ -13,3 +13,9 @@ target_link_libraries(interconnect-ut-lib INTERFACE contrib-libs-cxxsupp yutil ) +target_sources(interconnect-ut-lib INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/lib/node.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/lib/test_events.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/lib/test_actors.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/lib/ic_test_cluster.h +) diff --git a/ydb/library/actors/interconnect/ut/lib/CMakeLists.windows-x86_64.txt b/ydb/library/actors/interconnect/ut/lib/CMakeLists.windows-x86_64.txt index a6a86ac09baa..513a65b518a5 100644 --- a/ydb/library/actors/interconnect/ut/lib/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/interconnect/ut/lib/CMakeLists.windows-x86_64.txt @@ -12,3 +12,9 @@ target_link_libraries(interconnect-ut-lib INTERFACE contrib-libs-cxxsupp yutil ) +target_sources(interconnect-ut-lib INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/lib/node.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/lib/test_events.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/lib/test_actors.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/lib/ic_test_cluster.h +) diff --git a/ydb/library/actors/interconnect/ut/protos/CMakeLists.darwin-arm64.txt b/ydb/library/actors/interconnect/ut/protos/CMakeLists.darwin-arm64.txt index bf5d35cd2f9d..f9a0715be8e9 100644 --- a/ydb/library/actors/interconnect/ut/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/interconnect/ut/protos/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(interconnect-ut-protos PUBLIC target_proto_messages(interconnect-ut-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/protos/interconnect_test.proto ) +target_sources(interconnect-ut-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/actors/interconnect/ut/protos/interconnect_test.pb.h +) target_proto_addincls(interconnect-ut-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/actors/interconnect/ut/protos/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/interconnect/ut/protos/CMakeLists.darwin-x86_64.txt index bf5d35cd2f9d..f9a0715be8e9 100644 --- a/ydb/library/actors/interconnect/ut/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/interconnect/ut/protos/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(interconnect-ut-protos PUBLIC target_proto_messages(interconnect-ut-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/protos/interconnect_test.proto ) +target_sources(interconnect-ut-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/actors/interconnect/ut/protos/interconnect_test.pb.h +) target_proto_addincls(interconnect-ut-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/actors/interconnect/ut/protos/CMakeLists.linux-aarch64.txt b/ydb/library/actors/interconnect/ut/protos/CMakeLists.linux-aarch64.txt index b78993ebda68..74079f59d134 100644 --- a/ydb/library/actors/interconnect/ut/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/interconnect/ut/protos/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(interconnect-ut-protos PUBLIC target_proto_messages(interconnect-ut-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/protos/interconnect_test.proto ) +target_sources(interconnect-ut-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/actors/interconnect/ut/protos/interconnect_test.pb.h +) target_proto_addincls(interconnect-ut-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/actors/interconnect/ut/protos/CMakeLists.linux-x86_64.txt b/ydb/library/actors/interconnect/ut/protos/CMakeLists.linux-x86_64.txt index b78993ebda68..74079f59d134 100644 --- a/ydb/library/actors/interconnect/ut/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/interconnect/ut/protos/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(interconnect-ut-protos PUBLIC target_proto_messages(interconnect-ut-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/protos/interconnect_test.proto ) +target_sources(interconnect-ut-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/actors/interconnect/ut/protos/interconnect_test.pb.h +) target_proto_addincls(interconnect-ut-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/actors/interconnect/ut/protos/CMakeLists.windows-x86_64.txt b/ydb/library/actors/interconnect/ut/protos/CMakeLists.windows-x86_64.txt index bf5d35cd2f9d..f9a0715be8e9 100644 --- a/ydb/library/actors/interconnect/ut/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/interconnect/ut/protos/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(interconnect-ut-protos PUBLIC target_proto_messages(interconnect-ut-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut/protos/interconnect_test.proto ) +target_sources(interconnect-ut-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/actors/interconnect/ut/protos/interconnect_test.pb.h +) target_proto_addincls(interconnect-ut-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/actors/interconnect/ut_fat/CMakeLists.darwin-arm64.txt b/ydb/library/actors/interconnect/ut_fat/CMakeLists.darwin-arm64.txt index dc5e934b3d3b..f5110610e6a8 100644 --- a/ydb/library/actors/interconnect/ut_fat/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/interconnect/ut_fat/CMakeLists.darwin-arm64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-library-actors-interconnect-ut_fat PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-interconnect-ut_fat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut_fat/main.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/interconnect/ut_fat/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/interconnect/ut_fat/CMakeLists.darwin-x86_64.txt index 7dada1153777..71a58fe712f8 100644 --- a/ydb/library/actors/interconnect/ut_fat/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/interconnect/ut_fat/CMakeLists.darwin-x86_64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-library-actors-interconnect-ut_fat PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-interconnect-ut_fat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut_fat/main.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/interconnect/ut_fat/CMakeLists.linux-aarch64.txt b/ydb/library/actors/interconnect/ut_fat/CMakeLists.linux-aarch64.txt index 7551d04caf66..e42ecba465a5 100644 --- a/ydb/library/actors/interconnect/ut_fat/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/interconnect/ut_fat/CMakeLists.linux-aarch64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-library-actors-interconnect-ut_fat PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-interconnect-ut_fat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut_fat/main.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/interconnect/ut_fat/CMakeLists.linux-x86_64.txt b/ydb/library/actors/interconnect/ut_fat/CMakeLists.linux-x86_64.txt index 22b569c1e797..6bd9ed409473 100644 --- a/ydb/library/actors/interconnect/ut_fat/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/interconnect/ut_fat/CMakeLists.linux-x86_64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-library-actors-interconnect-ut_fat PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-interconnect-ut_fat PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut_fat/main.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/interconnect/ut_fat/CMakeLists.windows-x86_64.txt b/ydb/library/actors/interconnect/ut_fat/CMakeLists.windows-x86_64.txt index bcd9e0154797..b6a5f91b93a8 100644 --- a/ydb/library/actors/interconnect/ut_fat/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/interconnect/ut_fat/CMakeLists.windows-x86_64.txt @@ -49,6 +49,7 @@ set_yunittest_property( PROPERTY LABELS LARGE + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/interconnect/ut_huge_cluster/CMakeLists.darwin-arm64.txt b/ydb/library/actors/interconnect/ut_huge_cluster/CMakeLists.darwin-arm64.txt index 728322815b01..f3b64dce0f2b 100644 --- a/ydb/library/actors/interconnect/ut_huge_cluster/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/interconnect/ut_huge_cluster/CMakeLists.darwin-arm64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-library-actors-interconnect-ut_huge_cluster PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-interconnect-ut_huge_cluster PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut_huge_cluster/huge_cluster.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/interconnect/ut_huge_cluster/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/interconnect/ut_huge_cluster/CMakeLists.darwin-x86_64.txt index 82afb6345b83..1d3589011412 100644 --- a/ydb/library/actors/interconnect/ut_huge_cluster/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/interconnect/ut_huge_cluster/CMakeLists.darwin-x86_64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-library-actors-interconnect-ut_huge_cluster PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-interconnect-ut_huge_cluster PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut_huge_cluster/huge_cluster.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/interconnect/ut_huge_cluster/CMakeLists.linux-aarch64.txt b/ydb/library/actors/interconnect/ut_huge_cluster/CMakeLists.linux-aarch64.txt index 0e692cf15352..15b63a3ecd60 100644 --- a/ydb/library/actors/interconnect/ut_huge_cluster/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/interconnect/ut_huge_cluster/CMakeLists.linux-aarch64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-library-actors-interconnect-ut_huge_cluster PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-interconnect-ut_huge_cluster PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut_huge_cluster/huge_cluster.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/interconnect/ut_huge_cluster/CMakeLists.linux-x86_64.txt b/ydb/library/actors/interconnect/ut_huge_cluster/CMakeLists.linux-x86_64.txt index 2718ff5569ef..c8feef38e05c 100644 --- a/ydb/library/actors/interconnect/ut_huge_cluster/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/interconnect/ut_huge_cluster/CMakeLists.linux-x86_64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-library-actors-interconnect-ut_huge_cluster PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-interconnect-ut_huge_cluster PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/interconnect/ut_huge_cluster/huge_cluster.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/interconnect/ut_huge_cluster/CMakeLists.windows-x86_64.txt b/ydb/library/actors/interconnect/ut_huge_cluster/CMakeLists.windows-x86_64.txt index ac8a111e4ba4..9578a772a8bc 100644 --- a/ydb/library/actors/interconnect/ut_huge_cluster/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/interconnect/ut_huge_cluster/CMakeLists.windows-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/memory_log/CMakeLists.darwin-arm64.txt b/ydb/library/actors/memory_log/CMakeLists.darwin-arm64.txt index 8fec7339be8f..fb8d607542df 100644 --- a/ydb/library/actors/memory_log/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/memory_log/CMakeLists.darwin-arm64.txt @@ -16,6 +16,7 @@ target_link_libraries(library-actors-memory_log PUBLIC cpp-deprecated-atomic ) target_sources(library-actors-memory_log PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/memory_log/memlog.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/memory_log/memlog.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/memory_log/mmap.cpp ) diff --git a/ydb/library/actors/memory_log/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/memory_log/CMakeLists.darwin-x86_64.txt index 8fec7339be8f..fb8d607542df 100644 --- a/ydb/library/actors/memory_log/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/memory_log/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,7 @@ target_link_libraries(library-actors-memory_log PUBLIC cpp-deprecated-atomic ) target_sources(library-actors-memory_log PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/memory_log/memlog.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/memory_log/memlog.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/memory_log/mmap.cpp ) diff --git a/ydb/library/actors/memory_log/CMakeLists.linux-aarch64.txt b/ydb/library/actors/memory_log/CMakeLists.linux-aarch64.txt index ad4a71a59857..32ea1842e31d 100644 --- a/ydb/library/actors/memory_log/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/memory_log/CMakeLists.linux-aarch64.txt @@ -17,6 +17,7 @@ target_link_libraries(library-actors-memory_log PUBLIC cpp-deprecated-atomic ) target_sources(library-actors-memory_log PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/memory_log/memlog.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/memory_log/memlog.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/memory_log/mmap.cpp ) diff --git a/ydb/library/actors/memory_log/CMakeLists.linux-x86_64.txt b/ydb/library/actors/memory_log/CMakeLists.linux-x86_64.txt index ad4a71a59857..32ea1842e31d 100644 --- a/ydb/library/actors/memory_log/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/memory_log/CMakeLists.linux-x86_64.txt @@ -17,6 +17,7 @@ target_link_libraries(library-actors-memory_log PUBLIC cpp-deprecated-atomic ) target_sources(library-actors-memory_log PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/memory_log/memlog.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/memory_log/memlog.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/memory_log/mmap.cpp ) diff --git a/ydb/library/actors/memory_log/CMakeLists.windows-x86_64.txt b/ydb/library/actors/memory_log/CMakeLists.windows-x86_64.txt index 8fec7339be8f..fb8d607542df 100644 --- a/ydb/library/actors/memory_log/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/memory_log/CMakeLists.windows-x86_64.txt @@ -16,6 +16,7 @@ target_link_libraries(library-actors-memory_log PUBLIC cpp-deprecated-atomic ) target_sources(library-actors-memory_log PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/memory_log/memlog.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/memory_log/memlog.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/memory_log/mmap.cpp ) diff --git a/ydb/library/actors/prof/ut/CMakeLists.darwin-arm64.txt b/ydb/library/actors/prof/ut/CMakeLists.darwin-arm64.txt index bbe8c2ad2ba4..49815acfe6cd 100644 --- a/ydb/library/actors/prof/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/prof/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-library-actors-prof-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-prof-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/prof/ut/tag_ut.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/prof/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/prof/ut/CMakeLists.darwin-x86_64.txt index d404ef6bce5f..5a71ac4f8374 100644 --- a/ydb/library/actors/prof/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/prof/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-library-actors-prof-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-prof-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/prof/ut/tag_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/prof/ut/CMakeLists.linux-aarch64.txt b/ydb/library/actors/prof/ut/CMakeLists.linux-aarch64.txt index d8a0e6e13dcb..69db6a23c712 100644 --- a/ydb/library/actors/prof/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/prof/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-actors-prof-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-prof-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/prof/ut/tag_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/prof/ut/CMakeLists.linux-x86_64.txt b/ydb/library/actors/prof/ut/CMakeLists.linux-x86_64.txt index cceb96b67207..6e04530ec141 100644 --- a/ydb/library/actors/prof/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/prof/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-actors-prof-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-prof-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/prof/ut/tag_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/prof/ut/CMakeLists.windows-x86_64.txt b/ydb/library/actors/prof/ut/CMakeLists.windows-x86_64.txt index bfb38a55a6cf..1049a1086fd8 100644 --- a/ydb/library/actors/prof/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/prof/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/protos/CMakeLists.darwin-arm64.txt b/ydb/library/actors/protos/CMakeLists.darwin-arm64.txt index aa9845bc7db4..434689053e4f 100644 --- a/ydb/library/actors/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/protos/CMakeLists.darwin-arm64.txt @@ -67,6 +67,12 @@ target_proto_messages(library-actors-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/protos/services_common.proto ${CMAKE_SOURCE_DIR}/ydb/library/actors/protos/unittests.proto ) +target_sources(library-actors-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/actors/protos/actors.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/actors/protos/interconnect.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/actors/protos/services_common.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/actors/protos/unittests.pb.h +) target_proto_addincls(library-actors-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/actors/protos/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/protos/CMakeLists.darwin-x86_64.txt index aa9845bc7db4..434689053e4f 100644 --- a/ydb/library/actors/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/protos/CMakeLists.darwin-x86_64.txt @@ -67,6 +67,12 @@ target_proto_messages(library-actors-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/protos/services_common.proto ${CMAKE_SOURCE_DIR}/ydb/library/actors/protos/unittests.proto ) +target_sources(library-actors-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/actors/protos/actors.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/actors/protos/interconnect.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/actors/protos/services_common.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/actors/protos/unittests.pb.h +) target_proto_addincls(library-actors-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/actors/protos/CMakeLists.linux-aarch64.txt b/ydb/library/actors/protos/CMakeLists.linux-aarch64.txt index 8a9d740b0fc6..78e3c66d8ca9 100644 --- a/ydb/library/actors/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/protos/CMakeLists.linux-aarch64.txt @@ -68,6 +68,12 @@ target_proto_messages(library-actors-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/protos/services_common.proto ${CMAKE_SOURCE_DIR}/ydb/library/actors/protos/unittests.proto ) +target_sources(library-actors-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/actors/protos/actors.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/actors/protos/interconnect.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/actors/protos/services_common.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/actors/protos/unittests.pb.h +) target_proto_addincls(library-actors-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/actors/protos/CMakeLists.linux-x86_64.txt b/ydb/library/actors/protos/CMakeLists.linux-x86_64.txt index 8a9d740b0fc6..78e3c66d8ca9 100644 --- a/ydb/library/actors/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/protos/CMakeLists.linux-x86_64.txt @@ -68,6 +68,12 @@ target_proto_messages(library-actors-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/protos/services_common.proto ${CMAKE_SOURCE_DIR}/ydb/library/actors/protos/unittests.proto ) +target_sources(library-actors-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/actors/protos/actors.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/actors/protos/interconnect.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/actors/protos/services_common.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/actors/protos/unittests.pb.h +) target_proto_addincls(library-actors-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/actors/protos/CMakeLists.windows-x86_64.txt b/ydb/library/actors/protos/CMakeLists.windows-x86_64.txt index aa9845bc7db4..434689053e4f 100644 --- a/ydb/library/actors/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/protos/CMakeLists.windows-x86_64.txt @@ -67,6 +67,12 @@ target_proto_messages(library-actors-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/protos/services_common.proto ${CMAKE_SOURCE_DIR}/ydb/library/actors/protos/unittests.proto ) +target_sources(library-actors-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/actors/protos/actors.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/actors/protos/interconnect.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/actors/protos/services_common.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/actors/protos/unittests.pb.h +) target_proto_addincls(library-actors-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/actors/testlib/CMakeLists.darwin-arm64.txt b/ydb/library/actors/testlib/CMakeLists.darwin-arm64.txt index e65674383b67..c248dba8a864 100644 --- a/ydb/library/actors/testlib/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/testlib/CMakeLists.darwin-arm64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(common) add_subdirectory(ut) add_library(library-actors-testlib) @@ -15,6 +16,7 @@ target_link_libraries(library-actors-testlib PUBLIC library-actors-core actors-interconnect-mock library-actors-protos + actors-testlib-common library-cpp-random_provider library-cpp-time_provider ) diff --git a/ydb/library/actors/testlib/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/testlib/CMakeLists.darwin-x86_64.txt index e65674383b67..c248dba8a864 100644 --- a/ydb/library/actors/testlib/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/testlib/CMakeLists.darwin-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(common) add_subdirectory(ut) add_library(library-actors-testlib) @@ -15,6 +16,7 @@ target_link_libraries(library-actors-testlib PUBLIC library-actors-core actors-interconnect-mock library-actors-protos + actors-testlib-common library-cpp-random_provider library-cpp-time_provider ) diff --git a/ydb/library/actors/testlib/CMakeLists.linux-aarch64.txt b/ydb/library/actors/testlib/CMakeLists.linux-aarch64.txt index 143acbad0ee1..ff4779a584e1 100644 --- a/ydb/library/actors/testlib/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/testlib/CMakeLists.linux-aarch64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(common) add_subdirectory(ut) add_library(library-actors-testlib) @@ -16,6 +17,7 @@ target_link_libraries(library-actors-testlib PUBLIC library-actors-core actors-interconnect-mock library-actors-protos + actors-testlib-common library-cpp-random_provider library-cpp-time_provider ) diff --git a/ydb/library/actors/testlib/CMakeLists.linux-x86_64.txt b/ydb/library/actors/testlib/CMakeLists.linux-x86_64.txt index 143acbad0ee1..ff4779a584e1 100644 --- a/ydb/library/actors/testlib/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/testlib/CMakeLists.linux-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(common) add_subdirectory(ut) add_library(library-actors-testlib) @@ -16,6 +17,7 @@ target_link_libraries(library-actors-testlib PUBLIC library-actors-core actors-interconnect-mock library-actors-protos + actors-testlib-common library-cpp-random_provider library-cpp-time_provider ) diff --git a/ydb/library/actors/testlib/CMakeLists.windows-x86_64.txt b/ydb/library/actors/testlib/CMakeLists.windows-x86_64.txt index e65674383b67..c248dba8a864 100644 --- a/ydb/library/actors/testlib/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/testlib/CMakeLists.windows-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(common) add_subdirectory(ut) add_library(library-actors-testlib) @@ -15,6 +16,7 @@ target_link_libraries(library-actors-testlib PUBLIC library-actors-core actors-interconnect-mock library-actors-protos + actors-testlib-common library-cpp-random_provider library-cpp-time_provider ) diff --git a/ydb/library/actors/testlib/common/CMakeLists.darwin-arm64.txt b/ydb/library/actors/testlib/common/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..176d2283a844 --- /dev/null +++ b/ydb/library/actors/testlib/common/CMakeLists.darwin-arm64.txt @@ -0,0 +1,18 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(actors-testlib-common) +target_link_libraries(actors-testlib-common PUBLIC + contrib-libs-cxxsupp + yutil + library-actors-core +) +target_sources(actors-testlib-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/testlib/common/events_scheduling.cpp +) diff --git a/ydb/library/actors/testlib/common/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/testlib/common/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..176d2283a844 --- /dev/null +++ b/ydb/library/actors/testlib/common/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,18 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(actors-testlib-common) +target_link_libraries(actors-testlib-common PUBLIC + contrib-libs-cxxsupp + yutil + library-actors-core +) +target_sources(actors-testlib-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/testlib/common/events_scheduling.cpp +) diff --git a/ydb/library/yql/providers/yt/CMakeLists.linux-aarch64.txt b/ydb/library/actors/testlib/common/CMakeLists.linux-aarch64.txt similarity index 57% rename from ydb/library/yql/providers/yt/CMakeLists.linux-aarch64.txt rename to ydb/library/actors/testlib/common/CMakeLists.linux-aarch64.txt index c762ef5d46c5..283b0b0775f1 100644 --- a/ydb/library/yql/providers/yt/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/testlib/common/CMakeLists.linux-aarch64.txt @@ -6,14 +6,14 @@ # original buildsystem will not be accepted. -add_subdirectory(codec) -add_subdirectory(common) -add_subdirectory(comp_nodes) -add_subdirectory(dq_task_preprocessor) -add_subdirectory(expr_nodes) -add_subdirectory(gateway) -add_subdirectory(job) -add_subdirectory(lib) -add_subdirectory(mkql_dq) -add_subdirectory(opt) -add_subdirectory(provider) + +add_library(actors-testlib-common) +target_link_libraries(actors-testlib-common PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-actors-core +) +target_sources(actors-testlib-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/testlib/common/events_scheduling.cpp +) diff --git a/ydb/library/yql/providers/yt/CMakeLists.linux-x86_64.txt b/ydb/library/actors/testlib/common/CMakeLists.linux-x86_64.txt similarity index 57% rename from ydb/library/yql/providers/yt/CMakeLists.linux-x86_64.txt rename to ydb/library/actors/testlib/common/CMakeLists.linux-x86_64.txt index c762ef5d46c5..283b0b0775f1 100644 --- a/ydb/library/yql/providers/yt/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/testlib/common/CMakeLists.linux-x86_64.txt @@ -6,14 +6,14 @@ # original buildsystem will not be accepted. -add_subdirectory(codec) -add_subdirectory(common) -add_subdirectory(comp_nodes) -add_subdirectory(dq_task_preprocessor) -add_subdirectory(expr_nodes) -add_subdirectory(gateway) -add_subdirectory(job) -add_subdirectory(lib) -add_subdirectory(mkql_dq) -add_subdirectory(opt) -add_subdirectory(provider) + +add_library(actors-testlib-common) +target_link_libraries(actors-testlib-common PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-actors-core +) +target_sources(actors-testlib-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/testlib/common/events_scheduling.cpp +) diff --git a/ydb/library/actors/testlib/common/CMakeLists.txt b/ydb/library/actors/testlib/common/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/actors/testlib/common/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/providers/yt/CMakeLists.windows-x86_64.txt b/ydb/library/actors/testlib/common/CMakeLists.windows-x86_64.txt similarity index 60% rename from ydb/library/yql/providers/yt/CMakeLists.windows-x86_64.txt rename to ydb/library/actors/testlib/common/CMakeLists.windows-x86_64.txt index 8e464fc08e94..176d2283a844 100644 --- a/ydb/library/yql/providers/yt/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/testlib/common/CMakeLists.windows-x86_64.txt @@ -6,13 +6,13 @@ # original buildsystem will not be accepted. -add_subdirectory(codec) -add_subdirectory(common) -add_subdirectory(comp_nodes) -add_subdirectory(expr_nodes) -add_subdirectory(gateway) -add_subdirectory(job) -add_subdirectory(lib) -add_subdirectory(mkql_dq) -add_subdirectory(opt) -add_subdirectory(provider) + +add_library(actors-testlib-common) +target_link_libraries(actors-testlib-common PUBLIC + contrib-libs-cxxsupp + yutil + library-actors-core +) +target_sources(actors-testlib-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/testlib/common/events_scheduling.cpp +) diff --git a/ydb/library/actors/testlib/ut/CMakeLists.darwin-arm64.txt b/ydb/library/actors/testlib/ut/CMakeLists.darwin-arm64.txt index 34c0be7c7009..4e9f57395949 100644 --- a/ydb/library/actors/testlib/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/testlib/ut/CMakeLists.darwin-arm64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-library-actors-testlib-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-testlib-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/testlib/decorator_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/testlib/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/testlib/ut/CMakeLists.darwin-x86_64.txt index d1e9a26dd522..b07448718603 100644 --- a/ydb/library/actors/testlib/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/testlib/ut/CMakeLists.darwin-x86_64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-library-actors-testlib-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-testlib-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/testlib/decorator_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/testlib/ut/CMakeLists.linux-aarch64.txt b/ydb/library/actors/testlib/ut/CMakeLists.linux-aarch64.txt index 8e8d2153a94f..9b1f9cd40284 100644 --- a/ydb/library/actors/testlib/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/testlib/ut/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-actors-testlib-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-testlib-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/testlib/decorator_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/testlib/ut/CMakeLists.linux-x86_64.txt b/ydb/library/actors/testlib/ut/CMakeLists.linux-x86_64.txt index 7360d63cef38..a17ea6eccf8e 100644 --- a/ydb/library/actors/testlib/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/testlib/ut/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-library-actors-testlib-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-testlib-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/testlib/decorator_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/testlib/ut/CMakeLists.windows-x86_64.txt b/ydb/library/actors/testlib/ut/CMakeLists.windows-x86_64.txt index a156d09b75db..f8c231171f04 100644 --- a/ydb/library/actors/testlib/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/testlib/ut/CMakeLists.windows-x86_64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/util/CMakeLists.darwin-arm64.txt b/ydb/library/actors/util/CMakeLists.darwin-arm64.txt index 5e9051b08679..946e742765ab 100644 --- a/ydb/library/actors/util/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/util/CMakeLists.darwin-arm64.txt @@ -17,6 +17,32 @@ target_link_libraries(library-actors-util PUBLIC library-cpp-pop_count ) target_sources(library-actors-util PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/affinity.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/cpu_load_log.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/cpumask.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/datetime.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/funnel_queue.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/futex.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/intrinsics.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/local_process_key.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/named_tuple.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/queue_chunk.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/queue_oneone_inplace.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/memory_track.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/memory_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/recentwnd.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/rope.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/rc_buf.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/shared_data.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/shared_data_rope_backend.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/should_continue.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/thread.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/threadparkpad.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/thread_load_log.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/ticket_lock.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/timerfd.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/unordered_cache.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/affinity.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/memory_track.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/memory_tracker.cpp diff --git a/ydb/library/actors/util/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/util/CMakeLists.darwin-x86_64.txt index 5e9051b08679..946e742765ab 100644 --- a/ydb/library/actors/util/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/util/CMakeLists.darwin-x86_64.txt @@ -17,6 +17,32 @@ target_link_libraries(library-actors-util PUBLIC library-cpp-pop_count ) target_sources(library-actors-util PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/affinity.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/cpu_load_log.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/cpumask.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/datetime.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/funnel_queue.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/futex.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/intrinsics.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/local_process_key.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/named_tuple.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/queue_chunk.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/queue_oneone_inplace.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/memory_track.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/memory_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/recentwnd.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/rope.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/rc_buf.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/shared_data.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/shared_data_rope_backend.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/should_continue.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/thread.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/threadparkpad.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/thread_load_log.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/ticket_lock.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/timerfd.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/unordered_cache.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/affinity.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/memory_track.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/memory_tracker.cpp diff --git a/ydb/library/actors/util/CMakeLists.linux-aarch64.txt b/ydb/library/actors/util/CMakeLists.linux-aarch64.txt index ff623584ba7f..327786431f17 100644 --- a/ydb/library/actors/util/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/util/CMakeLists.linux-aarch64.txt @@ -18,6 +18,32 @@ target_link_libraries(library-actors-util PUBLIC library-cpp-pop_count ) target_sources(library-actors-util PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/affinity.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/cpu_load_log.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/cpumask.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/datetime.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/funnel_queue.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/futex.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/intrinsics.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/local_process_key.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/named_tuple.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/queue_chunk.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/queue_oneone_inplace.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/memory_track.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/memory_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/recentwnd.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/rope.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/rc_buf.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/shared_data.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/shared_data_rope_backend.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/should_continue.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/thread.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/threadparkpad.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/thread_load_log.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/ticket_lock.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/timerfd.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/unordered_cache.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/affinity.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/memory_track.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/memory_tracker.cpp diff --git a/ydb/library/actors/util/CMakeLists.linux-x86_64.txt b/ydb/library/actors/util/CMakeLists.linux-x86_64.txt index ff623584ba7f..327786431f17 100644 --- a/ydb/library/actors/util/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/util/CMakeLists.linux-x86_64.txt @@ -18,6 +18,32 @@ target_link_libraries(library-actors-util PUBLIC library-cpp-pop_count ) target_sources(library-actors-util PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/affinity.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/cpu_load_log.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/cpumask.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/datetime.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/funnel_queue.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/futex.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/intrinsics.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/local_process_key.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/named_tuple.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/queue_chunk.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/queue_oneone_inplace.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/memory_track.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/memory_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/recentwnd.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/rope.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/rc_buf.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/shared_data.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/shared_data_rope_backend.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/should_continue.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/thread.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/threadparkpad.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/thread_load_log.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/ticket_lock.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/timerfd.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/unordered_cache.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/affinity.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/memory_track.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/memory_tracker.cpp diff --git a/ydb/library/actors/util/CMakeLists.windows-x86_64.txt b/ydb/library/actors/util/CMakeLists.windows-x86_64.txt index 5e9051b08679..946e742765ab 100644 --- a/ydb/library/actors/util/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/util/CMakeLists.windows-x86_64.txt @@ -17,6 +17,32 @@ target_link_libraries(library-actors-util PUBLIC library-cpp-pop_count ) target_sources(library-actors-util PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/affinity.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/cpu_load_log.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/cpumask.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/datetime.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/funnel_queue.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/futex.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/intrinsics.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/local_process_key.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/named_tuple.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/queue_chunk.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/queue_oneone_inplace.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/memory_track.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/memory_tracker.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/recentwnd.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/rope.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/rc_buf.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/shared_data.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/shared_data_rope_backend.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/should_continue.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/thread.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/threadparkpad.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/thread_load_log.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/ticket_lock.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/timerfd.h + ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/unordered_cache.h ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/affinity.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/memory_track.cpp ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/memory_tracker.cpp diff --git a/ydb/library/actors/util/ut/CMakeLists.darwin-arm64.txt b/ydb/library/actors/util/ut/CMakeLists.darwin-arm64.txt index 77a22c8dc684..448e0e08d112 100644 --- a/ydb/library/actors/util/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/util/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-library-actors-util-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-util-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/cpu_load_log_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/util/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/util/ut/CMakeLists.darwin-x86_64.txt index 1e4d43ea8d4f..956340bda8e1 100644 --- a/ydb/library/actors/util/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/util/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-library-actors-util-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-actors-util-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/cpu_load_log_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/util/ut/CMakeLists.linux-aarch64.txt b/ydb/library/actors/util/ut/CMakeLists.linux-aarch64.txt index 6964e48984b5..2d43727f1e98 100644 --- a/ydb/library/actors/util/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/util/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-actors-util-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-util-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/cpu_load_log_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/util/ut/CMakeLists.linux-x86_64.txt b/ydb/library/actors/util/ut/CMakeLists.linux-x86_64.txt index a058eff70998..5214ed90e793 100644 --- a/ydb/library/actors/util/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/util/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-actors-util-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-actors-util-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/actors/util/cpu_load_log_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/util/ut/CMakeLists.windows-x86_64.txt b/ydb/library/actors/util/ut/CMakeLists.windows-x86_64.txt index b3c2fd07247c..ecfadbcd4cfc 100644 --- a/ydb/library/actors/util/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/util/ut/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/actors/wilson/CMakeLists.darwin-arm64.txt b/ydb/library/actors/wilson/CMakeLists.darwin-arm64.txt index 72967708de71..a8825f703ac6 100644 --- a/ydb/library/actors/wilson/CMakeLists.darwin-arm64.txt +++ b/ydb/library/actors/wilson/CMakeLists.darwin-arm64.txt @@ -7,11 +7,14 @@ add_subdirectory(protos) +add_subdirectory(test_util) +add_subdirectory(ut) add_library(library-actors-wilson) target_link_libraries(library-actors-wilson PUBLIC contrib-libs-cxxsupp yutil + contrib-libs-opentelemetry-proto library-actors-core library-actors-protos actors-wilson-protos diff --git a/ydb/library/actors/wilson/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/wilson/CMakeLists.darwin-x86_64.txt index 72967708de71..a8825f703ac6 100644 --- a/ydb/library/actors/wilson/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/actors/wilson/CMakeLists.darwin-x86_64.txt @@ -7,11 +7,14 @@ add_subdirectory(protos) +add_subdirectory(test_util) +add_subdirectory(ut) add_library(library-actors-wilson) target_link_libraries(library-actors-wilson PUBLIC contrib-libs-cxxsupp yutil + contrib-libs-opentelemetry-proto library-actors-core library-actors-protos actors-wilson-protos diff --git a/ydb/library/actors/wilson/CMakeLists.linux-aarch64.txt b/ydb/library/actors/wilson/CMakeLists.linux-aarch64.txt index 7fce57579d5f..042bb2774efd 100644 --- a/ydb/library/actors/wilson/CMakeLists.linux-aarch64.txt +++ b/ydb/library/actors/wilson/CMakeLists.linux-aarch64.txt @@ -7,12 +7,15 @@ add_subdirectory(protos) +add_subdirectory(test_util) +add_subdirectory(ut) add_library(library-actors-wilson) target_link_libraries(library-actors-wilson PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + contrib-libs-opentelemetry-proto library-actors-core library-actors-protos actors-wilson-protos diff --git a/ydb/library/actors/wilson/CMakeLists.linux-x86_64.txt b/ydb/library/actors/wilson/CMakeLists.linux-x86_64.txt index 7fce57579d5f..042bb2774efd 100644 --- a/ydb/library/actors/wilson/CMakeLists.linux-x86_64.txt +++ b/ydb/library/actors/wilson/CMakeLists.linux-x86_64.txt @@ -7,12 +7,15 @@ add_subdirectory(protos) +add_subdirectory(test_util) +add_subdirectory(ut) add_library(library-actors-wilson) target_link_libraries(library-actors-wilson PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + contrib-libs-opentelemetry-proto library-actors-core library-actors-protos actors-wilson-protos diff --git a/ydb/library/actors/wilson/CMakeLists.windows-x86_64.txt b/ydb/library/actors/wilson/CMakeLists.windows-x86_64.txt index 72967708de71..a8825f703ac6 100644 --- a/ydb/library/actors/wilson/CMakeLists.windows-x86_64.txt +++ b/ydb/library/actors/wilson/CMakeLists.windows-x86_64.txt @@ -7,11 +7,14 @@ add_subdirectory(protos) +add_subdirectory(test_util) +add_subdirectory(ut) add_library(library-actors-wilson) target_link_libraries(library-actors-wilson PUBLIC contrib-libs-cxxsupp yutil + contrib-libs-opentelemetry-proto library-actors-core library-actors-protos actors-wilson-protos diff --git a/ydb/library/actors/wilson/test_util/CMakeLists.darwin-arm64.txt b/ydb/library/actors/wilson/test_util/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..d5bf3f777e64 --- /dev/null +++ b/ydb/library/actors/wilson/test_util/CMakeLists.darwin-arm64.txt @@ -0,0 +1,17 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(actors-wilson-test_util INTERFACE) +target_link_libraries(actors-wilson-test_util INTERFACE + contrib-libs-cxxsupp + yutil +) +target_sources(actors-wilson-test_util INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/wilson/test_util/fake_wilson_uploader.h +) diff --git a/ydb/library/actors/wilson/test_util/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/wilson/test_util/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..d5bf3f777e64 --- /dev/null +++ b/ydb/library/actors/wilson/test_util/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,17 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(actors-wilson-test_util INTERFACE) +target_link_libraries(actors-wilson-test_util INTERFACE + contrib-libs-cxxsupp + yutil +) +target_sources(actors-wilson-test_util INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/wilson/test_util/fake_wilson_uploader.h +) diff --git a/ydb/library/actors/wilson/test_util/CMakeLists.linux-aarch64.txt b/ydb/library/actors/wilson/test_util/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..f0c8c19c444f --- /dev/null +++ b/ydb/library/actors/wilson/test_util/CMakeLists.linux-aarch64.txt @@ -0,0 +1,18 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(actors-wilson-test_util INTERFACE) +target_link_libraries(actors-wilson-test_util INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil +) +target_sources(actors-wilson-test_util INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/wilson/test_util/fake_wilson_uploader.h +) diff --git a/ydb/library/actors/wilson/test_util/CMakeLists.linux-x86_64.txt b/ydb/library/actors/wilson/test_util/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..f0c8c19c444f --- /dev/null +++ b/ydb/library/actors/wilson/test_util/CMakeLists.linux-x86_64.txt @@ -0,0 +1,18 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(actors-wilson-test_util INTERFACE) +target_link_libraries(actors-wilson-test_util INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil +) +target_sources(actors-wilson-test_util INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/wilson/test_util/fake_wilson_uploader.h +) diff --git a/ydb/library/actors/wilson/test_util/CMakeLists.txt b/ydb/library/actors/wilson/test_util/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/actors/wilson/test_util/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/actors/wilson/test_util/CMakeLists.windows-x86_64.txt b/ydb/library/actors/wilson/test_util/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..d5bf3f777e64 --- /dev/null +++ b/ydb/library/actors/wilson/test_util/CMakeLists.windows-x86_64.txt @@ -0,0 +1,17 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(actors-wilson-test_util INTERFACE) +target_link_libraries(actors-wilson-test_util INTERFACE + contrib-libs-cxxsupp + yutil +) +target_sources(actors-wilson-test_util INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/wilson/test_util/fake_wilson_uploader.h +) diff --git a/ydb/library/actors/wilson/ut/CMakeLists.darwin-arm64.txt b/ydb/library/actors/wilson/ut/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..3750af83dcb1 --- /dev/null +++ b/ydb/library/actors/wilson/ut/CMakeLists.darwin-arm64.txt @@ -0,0 +1,65 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-actors-wilson-ut) +target_include_directories(ydb-library-actors-wilson-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/wilson +) +target_link_libraries(ydb-library-actors-wilson-ut PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + library-actors-wilson +) +target_link_options(ydb-library-actors-wilson-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-library-actors-wilson-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/wilson/wilson_trace_ut.cpp +) +set_property( + TARGET + ydb-library-actors-wilson-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-actors-wilson-ut + TEST_TARGET + ydb-library-actors-wilson-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-actors-wilson-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-actors-wilson-ut + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-library-actors-wilson-ut + system_allocator +) +vcs_info(ydb-library-actors-wilson-ut) diff --git a/ydb/library/actors/wilson/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/actors/wilson/ut/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..abb61f6f2f5a --- /dev/null +++ b/ydb/library/actors/wilson/ut/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,66 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-actors-wilson-ut) +target_include_directories(ydb-library-actors-wilson-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/wilson +) +target_link_libraries(ydb-library-actors-wilson-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + library-actors-wilson +) +target_link_options(ydb-library-actors-wilson-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-library-actors-wilson-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/wilson/wilson_trace_ut.cpp +) +set_property( + TARGET + ydb-library-actors-wilson-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-actors-wilson-ut + TEST_TARGET + ydb-library-actors-wilson-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-actors-wilson-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-actors-wilson-ut + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-library-actors-wilson-ut + system_allocator +) +vcs_info(ydb-library-actors-wilson-ut) diff --git a/ydb/library/actors/wilson/ut/CMakeLists.linux-aarch64.txt b/ydb/library/actors/wilson/ut/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..bb1af84e8d03 --- /dev/null +++ b/ydb/library/actors/wilson/ut/CMakeLists.linux-aarch64.txt @@ -0,0 +1,68 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-actors-wilson-ut) +target_include_directories(ydb-library-actors-wilson-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/wilson +) +target_link_libraries(ydb-library-actors-wilson-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + library-actors-wilson +) +target_link_options(ydb-library-actors-wilson-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-library-actors-wilson-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/wilson/wilson_trace_ut.cpp +) +set_property( + TARGET + ydb-library-actors-wilson-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-actors-wilson-ut + TEST_TARGET + ydb-library-actors-wilson-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-actors-wilson-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-actors-wilson-ut + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-library-actors-wilson-ut + cpp-malloc-jemalloc +) +vcs_info(ydb-library-actors-wilson-ut) diff --git a/ydb/library/actors/wilson/ut/CMakeLists.linux-x86_64.txt b/ydb/library/actors/wilson/ut/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..b3803efed8c5 --- /dev/null +++ b/ydb/library/actors/wilson/ut/CMakeLists.linux-x86_64.txt @@ -0,0 +1,70 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-actors-wilson-ut) +target_include_directories(ydb-library-actors-wilson-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/wilson +) +target_link_libraries(ydb-library-actors-wilson-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + library-actors-wilson +) +target_link_options(ydb-library-actors-wilson-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-library-actors-wilson-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/wilson/wilson_trace_ut.cpp +) +set_property( + TARGET + ydb-library-actors-wilson-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-actors-wilson-ut + TEST_TARGET + ydb-library-actors-wilson-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-actors-wilson-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-actors-wilson-ut + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-library-actors-wilson-ut + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(ydb-library-actors-wilson-ut) diff --git a/ydb/library/actors/wilson/ut/CMakeLists.txt b/ydb/library/actors/wilson/ut/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/actors/wilson/ut/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/actors/wilson/ut/CMakeLists.windows-x86_64.txt b/ydb/library/actors/wilson/ut/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..d4661ee3c0ff --- /dev/null +++ b/ydb/library/actors/wilson/ut/CMakeLists.windows-x86_64.txt @@ -0,0 +1,61 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-actors-wilson-ut) +target_include_directories(ydb-library-actors-wilson-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/wilson +) +target_link_libraries(ydb-library-actors-wilson-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + library-actors-wilson +) +target_sources(ydb-library-actors-wilson-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/actors/wilson/wilson_trace_ut.cpp +) +set_property( + TARGET + ydb-library-actors-wilson-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-actors-wilson-ut + TEST_TARGET + ydb-library-actors-wilson-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-actors-wilson-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-actors-wilson-ut + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-library-actors-wilson-ut + system_allocator +) +vcs_info(ydb-library-actors-wilson-ut) diff --git a/ydb/library/arrow_clickhouse/ut/CMakeLists.darwin-arm64.txt b/ydb/library/arrow_clickhouse/ut/CMakeLists.darwin-arm64.txt index 569c3db98b5b..890934effe81 100644 --- a/ydb/library/arrow_clickhouse/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/arrow_clickhouse/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-library-arrow_clickhouse-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-arrow_clickhouse-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/arrow_clickhouse/ut_aggregator.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/arrow_clickhouse/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/arrow_clickhouse/ut/CMakeLists.darwin-x86_64.txt index 496bf7079bbc..31aa895461e8 100644 --- a/ydb/library/arrow_clickhouse/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/arrow_clickhouse/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-library-arrow_clickhouse-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-arrow_clickhouse-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/arrow_clickhouse/ut_aggregator.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/arrow_clickhouse/ut/CMakeLists.linux-aarch64.txt b/ydb/library/arrow_clickhouse/ut/CMakeLists.linux-aarch64.txt index 49d7f4cbb31d..26332ec6a5f9 100644 --- a/ydb/library/arrow_clickhouse/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/arrow_clickhouse/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-arrow_clickhouse-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-arrow_clickhouse-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/arrow_clickhouse/ut_aggregator.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/arrow_clickhouse/ut/CMakeLists.linux-x86_64.txt b/ydb/library/arrow_clickhouse/ut/CMakeLists.linux-x86_64.txt index 649807cc79e6..bc2847f9ab84 100644 --- a/ydb/library/arrow_clickhouse/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/arrow_clickhouse/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-arrow_clickhouse-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-arrow_clickhouse-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/arrow_clickhouse/ut_aggregator.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/arrow_clickhouse/ut/CMakeLists.windows-x86_64.txt b/ydb/library/arrow_clickhouse/ut/CMakeLists.windows-x86_64.txt index 3fd6d7c54b91..a76ff0f05ae7 100644 --- a/ydb/library/arrow_clickhouse/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/arrow_clickhouse/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/arrow_kernels/CMakeLists.darwin-arm64.txt b/ydb/library/arrow_kernels/CMakeLists.darwin-arm64.txt index a6a7cff53e9f..12185413e5fe 100644 --- a/ydb/library/arrow_kernels/CMakeLists.darwin-arm64.txt +++ b/ydb/library/arrow_kernels/CMakeLists.darwin-arm64.txt @@ -7,14 +7,26 @@ add_subdirectory(ut) +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) add_library(ydb-library-arrow_kernels) target_link_libraries(ydb-library-arrow_kernels PUBLIC contrib-libs-cxxsupp yutil libs-apache-arrow + tools-enum_parser-enum_serialization_runtime ) target_sources(ydb-library-arrow_kernels PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/arrow_kernels/func_cast.cpp ${CMAKE_SOURCE_DIR}/ydb/library/arrow_kernels/ut_common.cpp ) +generate_enum_serilization(ydb-library-arrow_kernels + ${CMAKE_SOURCE_DIR}/ydb/library/arrow_kernels/operations.h + INCLUDE_HEADERS + ydb/library/arrow_kernels/operations.h +) diff --git a/ydb/library/arrow_kernels/CMakeLists.darwin-x86_64.txt b/ydb/library/arrow_kernels/CMakeLists.darwin-x86_64.txt index a6a7cff53e9f..12185413e5fe 100644 --- a/ydb/library/arrow_kernels/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/arrow_kernels/CMakeLists.darwin-x86_64.txt @@ -7,14 +7,26 @@ add_subdirectory(ut) +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) add_library(ydb-library-arrow_kernels) target_link_libraries(ydb-library-arrow_kernels PUBLIC contrib-libs-cxxsupp yutil libs-apache-arrow + tools-enum_parser-enum_serialization_runtime ) target_sources(ydb-library-arrow_kernels PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/arrow_kernels/func_cast.cpp ${CMAKE_SOURCE_DIR}/ydb/library/arrow_kernels/ut_common.cpp ) +generate_enum_serilization(ydb-library-arrow_kernels + ${CMAKE_SOURCE_DIR}/ydb/library/arrow_kernels/operations.h + INCLUDE_HEADERS + ydb/library/arrow_kernels/operations.h +) diff --git a/ydb/library/arrow_kernels/CMakeLists.linux-aarch64.txt b/ydb/library/arrow_kernels/CMakeLists.linux-aarch64.txt index a6f80d3e7173..8e66aec6cd5e 100644 --- a/ydb/library/arrow_kernels/CMakeLists.linux-aarch64.txt +++ b/ydb/library/arrow_kernels/CMakeLists.linux-aarch64.txt @@ -7,6 +7,12 @@ add_subdirectory(ut) +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) add_library(ydb-library-arrow_kernels) target_link_libraries(ydb-library-arrow_kernels PUBLIC @@ -14,8 +20,14 @@ target_link_libraries(ydb-library-arrow_kernels PUBLIC contrib-libs-cxxsupp yutil libs-apache-arrow + tools-enum_parser-enum_serialization_runtime ) target_sources(ydb-library-arrow_kernels PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/arrow_kernels/func_cast.cpp ${CMAKE_SOURCE_DIR}/ydb/library/arrow_kernels/ut_common.cpp ) +generate_enum_serilization(ydb-library-arrow_kernels + ${CMAKE_SOURCE_DIR}/ydb/library/arrow_kernels/operations.h + INCLUDE_HEADERS + ydb/library/arrow_kernels/operations.h +) diff --git a/ydb/library/arrow_kernels/CMakeLists.linux-x86_64.txt b/ydb/library/arrow_kernels/CMakeLists.linux-x86_64.txt index a6f80d3e7173..8e66aec6cd5e 100644 --- a/ydb/library/arrow_kernels/CMakeLists.linux-x86_64.txt +++ b/ydb/library/arrow_kernels/CMakeLists.linux-x86_64.txt @@ -7,6 +7,12 @@ add_subdirectory(ut) +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) add_library(ydb-library-arrow_kernels) target_link_libraries(ydb-library-arrow_kernels PUBLIC @@ -14,8 +20,14 @@ target_link_libraries(ydb-library-arrow_kernels PUBLIC contrib-libs-cxxsupp yutil libs-apache-arrow + tools-enum_parser-enum_serialization_runtime ) target_sources(ydb-library-arrow_kernels PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/arrow_kernels/func_cast.cpp ${CMAKE_SOURCE_DIR}/ydb/library/arrow_kernels/ut_common.cpp ) +generate_enum_serilization(ydb-library-arrow_kernels + ${CMAKE_SOURCE_DIR}/ydb/library/arrow_kernels/operations.h + INCLUDE_HEADERS + ydb/library/arrow_kernels/operations.h +) diff --git a/ydb/library/arrow_kernels/CMakeLists.windows-x86_64.txt b/ydb/library/arrow_kernels/CMakeLists.windows-x86_64.txt index a6a7cff53e9f..12185413e5fe 100644 --- a/ydb/library/arrow_kernels/CMakeLists.windows-x86_64.txt +++ b/ydb/library/arrow_kernels/CMakeLists.windows-x86_64.txt @@ -7,14 +7,26 @@ add_subdirectory(ut) +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) add_library(ydb-library-arrow_kernels) target_link_libraries(ydb-library-arrow_kernels PUBLIC contrib-libs-cxxsupp yutil libs-apache-arrow + tools-enum_parser-enum_serialization_runtime ) target_sources(ydb-library-arrow_kernels PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/arrow_kernels/func_cast.cpp ${CMAKE_SOURCE_DIR}/ydb/library/arrow_kernels/ut_common.cpp ) +generate_enum_serilization(ydb-library-arrow_kernels + ${CMAKE_SOURCE_DIR}/ydb/library/arrow_kernels/operations.h + INCLUDE_HEADERS + ydb/library/arrow_kernels/operations.h +) diff --git a/ydb/library/arrow_kernels/ut/CMakeLists.darwin-arm64.txt b/ydb/library/arrow_kernels/ut/CMakeLists.darwin-arm64.txt index 16fbb4b260b4..0e215fb6457c 100644 --- a/ydb/library/arrow_kernels/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/arrow_kernels/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-library-arrow_kernels-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-arrow_kernels-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/arrow_kernels/ut_common.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/arrow_kernels/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/arrow_kernels/ut/CMakeLists.darwin-x86_64.txt index 65ff71fa682c..2746748be370 100644 --- a/ydb/library/arrow_kernels/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/arrow_kernels/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-library-arrow_kernels-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-arrow_kernels-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/arrow_kernels/ut_common.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/arrow_kernels/ut/CMakeLists.linux-aarch64.txt b/ydb/library/arrow_kernels/ut/CMakeLists.linux-aarch64.txt index 3d63e1b8de5b..49439c5c8c57 100644 --- a/ydb/library/arrow_kernels/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/arrow_kernels/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-library-arrow_kernels-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-arrow_kernels-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/arrow_kernels/ut_common.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/arrow_kernels/ut/CMakeLists.linux-x86_64.txt b/ydb/library/arrow_kernels/ut/CMakeLists.linux-x86_64.txt index 021182fcd9e6..a5673598da97 100644 --- a/ydb/library/arrow_kernels/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/arrow_kernels/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-library-arrow_kernels-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-arrow_kernels-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/arrow_kernels/ut_common.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/arrow_kernels/ut/CMakeLists.windows-x86_64.txt b/ydb/library/arrow_kernels/ut/CMakeLists.windows-x86_64.txt index 04dce8099b84..42a16e4c516c 100644 --- a/ydb/library/arrow_kernels/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/arrow_kernels/ut/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/yt/CMakeLists.darwin-arm64.txt b/ydb/library/arrow_parquet/CMakeLists.darwin-arm64.txt similarity index 57% rename from ydb/library/yql/providers/yt/CMakeLists.darwin-arm64.txt rename to ydb/library/arrow_parquet/CMakeLists.darwin-arm64.txt index c762ef5d46c5..c35626011d6b 100644 --- a/ydb/library/yql/providers/yt/CMakeLists.darwin-arm64.txt +++ b/ydb/library/arrow_parquet/CMakeLists.darwin-arm64.txt @@ -6,14 +6,14 @@ # original buildsystem will not be accepted. -add_subdirectory(codec) -add_subdirectory(common) -add_subdirectory(comp_nodes) -add_subdirectory(dq_task_preprocessor) -add_subdirectory(expr_nodes) -add_subdirectory(gateway) -add_subdirectory(job) -add_subdirectory(lib) -add_subdirectory(mkql_dq) -add_subdirectory(opt) -add_subdirectory(provider) + +add_library(ydb-library-arrow_parquet) +target_link_libraries(ydb-library-arrow_parquet PUBLIC + contrib-libs-cxxsupp + yutil + cpp-client-ydb_value + libs-apache-arrow +) +target_sources(ydb-library-arrow_parquet PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/arrow_parquet/result_set_parquet_printer.cpp +) diff --git a/ydb/library/yql/providers/yt/CMakeLists.darwin-x86_64.txt b/ydb/library/arrow_parquet/CMakeLists.darwin-x86_64.txt similarity index 57% rename from ydb/library/yql/providers/yt/CMakeLists.darwin-x86_64.txt rename to ydb/library/arrow_parquet/CMakeLists.darwin-x86_64.txt index c762ef5d46c5..c35626011d6b 100644 --- a/ydb/library/yql/providers/yt/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/arrow_parquet/CMakeLists.darwin-x86_64.txt @@ -6,14 +6,14 @@ # original buildsystem will not be accepted. -add_subdirectory(codec) -add_subdirectory(common) -add_subdirectory(comp_nodes) -add_subdirectory(dq_task_preprocessor) -add_subdirectory(expr_nodes) -add_subdirectory(gateway) -add_subdirectory(job) -add_subdirectory(lib) -add_subdirectory(mkql_dq) -add_subdirectory(opt) -add_subdirectory(provider) + +add_library(ydb-library-arrow_parquet) +target_link_libraries(ydb-library-arrow_parquet PUBLIC + contrib-libs-cxxsupp + yutil + cpp-client-ydb_value + libs-apache-arrow +) +target_sources(ydb-library-arrow_parquet PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/arrow_parquet/result_set_parquet_printer.cpp +) diff --git a/ydb/library/arrow_parquet/CMakeLists.linux-aarch64.txt b/ydb/library/arrow_parquet/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..4dca002a3b41 --- /dev/null +++ b/ydb/library/arrow_parquet/CMakeLists.linux-aarch64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(ydb-library-arrow_parquet) +target_link_libraries(ydb-library-arrow_parquet PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-client-ydb_value + libs-apache-arrow +) +target_sources(ydb-library-arrow_parquet PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/arrow_parquet/result_set_parquet_printer.cpp +) diff --git a/ydb/library/arrow_parquet/CMakeLists.linux-x86_64.txt b/ydb/library/arrow_parquet/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..4dca002a3b41 --- /dev/null +++ b/ydb/library/arrow_parquet/CMakeLists.linux-x86_64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(ydb-library-arrow_parquet) +target_link_libraries(ydb-library-arrow_parquet PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-client-ydb_value + libs-apache-arrow +) +target_sources(ydb-library-arrow_parquet PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/arrow_parquet/result_set_parquet_printer.cpp +) diff --git a/ydb/library/arrow_parquet/CMakeLists.txt b/ydb/library/arrow_parquet/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/arrow_parquet/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/arrow_parquet/CMakeLists.windows-x86_64.txt b/ydb/library/arrow_parquet/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..c35626011d6b --- /dev/null +++ b/ydb/library/arrow_parquet/CMakeLists.windows-x86_64.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(ydb-library-arrow_parquet) +target_link_libraries(ydb-library-arrow_parquet PUBLIC + contrib-libs-cxxsupp + yutil + cpp-client-ydb_value + libs-apache-arrow +) +target_sources(ydb-library-arrow_parquet PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/arrow_parquet/result_set_parquet_printer.cpp +) diff --git a/ydb/library/backup/ut/CMakeLists.darwin-arm64.txt b/ydb/library/backup/ut/CMakeLists.darwin-arm64.txt index 67e2c354c966..a9baf83ce428 100644 --- a/ydb/library/backup/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/backup/ut/CMakeLists.darwin-arm64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-library-backup-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-backup-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/backup/ut/ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/backup/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/backup/ut/CMakeLists.darwin-x86_64.txt index a86760851919..b775d50908ca 100644 --- a/ydb/library/backup/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/backup/ut/CMakeLists.darwin-x86_64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-library-backup-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-backup-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/backup/ut/ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/backup/ut/CMakeLists.linux-aarch64.txt b/ydb/library/backup/ut/CMakeLists.linux-aarch64.txt index d442a30ab524..395758ba4bfd 100644 --- a/ydb/library/backup/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/backup/ut/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-backup-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-backup-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/backup/ut/ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/backup/ut/CMakeLists.linux-x86_64.txt b/ydb/library/backup/ut/CMakeLists.linux-x86_64.txt index 8769cd2d0144..b79e440e2145 100644 --- a/ydb/library/backup/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/backup/ut/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-library-backup-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-backup-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/backup/ut/ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/backup/ut/CMakeLists.windows-x86_64.txt b/ydb/library/backup/ut/CMakeLists.windows-x86_64.txt index 164c83e2c047..484efd652fac 100644 --- a/ydb/library/backup/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/backup/ut/CMakeLists.windows-x86_64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/binary_json/ut/CMakeLists.darwin-arm64.txt b/ydb/library/binary_json/ut/CMakeLists.darwin-arm64.txt index bfb41fc4c3b8..422b30919793 100644 --- a/ydb/library/binary_json/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/binary_json/ut/CMakeLists.darwin-arm64.txt @@ -20,7 +20,7 @@ target_link_libraries(ydb-library-binary_json-ut PUBLIC cpp-testing-unittest_main ydb-library-binary_json yql-minikql-dom - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 udf-service-exception_policy core-issue-protos yql-sql-pg_dummy @@ -29,8 +29,6 @@ target_link_options(ydb-library-binary_json-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-binary_json-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/binary_json/ut/container_ut.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/binary_json/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/binary_json/ut/CMakeLists.darwin-x86_64.txt index 2092e96b8a56..bdddd1982ab3 100644 --- a/ydb/library/binary_json/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/binary_json/ut/CMakeLists.darwin-x86_64.txt @@ -21,7 +21,7 @@ target_link_libraries(ydb-library-binary_json-ut PUBLIC cpp-testing-unittest_main ydb-library-binary_json yql-minikql-dom - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 udf-service-exception_policy core-issue-protos yql-sql-pg_dummy @@ -30,8 +30,6 @@ target_link_options(ydb-library-binary_json-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-binary_json-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/binary_json/ut/container_ut.cpp @@ -65,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/binary_json/ut/CMakeLists.linux-aarch64.txt b/ydb/library/binary_json/ut/CMakeLists.linux-aarch64.txt index c39f2ec1a1e7..9e9c222755a2 100644 --- a/ydb/library/binary_json/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/binary_json/ut/CMakeLists.linux-aarch64.txt @@ -21,7 +21,7 @@ target_link_libraries(ydb-library-binary_json-ut PUBLIC cpp-testing-unittest_main ydb-library-binary_json yql-minikql-dom - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 udf-service-exception_policy core-issue-protos yql-sql-pg_dummy @@ -32,9 +32,6 @@ target_link_options(ydb-library-binary_json-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-binary_json-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/binary_json/ut/container_ut.cpp @@ -68,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/binary_json/ut/CMakeLists.linux-x86_64.txt b/ydb/library/binary_json/ut/CMakeLists.linux-x86_64.txt index 868f374d08d9..3bcaffb566a3 100644 --- a/ydb/library/binary_json/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/binary_json/ut/CMakeLists.linux-x86_64.txt @@ -22,7 +22,7 @@ target_link_libraries(ydb-library-binary_json-ut PUBLIC cpp-testing-unittest_main ydb-library-binary_json yql-minikql-dom - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 udf-service-exception_policy core-issue-protos yql-sql-pg_dummy @@ -33,9 +33,6 @@ target_link_options(ydb-library-binary_json-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-binary_json-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/binary_json/ut/container_ut.cpp @@ -69,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/binary_json/ut/CMakeLists.windows-x86_64.txt b/ydb/library/binary_json/ut/CMakeLists.windows-x86_64.txt index a01c249595fd..1f9d42dddfe7 100644 --- a/ydb/library/binary_json/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/binary_json/ut/CMakeLists.windows-x86_64.txt @@ -21,7 +21,7 @@ target_link_libraries(ydb-library-binary_json-ut PUBLIC cpp-testing-unittest_main ydb-library-binary_json yql-minikql-dom - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 udf-service-exception_policy core-issue-protos yql-sql-pg_dummy @@ -58,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/conclusion/CMakeLists.darwin-arm64.txt b/ydb/library/conclusion/CMakeLists.darwin-arm64.txt index ee4f4c3fa297..0998b6e45627 100644 --- a/ydb/library/conclusion/CMakeLists.darwin-arm64.txt +++ b/ydb/library/conclusion/CMakeLists.darwin-arm64.txt @@ -11,6 +11,7 @@ add_library(ydb-library-conclusion) target_link_libraries(ydb-library-conclusion PUBLIC contrib-libs-cxxsupp yutil + api-protos ) target_sources(ydb-library-conclusion PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/conclusion/result.cpp diff --git a/ydb/library/conclusion/CMakeLists.darwin-x86_64.txt b/ydb/library/conclusion/CMakeLists.darwin-x86_64.txt index ee4f4c3fa297..0998b6e45627 100644 --- a/ydb/library/conclusion/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/conclusion/CMakeLists.darwin-x86_64.txt @@ -11,6 +11,7 @@ add_library(ydb-library-conclusion) target_link_libraries(ydb-library-conclusion PUBLIC contrib-libs-cxxsupp yutil + api-protos ) target_sources(ydb-library-conclusion PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/conclusion/result.cpp diff --git a/ydb/library/conclusion/CMakeLists.linux-aarch64.txt b/ydb/library/conclusion/CMakeLists.linux-aarch64.txt index 64c5c16ee3ac..28c93468552a 100644 --- a/ydb/library/conclusion/CMakeLists.linux-aarch64.txt +++ b/ydb/library/conclusion/CMakeLists.linux-aarch64.txt @@ -12,6 +12,7 @@ target_link_libraries(ydb-library-conclusion PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + api-protos ) target_sources(ydb-library-conclusion PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/conclusion/result.cpp diff --git a/ydb/library/conclusion/CMakeLists.linux-x86_64.txt b/ydb/library/conclusion/CMakeLists.linux-x86_64.txt index 64c5c16ee3ac..28c93468552a 100644 --- a/ydb/library/conclusion/CMakeLists.linux-x86_64.txt +++ b/ydb/library/conclusion/CMakeLists.linux-x86_64.txt @@ -12,6 +12,7 @@ target_link_libraries(ydb-library-conclusion PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + api-protos ) target_sources(ydb-library-conclusion PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/conclusion/result.cpp diff --git a/ydb/library/conclusion/CMakeLists.windows-x86_64.txt b/ydb/library/conclusion/CMakeLists.windows-x86_64.txt index ee4f4c3fa297..0998b6e45627 100644 --- a/ydb/library/conclusion/CMakeLists.windows-x86_64.txt +++ b/ydb/library/conclusion/CMakeLists.windows-x86_64.txt @@ -11,6 +11,7 @@ add_library(ydb-library-conclusion) target_link_libraries(ydb-library-conclusion PUBLIC contrib-libs-cxxsupp yutil + api-protos ) target_sources(ydb-library-conclusion PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/conclusion/result.cpp diff --git a/ydb/library/db_pool/protos/CMakeLists.darwin-arm64.txt b/ydb/library/db_pool/protos/CMakeLists.darwin-arm64.txt index b27a2ed4f79e..ccbeeaffa74f 100644 --- a/ydb/library/db_pool/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/library/db_pool/protos/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(library-db_pool-protos PUBLIC target_proto_messages(library-db_pool-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/db_pool/protos/config.proto ) +target_sources(library-db_pool-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/db_pool/protos/config.pb.h +) target_proto_addincls(library-db_pool-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/db_pool/protos/CMakeLists.darwin-x86_64.txt b/ydb/library/db_pool/protos/CMakeLists.darwin-x86_64.txt index b27a2ed4f79e..ccbeeaffa74f 100644 --- a/ydb/library/db_pool/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/db_pool/protos/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(library-db_pool-protos PUBLIC target_proto_messages(library-db_pool-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/db_pool/protos/config.proto ) +target_sources(library-db_pool-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/db_pool/protos/config.pb.h +) target_proto_addincls(library-db_pool-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/db_pool/protos/CMakeLists.linux-aarch64.txt b/ydb/library/db_pool/protos/CMakeLists.linux-aarch64.txt index d3afcddab93a..6240defb1483 100644 --- a/ydb/library/db_pool/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/library/db_pool/protos/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(library-db_pool-protos PUBLIC target_proto_messages(library-db_pool-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/db_pool/protos/config.proto ) +target_sources(library-db_pool-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/db_pool/protos/config.pb.h +) target_proto_addincls(library-db_pool-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/db_pool/protos/CMakeLists.linux-x86_64.txt b/ydb/library/db_pool/protos/CMakeLists.linux-x86_64.txt index d3afcddab93a..6240defb1483 100644 --- a/ydb/library/db_pool/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/library/db_pool/protos/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(library-db_pool-protos PUBLIC target_proto_messages(library-db_pool-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/db_pool/protos/config.proto ) +target_sources(library-db_pool-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/db_pool/protos/config.pb.h +) target_proto_addincls(library-db_pool-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/db_pool/protos/CMakeLists.windows-x86_64.txt b/ydb/library/db_pool/protos/CMakeLists.windows-x86_64.txt index b27a2ed4f79e..ccbeeaffa74f 100644 --- a/ydb/library/db_pool/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/library/db_pool/protos/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(library-db_pool-protos PUBLIC target_proto_messages(library-db_pool-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/db_pool/protos/config.proto ) +target_sources(library-db_pool-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/db_pool/protos/config.pb.h +) target_proto_addincls(library-db_pool-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/dynumber/CMakeLists.darwin-arm64.txt b/ydb/library/dynumber/CMakeLists.darwin-arm64.txt index 8eba3e9ddc69..356f736137a0 100644 --- a/ydb/library/dynumber/CMakeLists.darwin-arm64.txt +++ b/ydb/library/dynumber/CMakeLists.darwin-arm64.txt @@ -15,5 +15,6 @@ target_link_libraries(ydb-library-dynumber PUBLIC cpp-containers-stack_vector ) target_sources(ydb-library-dynumber PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/dynumber/cast.h ${CMAKE_SOURCE_DIR}/ydb/library/dynumber/dynumber.cpp ) diff --git a/ydb/library/dynumber/CMakeLists.darwin-x86_64.txt b/ydb/library/dynumber/CMakeLists.darwin-x86_64.txt index 8eba3e9ddc69..356f736137a0 100644 --- a/ydb/library/dynumber/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/dynumber/CMakeLists.darwin-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(ydb-library-dynumber PUBLIC cpp-containers-stack_vector ) target_sources(ydb-library-dynumber PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/dynumber/cast.h ${CMAKE_SOURCE_DIR}/ydb/library/dynumber/dynumber.cpp ) diff --git a/ydb/library/dynumber/CMakeLists.linux-aarch64.txt b/ydb/library/dynumber/CMakeLists.linux-aarch64.txt index fe445ed48615..208e0a3de850 100644 --- a/ydb/library/dynumber/CMakeLists.linux-aarch64.txt +++ b/ydb/library/dynumber/CMakeLists.linux-aarch64.txt @@ -16,5 +16,6 @@ target_link_libraries(ydb-library-dynumber PUBLIC cpp-containers-stack_vector ) target_sources(ydb-library-dynumber PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/dynumber/cast.h ${CMAKE_SOURCE_DIR}/ydb/library/dynumber/dynumber.cpp ) diff --git a/ydb/library/dynumber/CMakeLists.linux-x86_64.txt b/ydb/library/dynumber/CMakeLists.linux-x86_64.txt index fe445ed48615..208e0a3de850 100644 --- a/ydb/library/dynumber/CMakeLists.linux-x86_64.txt +++ b/ydb/library/dynumber/CMakeLists.linux-x86_64.txt @@ -16,5 +16,6 @@ target_link_libraries(ydb-library-dynumber PUBLIC cpp-containers-stack_vector ) target_sources(ydb-library-dynumber PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/dynumber/cast.h ${CMAKE_SOURCE_DIR}/ydb/library/dynumber/dynumber.cpp ) diff --git a/ydb/library/dynumber/CMakeLists.windows-x86_64.txt b/ydb/library/dynumber/CMakeLists.windows-x86_64.txt index 8eba3e9ddc69..356f736137a0 100644 --- a/ydb/library/dynumber/CMakeLists.windows-x86_64.txt +++ b/ydb/library/dynumber/CMakeLists.windows-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(ydb-library-dynumber PUBLIC cpp-containers-stack_vector ) target_sources(ydb-library-dynumber PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/dynumber/cast.h ${CMAKE_SOURCE_DIR}/ydb/library/dynumber/dynumber.cpp ) diff --git a/ydb/library/dynumber/ut/CMakeLists.darwin-arm64.txt b/ydb/library/dynumber/ut/CMakeLists.darwin-arm64.txt index 7234bb130658..2d4b6fa3e5d6 100644 --- a/ydb/library/dynumber/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/dynumber/ut/CMakeLists.darwin-arm64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/dynumber/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/dynumber/ut/CMakeLists.darwin-x86_64.txt index 1e05c67ab4ae..3cd8b3f5c1da 100644 --- a/ydb/library/dynumber/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/dynumber/ut/CMakeLists.darwin-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/dynumber/ut/CMakeLists.linux-aarch64.txt b/ydb/library/dynumber/ut/CMakeLists.linux-aarch64.txt index d8ba55b2edd6..4ff2e490f47c 100644 --- a/ydb/library/dynumber/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/dynumber/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-dynumber-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-dynumber-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/dynumber/ut/dynumber_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/dynumber/ut/CMakeLists.linux-x86_64.txt b/ydb/library/dynumber/ut/CMakeLists.linux-x86_64.txt index 67e831c1b1d3..885c872d4fcb 100644 --- a/ydb/library/dynumber/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/dynumber/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-dynumber-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-dynumber-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/dynumber/ut/dynumber_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/dynumber/ut/CMakeLists.windows-x86_64.txt b/ydb/library/dynumber/ut/CMakeLists.windows-x86_64.txt index 92c4696922ee..991ec18e2d39 100644 --- a/ydb/library/dynumber/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/dynumber/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/folder_service/CMakeLists.darwin-arm64.txt b/ydb/library/folder_service/CMakeLists.darwin-arm64.txt index e5e5e5bd264c..15b5439edbf2 100644 --- a/ydb/library/folder_service/CMakeLists.darwin-arm64.txt +++ b/ydb/library/folder_service/CMakeLists.darwin-arm64.txt @@ -18,5 +18,7 @@ target_link_libraries(ydb-library-folder_service PUBLIC library-folder_service-proto ) target_sources(ydb-library-folder_service PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/folder_service/events.h + ${CMAKE_SOURCE_DIR}/ydb/library/folder_service/folder_service.h ${CMAKE_SOURCE_DIR}/ydb/library/folder_service/folder_service.cpp ) diff --git a/ydb/library/folder_service/CMakeLists.darwin-x86_64.txt b/ydb/library/folder_service/CMakeLists.darwin-x86_64.txt index e5e5e5bd264c..15b5439edbf2 100644 --- a/ydb/library/folder_service/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/folder_service/CMakeLists.darwin-x86_64.txt @@ -18,5 +18,7 @@ target_link_libraries(ydb-library-folder_service PUBLIC library-folder_service-proto ) target_sources(ydb-library-folder_service PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/folder_service/events.h + ${CMAKE_SOURCE_DIR}/ydb/library/folder_service/folder_service.h ${CMAKE_SOURCE_DIR}/ydb/library/folder_service/folder_service.cpp ) diff --git a/ydb/library/folder_service/CMakeLists.linux-aarch64.txt b/ydb/library/folder_service/CMakeLists.linux-aarch64.txt index 62335e7dfcea..ae965d060690 100644 --- a/ydb/library/folder_service/CMakeLists.linux-aarch64.txt +++ b/ydb/library/folder_service/CMakeLists.linux-aarch64.txt @@ -19,5 +19,7 @@ target_link_libraries(ydb-library-folder_service PUBLIC library-folder_service-proto ) target_sources(ydb-library-folder_service PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/folder_service/events.h + ${CMAKE_SOURCE_DIR}/ydb/library/folder_service/folder_service.h ${CMAKE_SOURCE_DIR}/ydb/library/folder_service/folder_service.cpp ) diff --git a/ydb/library/folder_service/CMakeLists.linux-x86_64.txt b/ydb/library/folder_service/CMakeLists.linux-x86_64.txt index 62335e7dfcea..ae965d060690 100644 --- a/ydb/library/folder_service/CMakeLists.linux-x86_64.txt +++ b/ydb/library/folder_service/CMakeLists.linux-x86_64.txt @@ -19,5 +19,7 @@ target_link_libraries(ydb-library-folder_service PUBLIC library-folder_service-proto ) target_sources(ydb-library-folder_service PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/folder_service/events.h + ${CMAKE_SOURCE_DIR}/ydb/library/folder_service/folder_service.h ${CMAKE_SOURCE_DIR}/ydb/library/folder_service/folder_service.cpp ) diff --git a/ydb/library/folder_service/CMakeLists.windows-x86_64.txt b/ydb/library/folder_service/CMakeLists.windows-x86_64.txt index e5e5e5bd264c..15b5439edbf2 100644 --- a/ydb/library/folder_service/CMakeLists.windows-x86_64.txt +++ b/ydb/library/folder_service/CMakeLists.windows-x86_64.txt @@ -18,5 +18,7 @@ target_link_libraries(ydb-library-folder_service PUBLIC library-folder_service-proto ) target_sources(ydb-library-folder_service PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/folder_service/events.h + ${CMAKE_SOURCE_DIR}/ydb/library/folder_service/folder_service.h ${CMAKE_SOURCE_DIR}/ydb/library/folder_service/folder_service.cpp ) diff --git a/ydb/library/folder_service/proto/CMakeLists.darwin-arm64.txt b/ydb/library/folder_service/proto/CMakeLists.darwin-arm64.txt index 9d9c4e98f2b7..cd716fd047fe 100644 --- a/ydb/library/folder_service/proto/CMakeLists.darwin-arm64.txt +++ b/ydb/library/folder_service/proto/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(library-folder_service-proto PUBLIC target_proto_messages(library-folder_service-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/folder_service/proto/config.proto ) +target_sources(library-folder_service-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/folder_service/proto/config.pb.h +) target_proto_addincls(library-folder_service-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/folder_service/proto/CMakeLists.darwin-x86_64.txt b/ydb/library/folder_service/proto/CMakeLists.darwin-x86_64.txt index 9d9c4e98f2b7..cd716fd047fe 100644 --- a/ydb/library/folder_service/proto/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/folder_service/proto/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(library-folder_service-proto PUBLIC target_proto_messages(library-folder_service-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/folder_service/proto/config.proto ) +target_sources(library-folder_service-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/folder_service/proto/config.pb.h +) target_proto_addincls(library-folder_service-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/folder_service/proto/CMakeLists.linux-aarch64.txt b/ydb/library/folder_service/proto/CMakeLists.linux-aarch64.txt index 9698675f9913..bec1821175fe 100644 --- a/ydb/library/folder_service/proto/CMakeLists.linux-aarch64.txt +++ b/ydb/library/folder_service/proto/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(library-folder_service-proto PUBLIC target_proto_messages(library-folder_service-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/folder_service/proto/config.proto ) +target_sources(library-folder_service-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/folder_service/proto/config.pb.h +) target_proto_addincls(library-folder_service-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/folder_service/proto/CMakeLists.linux-x86_64.txt b/ydb/library/folder_service/proto/CMakeLists.linux-x86_64.txt index 9698675f9913..bec1821175fe 100644 --- a/ydb/library/folder_service/proto/CMakeLists.linux-x86_64.txt +++ b/ydb/library/folder_service/proto/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(library-folder_service-proto PUBLIC target_proto_messages(library-folder_service-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/folder_service/proto/config.proto ) +target_sources(library-folder_service-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/folder_service/proto/config.pb.h +) target_proto_addincls(library-folder_service-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/folder_service/proto/CMakeLists.windows-x86_64.txt b/ydb/library/folder_service/proto/CMakeLists.windows-x86_64.txt index 9d9c4e98f2b7..cd716fd047fe 100644 --- a/ydb/library/folder_service/proto/CMakeLists.windows-x86_64.txt +++ b/ydb/library/folder_service/proto/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(library-folder_service-proto PUBLIC target_proto_messages(library-folder_service-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/folder_service/proto/config.proto ) +target_sources(library-folder_service-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/folder_service/proto/config.pb.h +) target_proto_addincls(library-folder_service-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/fyamlcpp/CMakeLists.darwin-arm64.txt b/ydb/library/fyamlcpp/CMakeLists.darwin-arm64.txt index 4687447d7f71..b0faab420c4b 100644 --- a/ydb/library/fyamlcpp/CMakeLists.darwin-arm64.txt +++ b/ydb/library/fyamlcpp/CMakeLists.darwin-arm64.txt @@ -14,5 +14,6 @@ target_link_libraries(ydb-library-fyamlcpp PUBLIC contrib-libs-libfyaml ) target_sources(ydb-library-fyamlcpp PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/fyamlcpp/fyamlcpp.h ${CMAKE_SOURCE_DIR}/ydb/library/fyamlcpp/fyamlcpp.cpp ) diff --git a/ydb/library/fyamlcpp/CMakeLists.darwin-x86_64.txt b/ydb/library/fyamlcpp/CMakeLists.darwin-x86_64.txt index 4687447d7f71..b0faab420c4b 100644 --- a/ydb/library/fyamlcpp/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/fyamlcpp/CMakeLists.darwin-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(ydb-library-fyamlcpp PUBLIC contrib-libs-libfyaml ) target_sources(ydb-library-fyamlcpp PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/fyamlcpp/fyamlcpp.h ${CMAKE_SOURCE_DIR}/ydb/library/fyamlcpp/fyamlcpp.cpp ) diff --git a/ydb/library/fyamlcpp/CMakeLists.linux-aarch64.txt b/ydb/library/fyamlcpp/CMakeLists.linux-aarch64.txt index afa6496d4116..1dff27671c72 100644 --- a/ydb/library/fyamlcpp/CMakeLists.linux-aarch64.txt +++ b/ydb/library/fyamlcpp/CMakeLists.linux-aarch64.txt @@ -15,5 +15,6 @@ target_link_libraries(ydb-library-fyamlcpp PUBLIC contrib-libs-libfyaml ) target_sources(ydb-library-fyamlcpp PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/fyamlcpp/fyamlcpp.h ${CMAKE_SOURCE_DIR}/ydb/library/fyamlcpp/fyamlcpp.cpp ) diff --git a/ydb/library/fyamlcpp/CMakeLists.linux-x86_64.txt b/ydb/library/fyamlcpp/CMakeLists.linux-x86_64.txt index afa6496d4116..1dff27671c72 100644 --- a/ydb/library/fyamlcpp/CMakeLists.linux-x86_64.txt +++ b/ydb/library/fyamlcpp/CMakeLists.linux-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(ydb-library-fyamlcpp PUBLIC contrib-libs-libfyaml ) target_sources(ydb-library-fyamlcpp PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/fyamlcpp/fyamlcpp.h ${CMAKE_SOURCE_DIR}/ydb/library/fyamlcpp/fyamlcpp.cpp ) diff --git a/ydb/library/fyamlcpp/CMakeLists.windows-x86_64.txt b/ydb/library/fyamlcpp/CMakeLists.windows-x86_64.txt index 4687447d7f71..b0faab420c4b 100644 --- a/ydb/library/fyamlcpp/CMakeLists.windows-x86_64.txt +++ b/ydb/library/fyamlcpp/CMakeLists.windows-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(ydb-library-fyamlcpp PUBLIC contrib-libs-libfyaml ) target_sources(ydb-library-fyamlcpp PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/fyamlcpp/fyamlcpp.h ${CMAKE_SOURCE_DIR}/ydb/library/fyamlcpp/fyamlcpp.cpp ) diff --git a/ydb/library/grpc/client/ut/CMakeLists.darwin-arm64.txt b/ydb/library/grpc/client/ut/CMakeLists.darwin-arm64.txt index eccaba597cb2..aef24c4b93ee 100644 --- a/ydb/library/grpc/client/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/grpc/client/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-library-grpc-client-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-grpc-client-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/grpc/client/ut/grpc_client_low_ut.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/grpc/client/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/grpc/client/ut/CMakeLists.darwin-x86_64.txt index 485241c214c1..155324799596 100644 --- a/ydb/library/grpc/client/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/grpc/client/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-library-grpc-client-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-grpc-client-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/grpc/client/ut/grpc_client_low_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/grpc/client/ut/CMakeLists.linux-aarch64.txt b/ydb/library/grpc/client/ut/CMakeLists.linux-aarch64.txt index 28edb2dbf69b..3dd17f3294c5 100644 --- a/ydb/library/grpc/client/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/grpc/client/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-grpc-client-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-grpc-client-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/grpc/client/ut/grpc_client_low_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/grpc/client/ut/CMakeLists.linux-x86_64.txt b/ydb/library/grpc/client/ut/CMakeLists.linux-x86_64.txt index 09a0126be1b4..4bd2b14d0869 100644 --- a/ydb/library/grpc/client/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/grpc/client/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-grpc-client-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-grpc-client-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/grpc/client/ut/grpc_client_low_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/grpc/client/ut/CMakeLists.windows-x86_64.txt b/ydb/library/grpc/client/ut/CMakeLists.windows-x86_64.txt index 82596d01ea0b..21b02c09f429 100644 --- a/ydb/library/grpc/client/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/grpc/client/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/grpc/common/CMakeLists.darwin-arm64.txt b/ydb/library/grpc/common/CMakeLists.darwin-arm64.txt index 01d036e60721..4209dd207caf 100644 --- a/ydb/library/grpc/common/CMakeLists.darwin-arm64.txt +++ b/ydb/library/grpc/common/CMakeLists.darwin-arm64.txt @@ -13,3 +13,7 @@ target_link_libraries(library-grpc-common INTERFACE yutil contrib-libs-grpc ) +target_sources(library-grpc-common INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/grpc/common/time_point.h + ${CMAKE_SOURCE_DIR}/ydb/library/grpc/common/constants.h +) diff --git a/ydb/library/grpc/common/CMakeLists.darwin-x86_64.txt b/ydb/library/grpc/common/CMakeLists.darwin-x86_64.txt index 01d036e60721..4209dd207caf 100644 --- a/ydb/library/grpc/common/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/grpc/common/CMakeLists.darwin-x86_64.txt @@ -13,3 +13,7 @@ target_link_libraries(library-grpc-common INTERFACE yutil contrib-libs-grpc ) +target_sources(library-grpc-common INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/grpc/common/time_point.h + ${CMAKE_SOURCE_DIR}/ydb/library/grpc/common/constants.h +) diff --git a/ydb/library/grpc/common/CMakeLists.linux-aarch64.txt b/ydb/library/grpc/common/CMakeLists.linux-aarch64.txt index 219760cd6dda..dcd477cc4819 100644 --- a/ydb/library/grpc/common/CMakeLists.linux-aarch64.txt +++ b/ydb/library/grpc/common/CMakeLists.linux-aarch64.txt @@ -14,3 +14,7 @@ target_link_libraries(library-grpc-common INTERFACE yutil contrib-libs-grpc ) +target_sources(library-grpc-common INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/grpc/common/time_point.h + ${CMAKE_SOURCE_DIR}/ydb/library/grpc/common/constants.h +) diff --git a/ydb/library/grpc/common/CMakeLists.linux-x86_64.txt b/ydb/library/grpc/common/CMakeLists.linux-x86_64.txt index 219760cd6dda..dcd477cc4819 100644 --- a/ydb/library/grpc/common/CMakeLists.linux-x86_64.txt +++ b/ydb/library/grpc/common/CMakeLists.linux-x86_64.txt @@ -14,3 +14,7 @@ target_link_libraries(library-grpc-common INTERFACE yutil contrib-libs-grpc ) +target_sources(library-grpc-common INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/grpc/common/time_point.h + ${CMAKE_SOURCE_DIR}/ydb/library/grpc/common/constants.h +) diff --git a/ydb/library/grpc/common/CMakeLists.windows-x86_64.txt b/ydb/library/grpc/common/CMakeLists.windows-x86_64.txt index 01d036e60721..4209dd207caf 100644 --- a/ydb/library/grpc/common/CMakeLists.windows-x86_64.txt +++ b/ydb/library/grpc/common/CMakeLists.windows-x86_64.txt @@ -13,3 +13,7 @@ target_link_libraries(library-grpc-common INTERFACE yutil contrib-libs-grpc ) +target_sources(library-grpc-common INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/grpc/common/time_point.h + ${CMAKE_SOURCE_DIR}/ydb/library/grpc/common/constants.h +) diff --git a/ydb/library/grpc/server/ut/CMakeLists.darwin-arm64.txt b/ydb/library/grpc/server/ut/CMakeLists.darwin-arm64.txt index a744e3c8758d..04f83052d713 100644 --- a/ydb/library/grpc/server/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/grpc/server/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-library-grpc-server-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-grpc-server-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/grpc/server/ut/grpc_response_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/grpc/server/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/grpc/server/ut/CMakeLists.darwin-x86_64.txt index 838718196351..1b51aad6f044 100644 --- a/ydb/library/grpc/server/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/grpc/server/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-library-grpc-server-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-grpc-server-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/grpc/server/ut/grpc_response_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/grpc/server/ut/CMakeLists.linux-aarch64.txt b/ydb/library/grpc/server/ut/CMakeLists.linux-aarch64.txt index 049e4d2a5ea5..202dae2348ed 100644 --- a/ydb/library/grpc/server/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/grpc/server/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-grpc-server-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-grpc-server-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/grpc/server/ut/grpc_response_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/grpc/server/ut/CMakeLists.linux-x86_64.txt b/ydb/library/grpc/server/ut/CMakeLists.linux-x86_64.txt index ed0ce2ccd89c..bd19b4b19a93 100644 --- a/ydb/library/grpc/server/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/grpc/server/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-grpc-server-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-grpc-server-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/grpc/server/ut/grpc_response_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/grpc/server/ut/CMakeLists.windows-x86_64.txt b/ydb/library/grpc/server/ut/CMakeLists.windows-x86_64.txt index 9bc5b10519d6..88fa6a0bbbe9 100644 --- a/ydb/library/grpc/server/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/grpc/server/ut/CMakeLists.windows-x86_64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/http_proxy/authorization/ut/CMakeLists.darwin-arm64.txt b/ydb/library/http_proxy/authorization/ut/CMakeLists.darwin-arm64.txt index f0c27f7ff32f..cecb854e86bc 100644 --- a/ydb/library/http_proxy/authorization/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/http_proxy/authorization/ut/CMakeLists.darwin-arm64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/http_proxy/authorization/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/http_proxy/authorization/ut/CMakeLists.darwin-x86_64.txt index c59736f16187..c295fc4c6cab 100644 --- a/ydb/library/http_proxy/authorization/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/http_proxy/authorization/ut/CMakeLists.darwin-x86_64.txt @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/http_proxy/authorization/ut/CMakeLists.linux-aarch64.txt b/ydb/library/http_proxy/authorization/ut/CMakeLists.linux-aarch64.txt index 86ac1883abcd..944c4f5ab978 100644 --- a/ydb/library/http_proxy/authorization/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/http_proxy/authorization/ut/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-http_proxy-authorization-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-http_proxy-authorization-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/http_proxy/authorization/ut/auth_helpers_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/http_proxy/authorization/ut/CMakeLists.linux-x86_64.txt b/ydb/library/http_proxy/authorization/ut/CMakeLists.linux-x86_64.txt index da7a82bf7b25..85ac7297f15c 100644 --- a/ydb/library/http_proxy/authorization/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/http_proxy/authorization/ut/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-library-http_proxy-authorization-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-http_proxy-authorization-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/http_proxy/authorization/ut/auth_helpers_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/http_proxy/authorization/ut/CMakeLists.windows-x86_64.txt b/ydb/library/http_proxy/authorization/ut/CMakeLists.windows-x86_64.txt index 75db995ea997..e802c35acd28 100644 --- a/ydb/library/http_proxy/authorization/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/http_proxy/authorization/ut/CMakeLists.windows-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/keys/ut/CMakeLists.darwin-arm64.txt b/ydb/library/keys/ut/CMakeLists.darwin-arm64.txt index 1461bee2fa31..50b5a00f8bf9 100644 --- a/ydb/library/keys/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/keys/ut/CMakeLists.darwin-arm64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/keys/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/keys/ut/CMakeLists.darwin-x86_64.txt index 6c6635f3a722..04df00e896f6 100644 --- a/ydb/library/keys/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/keys/ut/CMakeLists.darwin-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/keys/ut/CMakeLists.linux-aarch64.txt b/ydb/library/keys/ut/CMakeLists.linux-aarch64.txt index 26b4ae8d0726..033df32c5691 100644 --- a/ydb/library/keys/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/keys/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-keys-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-keys-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/keys/default_keys_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/keys/ut/CMakeLists.linux-x86_64.txt b/ydb/library/keys/ut/CMakeLists.linux-x86_64.txt index b9f4bdd132cd..a8121f625519 100644 --- a/ydb/library/keys/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/keys/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-keys-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-keys-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/keys/default_keys_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/keys/ut/CMakeLists.windows-x86_64.txt b/ydb/library/keys/ut/CMakeLists.windows-x86_64.txt index 2dd1b03275e1..2c0e613a3370 100644 --- a/ydb/library/keys/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/keys/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/login/CMakeLists.darwin-arm64.txt b/ydb/library/login/CMakeLists.darwin-arm64.txt index d9b859367bcf..d3424f8eb307 100644 --- a/ydb/library/login/CMakeLists.darwin-arm64.txt +++ b/ydb/library/login/CMakeLists.darwin-arm64.txt @@ -21,5 +21,6 @@ target_link_libraries(ydb-library-login PUBLIC library-login-protos ) target_sources(ydb-library-login PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/login/login.h ${CMAKE_SOURCE_DIR}/ydb/library/login/login.cpp ) diff --git a/ydb/library/login/CMakeLists.darwin-x86_64.txt b/ydb/library/login/CMakeLists.darwin-x86_64.txt index d9b859367bcf..d3424f8eb307 100644 --- a/ydb/library/login/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/login/CMakeLists.darwin-x86_64.txt @@ -21,5 +21,6 @@ target_link_libraries(ydb-library-login PUBLIC library-login-protos ) target_sources(ydb-library-login PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/login/login.h ${CMAKE_SOURCE_DIR}/ydb/library/login/login.cpp ) diff --git a/ydb/library/login/CMakeLists.linux-aarch64.txt b/ydb/library/login/CMakeLists.linux-aarch64.txt index e9f65247d286..616ed31ac8c4 100644 --- a/ydb/library/login/CMakeLists.linux-aarch64.txt +++ b/ydb/library/login/CMakeLists.linux-aarch64.txt @@ -22,5 +22,6 @@ target_link_libraries(ydb-library-login PUBLIC library-login-protos ) target_sources(ydb-library-login PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/login/login.h ${CMAKE_SOURCE_DIR}/ydb/library/login/login.cpp ) diff --git a/ydb/library/login/CMakeLists.linux-x86_64.txt b/ydb/library/login/CMakeLists.linux-x86_64.txt index e9f65247d286..616ed31ac8c4 100644 --- a/ydb/library/login/CMakeLists.linux-x86_64.txt +++ b/ydb/library/login/CMakeLists.linux-x86_64.txt @@ -22,5 +22,6 @@ target_link_libraries(ydb-library-login PUBLIC library-login-protos ) target_sources(ydb-library-login PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/login/login.h ${CMAKE_SOURCE_DIR}/ydb/library/login/login.cpp ) diff --git a/ydb/library/login/CMakeLists.windows-x86_64.txt b/ydb/library/login/CMakeLists.windows-x86_64.txt index d9b859367bcf..d3424f8eb307 100644 --- a/ydb/library/login/CMakeLists.windows-x86_64.txt +++ b/ydb/library/login/CMakeLists.windows-x86_64.txt @@ -21,5 +21,6 @@ target_link_libraries(ydb-library-login PUBLIC library-login-protos ) target_sources(ydb-library-login PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/login/login.h ${CMAKE_SOURCE_DIR}/ydb/library/login/login.cpp ) diff --git a/ydb/library/login/protos/CMakeLists.darwin-arm64.txt b/ydb/library/login/protos/CMakeLists.darwin-arm64.txt index bf877d4c78c9..0c35c2a3e9f8 100644 --- a/ydb/library/login/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/library/login/protos/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(library-login-protos PUBLIC target_proto_messages(library-login-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/login/protos/login.proto ) +target_sources(library-login-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/login/protos/login.pb.h +) target_proto_addincls(library-login-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/login/protos/CMakeLists.darwin-x86_64.txt b/ydb/library/login/protos/CMakeLists.darwin-x86_64.txt index bf877d4c78c9..0c35c2a3e9f8 100644 --- a/ydb/library/login/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/login/protos/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(library-login-protos PUBLIC target_proto_messages(library-login-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/login/protos/login.proto ) +target_sources(library-login-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/login/protos/login.pb.h +) target_proto_addincls(library-login-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/login/protos/CMakeLists.linux-aarch64.txt b/ydb/library/login/protos/CMakeLists.linux-aarch64.txt index 066ed1ab3a30..b757c6ebb369 100644 --- a/ydb/library/login/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/library/login/protos/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(library-login-protos PUBLIC target_proto_messages(library-login-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/login/protos/login.proto ) +target_sources(library-login-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/login/protos/login.pb.h +) target_proto_addincls(library-login-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/login/protos/CMakeLists.linux-x86_64.txt b/ydb/library/login/protos/CMakeLists.linux-x86_64.txt index 066ed1ab3a30..b757c6ebb369 100644 --- a/ydb/library/login/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/library/login/protos/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(library-login-protos PUBLIC target_proto_messages(library-login-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/login/protos/login.proto ) +target_sources(library-login-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/login/protos/login.pb.h +) target_proto_addincls(library-login-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/login/protos/CMakeLists.windows-x86_64.txt b/ydb/library/login/protos/CMakeLists.windows-x86_64.txt index bf877d4c78c9..0c35c2a3e9f8 100644 --- a/ydb/library/login/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/library/login/protos/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(library-login-protos PUBLIC target_proto_messages(library-login-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/login/protos/login.proto ) +target_sources(library-login-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/login/protos/login.pb.h +) target_proto_addincls(library-login-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/login/ut/CMakeLists.darwin-arm64.txt b/ydb/library/login/ut/CMakeLists.darwin-arm64.txt index 234a7df0d1cb..3bcf5c800b04 100644 --- a/ydb/library/login/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/login/ut/CMakeLists.darwin-arm64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/login/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/login/ut/CMakeLists.darwin-x86_64.txt index ccfa236f34c3..0d024cf2e208 100644 --- a/ydb/library/login/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/login/ut/CMakeLists.darwin-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/login/ut/CMakeLists.linux-aarch64.txt b/ydb/library/login/ut/CMakeLists.linux-aarch64.txt index a3b222a5cd62..580e961d848b 100644 --- a/ydb/library/login/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/login/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-login-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-login-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/login/login_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/login/ut/CMakeLists.linux-x86_64.txt b/ydb/library/login/ut/CMakeLists.linux-x86_64.txt index bfcd1ae8a0fd..92585d957eee 100644 --- a/ydb/library/login/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/login/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-login-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-login-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/login/login_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/login/ut/CMakeLists.windows-x86_64.txt b/ydb/library/login/ut/CMakeLists.windows-x86_64.txt index e42eb30689df..5e49264a03cf 100644 --- a/ydb/library/login/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/login/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/mkql_proto/CMakeLists.darwin-arm64.txt b/ydb/library/mkql_proto/CMakeLists.darwin-arm64.txt index 3293268a7246..938c6348aa31 100644 --- a/ydb/library/mkql_proto/CMakeLists.darwin-arm64.txt +++ b/ydb/library/mkql_proto/CMakeLists.darwin-arm64.txt @@ -17,7 +17,7 @@ target_link_libraries(ydb-library-mkql_proto PUBLIC contrib-libs-cxxsupp yutil library-mkql_proto-protos - minikql-computation-llvm + yql-minikql-computation yql-parser-pg_catalog providers-common-codec api-protos diff --git a/ydb/library/mkql_proto/CMakeLists.darwin-x86_64.txt b/ydb/library/mkql_proto/CMakeLists.darwin-x86_64.txt index 3293268a7246..938c6348aa31 100644 --- a/ydb/library/mkql_proto/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/mkql_proto/CMakeLists.darwin-x86_64.txt @@ -17,7 +17,7 @@ target_link_libraries(ydb-library-mkql_proto PUBLIC contrib-libs-cxxsupp yutil library-mkql_proto-protos - minikql-computation-llvm + yql-minikql-computation yql-parser-pg_catalog providers-common-codec api-protos diff --git a/ydb/library/mkql_proto/CMakeLists.linux-aarch64.txt b/ydb/library/mkql_proto/CMakeLists.linux-aarch64.txt index 7f9c3130a518..687ab40b17ba 100644 --- a/ydb/library/mkql_proto/CMakeLists.linux-aarch64.txt +++ b/ydb/library/mkql_proto/CMakeLists.linux-aarch64.txt @@ -18,7 +18,7 @@ target_link_libraries(ydb-library-mkql_proto PUBLIC contrib-libs-cxxsupp yutil library-mkql_proto-protos - minikql-computation-llvm + yql-minikql-computation yql-parser-pg_catalog providers-common-codec api-protos diff --git a/ydb/library/mkql_proto/CMakeLists.linux-x86_64.txt b/ydb/library/mkql_proto/CMakeLists.linux-x86_64.txt index 7f9c3130a518..687ab40b17ba 100644 --- a/ydb/library/mkql_proto/CMakeLists.linux-x86_64.txt +++ b/ydb/library/mkql_proto/CMakeLists.linux-x86_64.txt @@ -18,7 +18,7 @@ target_link_libraries(ydb-library-mkql_proto PUBLIC contrib-libs-cxxsupp yutil library-mkql_proto-protos - minikql-computation-llvm + yql-minikql-computation yql-parser-pg_catalog providers-common-codec api-protos diff --git a/ydb/library/mkql_proto/CMakeLists.windows-x86_64.txt b/ydb/library/mkql_proto/CMakeLists.windows-x86_64.txt index 3293268a7246..938c6348aa31 100644 --- a/ydb/library/mkql_proto/CMakeLists.windows-x86_64.txt +++ b/ydb/library/mkql_proto/CMakeLists.windows-x86_64.txt @@ -17,7 +17,7 @@ target_link_libraries(ydb-library-mkql_proto PUBLIC contrib-libs-cxxsupp yutil library-mkql_proto-protos - minikql-computation-llvm + yql-minikql-computation yql-parser-pg_catalog providers-common-codec api-protos diff --git a/ydb/library/mkql_proto/protos/CMakeLists.darwin-arm64.txt b/ydb/library/mkql_proto/protos/CMakeLists.darwin-arm64.txt index 68671e8b3962..ba43d0115725 100644 --- a/ydb/library/mkql_proto/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/library/mkql_proto/protos/CMakeLists.darwin-arm64.txt @@ -38,6 +38,10 @@ target_link_libraries(library-mkql_proto-protos PUBLIC target_proto_messages(library-mkql_proto-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/mkql_proto/protos/minikql.proto ) +target_sources(library-mkql_proto-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/mkql_proto/protos/minikql.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/mkql_proto/protos/minikql.grpc.pb.h +) target_proto_addincls(library-mkql_proto-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/mkql_proto/protos/CMakeLists.darwin-x86_64.txt b/ydb/library/mkql_proto/protos/CMakeLists.darwin-x86_64.txt index 68671e8b3962..ba43d0115725 100644 --- a/ydb/library/mkql_proto/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/mkql_proto/protos/CMakeLists.darwin-x86_64.txt @@ -38,6 +38,10 @@ target_link_libraries(library-mkql_proto-protos PUBLIC target_proto_messages(library-mkql_proto-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/mkql_proto/protos/minikql.proto ) +target_sources(library-mkql_proto-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/mkql_proto/protos/minikql.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/mkql_proto/protos/minikql.grpc.pb.h +) target_proto_addincls(library-mkql_proto-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/mkql_proto/protos/CMakeLists.linux-aarch64.txt b/ydb/library/mkql_proto/protos/CMakeLists.linux-aarch64.txt index 4ba81eed8a31..c31cc65de313 100644 --- a/ydb/library/mkql_proto/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/library/mkql_proto/protos/CMakeLists.linux-aarch64.txt @@ -39,6 +39,10 @@ target_link_libraries(library-mkql_proto-protos PUBLIC target_proto_messages(library-mkql_proto-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/mkql_proto/protos/minikql.proto ) +target_sources(library-mkql_proto-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/mkql_proto/protos/minikql.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/mkql_proto/protos/minikql.grpc.pb.h +) target_proto_addincls(library-mkql_proto-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/mkql_proto/protos/CMakeLists.linux-x86_64.txt b/ydb/library/mkql_proto/protos/CMakeLists.linux-x86_64.txt index 4ba81eed8a31..c31cc65de313 100644 --- a/ydb/library/mkql_proto/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/library/mkql_proto/protos/CMakeLists.linux-x86_64.txt @@ -39,6 +39,10 @@ target_link_libraries(library-mkql_proto-protos PUBLIC target_proto_messages(library-mkql_proto-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/mkql_proto/protos/minikql.proto ) +target_sources(library-mkql_proto-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/mkql_proto/protos/minikql.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/mkql_proto/protos/minikql.grpc.pb.h +) target_proto_addincls(library-mkql_proto-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/mkql_proto/protos/CMakeLists.windows-x86_64.txt b/ydb/library/mkql_proto/protos/CMakeLists.windows-x86_64.txt index 68671e8b3962..ba43d0115725 100644 --- a/ydb/library/mkql_proto/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/library/mkql_proto/protos/CMakeLists.windows-x86_64.txt @@ -38,6 +38,10 @@ target_link_libraries(library-mkql_proto-protos PUBLIC target_proto_messages(library-mkql_proto-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/mkql_proto/protos/minikql.proto ) +target_sources(library-mkql_proto-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/mkql_proto/protos/minikql.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/mkql_proto/protos/minikql.grpc.pb.h +) target_proto_addincls(library-mkql_proto-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/mkql_proto/ut/CMakeLists.darwin-arm64.txt b/ydb/library/mkql_proto/ut/CMakeLists.darwin-arm64.txt index 86919d88b785..4fbccfbf185f 100644 --- a/ydb/library/mkql_proto/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/mkql_proto/ut/CMakeLists.darwin-arm64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-library-mkql_proto-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-mkql_proto-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/mkql_proto/mkql_proto_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/mkql_proto/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/mkql_proto/ut/CMakeLists.darwin-x86_64.txt index 6a14ff38ce92..1c07499f2851 100644 --- a/ydb/library/mkql_proto/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/mkql_proto/ut/CMakeLists.darwin-x86_64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-library-mkql_proto-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-mkql_proto-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/mkql_proto/mkql_proto_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/mkql_proto/ut/CMakeLists.linux-aarch64.txt b/ydb/library/mkql_proto/ut/CMakeLists.linux-aarch64.txt index 0c46b134beee..e2eb944c22da 100644 --- a/ydb/library/mkql_proto/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/mkql_proto/ut/CMakeLists.linux-aarch64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-library-mkql_proto-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-mkql_proto-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/mkql_proto/mkql_proto_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/mkql_proto/ut/CMakeLists.linux-x86_64.txt b/ydb/library/mkql_proto/ut/CMakeLists.linux-x86_64.txt index a58fe535e504..eea32713cc8f 100644 --- a/ydb/library/mkql_proto/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/mkql_proto/ut/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-library-mkql_proto-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-mkql_proto-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/mkql_proto/mkql_proto_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/mkql_proto/ut/CMakeLists.windows-x86_64.txt b/ydb/library/mkql_proto/ut/CMakeLists.windows-x86_64.txt index 6e6659d2ff87..86ff2b66492e 100644 --- a/ydb/library/mkql_proto/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/mkql_proto/ut/CMakeLists.windows-x86_64.txt @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/mkql_proto/ut/helpers/CMakeLists.darwin-arm64.txt b/ydb/library/mkql_proto/ut/helpers/CMakeLists.darwin-arm64.txt index 3b9fd31457e3..f319a4127d3a 100644 --- a/ydb/library/mkql_proto/ut/helpers/CMakeLists.darwin-arm64.txt +++ b/ydb/library/mkql_proto/ut/helpers/CMakeLists.darwin-arm64.txt @@ -14,7 +14,7 @@ target_compile_options(mkql_proto-ut-helpers PRIVATE target_link_libraries(mkql_proto-ut-helpers PUBLIC contrib-libs-cxxsupp yutil - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 cpp-testing-unittest contrib-libs-protobuf ) diff --git a/ydb/library/mkql_proto/ut/helpers/CMakeLists.darwin-x86_64.txt b/ydb/library/mkql_proto/ut/helpers/CMakeLists.darwin-x86_64.txt index 3b9fd31457e3..f319a4127d3a 100644 --- a/ydb/library/mkql_proto/ut/helpers/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/mkql_proto/ut/helpers/CMakeLists.darwin-x86_64.txt @@ -14,7 +14,7 @@ target_compile_options(mkql_proto-ut-helpers PRIVATE target_link_libraries(mkql_proto-ut-helpers PUBLIC contrib-libs-cxxsupp yutil - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 cpp-testing-unittest contrib-libs-protobuf ) diff --git a/ydb/library/mkql_proto/ut/helpers/CMakeLists.linux-aarch64.txt b/ydb/library/mkql_proto/ut/helpers/CMakeLists.linux-aarch64.txt index 6d03f280d270..a94a50327a41 100644 --- a/ydb/library/mkql_proto/ut/helpers/CMakeLists.linux-aarch64.txt +++ b/ydb/library/mkql_proto/ut/helpers/CMakeLists.linux-aarch64.txt @@ -15,7 +15,7 @@ target_link_libraries(mkql_proto-ut-helpers PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 cpp-testing-unittest contrib-libs-protobuf ) diff --git a/ydb/library/mkql_proto/ut/helpers/CMakeLists.linux-x86_64.txt b/ydb/library/mkql_proto/ut/helpers/CMakeLists.linux-x86_64.txt index 6d03f280d270..a94a50327a41 100644 --- a/ydb/library/mkql_proto/ut/helpers/CMakeLists.linux-x86_64.txt +++ b/ydb/library/mkql_proto/ut/helpers/CMakeLists.linux-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(mkql_proto-ut-helpers PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 cpp-testing-unittest contrib-libs-protobuf ) diff --git a/ydb/library/mkql_proto/ut/helpers/CMakeLists.windows-x86_64.txt b/ydb/library/mkql_proto/ut/helpers/CMakeLists.windows-x86_64.txt index 3b9fd31457e3..f319a4127d3a 100644 --- a/ydb/library/mkql_proto/ut/helpers/CMakeLists.windows-x86_64.txt +++ b/ydb/library/mkql_proto/ut/helpers/CMakeLists.windows-x86_64.txt @@ -14,7 +14,7 @@ target_compile_options(mkql_proto-ut-helpers PRIVATE target_link_libraries(mkql_proto-ut-helpers PUBLIC contrib-libs-cxxsupp yutil - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 cpp-testing-unittest contrib-libs-protobuf ) diff --git a/ydb/library/naming_conventions/ut/CMakeLists.darwin-arm64.txt b/ydb/library/naming_conventions/ut/CMakeLists.darwin-arm64.txt index 9ab69002f731..11ad1f72b95f 100644 --- a/ydb/library/naming_conventions/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/naming_conventions/ut/CMakeLists.darwin-arm64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/naming_conventions/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/naming_conventions/ut/CMakeLists.darwin-x86_64.txt index 69a85ebc7405..bd27396ee821 100644 --- a/ydb/library/naming_conventions/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/naming_conventions/ut/CMakeLists.darwin-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/naming_conventions/ut/CMakeLists.linux-aarch64.txt b/ydb/library/naming_conventions/ut/CMakeLists.linux-aarch64.txt index 044e2ccb4ea6..6ee33773668f 100644 --- a/ydb/library/naming_conventions/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/naming_conventions/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-naming_conventions-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-naming_conventions-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/naming_conventions/ut/naming_conventions_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/naming_conventions/ut/CMakeLists.linux-x86_64.txt b/ydb/library/naming_conventions/ut/CMakeLists.linux-x86_64.txt index 24a509798b67..6bd7dd97aefa 100644 --- a/ydb/library/naming_conventions/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/naming_conventions/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-naming_conventions-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-naming_conventions-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/naming_conventions/ut/naming_conventions_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/naming_conventions/ut/CMakeLists.windows-x86_64.txt b/ydb/library/naming_conventions/ut/CMakeLists.windows-x86_64.txt index 4ffcb893d616..a16110b390dc 100644 --- a/ydb/library/naming_conventions/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/naming_conventions/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/pdisk_io/CMakeLists.darwin-arm64.txt b/ydb/library/pdisk_io/CMakeLists.darwin-arm64.txt index f29001c38650..771d0ae2cdbe 100644 --- a/ydb/library/pdisk_io/CMakeLists.darwin-arm64.txt +++ b/ydb/library/pdisk_io/CMakeLists.darwin-arm64.txt @@ -26,6 +26,12 @@ target_link_libraries(ydb-library-pdisk_io PUBLIC library-pdisk_io-protos ) target_sources(ydb-library-pdisk_io PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/aio.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/buffers.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/device_type.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/drivedata.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/sector_map.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/wcache.h ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/aio_mtp.cpp ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/file_params_darwin.cpp ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/aio.cpp diff --git a/ydb/library/pdisk_io/CMakeLists.darwin-x86_64.txt b/ydb/library/pdisk_io/CMakeLists.darwin-x86_64.txt index f29001c38650..771d0ae2cdbe 100644 --- a/ydb/library/pdisk_io/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/pdisk_io/CMakeLists.darwin-x86_64.txt @@ -26,6 +26,12 @@ target_link_libraries(ydb-library-pdisk_io PUBLIC library-pdisk_io-protos ) target_sources(ydb-library-pdisk_io PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/aio.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/buffers.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/device_type.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/drivedata.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/sector_map.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/wcache.h ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/aio_mtp.cpp ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/file_params_darwin.cpp ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/aio.cpp diff --git a/ydb/library/pdisk_io/CMakeLists.linux-aarch64.txt b/ydb/library/pdisk_io/CMakeLists.linux-aarch64.txt index 41331b6eabff..1caf9e924c92 100644 --- a/ydb/library/pdisk_io/CMakeLists.linux-aarch64.txt +++ b/ydb/library/pdisk_io/CMakeLists.linux-aarch64.txt @@ -30,6 +30,12 @@ target_link_libraries(ydb-library-pdisk_io PUBLIC library-pdisk_io-protos ) target_sources(ydb-library-pdisk_io PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/aio.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/buffers.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/device_type.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/drivedata.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/sector_map.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/wcache.h ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/aio_linux.cpp ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/file_params_linux.cpp ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/aio.cpp diff --git a/ydb/library/pdisk_io/CMakeLists.linux-x86_64.txt b/ydb/library/pdisk_io/CMakeLists.linux-x86_64.txt index 41331b6eabff..1caf9e924c92 100644 --- a/ydb/library/pdisk_io/CMakeLists.linux-x86_64.txt +++ b/ydb/library/pdisk_io/CMakeLists.linux-x86_64.txt @@ -30,6 +30,12 @@ target_link_libraries(ydb-library-pdisk_io PUBLIC library-pdisk_io-protos ) target_sources(ydb-library-pdisk_io PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/aio.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/buffers.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/device_type.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/drivedata.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/sector_map.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/wcache.h ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/aio_linux.cpp ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/file_params_linux.cpp ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/aio.cpp diff --git a/ydb/library/pdisk_io/CMakeLists.windows-x86_64.txt b/ydb/library/pdisk_io/CMakeLists.windows-x86_64.txt index c168c9e90875..7107409c336a 100644 --- a/ydb/library/pdisk_io/CMakeLists.windows-x86_64.txt +++ b/ydb/library/pdisk_io/CMakeLists.windows-x86_64.txt @@ -26,6 +26,12 @@ target_link_libraries(ydb-library-pdisk_io PUBLIC library-pdisk_io-protos ) target_sources(ydb-library-pdisk_io PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/aio.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/buffers.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/device_type.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/drivedata.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/sector_map.h + ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/wcache.h ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/aio_mtp.cpp ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/file_params_win.cpp ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/aio.cpp diff --git a/ydb/library/pdisk_io/protos/CMakeLists.darwin-arm64.txt b/ydb/library/pdisk_io/protos/CMakeLists.darwin-arm64.txt index ffdbd27becae..e22904c0231f 100644 --- a/ydb/library/pdisk_io/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/library/pdisk_io/protos/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(library-pdisk_io-protos PUBLIC target_proto_messages(library-pdisk_io-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/protos/sector_map.proto ) +target_sources(library-pdisk_io-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/pdisk_io/protos/sector_map.pb.h +) target_proto_addincls(library-pdisk_io-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/pdisk_io/protos/CMakeLists.darwin-x86_64.txt b/ydb/library/pdisk_io/protos/CMakeLists.darwin-x86_64.txt index ffdbd27becae..e22904c0231f 100644 --- a/ydb/library/pdisk_io/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/pdisk_io/protos/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(library-pdisk_io-protos PUBLIC target_proto_messages(library-pdisk_io-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/protos/sector_map.proto ) +target_sources(library-pdisk_io-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/pdisk_io/protos/sector_map.pb.h +) target_proto_addincls(library-pdisk_io-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/pdisk_io/protos/CMakeLists.linux-aarch64.txt b/ydb/library/pdisk_io/protos/CMakeLists.linux-aarch64.txt index 725db4dd9a85..8bc2048abc54 100644 --- a/ydb/library/pdisk_io/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/library/pdisk_io/protos/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(library-pdisk_io-protos PUBLIC target_proto_messages(library-pdisk_io-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/protos/sector_map.proto ) +target_sources(library-pdisk_io-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/pdisk_io/protos/sector_map.pb.h +) target_proto_addincls(library-pdisk_io-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/pdisk_io/protos/CMakeLists.linux-x86_64.txt b/ydb/library/pdisk_io/protos/CMakeLists.linux-x86_64.txt index 725db4dd9a85..8bc2048abc54 100644 --- a/ydb/library/pdisk_io/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/library/pdisk_io/protos/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(library-pdisk_io-protos PUBLIC target_proto_messages(library-pdisk_io-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/protos/sector_map.proto ) +target_sources(library-pdisk_io-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/pdisk_io/protos/sector_map.pb.h +) target_proto_addincls(library-pdisk_io-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/pdisk_io/protos/CMakeLists.windows-x86_64.txt b/ydb/library/pdisk_io/protos/CMakeLists.windows-x86_64.txt index ffdbd27becae..e22904c0231f 100644 --- a/ydb/library/pdisk_io/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/library/pdisk_io/protos/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(library-pdisk_io-protos PUBLIC target_proto_messages(library-pdisk_io-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/pdisk_io/protos/sector_map.proto ) +target_sources(library-pdisk_io-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/pdisk_io/protos/sector_map.pb.h +) target_proto_addincls(library-pdisk_io-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/persqueue/counter_time_keeper/CMakeLists.darwin-arm64.txt b/ydb/library/persqueue/counter_time_keeper/CMakeLists.darwin-arm64.txt index c620fd394bbb..ebfa9160aa8c 100644 --- a/ydb/library/persqueue/counter_time_keeper/CMakeLists.darwin-arm64.txt +++ b/ydb/library/persqueue/counter_time_keeper/CMakeLists.darwin-arm64.txt @@ -16,5 +16,6 @@ target_link_libraries(library-persqueue-counter_time_keeper PUBLIC ydb-core-protos ) target_sources(library-persqueue-counter_time_keeper PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/counter_time_keeper/counter_time_keeper.h ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/counter_time_keeper/counter_time_keeper.cpp ) diff --git a/ydb/library/persqueue/counter_time_keeper/CMakeLists.darwin-x86_64.txt b/ydb/library/persqueue/counter_time_keeper/CMakeLists.darwin-x86_64.txt index c620fd394bbb..ebfa9160aa8c 100644 --- a/ydb/library/persqueue/counter_time_keeper/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/persqueue/counter_time_keeper/CMakeLists.darwin-x86_64.txt @@ -16,5 +16,6 @@ target_link_libraries(library-persqueue-counter_time_keeper PUBLIC ydb-core-protos ) target_sources(library-persqueue-counter_time_keeper PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/counter_time_keeper/counter_time_keeper.h ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/counter_time_keeper/counter_time_keeper.cpp ) diff --git a/ydb/library/persqueue/counter_time_keeper/CMakeLists.linux-aarch64.txt b/ydb/library/persqueue/counter_time_keeper/CMakeLists.linux-aarch64.txt index 1bb5d2972fff..9011130bc42c 100644 --- a/ydb/library/persqueue/counter_time_keeper/CMakeLists.linux-aarch64.txt +++ b/ydb/library/persqueue/counter_time_keeper/CMakeLists.linux-aarch64.txt @@ -17,5 +17,6 @@ target_link_libraries(library-persqueue-counter_time_keeper PUBLIC ydb-core-protos ) target_sources(library-persqueue-counter_time_keeper PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/counter_time_keeper/counter_time_keeper.h ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/counter_time_keeper/counter_time_keeper.cpp ) diff --git a/ydb/library/persqueue/counter_time_keeper/CMakeLists.linux-x86_64.txt b/ydb/library/persqueue/counter_time_keeper/CMakeLists.linux-x86_64.txt index 1bb5d2972fff..9011130bc42c 100644 --- a/ydb/library/persqueue/counter_time_keeper/CMakeLists.linux-x86_64.txt +++ b/ydb/library/persqueue/counter_time_keeper/CMakeLists.linux-x86_64.txt @@ -17,5 +17,6 @@ target_link_libraries(library-persqueue-counter_time_keeper PUBLIC ydb-core-protos ) target_sources(library-persqueue-counter_time_keeper PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/counter_time_keeper/counter_time_keeper.h ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/counter_time_keeper/counter_time_keeper.cpp ) diff --git a/ydb/library/persqueue/counter_time_keeper/CMakeLists.windows-x86_64.txt b/ydb/library/persqueue/counter_time_keeper/CMakeLists.windows-x86_64.txt index c620fd394bbb..ebfa9160aa8c 100644 --- a/ydb/library/persqueue/counter_time_keeper/CMakeLists.windows-x86_64.txt +++ b/ydb/library/persqueue/counter_time_keeper/CMakeLists.windows-x86_64.txt @@ -16,5 +16,6 @@ target_link_libraries(library-persqueue-counter_time_keeper PUBLIC ydb-core-protos ) target_sources(library-persqueue-counter_time_keeper PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/counter_time_keeper/counter_time_keeper.h ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/counter_time_keeper/counter_time_keeper.cpp ) diff --git a/ydb/library/persqueue/obfuscate/CMakeLists.darwin-arm64.txt b/ydb/library/persqueue/obfuscate/CMakeLists.darwin-arm64.txt index 02f21933a905..b6e8fc060f01 100644 --- a/ydb/library/persqueue/obfuscate/CMakeLists.darwin-arm64.txt +++ b/ydb/library/persqueue/obfuscate/CMakeLists.darwin-arm64.txt @@ -13,5 +13,6 @@ target_link_libraries(library-persqueue-obfuscate PUBLIC yutil ) target_sources(library-persqueue-obfuscate PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/obfuscate/obfuscate.h ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/obfuscate/obfuscate.cpp ) diff --git a/ydb/library/persqueue/obfuscate/CMakeLists.darwin-x86_64.txt b/ydb/library/persqueue/obfuscate/CMakeLists.darwin-x86_64.txt index 02f21933a905..b6e8fc060f01 100644 --- a/ydb/library/persqueue/obfuscate/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/persqueue/obfuscate/CMakeLists.darwin-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(library-persqueue-obfuscate PUBLIC yutil ) target_sources(library-persqueue-obfuscate PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/obfuscate/obfuscate.h ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/obfuscate/obfuscate.cpp ) diff --git a/ydb/library/persqueue/obfuscate/CMakeLists.linux-aarch64.txt b/ydb/library/persqueue/obfuscate/CMakeLists.linux-aarch64.txt index 9b03ab9bc577..2268efd2ac65 100644 --- a/ydb/library/persqueue/obfuscate/CMakeLists.linux-aarch64.txt +++ b/ydb/library/persqueue/obfuscate/CMakeLists.linux-aarch64.txt @@ -14,5 +14,6 @@ target_link_libraries(library-persqueue-obfuscate PUBLIC yutil ) target_sources(library-persqueue-obfuscate PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/obfuscate/obfuscate.h ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/obfuscate/obfuscate.cpp ) diff --git a/ydb/library/persqueue/obfuscate/CMakeLists.linux-x86_64.txt b/ydb/library/persqueue/obfuscate/CMakeLists.linux-x86_64.txt index 9b03ab9bc577..2268efd2ac65 100644 --- a/ydb/library/persqueue/obfuscate/CMakeLists.linux-x86_64.txt +++ b/ydb/library/persqueue/obfuscate/CMakeLists.linux-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(library-persqueue-obfuscate PUBLIC yutil ) target_sources(library-persqueue-obfuscate PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/obfuscate/obfuscate.h ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/obfuscate/obfuscate.cpp ) diff --git a/ydb/library/persqueue/obfuscate/CMakeLists.windows-x86_64.txt b/ydb/library/persqueue/obfuscate/CMakeLists.windows-x86_64.txt index 02f21933a905..b6e8fc060f01 100644 --- a/ydb/library/persqueue/obfuscate/CMakeLists.windows-x86_64.txt +++ b/ydb/library/persqueue/obfuscate/CMakeLists.windows-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(library-persqueue-obfuscate PUBLIC yutil ) target_sources(library-persqueue-obfuscate PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/obfuscate/obfuscate.h ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/obfuscate/obfuscate.cpp ) diff --git a/ydb/library/persqueue/topic_parser/CMakeLists.darwin-arm64.txt b/ydb/library/persqueue/topic_parser/CMakeLists.darwin-arm64.txt index b53684c776db..14da9cbf85b7 100644 --- a/ydb/library/persqueue/topic_parser/CMakeLists.darwin-arm64.txt +++ b/ydb/library/persqueue/topic_parser/CMakeLists.darwin-arm64.txt @@ -17,6 +17,9 @@ target_link_libraries(library-persqueue-topic_parser PUBLIC api-protos ) target_sources(library-persqueue-topic_parser PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/topic_parser.h + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/counters.h + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/type_definitions.h ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/topic_parser.cpp ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/counters.cpp ) diff --git a/ydb/library/persqueue/topic_parser/CMakeLists.darwin-x86_64.txt b/ydb/library/persqueue/topic_parser/CMakeLists.darwin-x86_64.txt index b53684c776db..14da9cbf85b7 100644 --- a/ydb/library/persqueue/topic_parser/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/persqueue/topic_parser/CMakeLists.darwin-x86_64.txt @@ -17,6 +17,9 @@ target_link_libraries(library-persqueue-topic_parser PUBLIC api-protos ) target_sources(library-persqueue-topic_parser PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/topic_parser.h + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/counters.h + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/type_definitions.h ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/topic_parser.cpp ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/counters.cpp ) diff --git a/ydb/library/persqueue/topic_parser/CMakeLists.linux-aarch64.txt b/ydb/library/persqueue/topic_parser/CMakeLists.linux-aarch64.txt index 337eb74e3b1a..3e060753d822 100644 --- a/ydb/library/persqueue/topic_parser/CMakeLists.linux-aarch64.txt +++ b/ydb/library/persqueue/topic_parser/CMakeLists.linux-aarch64.txt @@ -18,6 +18,9 @@ target_link_libraries(library-persqueue-topic_parser PUBLIC api-protos ) target_sources(library-persqueue-topic_parser PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/topic_parser.h + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/counters.h + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/type_definitions.h ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/topic_parser.cpp ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/counters.cpp ) diff --git a/ydb/library/persqueue/topic_parser/CMakeLists.linux-x86_64.txt b/ydb/library/persqueue/topic_parser/CMakeLists.linux-x86_64.txt index 337eb74e3b1a..3e060753d822 100644 --- a/ydb/library/persqueue/topic_parser/CMakeLists.linux-x86_64.txt +++ b/ydb/library/persqueue/topic_parser/CMakeLists.linux-x86_64.txt @@ -18,6 +18,9 @@ target_link_libraries(library-persqueue-topic_parser PUBLIC api-protos ) target_sources(library-persqueue-topic_parser PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/topic_parser.h + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/counters.h + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/type_definitions.h ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/topic_parser.cpp ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/counters.cpp ) diff --git a/ydb/library/persqueue/topic_parser/CMakeLists.windows-x86_64.txt b/ydb/library/persqueue/topic_parser/CMakeLists.windows-x86_64.txt index b53684c776db..14da9cbf85b7 100644 --- a/ydb/library/persqueue/topic_parser/CMakeLists.windows-x86_64.txt +++ b/ydb/library/persqueue/topic_parser/CMakeLists.windows-x86_64.txt @@ -17,6 +17,9 @@ target_link_libraries(library-persqueue-topic_parser PUBLIC api-protos ) target_sources(library-persqueue-topic_parser PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/topic_parser.h + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/counters.h + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/type_definitions.h ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/topic_parser.cpp ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/counters.cpp ) diff --git a/ydb/library/persqueue/topic_parser/ut/CMakeLists.darwin-arm64.txt b/ydb/library/persqueue/topic_parser/ut/CMakeLists.darwin-arm64.txt index ccd343ccd90f..f2cf15ef7b00 100644 --- a/ydb/library/persqueue/topic_parser/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/persqueue/topic_parser/ut/CMakeLists.darwin-arm64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-library-persqueue-topic_parser-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-persqueue-topic_parser-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/ut/topic_names_converter_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/persqueue/topic_parser/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/persqueue/topic_parser/ut/CMakeLists.darwin-x86_64.txt index 643028fb1b4b..13ced15781aa 100644 --- a/ydb/library/persqueue/topic_parser/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/persqueue/topic_parser/ut/CMakeLists.darwin-x86_64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-library-persqueue-topic_parser-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-persqueue-topic_parser-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/ut/topic_names_converter_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/persqueue/topic_parser/ut/CMakeLists.linux-aarch64.txt b/ydb/library/persqueue/topic_parser/ut/CMakeLists.linux-aarch64.txt index c79bb4de324d..e4b55d816c71 100644 --- a/ydb/library/persqueue/topic_parser/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/persqueue/topic_parser/ut/CMakeLists.linux-aarch64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-library-persqueue-topic_parser-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-persqueue-topic_parser-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/ut/topic_names_converter_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/persqueue/topic_parser/ut/CMakeLists.linux-x86_64.txt b/ydb/library/persqueue/topic_parser/ut/CMakeLists.linux-x86_64.txt index cb2538b72461..b067f609192e 100644 --- a/ydb/library/persqueue/topic_parser/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/persqueue/topic_parser/ut/CMakeLists.linux-x86_64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-library-persqueue-topic_parser-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-persqueue-topic_parser-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser/ut/topic_names_converter_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/persqueue/topic_parser/ut/CMakeLists.windows-x86_64.txt b/ydb/library/persqueue/topic_parser/ut/CMakeLists.windows-x86_64.txt index 8f72dc9b39d9..fa1ecfbf523b 100644 --- a/ydb/library/persqueue/topic_parser/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/persqueue/topic_parser/ut/CMakeLists.windows-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/persqueue/topic_parser_public/CMakeLists.darwin-arm64.txt b/ydb/library/persqueue/topic_parser_public/CMakeLists.darwin-arm64.txt index b6e8e1156adb..24be802ff972 100644 --- a/ydb/library/persqueue/topic_parser_public/CMakeLists.darwin-arm64.txt +++ b/ydb/library/persqueue/topic_parser_public/CMakeLists.darwin-arm64.txt @@ -13,5 +13,6 @@ target_link_libraries(library-persqueue-topic_parser_public PUBLIC yutil ) target_sources(library-persqueue-topic_parser_public PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser_public/topic_parser.h ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser_public/topic_parser.cpp ) diff --git a/ydb/library/persqueue/topic_parser_public/CMakeLists.darwin-x86_64.txt b/ydb/library/persqueue/topic_parser_public/CMakeLists.darwin-x86_64.txt index b6e8e1156adb..24be802ff972 100644 --- a/ydb/library/persqueue/topic_parser_public/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/persqueue/topic_parser_public/CMakeLists.darwin-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(library-persqueue-topic_parser_public PUBLIC yutil ) target_sources(library-persqueue-topic_parser_public PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser_public/topic_parser.h ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser_public/topic_parser.cpp ) diff --git a/ydb/library/persqueue/topic_parser_public/CMakeLists.linux-aarch64.txt b/ydb/library/persqueue/topic_parser_public/CMakeLists.linux-aarch64.txt index 851cc4226813..a7943ddde6cd 100644 --- a/ydb/library/persqueue/topic_parser_public/CMakeLists.linux-aarch64.txt +++ b/ydb/library/persqueue/topic_parser_public/CMakeLists.linux-aarch64.txt @@ -14,5 +14,6 @@ target_link_libraries(library-persqueue-topic_parser_public PUBLIC yutil ) target_sources(library-persqueue-topic_parser_public PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser_public/topic_parser.h ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser_public/topic_parser.cpp ) diff --git a/ydb/library/persqueue/topic_parser_public/CMakeLists.linux-x86_64.txt b/ydb/library/persqueue/topic_parser_public/CMakeLists.linux-x86_64.txt index 851cc4226813..a7943ddde6cd 100644 --- a/ydb/library/persqueue/topic_parser_public/CMakeLists.linux-x86_64.txt +++ b/ydb/library/persqueue/topic_parser_public/CMakeLists.linux-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(library-persqueue-topic_parser_public PUBLIC yutil ) target_sources(library-persqueue-topic_parser_public PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser_public/topic_parser.h ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser_public/topic_parser.cpp ) diff --git a/ydb/library/persqueue/topic_parser_public/CMakeLists.windows-x86_64.txt b/ydb/library/persqueue/topic_parser_public/CMakeLists.windows-x86_64.txt index b6e8e1156adb..24be802ff972 100644 --- a/ydb/library/persqueue/topic_parser_public/CMakeLists.windows-x86_64.txt +++ b/ydb/library/persqueue/topic_parser_public/CMakeLists.windows-x86_64.txt @@ -13,5 +13,6 @@ target_link_libraries(library-persqueue-topic_parser_public PUBLIC yutil ) target_sources(library-persqueue-topic_parser_public PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser_public/topic_parser.h ${CMAKE_SOURCE_DIR}/ydb/library/persqueue/topic_parser_public/topic_parser.cpp ) diff --git a/ydb/library/protobuf_printer/ut/CMakeLists.darwin-arm64.txt b/ydb/library/protobuf_printer/ut/CMakeLists.darwin-arm64.txt index 62e52c03ce91..0da37e5dd45b 100644 --- a/ydb/library/protobuf_printer/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/protobuf_printer/ut/CMakeLists.darwin-arm64.txt @@ -34,13 +34,12 @@ target_link_options(ydb-library-protobuf_printer-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_proto_messages(ydb-library-protobuf_printer-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/protobuf_printer/ut/test_proto.proto ) target_sources(ydb-library-protobuf_printer-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/protobuf_printer/ut/test_proto.pb.h ${CMAKE_SOURCE_DIR}/ydb/library/protobuf_printer/protobuf_printer_ut.cpp ) set_property( @@ -68,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/protobuf_printer/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/protobuf_printer/ut/CMakeLists.darwin-x86_64.txt index 1d31ccfea560..fa1c3d630498 100644 --- a/ydb/library/protobuf_printer/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/protobuf_printer/ut/CMakeLists.darwin-x86_64.txt @@ -35,13 +35,12 @@ target_link_options(ydb-library-protobuf_printer-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_proto_messages(ydb-library-protobuf_printer-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/protobuf_printer/ut/test_proto.proto ) target_sources(ydb-library-protobuf_printer-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/protobuf_printer/ut/test_proto.pb.h ${CMAKE_SOURCE_DIR}/ydb/library/protobuf_printer/protobuf_printer_ut.cpp ) set_property( @@ -69,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/protobuf_printer/ut/CMakeLists.linux-aarch64.txt b/ydb/library/protobuf_printer/ut/CMakeLists.linux-aarch64.txt index 74632f5235db..bb7f22b5bf01 100644 --- a/ydb/library/protobuf_printer/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/protobuf_printer/ut/CMakeLists.linux-aarch64.txt @@ -37,14 +37,12 @@ target_link_options(ydb-library-protobuf_printer-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_proto_messages(ydb-library-protobuf_printer-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/protobuf_printer/ut/test_proto.proto ) target_sources(ydb-library-protobuf_printer-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/protobuf_printer/ut/test_proto.pb.h ${CMAKE_SOURCE_DIR}/ydb/library/protobuf_printer/protobuf_printer_ut.cpp ) set_property( @@ -72,6 +70,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/protobuf_printer/ut/CMakeLists.linux-x86_64.txt b/ydb/library/protobuf_printer/ut/CMakeLists.linux-x86_64.txt index 3026af5d12b2..bd9171805e29 100644 --- a/ydb/library/protobuf_printer/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/protobuf_printer/ut/CMakeLists.linux-x86_64.txt @@ -38,14 +38,12 @@ target_link_options(ydb-library-protobuf_printer-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_proto_messages(ydb-library-protobuf_printer-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/protobuf_printer/ut/test_proto.proto ) target_sources(ydb-library-protobuf_printer-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/protobuf_printer/ut/test_proto.pb.h ${CMAKE_SOURCE_DIR}/ydb/library/protobuf_printer/protobuf_printer_ut.cpp ) set_property( @@ -73,6 +71,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/protobuf_printer/ut/CMakeLists.windows-x86_64.txt b/ydb/library/protobuf_printer/ut/CMakeLists.windows-x86_64.txt index 88b46f478546..3717c0b7a3e5 100644 --- a/ydb/library/protobuf_printer/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/protobuf_printer/ut/CMakeLists.windows-x86_64.txt @@ -35,6 +35,7 @@ target_proto_messages(ydb-library-protobuf_printer-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/protobuf_printer/ut/test_proto.proto ) target_sources(ydb-library-protobuf_printer-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/protobuf_printer/ut/test_proto.pb.h ${CMAKE_SOURCE_DIR}/ydb/library/protobuf_printer/protobuf_printer_ut.cpp ) set_property( @@ -62,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/query_actor/ut/CMakeLists.darwin-arm64.txt b/ydb/library/query_actor/ut/CMakeLists.darwin-arm64.txt index 7228ab62d98a..a943cbb00b7f 100644 --- a/ydb/library/query_actor/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/query_actor/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-library-query_actor-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-query_actor-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/query_actor/query_actor_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/query_actor/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/query_actor/ut/CMakeLists.darwin-x86_64.txt index 91813befa170..78fb218b6fc4 100644 --- a/ydb/library/query_actor/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/query_actor/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-library-query_actor-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-query_actor-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/query_actor/query_actor_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/query_actor/ut/CMakeLists.linux-aarch64.txt b/ydb/library/query_actor/ut/CMakeLists.linux-aarch64.txt index 3cebe53773cc..ed22b9345006 100644 --- a/ydb/library/query_actor/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/query_actor/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-library-query_actor-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-query_actor-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/query_actor/query_actor_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/query_actor/ut/CMakeLists.linux-x86_64.txt b/ydb/library/query_actor/ut/CMakeLists.linux-x86_64.txt index e3a9e50c8b25..2b42f4fa1541 100644 --- a/ydb/library/query_actor/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/query_actor/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-library-query_actor-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-query_actor-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/query_actor/query_actor_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/query_actor/ut/CMakeLists.windows-x86_64.txt b/ydb/library/query_actor/ut/CMakeLists.windows-x86_64.txt index cc1ab4d175de..d949278664b6 100644 --- a/ydb/library/query_actor/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/query_actor/ut/CMakeLists.windows-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/rewrapper/proto/CMakeLists.darwin-arm64.txt b/ydb/library/rewrapper/proto/CMakeLists.darwin-arm64.txt index 118580ff4cf0..5a3794dea5a7 100644 --- a/ydb/library/rewrapper/proto/CMakeLists.darwin-arm64.txt +++ b/ydb/library/rewrapper/proto/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(library-rewrapper-proto PUBLIC target_proto_messages(library-rewrapper-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/rewrapper/proto/serialization.proto ) +target_sources(library-rewrapper-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/rewrapper/proto/serialization.pb.h +) target_proto_addincls(library-rewrapper-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/rewrapper/proto/CMakeLists.darwin-x86_64.txt b/ydb/library/rewrapper/proto/CMakeLists.darwin-x86_64.txt index 118580ff4cf0..5a3794dea5a7 100644 --- a/ydb/library/rewrapper/proto/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/rewrapper/proto/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(library-rewrapper-proto PUBLIC target_proto_messages(library-rewrapper-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/rewrapper/proto/serialization.proto ) +target_sources(library-rewrapper-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/rewrapper/proto/serialization.pb.h +) target_proto_addincls(library-rewrapper-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/rewrapper/proto/CMakeLists.linux-aarch64.txt b/ydb/library/rewrapper/proto/CMakeLists.linux-aarch64.txt index 0bfb5e568442..c441c264d481 100644 --- a/ydb/library/rewrapper/proto/CMakeLists.linux-aarch64.txt +++ b/ydb/library/rewrapper/proto/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(library-rewrapper-proto PUBLIC target_proto_messages(library-rewrapper-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/rewrapper/proto/serialization.proto ) +target_sources(library-rewrapper-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/rewrapper/proto/serialization.pb.h +) target_proto_addincls(library-rewrapper-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/rewrapper/proto/CMakeLists.linux-x86_64.txt b/ydb/library/rewrapper/proto/CMakeLists.linux-x86_64.txt index 0bfb5e568442..c441c264d481 100644 --- a/ydb/library/rewrapper/proto/CMakeLists.linux-x86_64.txt +++ b/ydb/library/rewrapper/proto/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(library-rewrapper-proto PUBLIC target_proto_messages(library-rewrapper-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/rewrapper/proto/serialization.proto ) +target_sources(library-rewrapper-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/rewrapper/proto/serialization.pb.h +) target_proto_addincls(library-rewrapper-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/rewrapper/proto/CMakeLists.windows-x86_64.txt b/ydb/library/rewrapper/proto/CMakeLists.windows-x86_64.txt index 118580ff4cf0..5a3794dea5a7 100644 --- a/ydb/library/rewrapper/proto/CMakeLists.windows-x86_64.txt +++ b/ydb/library/rewrapper/proto/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(library-rewrapper-proto PUBLIC target_proto_messages(library-rewrapper-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/rewrapper/proto/serialization.proto ) +target_sources(library-rewrapper-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/rewrapper/proto/serialization.pb.h +) target_proto_addincls(library-rewrapper-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/schlab/CMakeLists.darwin-arm64.txt b/ydb/library/schlab/CMakeLists.darwin-arm64.txt index 35b5487e79e7..d266ae4e2ec4 100644 --- a/ydb/library/schlab/CMakeLists.darwin-arm64.txt +++ b/ydb/library/schlab/CMakeLists.darwin-arm64.txt @@ -21,5 +21,7 @@ target_link_libraries(ydb-library-schlab PUBLIC library-schlab-schine ) target_sources(ydb-library-schlab PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schlab_actor.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schlab_actor.cpp ) diff --git a/ydb/library/schlab/CMakeLists.darwin-x86_64.txt b/ydb/library/schlab/CMakeLists.darwin-x86_64.txt index 35b5487e79e7..d266ae4e2ec4 100644 --- a/ydb/library/schlab/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/schlab/CMakeLists.darwin-x86_64.txt @@ -21,5 +21,7 @@ target_link_libraries(ydb-library-schlab PUBLIC library-schlab-schine ) target_sources(ydb-library-schlab PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schlab_actor.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schlab_actor.cpp ) diff --git a/ydb/library/schlab/CMakeLists.linux-aarch64.txt b/ydb/library/schlab/CMakeLists.linux-aarch64.txt index 4ce9056fc0e4..84c3a1d1ab8c 100644 --- a/ydb/library/schlab/CMakeLists.linux-aarch64.txt +++ b/ydb/library/schlab/CMakeLists.linux-aarch64.txt @@ -22,5 +22,7 @@ target_link_libraries(ydb-library-schlab PUBLIC library-schlab-schine ) target_sources(ydb-library-schlab PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schlab_actor.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schlab_actor.cpp ) diff --git a/ydb/library/schlab/CMakeLists.linux-x86_64.txt b/ydb/library/schlab/CMakeLists.linux-x86_64.txt index 4ce9056fc0e4..84c3a1d1ab8c 100644 --- a/ydb/library/schlab/CMakeLists.linux-x86_64.txt +++ b/ydb/library/schlab/CMakeLists.linux-x86_64.txt @@ -22,5 +22,7 @@ target_link_libraries(ydb-library-schlab PUBLIC library-schlab-schine ) target_sources(ydb-library-schlab PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schlab_actor.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schlab_actor.cpp ) diff --git a/ydb/library/schlab/CMakeLists.windows-x86_64.txt b/ydb/library/schlab/CMakeLists.windows-x86_64.txt index 35b5487e79e7..d266ae4e2ec4 100644 --- a/ydb/library/schlab/CMakeLists.windows-x86_64.txt +++ b/ydb/library/schlab/CMakeLists.windows-x86_64.txt @@ -21,5 +21,7 @@ target_link_libraries(ydb-library-schlab PUBLIC library-schlab-schine ) target_sources(ydb-library-schlab PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schlab_actor.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schlab_actor.cpp ) diff --git a/ydb/library/schlab/mon/test/CMakeLists.linux-aarch64.txt b/ydb/library/schlab/mon/test/CMakeLists.linux-aarch64.txt index 361782b7648c..0afc23a9499b 100644 --- a/ydb/library/schlab/mon/test/CMakeLists.linux-aarch64.txt +++ b/ydb/library/schlab/mon/test/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(mon-test PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(mon-test PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/schlab/mon/test/test.cpp diff --git a/ydb/library/schlab/mon/test/CMakeLists.linux-x86_64.txt b/ydb/library/schlab/mon/test/CMakeLists.linux-x86_64.txt index 983fa552f322..aba84a74d3ca 100644 --- a/ydb/library/schlab/mon/test/CMakeLists.linux-x86_64.txt +++ b/ydb/library/schlab/mon/test/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(mon-test PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(mon-test PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/schlab/mon/test/test.cpp diff --git a/ydb/library/schlab/probes/CMakeLists.darwin-arm64.txt b/ydb/library/schlab/probes/CMakeLists.darwin-arm64.txt index 357d4c0baf1a..5d891bcc7095 100644 --- a/ydb/library/schlab/probes/CMakeLists.darwin-arm64.txt +++ b/ydb/library/schlab/probes/CMakeLists.darwin-arm64.txt @@ -14,5 +14,6 @@ target_link_libraries(library-schlab-probes PUBLIC library-cpp-lwtrace ) target_sources(library-schlab-probes PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/probes/probes.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/probes/probes.cpp ) diff --git a/ydb/library/schlab/probes/CMakeLists.darwin-x86_64.txt b/ydb/library/schlab/probes/CMakeLists.darwin-x86_64.txt index 357d4c0baf1a..5d891bcc7095 100644 --- a/ydb/library/schlab/probes/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/schlab/probes/CMakeLists.darwin-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(library-schlab-probes PUBLIC library-cpp-lwtrace ) target_sources(library-schlab-probes PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/probes/probes.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/probes/probes.cpp ) diff --git a/ydb/library/schlab/probes/CMakeLists.linux-aarch64.txt b/ydb/library/schlab/probes/CMakeLists.linux-aarch64.txt index ef987e0506a9..c404968f8b65 100644 --- a/ydb/library/schlab/probes/CMakeLists.linux-aarch64.txt +++ b/ydb/library/schlab/probes/CMakeLists.linux-aarch64.txt @@ -15,5 +15,6 @@ target_link_libraries(library-schlab-probes PUBLIC library-cpp-lwtrace ) target_sources(library-schlab-probes PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/probes/probes.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/probes/probes.cpp ) diff --git a/ydb/library/schlab/probes/CMakeLists.linux-x86_64.txt b/ydb/library/schlab/probes/CMakeLists.linux-x86_64.txt index ef987e0506a9..c404968f8b65 100644 --- a/ydb/library/schlab/probes/CMakeLists.linux-x86_64.txt +++ b/ydb/library/schlab/probes/CMakeLists.linux-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(library-schlab-probes PUBLIC library-cpp-lwtrace ) target_sources(library-schlab-probes PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/probes/probes.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/probes/probes.cpp ) diff --git a/ydb/library/schlab/probes/CMakeLists.windows-x86_64.txt b/ydb/library/schlab/probes/CMakeLists.windows-x86_64.txt index 357d4c0baf1a..5d891bcc7095 100644 --- a/ydb/library/schlab/probes/CMakeLists.windows-x86_64.txt +++ b/ydb/library/schlab/probes/CMakeLists.windows-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(library-schlab-probes PUBLIC library-cpp-lwtrace ) target_sources(library-schlab-probes PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/probes/probes.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/probes/probes.cpp ) diff --git a/ydb/library/schlab/protos/CMakeLists.darwin-arm64.txt b/ydb/library/schlab/protos/CMakeLists.darwin-arm64.txt index 8e9addba1359..826f68068a60 100644 --- a/ydb/library/schlab/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/library/schlab/protos/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(library-schlab-protos PUBLIC target_proto_messages(library-schlab-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/schlab/protos/schlab.proto ) +target_sources(library-schlab-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/schlab/protos/schlab.pb.h +) target_proto_addincls(library-schlab-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/schlab/protos/CMakeLists.darwin-x86_64.txt b/ydb/library/schlab/protos/CMakeLists.darwin-x86_64.txt index 8e9addba1359..826f68068a60 100644 --- a/ydb/library/schlab/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/schlab/protos/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(library-schlab-protos PUBLIC target_proto_messages(library-schlab-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/schlab/protos/schlab.proto ) +target_sources(library-schlab-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/schlab/protos/schlab.pb.h +) target_proto_addincls(library-schlab-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/schlab/protos/CMakeLists.linux-aarch64.txt b/ydb/library/schlab/protos/CMakeLists.linux-aarch64.txt index 0523a3a5a8e6..a477c9203898 100644 --- a/ydb/library/schlab/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/library/schlab/protos/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(library-schlab-protos PUBLIC target_proto_messages(library-schlab-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/schlab/protos/schlab.proto ) +target_sources(library-schlab-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/schlab/protos/schlab.pb.h +) target_proto_addincls(library-schlab-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/schlab/protos/CMakeLists.linux-x86_64.txt b/ydb/library/schlab/protos/CMakeLists.linux-x86_64.txt index 0523a3a5a8e6..a477c9203898 100644 --- a/ydb/library/schlab/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/library/schlab/protos/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(library-schlab-protos PUBLIC target_proto_messages(library-schlab-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/schlab/protos/schlab.proto ) +target_sources(library-schlab-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/schlab/protos/schlab.pb.h +) target_proto_addincls(library-schlab-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/schlab/protos/CMakeLists.windows-x86_64.txt b/ydb/library/schlab/protos/CMakeLists.windows-x86_64.txt index 8e9addba1359..826f68068a60 100644 --- a/ydb/library/schlab/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/library/schlab/protos/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(library-schlab-protos PUBLIC target_proto_messages(library-schlab-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/schlab/protos/schlab.proto ) +target_sources(library-schlab-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/schlab/protos/schlab.pb.h +) target_proto_addincls(library-schlab-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/schlab/schemu/CMakeLists.darwin-arm64.txt b/ydb/library/schlab/schemu/CMakeLists.darwin-arm64.txt index 007223c328db..7e3ff8947078 100644 --- a/ydb/library/schlab/schemu/CMakeLists.darwin-arm64.txt +++ b/ydb/library/schlab/schemu/CMakeLists.darwin-arm64.txt @@ -15,5 +15,7 @@ target_link_libraries(library-schlab-schemu PUBLIC library-schlab-schoot ) target_sources(library-schlab-schemu PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schemu/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schemu/schemu.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schemu/schemu.cpp ) diff --git a/ydb/library/schlab/schemu/CMakeLists.darwin-x86_64.txt b/ydb/library/schlab/schemu/CMakeLists.darwin-x86_64.txt index 007223c328db..7e3ff8947078 100644 --- a/ydb/library/schlab/schemu/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/schlab/schemu/CMakeLists.darwin-x86_64.txt @@ -15,5 +15,7 @@ target_link_libraries(library-schlab-schemu PUBLIC library-schlab-schoot ) target_sources(library-schlab-schemu PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schemu/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schemu/schemu.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schemu/schemu.cpp ) diff --git a/ydb/library/schlab/schemu/CMakeLists.linux-aarch64.txt b/ydb/library/schlab/schemu/CMakeLists.linux-aarch64.txt index ef80cbd3ea61..e986e313e7eb 100644 --- a/ydb/library/schlab/schemu/CMakeLists.linux-aarch64.txt +++ b/ydb/library/schlab/schemu/CMakeLists.linux-aarch64.txt @@ -16,5 +16,7 @@ target_link_libraries(library-schlab-schemu PUBLIC library-schlab-schoot ) target_sources(library-schlab-schemu PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schemu/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schemu/schemu.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schemu/schemu.cpp ) diff --git a/ydb/library/schlab/schemu/CMakeLists.linux-x86_64.txt b/ydb/library/schlab/schemu/CMakeLists.linux-x86_64.txt index ef80cbd3ea61..e986e313e7eb 100644 --- a/ydb/library/schlab/schemu/CMakeLists.linux-x86_64.txt +++ b/ydb/library/schlab/schemu/CMakeLists.linux-x86_64.txt @@ -16,5 +16,7 @@ target_link_libraries(library-schlab-schemu PUBLIC library-schlab-schoot ) target_sources(library-schlab-schemu PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schemu/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schemu/schemu.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schemu/schemu.cpp ) diff --git a/ydb/library/schlab/schemu/CMakeLists.windows-x86_64.txt b/ydb/library/schlab/schemu/CMakeLists.windows-x86_64.txt index 007223c328db..7e3ff8947078 100644 --- a/ydb/library/schlab/schemu/CMakeLists.windows-x86_64.txt +++ b/ydb/library/schlab/schemu/CMakeLists.windows-x86_64.txt @@ -15,5 +15,7 @@ target_link_libraries(library-schlab-schemu PUBLIC library-schlab-schoot ) target_sources(library-schlab-schemu PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schemu/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schemu/schemu.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schemu/schemu.cpp ) diff --git a/ydb/library/schlab/schine/CMakeLists.darwin-arm64.txt b/ydb/library/schlab/schine/CMakeLists.darwin-arm64.txt index 9ab206f78598..6610fdd75235 100644 --- a/ydb/library/schlab/schine/CMakeLists.darwin-arm64.txt +++ b/ydb/library/schlab/schine/CMakeLists.darwin-arm64.txt @@ -17,6 +17,18 @@ target_link_libraries(library-schlab-schine PUBLIC library-schlab-probes ) target_sources(library-schlab-schine PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/bin_log.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs_bin.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs_state.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/job.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/job_kind.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/job_state.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/name_table.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/scheduler.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/schlog.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/schlog_frame.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs.cpp ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs_bin.cpp ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs_state.cpp diff --git a/ydb/library/schlab/schine/CMakeLists.darwin-x86_64.txt b/ydb/library/schlab/schine/CMakeLists.darwin-x86_64.txt index 9ab206f78598..6610fdd75235 100644 --- a/ydb/library/schlab/schine/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/schlab/schine/CMakeLists.darwin-x86_64.txt @@ -17,6 +17,18 @@ target_link_libraries(library-schlab-schine PUBLIC library-schlab-probes ) target_sources(library-schlab-schine PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/bin_log.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs_bin.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs_state.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/job.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/job_kind.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/job_state.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/name_table.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/scheduler.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/schlog.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/schlog_frame.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs.cpp ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs_bin.cpp ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs_state.cpp diff --git a/ydb/library/schlab/schine/CMakeLists.linux-aarch64.txt b/ydb/library/schlab/schine/CMakeLists.linux-aarch64.txt index cf733641cc95..3c07cf374235 100644 --- a/ydb/library/schlab/schine/CMakeLists.linux-aarch64.txt +++ b/ydb/library/schlab/schine/CMakeLists.linux-aarch64.txt @@ -18,6 +18,18 @@ target_link_libraries(library-schlab-schine PUBLIC library-schlab-probes ) target_sources(library-schlab-schine PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/bin_log.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs_bin.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs_state.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/job.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/job_kind.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/job_state.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/name_table.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/scheduler.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/schlog.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/schlog_frame.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs.cpp ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs_bin.cpp ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs_state.cpp diff --git a/ydb/library/schlab/schine/CMakeLists.linux-x86_64.txt b/ydb/library/schlab/schine/CMakeLists.linux-x86_64.txt index cf733641cc95..3c07cf374235 100644 --- a/ydb/library/schlab/schine/CMakeLists.linux-x86_64.txt +++ b/ydb/library/schlab/schine/CMakeLists.linux-x86_64.txt @@ -18,6 +18,18 @@ target_link_libraries(library-schlab-schine PUBLIC library-schlab-probes ) target_sources(library-schlab-schine PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/bin_log.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs_bin.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs_state.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/job.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/job_kind.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/job_state.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/name_table.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/scheduler.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/schlog.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/schlog_frame.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs.cpp ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs_bin.cpp ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs_state.cpp diff --git a/ydb/library/schlab/schine/CMakeLists.windows-x86_64.txt b/ydb/library/schlab/schine/CMakeLists.windows-x86_64.txt index 9ab206f78598..6610fdd75235 100644 --- a/ydb/library/schlab/schine/CMakeLists.windows-x86_64.txt +++ b/ydb/library/schlab/schine/CMakeLists.windows-x86_64.txt @@ -17,6 +17,18 @@ target_link_libraries(library-schlab-schine PUBLIC library-schlab-probes ) target_sources(library-schlab-schine PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/bin_log.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs_bin.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs_state.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/job.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/job_kind.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/job_state.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/name_table.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/scheduler.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/schlog.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/schlog_frame.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs.cpp ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs_bin.cpp ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schine/cbs_state.cpp diff --git a/ydb/library/schlab/schoot/CMakeLists.darwin-arm64.txt b/ydb/library/schlab/schoot/CMakeLists.darwin-arm64.txt index f4ef52b638a5..fb04df420493 100644 --- a/ydb/library/schlab/schoot/CMakeLists.darwin-arm64.txt +++ b/ydb/library/schlab/schoot/CMakeLists.darwin-arm64.txt @@ -16,6 +16,9 @@ target_link_libraries(library-schlab-schoot PUBLIC library-schlab-protos ) target_sources(library-schlab-schoot PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/schoot_gen.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/schoot_gen_cfg.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/schoot_gen.cpp ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/schoot_gen_cfg.cpp ) diff --git a/ydb/library/schlab/schoot/CMakeLists.darwin-x86_64.txt b/ydb/library/schlab/schoot/CMakeLists.darwin-x86_64.txt index f4ef52b638a5..fb04df420493 100644 --- a/ydb/library/schlab/schoot/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/schlab/schoot/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(library-schlab-schoot PUBLIC library-schlab-protos ) target_sources(library-schlab-schoot PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/schoot_gen.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/schoot_gen_cfg.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/schoot_gen.cpp ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/schoot_gen_cfg.cpp ) diff --git a/ydb/library/schlab/schoot/CMakeLists.linux-aarch64.txt b/ydb/library/schlab/schoot/CMakeLists.linux-aarch64.txt index 91952ef4ad63..4bcc0689005b 100644 --- a/ydb/library/schlab/schoot/CMakeLists.linux-aarch64.txt +++ b/ydb/library/schlab/schoot/CMakeLists.linux-aarch64.txt @@ -17,6 +17,9 @@ target_link_libraries(library-schlab-schoot PUBLIC library-schlab-protos ) target_sources(library-schlab-schoot PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/schoot_gen.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/schoot_gen_cfg.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/schoot_gen.cpp ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/schoot_gen_cfg.cpp ) diff --git a/ydb/library/schlab/schoot/CMakeLists.linux-x86_64.txt b/ydb/library/schlab/schoot/CMakeLists.linux-x86_64.txt index 91952ef4ad63..4bcc0689005b 100644 --- a/ydb/library/schlab/schoot/CMakeLists.linux-x86_64.txt +++ b/ydb/library/schlab/schoot/CMakeLists.linux-x86_64.txt @@ -17,6 +17,9 @@ target_link_libraries(library-schlab-schoot PUBLIC library-schlab-protos ) target_sources(library-schlab-schoot PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/schoot_gen.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/schoot_gen_cfg.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/schoot_gen.cpp ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/schoot_gen_cfg.cpp ) diff --git a/ydb/library/schlab/schoot/CMakeLists.windows-x86_64.txt b/ydb/library/schlab/schoot/CMakeLists.windows-x86_64.txt index f4ef52b638a5..fb04df420493 100644 --- a/ydb/library/schlab/schoot/CMakeLists.windows-x86_64.txt +++ b/ydb/library/schlab/schoot/CMakeLists.windows-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(library-schlab-schoot PUBLIC library-schlab-protos ) target_sources(library-schlab-schoot PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/schoot_gen.h + ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/schoot_gen_cfg.h ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/schoot_gen.cpp ${CMAKE_SOURCE_DIR}/ydb/library/schlab/schoot/schoot_gen_cfg.cpp ) diff --git a/ydb/library/schlab/ut/CMakeLists.darwin-arm64.txt b/ydb/library/schlab/ut/CMakeLists.darwin-arm64.txt index 5571c2c3f4c6..6108b2b5f9ab 100644 --- a/ydb/library/schlab/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/schlab/ut/CMakeLists.darwin-arm64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/schlab/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/schlab/ut/CMakeLists.darwin-x86_64.txt index 4cf50db6313e..3b0017f1bd31 100644 --- a/ydb/library/schlab/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/schlab/ut/CMakeLists.darwin-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/schlab/ut/CMakeLists.linux-aarch64.txt b/ydb/library/schlab/ut/CMakeLists.linux-aarch64.txt index c21377f43e87..3f12c8044697 100644 --- a/ydb/library/schlab/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/schlab/ut/CMakeLists.linux-aarch64.txt @@ -21,9 +21,6 @@ target_link_options(ydb-library-schlab-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-schlab-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/schlab/ut/schlab_ut.cpp @@ -53,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/schlab/ut/CMakeLists.linux-x86_64.txt b/ydb/library/schlab/ut/CMakeLists.linux-x86_64.txt index a17d30fdc098..ed6ba467271e 100644 --- a/ydb/library/schlab/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/schlab/ut/CMakeLists.linux-x86_64.txt @@ -22,9 +22,6 @@ target_link_options(ydb-library-schlab-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-schlab-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/schlab/ut/schlab_ut.cpp @@ -54,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/schlab/ut/CMakeLists.windows-x86_64.txt b/ydb/library/schlab/ut/CMakeLists.windows-x86_64.txt index 9c41d779fd6d..370e30110bf3 100644 --- a/ydb/library/schlab/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/schlab/ut/CMakeLists.windows-x86_64.txt @@ -43,6 +43,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/security/ut/CMakeLists.darwin-arm64.txt b/ydb/library/security/ut/CMakeLists.darwin-arm64.txt index 1792e6fdaf2b..bb2f73c30b7b 100644 --- a/ydb/library/security/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/security/ut/CMakeLists.darwin-arm64.txt @@ -18,8 +18,6 @@ target_link_options(ydb-library-security-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-security-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/security/ut/util_ut.cpp @@ -49,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/security/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/security/ut/CMakeLists.darwin-x86_64.txt index c3a8502e388c..92d5db30ed93 100644 --- a/ydb/library/security/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/security/ut/CMakeLists.darwin-x86_64.txt @@ -19,8 +19,6 @@ target_link_options(ydb-library-security-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-security-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/security/ut/util_ut.cpp @@ -50,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/security/ut/CMakeLists.linux-aarch64.txt b/ydb/library/security/ut/CMakeLists.linux-aarch64.txt index 3968731ceace..f2ad29f1e2dc 100644 --- a/ydb/library/security/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/security/ut/CMakeLists.linux-aarch64.txt @@ -21,9 +21,6 @@ target_link_options(ydb-library-security-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-security-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/security/ut/util_ut.cpp @@ -53,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/security/ut/CMakeLists.linux-x86_64.txt b/ydb/library/security/ut/CMakeLists.linux-x86_64.txt index 2f3e40cb5fa3..23e85da2a148 100644 --- a/ydb/library/security/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/security/ut/CMakeLists.linux-x86_64.txt @@ -22,9 +22,6 @@ target_link_options(ydb-library-security-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-security-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/security/ut/util_ut.cpp @@ -54,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/security/ut/CMakeLists.windows-x86_64.txt b/ydb/library/security/ut/CMakeLists.windows-x86_64.txt index ffde3def909e..d912cc51650e 100644 --- a/ydb/library/security/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/security/ut/CMakeLists.windows-x86_64.txt @@ -43,6 +43,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/services/CMakeLists.darwin-arm64.txt b/ydb/library/services/CMakeLists.darwin-arm64.txt index bd9c4cc13df2..a7633bb60963 100644 --- a/ydb/library/services/CMakeLists.darwin-arm64.txt +++ b/ydb/library/services/CMakeLists.darwin-arm64.txt @@ -38,6 +38,10 @@ target_link_libraries(ydb-library-services PUBLIC target_proto_messages(ydb-library-services PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/services/services.proto ) +target_sources(ydb-library-services PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/services/services.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/services/services.grpc.pb.h +) target_proto_addincls(ydb-library-services ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/services/CMakeLists.darwin-x86_64.txt b/ydb/library/services/CMakeLists.darwin-x86_64.txt index bd9c4cc13df2..a7633bb60963 100644 --- a/ydb/library/services/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/services/CMakeLists.darwin-x86_64.txt @@ -38,6 +38,10 @@ target_link_libraries(ydb-library-services PUBLIC target_proto_messages(ydb-library-services PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/services/services.proto ) +target_sources(ydb-library-services PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/services/services.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/services/services.grpc.pb.h +) target_proto_addincls(ydb-library-services ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/services/CMakeLists.linux-aarch64.txt b/ydb/library/services/CMakeLists.linux-aarch64.txt index 3b4686c0b4a9..e50a1f6b29c0 100644 --- a/ydb/library/services/CMakeLists.linux-aarch64.txt +++ b/ydb/library/services/CMakeLists.linux-aarch64.txt @@ -39,6 +39,10 @@ target_link_libraries(ydb-library-services PUBLIC target_proto_messages(ydb-library-services PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/services/services.proto ) +target_sources(ydb-library-services PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/services/services.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/services/services.grpc.pb.h +) target_proto_addincls(ydb-library-services ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/services/CMakeLists.linux-x86_64.txt b/ydb/library/services/CMakeLists.linux-x86_64.txt index 3b4686c0b4a9..e50a1f6b29c0 100644 --- a/ydb/library/services/CMakeLists.linux-x86_64.txt +++ b/ydb/library/services/CMakeLists.linux-x86_64.txt @@ -39,6 +39,10 @@ target_link_libraries(ydb-library-services PUBLIC target_proto_messages(ydb-library-services PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/services/services.proto ) +target_sources(ydb-library-services PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/services/services.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/services/services.grpc.pb.h +) target_proto_addincls(ydb-library-services ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/services/CMakeLists.windows-x86_64.txt b/ydb/library/services/CMakeLists.windows-x86_64.txt index bd9c4cc13df2..a7633bb60963 100644 --- a/ydb/library/services/CMakeLists.windows-x86_64.txt +++ b/ydb/library/services/CMakeLists.windows-x86_64.txt @@ -38,6 +38,10 @@ target_link_libraries(ydb-library-services PUBLIC target_proto_messages(ydb-library-services PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/services/services.proto ) +target_sources(ydb-library-services PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/services/services.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/services/services.grpc.pb.h +) target_proto_addincls(ydb-library-services ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/table_creator/CMakeLists.darwin-arm64.txt b/ydb/library/table_creator/CMakeLists.darwin-arm64.txt index f312fda6ba8d..5c91af3a07d3 100644 --- a/ydb/library/table_creator/CMakeLists.darwin-arm64.txt +++ b/ydb/library/table_creator/CMakeLists.darwin-arm64.txt @@ -20,5 +20,6 @@ target_link_libraries(ydb-library-table_creator PUBLIC library-actors-core ) target_sources(ydb-library-table_creator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/table_creator/table_creator.h ${CMAKE_SOURCE_DIR}/ydb/library/table_creator/table_creator.cpp ) diff --git a/ydb/library/table_creator/CMakeLists.darwin-x86_64.txt b/ydb/library/table_creator/CMakeLists.darwin-x86_64.txt index f312fda6ba8d..5c91af3a07d3 100644 --- a/ydb/library/table_creator/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/table_creator/CMakeLists.darwin-x86_64.txt @@ -20,5 +20,6 @@ target_link_libraries(ydb-library-table_creator PUBLIC library-actors-core ) target_sources(ydb-library-table_creator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/table_creator/table_creator.h ${CMAKE_SOURCE_DIR}/ydb/library/table_creator/table_creator.cpp ) diff --git a/ydb/library/table_creator/CMakeLists.linux-aarch64.txt b/ydb/library/table_creator/CMakeLists.linux-aarch64.txt index 260264f39f2d..6a1740ecbb09 100644 --- a/ydb/library/table_creator/CMakeLists.linux-aarch64.txt +++ b/ydb/library/table_creator/CMakeLists.linux-aarch64.txt @@ -21,5 +21,6 @@ target_link_libraries(ydb-library-table_creator PUBLIC library-actors-core ) target_sources(ydb-library-table_creator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/table_creator/table_creator.h ${CMAKE_SOURCE_DIR}/ydb/library/table_creator/table_creator.cpp ) diff --git a/ydb/library/table_creator/CMakeLists.linux-x86_64.txt b/ydb/library/table_creator/CMakeLists.linux-x86_64.txt index 260264f39f2d..6a1740ecbb09 100644 --- a/ydb/library/table_creator/CMakeLists.linux-x86_64.txt +++ b/ydb/library/table_creator/CMakeLists.linux-x86_64.txt @@ -21,5 +21,6 @@ target_link_libraries(ydb-library-table_creator PUBLIC library-actors-core ) target_sources(ydb-library-table_creator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/table_creator/table_creator.h ${CMAKE_SOURCE_DIR}/ydb/library/table_creator/table_creator.cpp ) diff --git a/ydb/library/table_creator/CMakeLists.windows-x86_64.txt b/ydb/library/table_creator/CMakeLists.windows-x86_64.txt index f312fda6ba8d..5c91af3a07d3 100644 --- a/ydb/library/table_creator/CMakeLists.windows-x86_64.txt +++ b/ydb/library/table_creator/CMakeLists.windows-x86_64.txt @@ -20,5 +20,6 @@ target_link_libraries(ydb-library-table_creator PUBLIC library-actors-core ) target_sources(ydb-library-table_creator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/table_creator/table_creator.h ${CMAKE_SOURCE_DIR}/ydb/library/table_creator/table_creator.cpp ) diff --git a/ydb/library/table_creator/ut/CMakeLists.darwin-arm64.txt b/ydb/library/table_creator/ut/CMakeLists.darwin-arm64.txt index 151f8503df54..be1006ed6849 100644 --- a/ydb/library/table_creator/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/table_creator/ut/CMakeLists.darwin-arm64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-library-table_creator-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-table_creator-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/table_creator/table_creator_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/table_creator/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/table_creator/ut/CMakeLists.darwin-x86_64.txt index 8ef3f73c1b94..f3f21e07433b 100644 --- a/ydb/library/table_creator/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/table_creator/ut/CMakeLists.darwin-x86_64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-library-table_creator-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-table_creator-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/table_creator/table_creator_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/table_creator/ut/CMakeLists.linux-aarch64.txt b/ydb/library/table_creator/ut/CMakeLists.linux-aarch64.txt index 947f86769d04..be66b9b3857e 100644 --- a/ydb/library/table_creator/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/table_creator/ut/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-library-table_creator-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-table_creator-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/table_creator/table_creator_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/table_creator/ut/CMakeLists.linux-x86_64.txt b/ydb/library/table_creator/ut/CMakeLists.linux-x86_64.txt index f81d6bb00e14..4f7f00b2f9f4 100644 --- a/ydb/library/table_creator/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/table_creator/ut/CMakeLists.linux-x86_64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-library-table_creator-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-table_creator-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/table_creator/table_creator_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/table_creator/ut/CMakeLists.windows-x86_64.txt b/ydb/library/table_creator/ut/CMakeLists.windows-x86_64.txt index 2f38ae2535bc..3f8e116cea1c 100644 --- a/ydb/library/table_creator/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/table_creator/ut/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/testlib/service_mocks/CMakeLists.darwin-arm64.txt b/ydb/library/testlib/service_mocks/CMakeLists.darwin-arm64.txt index b452859068f8..a609c8b22ab1 100644 --- a/ydb/library/testlib/service_mocks/CMakeLists.darwin-arm64.txt +++ b/ydb/library/testlib/service_mocks/CMakeLists.darwin-arm64.txt @@ -13,7 +13,17 @@ target_link_libraries(library-testlib-service_mocks INTERFACE contrib-libs-cxxsupp yutil client-yc_private-servicecontrol + client-yc_private-accessservice api-grpc-draft client-yc_private-resourcemanager client-yc_private-iam ) +target_sources(library-testlib-service_mocks INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/access_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/datastreams_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/folder_service_transitional_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/folder_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/iam_token_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/service_account_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/user_account_service_mock.h +) diff --git a/ydb/library/testlib/service_mocks/CMakeLists.darwin-x86_64.txt b/ydb/library/testlib/service_mocks/CMakeLists.darwin-x86_64.txt index b452859068f8..a609c8b22ab1 100644 --- a/ydb/library/testlib/service_mocks/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/testlib/service_mocks/CMakeLists.darwin-x86_64.txt @@ -13,7 +13,17 @@ target_link_libraries(library-testlib-service_mocks INTERFACE contrib-libs-cxxsupp yutil client-yc_private-servicecontrol + client-yc_private-accessservice api-grpc-draft client-yc_private-resourcemanager client-yc_private-iam ) +target_sources(library-testlib-service_mocks INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/access_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/datastreams_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/folder_service_transitional_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/folder_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/iam_token_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/service_account_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/user_account_service_mock.h +) diff --git a/ydb/library/testlib/service_mocks/CMakeLists.linux-aarch64.txt b/ydb/library/testlib/service_mocks/CMakeLists.linux-aarch64.txt index d676c2c8c13a..d3dfc5991511 100644 --- a/ydb/library/testlib/service_mocks/CMakeLists.linux-aarch64.txt +++ b/ydb/library/testlib/service_mocks/CMakeLists.linux-aarch64.txt @@ -14,7 +14,17 @@ target_link_libraries(library-testlib-service_mocks INTERFACE contrib-libs-cxxsupp yutil client-yc_private-servicecontrol + client-yc_private-accessservice api-grpc-draft client-yc_private-resourcemanager client-yc_private-iam ) +target_sources(library-testlib-service_mocks INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/access_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/datastreams_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/folder_service_transitional_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/folder_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/iam_token_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/service_account_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/user_account_service_mock.h +) diff --git a/ydb/library/testlib/service_mocks/CMakeLists.linux-x86_64.txt b/ydb/library/testlib/service_mocks/CMakeLists.linux-x86_64.txt index d676c2c8c13a..d3dfc5991511 100644 --- a/ydb/library/testlib/service_mocks/CMakeLists.linux-x86_64.txt +++ b/ydb/library/testlib/service_mocks/CMakeLists.linux-x86_64.txt @@ -14,7 +14,17 @@ target_link_libraries(library-testlib-service_mocks INTERFACE contrib-libs-cxxsupp yutil client-yc_private-servicecontrol + client-yc_private-accessservice api-grpc-draft client-yc_private-resourcemanager client-yc_private-iam ) +target_sources(library-testlib-service_mocks INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/access_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/datastreams_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/folder_service_transitional_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/folder_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/iam_token_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/service_account_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/user_account_service_mock.h +) diff --git a/ydb/library/testlib/service_mocks/CMakeLists.windows-x86_64.txt b/ydb/library/testlib/service_mocks/CMakeLists.windows-x86_64.txt index b452859068f8..a609c8b22ab1 100644 --- a/ydb/library/testlib/service_mocks/CMakeLists.windows-x86_64.txt +++ b/ydb/library/testlib/service_mocks/CMakeLists.windows-x86_64.txt @@ -13,7 +13,17 @@ target_link_libraries(library-testlib-service_mocks INTERFACE contrib-libs-cxxsupp yutil client-yc_private-servicecontrol + client-yc_private-accessservice api-grpc-draft client-yc_private-resourcemanager client-yc_private-iam ) +target_sources(library-testlib-service_mocks INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/access_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/datastreams_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/folder_service_transitional_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/folder_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/iam_token_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/service_account_service_mock.h + ${CMAKE_SOURCE_DIR}/ydb/library/testlib/service_mocks/user_account_service_mock.h +) diff --git a/ydb/library/testlib/ut/CMakeLists.darwin-arm64.txt b/ydb/library/testlib/ut/CMakeLists.darwin-arm64.txt index fbcbe07c03c0..ae2415f2c82b 100644 --- a/ydb/library/testlib/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/testlib/ut/CMakeLists.darwin-arm64.txt @@ -18,8 +18,6 @@ target_link_options(ydb-library-testlib-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-testlib-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/testlib/ut/gtest_compat_ut.cpp @@ -36,6 +34,7 @@ set_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_property( TEST diff --git a/ydb/library/testlib/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/testlib/ut/CMakeLists.darwin-x86_64.txt index c6fc761faccd..212d74942f0b 100644 --- a/ydb/library/testlib/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/testlib/ut/CMakeLists.darwin-x86_64.txt @@ -19,8 +19,6 @@ target_link_options(ydb-library-testlib-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-testlib-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/testlib/ut/gtest_compat_ut.cpp @@ -37,6 +35,7 @@ set_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_property( TEST diff --git a/ydb/library/testlib/ut/CMakeLists.linux-aarch64.txt b/ydb/library/testlib/ut/CMakeLists.linux-aarch64.txt index 74336c1f6c5c..a2a1cd73ffe0 100644 --- a/ydb/library/testlib/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/testlib/ut/CMakeLists.linux-aarch64.txt @@ -21,9 +21,6 @@ target_link_options(ydb-library-testlib-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-testlib-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/testlib/ut/gtest_compat_ut.cpp @@ -40,6 +37,7 @@ set_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_property( TEST diff --git a/ydb/library/testlib/ut/CMakeLists.linux-x86_64.txt b/ydb/library/testlib/ut/CMakeLists.linux-x86_64.txt index 8fa3bace4658..f4d26a6c3dbb 100644 --- a/ydb/library/testlib/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/testlib/ut/CMakeLists.linux-x86_64.txt @@ -22,9 +22,6 @@ target_link_options(ydb-library-testlib-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-testlib-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/testlib/ut/gtest_compat_ut.cpp @@ -41,6 +38,7 @@ set_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_property( TEST diff --git a/ydb/library/testlib/ut/CMakeLists.windows-x86_64.txt b/ydb/library/testlib/ut/CMakeLists.windows-x86_64.txt index 1d9eb77da6d0..61facd3a5e4c 100644 --- a/ydb/library/testlib/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/testlib/ut/CMakeLists.windows-x86_64.txt @@ -30,6 +30,7 @@ set_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_property( TEST diff --git a/ydb/library/time_series_vec/CMakeLists.darwin-arm64.txt b/ydb/library/time_series_vec/CMakeLists.darwin-arm64.txt index 51cc6db3cb6c..c797c0ae6150 100644 --- a/ydb/library/time_series_vec/CMakeLists.darwin-arm64.txt +++ b/ydb/library/time_series_vec/CMakeLists.darwin-arm64.txt @@ -13,3 +13,6 @@ target_link_libraries(ydb-library-time_series_vec INTERFACE contrib-libs-cxxsupp yutil ) +target_sources(ydb-library-time_series_vec INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/time_series_vec/time_series_vec.h +) diff --git a/ydb/library/time_series_vec/CMakeLists.darwin-x86_64.txt b/ydb/library/time_series_vec/CMakeLists.darwin-x86_64.txt index 51cc6db3cb6c..c797c0ae6150 100644 --- a/ydb/library/time_series_vec/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/time_series_vec/CMakeLists.darwin-x86_64.txt @@ -13,3 +13,6 @@ target_link_libraries(ydb-library-time_series_vec INTERFACE contrib-libs-cxxsupp yutil ) +target_sources(ydb-library-time_series_vec INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/time_series_vec/time_series_vec.h +) diff --git a/ydb/library/time_series_vec/CMakeLists.linux-aarch64.txt b/ydb/library/time_series_vec/CMakeLists.linux-aarch64.txt index 548d33d23bac..2eec02fc4a4a 100644 --- a/ydb/library/time_series_vec/CMakeLists.linux-aarch64.txt +++ b/ydb/library/time_series_vec/CMakeLists.linux-aarch64.txt @@ -14,3 +14,6 @@ target_link_libraries(ydb-library-time_series_vec INTERFACE contrib-libs-cxxsupp yutil ) +target_sources(ydb-library-time_series_vec INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/time_series_vec/time_series_vec.h +) diff --git a/ydb/library/time_series_vec/CMakeLists.linux-x86_64.txt b/ydb/library/time_series_vec/CMakeLists.linux-x86_64.txt index 548d33d23bac..2eec02fc4a4a 100644 --- a/ydb/library/time_series_vec/CMakeLists.linux-x86_64.txt +++ b/ydb/library/time_series_vec/CMakeLists.linux-x86_64.txt @@ -14,3 +14,6 @@ target_link_libraries(ydb-library-time_series_vec INTERFACE contrib-libs-cxxsupp yutil ) +target_sources(ydb-library-time_series_vec INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/time_series_vec/time_series_vec.h +) diff --git a/ydb/library/time_series_vec/CMakeLists.windows-x86_64.txt b/ydb/library/time_series_vec/CMakeLists.windows-x86_64.txt index 51cc6db3cb6c..c797c0ae6150 100644 --- a/ydb/library/time_series_vec/CMakeLists.windows-x86_64.txt +++ b/ydb/library/time_series_vec/CMakeLists.windows-x86_64.txt @@ -13,3 +13,6 @@ target_link_libraries(ydb-library-time_series_vec INTERFACE contrib-libs-cxxsupp yutil ) +target_sources(ydb-library-time_series_vec INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/time_series_vec/time_series_vec.h +) diff --git a/ydb/library/time_series_vec/ut/CMakeLists.darwin-arm64.txt b/ydb/library/time_series_vec/ut/CMakeLists.darwin-arm64.txt index 8ec87086f182..fc971fc9f6e9 100644 --- a/ydb/library/time_series_vec/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/time_series_vec/ut/CMakeLists.darwin-arm64.txt @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/time_series_vec/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/time_series_vec/ut/CMakeLists.darwin-x86_64.txt index 8be10746c0df..4daf3523091c 100644 --- a/ydb/library/time_series_vec/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/time_series_vec/ut/CMakeLists.darwin-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/time_series_vec/ut/CMakeLists.linux-aarch64.txt b/ydb/library/time_series_vec/ut/CMakeLists.linux-aarch64.txt index e57f86f7b187..27cc8dbf9e29 100644 --- a/ydb/library/time_series_vec/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/time_series_vec/ut/CMakeLists.linux-aarch64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-library-time_series_vec-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-time_series_vec-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/time_series_vec/time_series_vec_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/time_series_vec/ut/CMakeLists.linux-x86_64.txt b/ydb/library/time_series_vec/ut/CMakeLists.linux-x86_64.txt index 0dbaf30c6e56..e75cd24d0696 100644 --- a/ydb/library/time_series_vec/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/time_series_vec/ut/CMakeLists.linux-x86_64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-library-time_series_vec-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-time_series_vec-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/time_series_vec/time_series_vec_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/time_series_vec/ut/CMakeLists.windows-x86_64.txt b/ydb/library/time_series_vec/ut/CMakeLists.windows-x86_64.txt index 17b542c9370f..2f68e5185b55 100644 --- a/ydb/library/time_series_vec/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/time_series_vec/ut/CMakeLists.windows-x86_64.txt @@ -49,6 +49,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/wilson_ids/CMakeLists.darwin-arm64.txt b/ydb/library/wilson_ids/CMakeLists.darwin-arm64.txt index ae2afc4629d0..94fa617d9f67 100644 --- a/ydb/library/wilson_ids/CMakeLists.darwin-arm64.txt +++ b/ydb/library/wilson_ids/CMakeLists.darwin-arm64.txt @@ -12,3 +12,6 @@ target_link_libraries(ydb-library-wilson_ids INTERFACE contrib-libs-cxxsupp yutil ) +target_sources(ydb-library-wilson_ids INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/wilson_ids/wilson.h +) diff --git a/ydb/library/wilson_ids/CMakeLists.darwin-x86_64.txt b/ydb/library/wilson_ids/CMakeLists.darwin-x86_64.txt index ae2afc4629d0..94fa617d9f67 100644 --- a/ydb/library/wilson_ids/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/wilson_ids/CMakeLists.darwin-x86_64.txt @@ -12,3 +12,6 @@ target_link_libraries(ydb-library-wilson_ids INTERFACE contrib-libs-cxxsupp yutil ) +target_sources(ydb-library-wilson_ids INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/wilson_ids/wilson.h +) diff --git a/ydb/library/wilson_ids/CMakeLists.linux-aarch64.txt b/ydb/library/wilson_ids/CMakeLists.linux-aarch64.txt index 16ce0bf4a808..55b6831349f6 100644 --- a/ydb/library/wilson_ids/CMakeLists.linux-aarch64.txt +++ b/ydb/library/wilson_ids/CMakeLists.linux-aarch64.txt @@ -13,3 +13,6 @@ target_link_libraries(ydb-library-wilson_ids INTERFACE contrib-libs-cxxsupp yutil ) +target_sources(ydb-library-wilson_ids INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/wilson_ids/wilson.h +) diff --git a/ydb/library/wilson_ids/CMakeLists.linux-x86_64.txt b/ydb/library/wilson_ids/CMakeLists.linux-x86_64.txt index 16ce0bf4a808..55b6831349f6 100644 --- a/ydb/library/wilson_ids/CMakeLists.linux-x86_64.txt +++ b/ydb/library/wilson_ids/CMakeLists.linux-x86_64.txt @@ -13,3 +13,6 @@ target_link_libraries(ydb-library-wilson_ids INTERFACE contrib-libs-cxxsupp yutil ) +target_sources(ydb-library-wilson_ids INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/wilson_ids/wilson.h +) diff --git a/ydb/library/wilson_ids/CMakeLists.windows-x86_64.txt b/ydb/library/wilson_ids/CMakeLists.windows-x86_64.txt index ae2afc4629d0..94fa617d9f67 100644 --- a/ydb/library/wilson_ids/CMakeLists.windows-x86_64.txt +++ b/ydb/library/wilson_ids/CMakeLists.windows-x86_64.txt @@ -12,3 +12,6 @@ target_link_libraries(ydb-library-wilson_ids INTERFACE contrib-libs-cxxsupp yutil ) +target_sources(ydb-library-wilson_ids INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/wilson_ids/wilson.h +) diff --git a/ydb/library/workload/CMakeLists.darwin-arm64.txt b/ydb/library/workload/CMakeLists.darwin-arm64.txt index 4b6d17589ecd..afdfd0557f01 100644 --- a/ydb/library/workload/CMakeLists.darwin-arm64.txt +++ b/ydb/library/workload/CMakeLists.darwin-arm64.txt @@ -6,6 +6,12 @@ # original buildsystem will not be accepted. +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) get_built_tool_path( TOOL_enum_parser_bin TOOL_enum_parser_dependency @@ -17,29 +23,41 @@ add_library(ydb-library-workload) target_link_libraries(ydb-library-workload PUBLIC contrib-libs-cxxsupp yutil - tools-enum_parser-enum_serialization_runtime + library-cpp-getopt api-protos cpp-client-ydb_table + tools-enum_parser-enum_serialization_runtime ) target_sources(ydb-library-workload PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/workload/stock_workload.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/workload/kv_workload.cpp + ${CMAKE_BINARY_DIR}/ydb/library/workload/kv_workload.h_serialized.h + ${CMAKE_BINARY_DIR}/ydb/library/workload/stock_workload.h_serialized.h ${CMAKE_SOURCE_DIR}/ydb/library/workload/workload_factory.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/workload/tpcc/tpcc_workload.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/workload/tpcc/load_data/customer.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/workload/tpcc/load_data/district.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/workload/tpcc/load_data/history.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/workload/tpcc/load_data/item.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/workload/tpcc/load_data/new_order.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/workload/tpcc/load_data/oorder.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/workload/tpcc/load_data/order_line.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/workload/tpcc/load_data/query_generator.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/workload/tpcc/load_data/stock.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/workload/tpcc/load_data/warehouse.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/workload/tpcc/load_data/load_thread_pool.cpp ) generate_enum_serilization(ydb-library-workload - ${CMAKE_SOURCE_DIR}/ydb/library/workload/tpcc/tpcc_config.h + ${CMAKE_SOURCE_DIR}/ydb/library/workload/kv_workload.h + GEN_HEADER + ${CMAKE_BINARY_DIR}/ydb/library/workload/kv_workload.h_serialized.h INCLUDE_HEADERS - ydb/library/workload/tpcc/tpcc_config.h + ydb/library/workload/kv_workload.h +) +generate_enum_serilization(ydb-library-workload + ${CMAKE_SOURCE_DIR}/ydb/library/workload/stock_workload.h + GEN_HEADER + ${CMAKE_BINARY_DIR}/ydb/library/workload/stock_workload.h_serialized.h + INCLUDE_HEADERS + ydb/library/workload/stock_workload.h +) + +add_global_library_for(ydb-library-workload.global ydb-library-workload) +target_link_libraries(ydb-library-workload.global PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-getopt + api-protos + cpp-client-ydb_table + tools-enum_parser-enum_serialization_runtime +) +target_sources(ydb-library-workload.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/workload/stock_workload.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/workload/kv_workload.cpp ) diff --git a/ydb/library/workload/CMakeLists.darwin-x86_64.txt b/ydb/library/workload/CMakeLists.darwin-x86_64.txt index 69416c94e704..afdfd0557f01 100644 --- a/ydb/library/workload/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/workload/CMakeLists.darwin-x86_64.txt @@ -6,16 +6,58 @@ # original buildsystem will not be accepted. +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) add_library(ydb-library-workload) target_link_libraries(ydb-library-workload PUBLIC contrib-libs-cxxsupp yutil + library-cpp-getopt api-protos cpp-client-ydb_table + tools-enum_parser-enum_serialization_runtime ) target_sources(ydb-library-workload PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/workload/kv_workload.h_serialized.h + ${CMAKE_BINARY_DIR}/ydb/library/workload/stock_workload.h_serialized.h + ${CMAKE_SOURCE_DIR}/ydb/library/workload/workload_factory.cpp +) +generate_enum_serilization(ydb-library-workload + ${CMAKE_SOURCE_DIR}/ydb/library/workload/kv_workload.h + GEN_HEADER + ${CMAKE_BINARY_DIR}/ydb/library/workload/kv_workload.h_serialized.h + INCLUDE_HEADERS + ydb/library/workload/kv_workload.h +) +generate_enum_serilization(ydb-library-workload + ${CMAKE_SOURCE_DIR}/ydb/library/workload/stock_workload.h + GEN_HEADER + ${CMAKE_BINARY_DIR}/ydb/library/workload/stock_workload.h_serialized.h + INCLUDE_HEADERS + ydb/library/workload/stock_workload.h +) + +add_global_library_for(ydb-library-workload.global ydb-library-workload) +target_link_libraries(ydb-library-workload.global PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-getopt + api-protos + cpp-client-ydb_table + tools-enum_parser-enum_serialization_runtime +) +target_sources(ydb-library-workload.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/workload/stock_workload.cpp ${CMAKE_SOURCE_DIR}/ydb/library/workload/kv_workload.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/workload/workload_factory.cpp ) diff --git a/ydb/library/workload/CMakeLists.linux-aarch64.txt b/ydb/library/workload/CMakeLists.linux-aarch64.txt index d5dba36558cd..07a824c5ed8d 100644 --- a/ydb/library/workload/CMakeLists.linux-aarch64.txt +++ b/ydb/library/workload/CMakeLists.linux-aarch64.txt @@ -6,17 +6,60 @@ # original buildsystem will not be accepted. +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) add_library(ydb-library-workload) target_link_libraries(ydb-library-workload PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + library-cpp-getopt api-protos cpp-client-ydb_table + tools-enum_parser-enum_serialization_runtime ) target_sources(ydb-library-workload PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/workload/kv_workload.h_serialized.h + ${CMAKE_BINARY_DIR}/ydb/library/workload/stock_workload.h_serialized.h + ${CMAKE_SOURCE_DIR}/ydb/library/workload/workload_factory.cpp +) +generate_enum_serilization(ydb-library-workload + ${CMAKE_SOURCE_DIR}/ydb/library/workload/kv_workload.h + GEN_HEADER + ${CMAKE_BINARY_DIR}/ydb/library/workload/kv_workload.h_serialized.h + INCLUDE_HEADERS + ydb/library/workload/kv_workload.h +) +generate_enum_serilization(ydb-library-workload + ${CMAKE_SOURCE_DIR}/ydb/library/workload/stock_workload.h + GEN_HEADER + ${CMAKE_BINARY_DIR}/ydb/library/workload/stock_workload.h_serialized.h + INCLUDE_HEADERS + ydb/library/workload/stock_workload.h +) + +add_global_library_for(ydb-library-workload.global ydb-library-workload) +target_link_libraries(ydb-library-workload.global PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-getopt + api-protos + cpp-client-ydb_table + tools-enum_parser-enum_serialization_runtime +) +target_sources(ydb-library-workload.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/workload/stock_workload.cpp ${CMAKE_SOURCE_DIR}/ydb/library/workload/kv_workload.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/workload/workload_factory.cpp ) diff --git a/ydb/library/workload/CMakeLists.linux-x86_64.txt b/ydb/library/workload/CMakeLists.linux-x86_64.txt index d5dba36558cd..07a824c5ed8d 100644 --- a/ydb/library/workload/CMakeLists.linux-x86_64.txt +++ b/ydb/library/workload/CMakeLists.linux-x86_64.txt @@ -6,17 +6,60 @@ # original buildsystem will not be accepted. +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) add_library(ydb-library-workload) target_link_libraries(ydb-library-workload PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + library-cpp-getopt api-protos cpp-client-ydb_table + tools-enum_parser-enum_serialization_runtime ) target_sources(ydb-library-workload PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/workload/kv_workload.h_serialized.h + ${CMAKE_BINARY_DIR}/ydb/library/workload/stock_workload.h_serialized.h + ${CMAKE_SOURCE_DIR}/ydb/library/workload/workload_factory.cpp +) +generate_enum_serilization(ydb-library-workload + ${CMAKE_SOURCE_DIR}/ydb/library/workload/kv_workload.h + GEN_HEADER + ${CMAKE_BINARY_DIR}/ydb/library/workload/kv_workload.h_serialized.h + INCLUDE_HEADERS + ydb/library/workload/kv_workload.h +) +generate_enum_serilization(ydb-library-workload + ${CMAKE_SOURCE_DIR}/ydb/library/workload/stock_workload.h + GEN_HEADER + ${CMAKE_BINARY_DIR}/ydb/library/workload/stock_workload.h_serialized.h + INCLUDE_HEADERS + ydb/library/workload/stock_workload.h +) + +add_global_library_for(ydb-library-workload.global ydb-library-workload) +target_link_libraries(ydb-library-workload.global PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-getopt + api-protos + cpp-client-ydb_table + tools-enum_parser-enum_serialization_runtime +) +target_sources(ydb-library-workload.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/workload/stock_workload.cpp ${CMAKE_SOURCE_DIR}/ydb/library/workload/kv_workload.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/workload/workload_factory.cpp ) diff --git a/ydb/library/workload/CMakeLists.windows-x86_64.txt b/ydb/library/workload/CMakeLists.windows-x86_64.txt index 69416c94e704..afdfd0557f01 100644 --- a/ydb/library/workload/CMakeLists.windows-x86_64.txt +++ b/ydb/library/workload/CMakeLists.windows-x86_64.txt @@ -6,16 +6,58 @@ # original buildsystem will not be accepted. +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) add_library(ydb-library-workload) target_link_libraries(ydb-library-workload PUBLIC contrib-libs-cxxsupp yutil + library-cpp-getopt api-protos cpp-client-ydb_table + tools-enum_parser-enum_serialization_runtime ) target_sources(ydb-library-workload PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/workload/kv_workload.h_serialized.h + ${CMAKE_BINARY_DIR}/ydb/library/workload/stock_workload.h_serialized.h + ${CMAKE_SOURCE_DIR}/ydb/library/workload/workload_factory.cpp +) +generate_enum_serilization(ydb-library-workload + ${CMAKE_SOURCE_DIR}/ydb/library/workload/kv_workload.h + GEN_HEADER + ${CMAKE_BINARY_DIR}/ydb/library/workload/kv_workload.h_serialized.h + INCLUDE_HEADERS + ydb/library/workload/kv_workload.h +) +generate_enum_serilization(ydb-library-workload + ${CMAKE_SOURCE_DIR}/ydb/library/workload/stock_workload.h + GEN_HEADER + ${CMAKE_BINARY_DIR}/ydb/library/workload/stock_workload.h_serialized.h + INCLUDE_HEADERS + ydb/library/workload/stock_workload.h +) + +add_global_library_for(ydb-library-workload.global ydb-library-workload) +target_link_libraries(ydb-library-workload.global PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-getopt + api-protos + cpp-client-ydb_table + tools-enum_parser-enum_serialization_runtime +) +target_sources(ydb-library-workload.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/workload/stock_workload.cpp ${CMAKE_SOURCE_DIR}/ydb/library/workload/kv_workload.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/workload/workload_factory.cpp ) diff --git a/ydb/library/yaml_config/CMakeLists.darwin-arm64.txt b/ydb/library/yaml_config/CMakeLists.darwin-arm64.txt index 1f24b387bde0..368bdd94ba4d 100644 --- a/ydb/library/yaml_config/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yaml_config/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(ydb-library-yaml_config PUBLIC library-yaml_config-public ) target_sources(ydb-library-yaml_config PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/console_dumper.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/yaml_config.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/yaml_config_parser.h ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/console_dumper.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/yaml_config.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/yaml_config_parser.cpp diff --git a/ydb/library/yaml_config/CMakeLists.darwin-x86_64.txt b/ydb/library/yaml_config/CMakeLists.darwin-x86_64.txt index 1f24b387bde0..368bdd94ba4d 100644 --- a/ydb/library/yaml_config/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yaml_config/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(ydb-library-yaml_config PUBLIC library-yaml_config-public ) target_sources(ydb-library-yaml_config PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/console_dumper.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/yaml_config.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/yaml_config_parser.h ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/console_dumper.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/yaml_config.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/yaml_config_parser.cpp diff --git a/ydb/library/yaml_config/CMakeLists.linux-aarch64.txt b/ydb/library/yaml_config/CMakeLists.linux-aarch64.txt index ab981337ee7a..88bd9259f98f 100644 --- a/ydb/library/yaml_config/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yaml_config/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(ydb-library-yaml_config PUBLIC library-yaml_config-public ) target_sources(ydb-library-yaml_config PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/console_dumper.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/yaml_config.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/yaml_config_parser.h ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/console_dumper.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/yaml_config.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/yaml_config_parser.cpp diff --git a/ydb/library/yaml_config/CMakeLists.linux-x86_64.txt b/ydb/library/yaml_config/CMakeLists.linux-x86_64.txt index ab981337ee7a..88bd9259f98f 100644 --- a/ydb/library/yaml_config/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yaml_config/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(ydb-library-yaml_config PUBLIC library-yaml_config-public ) target_sources(ydb-library-yaml_config PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/console_dumper.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/yaml_config.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/yaml_config_parser.h ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/console_dumper.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/yaml_config.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/yaml_config_parser.cpp diff --git a/ydb/library/yaml_config/CMakeLists.windows-x86_64.txt b/ydb/library/yaml_config/CMakeLists.windows-x86_64.txt index 1f24b387bde0..368bdd94ba4d 100644 --- a/ydb/library/yaml_config/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yaml_config/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(ydb-library-yaml_config PUBLIC library-yaml_config-public ) target_sources(ydb-library-yaml_config PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/console_dumper.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/yaml_config.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/yaml_config_parser.h ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/console_dumper.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/yaml_config.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/yaml_config_parser.cpp diff --git a/ydb/library/yaml_config/public/CMakeLists.darwin-arm64.txt b/ydb/library/yaml_config/public/CMakeLists.darwin-arm64.txt index 4c870b43501b..5c825874a70b 100644 --- a/ydb/library/yaml_config/public/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yaml_config/public/CMakeLists.darwin-arm64.txt @@ -19,5 +19,6 @@ target_link_libraries(library-yaml_config-public PUBLIC ydb-library-fyamlcpp ) target_sources(library-yaml_config-public PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/public/yaml_config.h ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/public/yaml_config.cpp ) diff --git a/ydb/library/yaml_config/public/CMakeLists.darwin-x86_64.txt b/ydb/library/yaml_config/public/CMakeLists.darwin-x86_64.txt index 4c870b43501b..5c825874a70b 100644 --- a/ydb/library/yaml_config/public/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yaml_config/public/CMakeLists.darwin-x86_64.txt @@ -19,5 +19,6 @@ target_link_libraries(library-yaml_config-public PUBLIC ydb-library-fyamlcpp ) target_sources(library-yaml_config-public PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/public/yaml_config.h ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/public/yaml_config.cpp ) diff --git a/ydb/library/yaml_config/public/CMakeLists.linux-aarch64.txt b/ydb/library/yaml_config/public/CMakeLists.linux-aarch64.txt index 82c428c6bcfd..d2017e46f2a7 100644 --- a/ydb/library/yaml_config/public/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yaml_config/public/CMakeLists.linux-aarch64.txt @@ -20,5 +20,6 @@ target_link_libraries(library-yaml_config-public PUBLIC ydb-library-fyamlcpp ) target_sources(library-yaml_config-public PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/public/yaml_config.h ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/public/yaml_config.cpp ) diff --git a/ydb/library/yaml_config/public/CMakeLists.linux-x86_64.txt b/ydb/library/yaml_config/public/CMakeLists.linux-x86_64.txt index 82c428c6bcfd..d2017e46f2a7 100644 --- a/ydb/library/yaml_config/public/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yaml_config/public/CMakeLists.linux-x86_64.txt @@ -20,5 +20,6 @@ target_link_libraries(library-yaml_config-public PUBLIC ydb-library-fyamlcpp ) target_sources(library-yaml_config-public PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/public/yaml_config.h ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/public/yaml_config.cpp ) diff --git a/ydb/library/yaml_config/public/CMakeLists.windows-x86_64.txt b/ydb/library/yaml_config/public/CMakeLists.windows-x86_64.txt index 4c870b43501b..5c825874a70b 100644 --- a/ydb/library/yaml_config/public/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yaml_config/public/CMakeLists.windows-x86_64.txt @@ -19,5 +19,6 @@ target_link_libraries(library-yaml_config-public PUBLIC ydb-library-fyamlcpp ) target_sources(library-yaml_config-public PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/public/yaml_config.h ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/public/yaml_config.cpp ) diff --git a/ydb/library/yaml_config/static_validator/CMakeLists.darwin-arm64.txt b/ydb/library/yaml_config/static_validator/CMakeLists.darwin-arm64.txt index 254d5ad015f9..b7b45d01830e 100644 --- a/ydb/library/yaml_config/static_validator/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yaml_config/static_validator/CMakeLists.darwin-arm64.txt @@ -15,5 +15,6 @@ target_link_libraries(library-yaml_config-static_validator PUBLIC library-yaml_config-validator ) target_sources(library-yaml_config-static_validator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/static_validator/builders.h ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/static_validator/builders.cpp ) diff --git a/ydb/library/yaml_config/static_validator/CMakeLists.darwin-x86_64.txt b/ydb/library/yaml_config/static_validator/CMakeLists.darwin-x86_64.txt index 254d5ad015f9..b7b45d01830e 100644 --- a/ydb/library/yaml_config/static_validator/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yaml_config/static_validator/CMakeLists.darwin-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(library-yaml_config-static_validator PUBLIC library-yaml_config-validator ) target_sources(library-yaml_config-static_validator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/static_validator/builders.h ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/static_validator/builders.cpp ) diff --git a/ydb/library/yaml_config/static_validator/CMakeLists.linux-aarch64.txt b/ydb/library/yaml_config/static_validator/CMakeLists.linux-aarch64.txt index b97f4674a8ec..3b4f433ecfe1 100644 --- a/ydb/library/yaml_config/static_validator/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yaml_config/static_validator/CMakeLists.linux-aarch64.txt @@ -16,5 +16,6 @@ target_link_libraries(library-yaml_config-static_validator PUBLIC library-yaml_config-validator ) target_sources(library-yaml_config-static_validator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/static_validator/builders.h ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/static_validator/builders.cpp ) diff --git a/ydb/library/yaml_config/static_validator/CMakeLists.linux-x86_64.txt b/ydb/library/yaml_config/static_validator/CMakeLists.linux-x86_64.txt index b97f4674a8ec..3b4f433ecfe1 100644 --- a/ydb/library/yaml_config/static_validator/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yaml_config/static_validator/CMakeLists.linux-x86_64.txt @@ -16,5 +16,6 @@ target_link_libraries(library-yaml_config-static_validator PUBLIC library-yaml_config-validator ) target_sources(library-yaml_config-static_validator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/static_validator/builders.h ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/static_validator/builders.cpp ) diff --git a/ydb/library/yaml_config/static_validator/CMakeLists.windows-x86_64.txt b/ydb/library/yaml_config/static_validator/CMakeLists.windows-x86_64.txt index 254d5ad015f9..b7b45d01830e 100644 --- a/ydb/library/yaml_config/static_validator/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yaml_config/static_validator/CMakeLists.windows-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(library-yaml_config-static_validator PUBLIC library-yaml_config-validator ) target_sources(library-yaml_config-static_validator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/static_validator/builders.h ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/static_validator/builders.cpp ) diff --git a/ydb/library/yaml_config/static_validator/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yaml_config/static_validator/ut/CMakeLists.darwin-arm64.txt index 2ef879c0e242..d7e915fc05df 100644 --- a/ydb/library/yaml_config/static_validator/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yaml_config/static_validator/ut/CMakeLists.darwin-arm64.txt @@ -49,6 +49,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/static_validator/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yaml_config/static_validator/ut/CMakeLists.darwin-x86_64.txt index 83e5fe99d194..fadcb94e15a5 100644 --- a/ydb/library/yaml_config/static_validator/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yaml_config/static_validator/ut/CMakeLists.darwin-x86_64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/static_validator/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yaml_config/static_validator/ut/CMakeLists.linux-aarch64.txt index f943c0a96206..27f29ffcb018 100644 --- a/ydb/library/yaml_config/static_validator/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yaml_config/static_validator/ut/CMakeLists.linux-aarch64.txt @@ -23,9 +23,6 @@ target_link_options(ydb-library-yaml_config-static_validator-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yaml_config-static_validator-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/static_validator/ut/test.cpp @@ -55,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/static_validator/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yaml_config/static_validator/ut/CMakeLists.linux-x86_64.txt index 8de063feaae5..66ff9fd1dff3 100644 --- a/ydb/library/yaml_config/static_validator/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yaml_config/static_validator/ut/CMakeLists.linux-x86_64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-yaml_config-static_validator-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yaml_config-static_validator-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/static_validator/ut/test.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/static_validator/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yaml_config/static_validator/ut/CMakeLists.windows-x86_64.txt index 68abb354411d..57da84ccb20d 100644 --- a/ydb/library/yaml_config/static_validator/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yaml_config/static_validator/ut/CMakeLists.windows-x86_64.txt @@ -45,6 +45,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/static_validator/ut/example_configs/CMakeLists.darwin-arm64.txt b/ydb/library/yaml_config/static_validator/ut/example_configs/CMakeLists.darwin-arm64.txt index 348c6b4e36aa..dfebe7a64bc1 100644 --- a/ydb/library/yaml_config/static_validator/ut/example_configs/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yaml_config/static_validator/ut/example_configs/CMakeLists.darwin-arm64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/static_validator/ut/example_configs/CMakeLists.darwin-x86_64.txt b/ydb/library/yaml_config/static_validator/ut/example_configs/CMakeLists.darwin-x86_64.txt index cfdca304d91e..d97d6892f282 100644 --- a/ydb/library/yaml_config/static_validator/ut/example_configs/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yaml_config/static_validator/ut/example_configs/CMakeLists.darwin-x86_64.txt @@ -49,6 +49,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/static_validator/ut/example_configs/CMakeLists.linux-aarch64.txt b/ydb/library/yaml_config/static_validator/ut/example_configs/CMakeLists.linux-aarch64.txt index f5e109052aaa..4bf5e2cde514 100644 --- a/ydb/library/yaml_config/static_validator/ut/example_configs/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yaml_config/static_validator/ut/example_configs/CMakeLists.linux-aarch64.txt @@ -22,9 +22,6 @@ target_link_options(static_validator-ut-example_configs PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(static_validator-ut-example_configs PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/static_validator/ut/example_configs/test.cpp @@ -54,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/static_validator/ut/example_configs/CMakeLists.linux-x86_64.txt b/ydb/library/yaml_config/static_validator/ut/example_configs/CMakeLists.linux-x86_64.txt index f75721a24e75..e1596e306b98 100644 --- a/ydb/library/yaml_config/static_validator/ut/example_configs/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yaml_config/static_validator/ut/example_configs/CMakeLists.linux-x86_64.txt @@ -23,9 +23,6 @@ target_link_options(static_validator-ut-example_configs PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(static_validator-ut-example_configs PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/static_validator/ut/example_configs/test.cpp @@ -55,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/static_validator/ut/example_configs/CMakeLists.windows-x86_64.txt b/ydb/library/yaml_config/static_validator/ut/example_configs/CMakeLists.windows-x86_64.txt index 8521e7c92f80..16c7ca3e866b 100644 --- a/ydb/library/yaml_config/static_validator/ut/example_configs/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yaml_config/static_validator/ut/example_configs/CMakeLists.windows-x86_64.txt @@ -44,6 +44,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yaml_config/ut/CMakeLists.darwin-arm64.txt index 610cc3631f74..60a5c476a8f1 100644 --- a/ydb/library/yaml_config/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yaml_config/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-library-yaml_config-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yaml_config-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/console_dumper_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yaml_config/ut/CMakeLists.darwin-x86_64.txt index 16d1c98e734f..b1102d2e2705 100644 --- a/ydb/library/yaml_config/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yaml_config/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-library-yaml_config-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yaml_config-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/console_dumper_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yaml_config/ut/CMakeLists.linux-aarch64.txt index dc3cf97eda8a..d132dea19100 100644 --- a/ydb/library/yaml_config/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yaml_config/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-yaml_config-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yaml_config-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/console_dumper_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yaml_config/ut/CMakeLists.linux-x86_64.txt index 7369ea0dd2cb..e68824511a83 100644 --- a/ydb/library/yaml_config/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yaml_config/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-yaml_config-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yaml_config-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/console_dumper_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yaml_config/ut/CMakeLists.windows-x86_64.txt index 88e9923821c4..d023b2b5b19f 100644 --- a/ydb/library/yaml_config/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yaml_config/ut/CMakeLists.windows-x86_64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/validator/CMakeLists.darwin-arm64.txt b/ydb/library/yaml_config/validator/CMakeLists.darwin-arm64.txt index effa87c8149d..42e66987015e 100644 --- a/ydb/library/yaml_config/validator/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yaml_config/validator/CMakeLists.darwin-arm64.txt @@ -22,6 +22,10 @@ target_link_libraries(library-yaml_config-validator PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(library-yaml_config-validator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator_checks.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/configurators.h ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator_builder.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator_checks.cpp diff --git a/ydb/library/yaml_config/validator/CMakeLists.darwin-x86_64.txt b/ydb/library/yaml_config/validator/CMakeLists.darwin-x86_64.txt index effa87c8149d..42e66987015e 100644 --- a/ydb/library/yaml_config/validator/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yaml_config/validator/CMakeLists.darwin-x86_64.txt @@ -22,6 +22,10 @@ target_link_libraries(library-yaml_config-validator PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(library-yaml_config-validator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator_checks.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/configurators.h ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator_builder.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator_checks.cpp diff --git a/ydb/library/yaml_config/validator/CMakeLists.linux-aarch64.txt b/ydb/library/yaml_config/validator/CMakeLists.linux-aarch64.txt index bbd11d351c99..92d7c6ac92ba 100644 --- a/ydb/library/yaml_config/validator/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yaml_config/validator/CMakeLists.linux-aarch64.txt @@ -23,6 +23,10 @@ target_link_libraries(library-yaml_config-validator PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(library-yaml_config-validator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator_checks.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/configurators.h ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator_builder.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator_checks.cpp diff --git a/ydb/library/yaml_config/validator/CMakeLists.linux-x86_64.txt b/ydb/library/yaml_config/validator/CMakeLists.linux-x86_64.txt index bbd11d351c99..92d7c6ac92ba 100644 --- a/ydb/library/yaml_config/validator/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yaml_config/validator/CMakeLists.linux-x86_64.txt @@ -23,6 +23,10 @@ target_link_libraries(library-yaml_config-validator PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(library-yaml_config-validator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator_checks.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/configurators.h ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator_builder.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator_checks.cpp diff --git a/ydb/library/yaml_config/validator/CMakeLists.windows-x86_64.txt b/ydb/library/yaml_config/validator/CMakeLists.windows-x86_64.txt index effa87c8149d..42e66987015e 100644 --- a/ydb/library/yaml_config/validator/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yaml_config/validator/CMakeLists.windows-x86_64.txt @@ -22,6 +22,10 @@ target_link_libraries(library-yaml_config-validator PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(library-yaml_config-validator PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator_checks.h + ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/configurators.h ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator_builder.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/validator_checks.cpp diff --git a/ydb/library/yaml_config/validator/ut/validator/CMakeLists.darwin-arm64.txt b/ydb/library/yaml_config/validator/ut/validator/CMakeLists.darwin-arm64.txt index 77fc23cbe957..d4316aaf92b1 100644 --- a/ydb/library/yaml_config/validator/ut/validator/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yaml_config/validator/ut/validator/CMakeLists.darwin-arm64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/validator/ut/validator/CMakeLists.darwin-x86_64.txt b/ydb/library/yaml_config/validator/ut/validator/CMakeLists.darwin-x86_64.txt index ed0bb8123497..45eeac22042f 100644 --- a/ydb/library/yaml_config/validator/ut/validator/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yaml_config/validator/ut/validator/CMakeLists.darwin-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/validator/ut/validator/CMakeLists.linux-aarch64.txt b/ydb/library/yaml_config/validator/ut/validator/CMakeLists.linux-aarch64.txt index fb8cd8343697..1e73e4def5e5 100644 --- a/ydb/library/yaml_config/validator/ut/validator/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yaml_config/validator/ut/validator/CMakeLists.linux-aarch64.txt @@ -21,9 +21,6 @@ target_link_options(ydb-library-yaml_config-validator-ut-validator PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yaml_config-validator-ut-validator PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/ut/validator/validator_ut.cpp @@ -53,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/validator/ut/validator/CMakeLists.linux-x86_64.txt b/ydb/library/yaml_config/validator/ut/validator/CMakeLists.linux-x86_64.txt index 6017dd9f8356..e52211bb4da7 100644 --- a/ydb/library/yaml_config/validator/ut/validator/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yaml_config/validator/ut/validator/CMakeLists.linux-x86_64.txt @@ -22,9 +22,6 @@ target_link_options(ydb-library-yaml_config-validator-ut-validator PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yaml_config-validator-ut-validator PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/ut/validator/validator_ut.cpp @@ -54,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/validator/ut/validator/CMakeLists.windows-x86_64.txt b/ydb/library/yaml_config/validator/ut/validator/CMakeLists.windows-x86_64.txt index 65ef01ab15f5..805a494642b9 100644 --- a/ydb/library/yaml_config/validator/ut/validator/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yaml_config/validator/ut/validator/CMakeLists.windows-x86_64.txt @@ -43,6 +43,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/validator/ut/validator_builder/CMakeLists.darwin-arm64.txt b/ydb/library/yaml_config/validator/ut/validator_builder/CMakeLists.darwin-arm64.txt index 093b059d1a48..9e4c2706e5ed 100644 --- a/ydb/library/yaml_config/validator/ut/validator_builder/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yaml_config/validator/ut/validator_builder/CMakeLists.darwin-arm64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/validator/ut/validator_builder/CMakeLists.darwin-x86_64.txt b/ydb/library/yaml_config/validator/ut/validator_builder/CMakeLists.darwin-x86_64.txt index 7584c9fe36e2..732cc310633e 100644 --- a/ydb/library/yaml_config/validator/ut/validator_builder/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yaml_config/validator/ut/validator_builder/CMakeLists.darwin-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/validator/ut/validator_builder/CMakeLists.linux-aarch64.txt b/ydb/library/yaml_config/validator/ut/validator_builder/CMakeLists.linux-aarch64.txt index cb1b241848e0..346b38efc47c 100644 --- a/ydb/library/yaml_config/validator/ut/validator_builder/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yaml_config/validator/ut/validator_builder/CMakeLists.linux-aarch64.txt @@ -21,9 +21,6 @@ target_link_options(yaml_config-validator-ut-validator_builder PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(yaml_config-validator-ut-validator_builder PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/ut/validator_builder/validator_builder_ut.cpp @@ -53,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/validator/ut/validator_builder/CMakeLists.linux-x86_64.txt b/ydb/library/yaml_config/validator/ut/validator_builder/CMakeLists.linux-x86_64.txt index a3875ea50b63..445cecd4d61e 100644 --- a/ydb/library/yaml_config/validator/ut/validator_builder/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yaml_config/validator/ut/validator_builder/CMakeLists.linux-x86_64.txt @@ -22,9 +22,6 @@ target_link_options(yaml_config-validator-ut-validator_builder PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(yaml_config-validator-ut-validator_builder PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/ut/validator_builder/validator_builder_ut.cpp @@ -54,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/validator/ut/validator_builder/CMakeLists.windows-x86_64.txt b/ydb/library/yaml_config/validator/ut/validator_builder/CMakeLists.windows-x86_64.txt index e83b948e00e1..8cdf4ee07af3 100644 --- a/ydb/library/yaml_config/validator/ut/validator_builder/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yaml_config/validator/ut/validator_builder/CMakeLists.windows-x86_64.txt @@ -43,6 +43,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/validator/ut/validator_checks/CMakeLists.darwin-arm64.txt b/ydb/library/yaml_config/validator/ut/validator_checks/CMakeLists.darwin-arm64.txt index 0b02ef5a43af..f57405d8f97d 100644 --- a/ydb/library/yaml_config/validator/ut/validator_checks/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yaml_config/validator/ut/validator_checks/CMakeLists.darwin-arm64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/validator/ut/validator_checks/CMakeLists.darwin-x86_64.txt b/ydb/library/yaml_config/validator/ut/validator_checks/CMakeLists.darwin-x86_64.txt index 34f77f222d61..aab280905380 100644 --- a/ydb/library/yaml_config/validator/ut/validator_checks/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yaml_config/validator/ut/validator_checks/CMakeLists.darwin-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/validator/ut/validator_checks/CMakeLists.linux-aarch64.txt b/ydb/library/yaml_config/validator/ut/validator_checks/CMakeLists.linux-aarch64.txt index 42f7fe333117..92de541924f1 100644 --- a/ydb/library/yaml_config/validator/ut/validator_checks/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yaml_config/validator/ut/validator_checks/CMakeLists.linux-aarch64.txt @@ -21,9 +21,6 @@ target_link_options(yaml_config-validator-ut-validator_checks PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(yaml_config-validator-ut-validator_checks PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/ut/validator_checks/validator_checks_ut.cpp @@ -53,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/validator/ut/validator_checks/CMakeLists.linux-x86_64.txt b/ydb/library/yaml_config/validator/ut/validator_checks/CMakeLists.linux-x86_64.txt index 89ff9e32ffb2..9c65e14e48d6 100644 --- a/ydb/library/yaml_config/validator/ut/validator_checks/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yaml_config/validator/ut/validator_checks/CMakeLists.linux-x86_64.txt @@ -22,9 +22,6 @@ target_link_options(yaml_config-validator-ut-validator_checks PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(yaml_config-validator-ut-validator_checks PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yaml_config/validator/ut/validator_checks/validator_checks_ut.cpp @@ -54,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yaml_config/validator/ut/validator_checks/CMakeLists.windows-x86_64.txt b/ydb/library/yaml_config/validator/ut/validator_checks/CMakeLists.windows-x86_64.txt index ca67957eab43..ee586d8b89a3 100644 --- a/ydb/library/yaml_config/validator/ut/validator_checks/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yaml_config/validator/ut/validator_checks/CMakeLists.windows-x86_64.txt @@ -43,6 +43,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/ycloud/api/CMakeLists.darwin-arm64.txt b/ydb/library/ycloud/api/CMakeLists.darwin-arm64.txt index 2644f7fc5ea9..d81bd368f190 100644 --- a/ydb/library/ycloud/api/CMakeLists.darwin-arm64.txt +++ b/ydb/library/ycloud/api/CMakeLists.darwin-arm64.txt @@ -13,9 +13,17 @@ target_link_libraries(library-ycloud-api INTERFACE yutil client-yc_private-iam client-yc_private-servicecontrol + client-yc_private-accessservice client-yc_private-resourcemanager library-actors-core library-grpc-client ydb-core-base ydb-core-grpc_caching ) +target_sources(library-ycloud-api INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/access_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/folder_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/folder_service_transitional.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/iam_token_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/user_account_service.h +) diff --git a/ydb/library/ycloud/api/CMakeLists.darwin-x86_64.txt b/ydb/library/ycloud/api/CMakeLists.darwin-x86_64.txt index 2644f7fc5ea9..d81bd368f190 100644 --- a/ydb/library/ycloud/api/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/ycloud/api/CMakeLists.darwin-x86_64.txt @@ -13,9 +13,17 @@ target_link_libraries(library-ycloud-api INTERFACE yutil client-yc_private-iam client-yc_private-servicecontrol + client-yc_private-accessservice client-yc_private-resourcemanager library-actors-core library-grpc-client ydb-core-base ydb-core-grpc_caching ) +target_sources(library-ycloud-api INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/access_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/folder_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/folder_service_transitional.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/iam_token_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/user_account_service.h +) diff --git a/ydb/library/ycloud/api/CMakeLists.linux-aarch64.txt b/ydb/library/ycloud/api/CMakeLists.linux-aarch64.txt index 22bf4a03ea14..0c7b40bafcad 100644 --- a/ydb/library/ycloud/api/CMakeLists.linux-aarch64.txt +++ b/ydb/library/ycloud/api/CMakeLists.linux-aarch64.txt @@ -14,9 +14,17 @@ target_link_libraries(library-ycloud-api INTERFACE yutil client-yc_private-iam client-yc_private-servicecontrol + client-yc_private-accessservice client-yc_private-resourcemanager library-actors-core library-grpc-client ydb-core-base ydb-core-grpc_caching ) +target_sources(library-ycloud-api INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/access_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/folder_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/folder_service_transitional.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/iam_token_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/user_account_service.h +) diff --git a/ydb/library/ycloud/api/CMakeLists.linux-x86_64.txt b/ydb/library/ycloud/api/CMakeLists.linux-x86_64.txt index 22bf4a03ea14..0c7b40bafcad 100644 --- a/ydb/library/ycloud/api/CMakeLists.linux-x86_64.txt +++ b/ydb/library/ycloud/api/CMakeLists.linux-x86_64.txt @@ -14,9 +14,17 @@ target_link_libraries(library-ycloud-api INTERFACE yutil client-yc_private-iam client-yc_private-servicecontrol + client-yc_private-accessservice client-yc_private-resourcemanager library-actors-core library-grpc-client ydb-core-base ydb-core-grpc_caching ) +target_sources(library-ycloud-api INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/access_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/folder_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/folder_service_transitional.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/iam_token_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/user_account_service.h +) diff --git a/ydb/library/ycloud/api/CMakeLists.windows-x86_64.txt b/ydb/library/ycloud/api/CMakeLists.windows-x86_64.txt index 2644f7fc5ea9..d81bd368f190 100644 --- a/ydb/library/ycloud/api/CMakeLists.windows-x86_64.txt +++ b/ydb/library/ycloud/api/CMakeLists.windows-x86_64.txt @@ -13,9 +13,17 @@ target_link_libraries(library-ycloud-api INTERFACE yutil client-yc_private-iam client-yc_private-servicecontrol + client-yc_private-accessservice client-yc_private-resourcemanager library-actors-core library-grpc-client ydb-core-base ydb-core-grpc_caching ) +target_sources(library-ycloud-api INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/access_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/folder_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/folder_service_transitional.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/iam_token_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/api/user_account_service.h +) diff --git a/ydb/library/ycloud/impl/CMakeLists.darwin-arm64.txt b/ydb/library/ycloud/impl/CMakeLists.darwin-arm64.txt index 1338ae8e93aa..6c31d6eb8ee3 100644 --- a/ydb/library/ycloud/impl/CMakeLists.darwin-arm64.txt +++ b/ydb/library/ycloud/impl/CMakeLists.darwin-arm64.txt @@ -23,6 +23,16 @@ target_link_libraries(library-ycloud-impl PUBLIC lib-deprecated-kicli ) target_sources(library-ycloud-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/access_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/folder_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/folder_service_transitional.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/grpc_service_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/grpc_service_client.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/grpc_service_settings.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/iam_token_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/mock_access_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/service_account_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/user_account_service.h ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/access_service.cpp ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/folder_service.cpp ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/folder_service_transitional.cpp diff --git a/ydb/library/ycloud/impl/CMakeLists.darwin-x86_64.txt b/ydb/library/ycloud/impl/CMakeLists.darwin-x86_64.txt index 1338ae8e93aa..6c31d6eb8ee3 100644 --- a/ydb/library/ycloud/impl/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/ycloud/impl/CMakeLists.darwin-x86_64.txt @@ -23,6 +23,16 @@ target_link_libraries(library-ycloud-impl PUBLIC lib-deprecated-kicli ) target_sources(library-ycloud-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/access_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/folder_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/folder_service_transitional.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/grpc_service_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/grpc_service_client.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/grpc_service_settings.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/iam_token_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/mock_access_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/service_account_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/user_account_service.h ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/access_service.cpp ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/folder_service.cpp ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/folder_service_transitional.cpp diff --git a/ydb/library/ycloud/impl/CMakeLists.linux-aarch64.txt b/ydb/library/ycloud/impl/CMakeLists.linux-aarch64.txt index 0ef5e48a4ab4..25227b669d28 100644 --- a/ydb/library/ycloud/impl/CMakeLists.linux-aarch64.txt +++ b/ydb/library/ycloud/impl/CMakeLists.linux-aarch64.txt @@ -24,6 +24,16 @@ target_link_libraries(library-ycloud-impl PUBLIC lib-deprecated-kicli ) target_sources(library-ycloud-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/access_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/folder_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/folder_service_transitional.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/grpc_service_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/grpc_service_client.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/grpc_service_settings.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/iam_token_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/mock_access_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/service_account_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/user_account_service.h ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/access_service.cpp ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/folder_service.cpp ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/folder_service_transitional.cpp diff --git a/ydb/library/ycloud/impl/CMakeLists.linux-x86_64.txt b/ydb/library/ycloud/impl/CMakeLists.linux-x86_64.txt index 0ef5e48a4ab4..25227b669d28 100644 --- a/ydb/library/ycloud/impl/CMakeLists.linux-x86_64.txt +++ b/ydb/library/ycloud/impl/CMakeLists.linux-x86_64.txt @@ -24,6 +24,16 @@ target_link_libraries(library-ycloud-impl PUBLIC lib-deprecated-kicli ) target_sources(library-ycloud-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/access_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/folder_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/folder_service_transitional.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/grpc_service_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/grpc_service_client.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/grpc_service_settings.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/iam_token_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/mock_access_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/service_account_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/user_account_service.h ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/access_service.cpp ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/folder_service.cpp ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/folder_service_transitional.cpp diff --git a/ydb/library/ycloud/impl/CMakeLists.windows-x86_64.txt b/ydb/library/ycloud/impl/CMakeLists.windows-x86_64.txt index 1338ae8e93aa..6c31d6eb8ee3 100644 --- a/ydb/library/ycloud/impl/CMakeLists.windows-x86_64.txt +++ b/ydb/library/ycloud/impl/CMakeLists.windows-x86_64.txt @@ -23,6 +23,16 @@ target_link_libraries(library-ycloud-impl PUBLIC lib-deprecated-kicli ) target_sources(library-ycloud-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/access_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/folder_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/folder_service_transitional.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/grpc_service_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/grpc_service_client.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/grpc_service_settings.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/iam_token_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/mock_access_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/service_account_service.h + ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/user_account_service.h ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/access_service.cpp ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/folder_service.cpp ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/folder_service_transitional.cpp diff --git a/ydb/library/ycloud/impl/ut/CMakeLists.darwin-arm64.txt b/ydb/library/ycloud/impl/ut/CMakeLists.darwin-arm64.txt index d302272e9bde..0466efe38bfd 100644 --- a/ydb/library/ycloud/impl/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/ycloud/impl/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-library-ycloud-impl-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-ycloud-impl-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/access_service_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/ycloud/impl/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/ycloud/impl/ut/CMakeLists.darwin-x86_64.txt index bb1da9c69446..98585b4fe1ad 100644 --- a/ydb/library/ycloud/impl/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/ycloud/impl/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-library-ycloud-impl-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-ycloud-impl-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/access_service_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/ycloud/impl/ut/CMakeLists.linux-aarch64.txt b/ydb/library/ycloud/impl/ut/CMakeLists.linux-aarch64.txt index 5192e4b68e71..f0a1b7e8318c 100644 --- a/ydb/library/ycloud/impl/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/ycloud/impl/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-library-ycloud-impl-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-ycloud-impl-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/access_service_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/ycloud/impl/ut/CMakeLists.linux-x86_64.txt b/ydb/library/ycloud/impl/ut/CMakeLists.linux-x86_64.txt index 3c3c22851a65..9c997a9b2305 100644 --- a/ydb/library/ycloud/impl/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/ycloud/impl/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-library-ycloud-impl-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-ycloud-impl-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/ycloud/impl/access_service_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/ycloud/impl/ut/CMakeLists.windows-x86_64.txt b/ydb/library/ycloud/impl/ut/CMakeLists.windows-x86_64.txt index 3429e63f41ac..6de24534672d 100644 --- a/ydb/library/ycloud/impl/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/ycloud/impl/ut/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/ydb_issue/CMakeLists.darwin-arm64.txt b/ydb/library/ydb_issue/CMakeLists.darwin-arm64.txt index 69d90656e372..99c609c81e84 100644 --- a/ydb/library/ydb_issue/CMakeLists.darwin-arm64.txt +++ b/ydb/library/ydb_issue/CMakeLists.darwin-arm64.txt @@ -22,6 +22,7 @@ target_link_libraries(ydb-library-ydb_issue PUBLIC library-cpp-resource ) target_sources(ydb-library-ydb_issue PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/ydb_issue/issue_helpers.h ${CMAKE_SOURCE_DIR}/ydb/library/ydb_issue/issue_helpers.cpp ) diff --git a/ydb/library/ydb_issue/CMakeLists.darwin-x86_64.txt b/ydb/library/ydb_issue/CMakeLists.darwin-x86_64.txt index 69d90656e372..99c609c81e84 100644 --- a/ydb/library/ydb_issue/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/ydb_issue/CMakeLists.darwin-x86_64.txt @@ -22,6 +22,7 @@ target_link_libraries(ydb-library-ydb_issue PUBLIC library-cpp-resource ) target_sources(ydb-library-ydb_issue PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/ydb_issue/issue_helpers.h ${CMAKE_SOURCE_DIR}/ydb/library/ydb_issue/issue_helpers.cpp ) diff --git a/ydb/library/ydb_issue/CMakeLists.linux-aarch64.txt b/ydb/library/ydb_issue/CMakeLists.linux-aarch64.txt index 0184ab7c31c4..d1101d3b3595 100644 --- a/ydb/library/ydb_issue/CMakeLists.linux-aarch64.txt +++ b/ydb/library/ydb_issue/CMakeLists.linux-aarch64.txt @@ -23,6 +23,7 @@ target_link_libraries(ydb-library-ydb_issue PUBLIC library-cpp-resource ) target_sources(ydb-library-ydb_issue PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/ydb_issue/issue_helpers.h ${CMAKE_SOURCE_DIR}/ydb/library/ydb_issue/issue_helpers.cpp ) diff --git a/ydb/library/ydb_issue/CMakeLists.linux-x86_64.txt b/ydb/library/ydb_issue/CMakeLists.linux-x86_64.txt index 0184ab7c31c4..d1101d3b3595 100644 --- a/ydb/library/ydb_issue/CMakeLists.linux-x86_64.txt +++ b/ydb/library/ydb_issue/CMakeLists.linux-x86_64.txt @@ -23,6 +23,7 @@ target_link_libraries(ydb-library-ydb_issue PUBLIC library-cpp-resource ) target_sources(ydb-library-ydb_issue PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/ydb_issue/issue_helpers.h ${CMAKE_SOURCE_DIR}/ydb/library/ydb_issue/issue_helpers.cpp ) diff --git a/ydb/library/ydb_issue/CMakeLists.windows-x86_64.txt b/ydb/library/ydb_issue/CMakeLists.windows-x86_64.txt index 69d90656e372..99c609c81e84 100644 --- a/ydb/library/ydb_issue/CMakeLists.windows-x86_64.txt +++ b/ydb/library/ydb_issue/CMakeLists.windows-x86_64.txt @@ -22,6 +22,7 @@ target_link_libraries(ydb-library-ydb_issue PUBLIC library-cpp-resource ) target_sources(ydb-library-ydb_issue PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/ydb_issue/issue_helpers.h ${CMAKE_SOURCE_DIR}/ydb/library/ydb_issue/issue_helpers.cpp ) diff --git a/ydb/library/ydb_issue/proto/CMakeLists.darwin-arm64.txt b/ydb/library/ydb_issue/proto/CMakeLists.darwin-arm64.txt index d4c186028bc5..169ed2ccaea8 100644 --- a/ydb/library/ydb_issue/proto/CMakeLists.darwin-arm64.txt +++ b/ydb/library/ydb_issue/proto/CMakeLists.darwin-arm64.txt @@ -39,6 +39,10 @@ target_link_libraries(library-ydb_issue-proto PUBLIC target_proto_messages(library-ydb_issue-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/ydb_issue/proto/issue_id.proto ) +target_sources(library-ydb_issue-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/ydb_issue/proto/issue_id.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/ydb_issue/proto/issue_id.grpc.pb.h +) target_proto_addincls(library-ydb_issue-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/ydb_issue/proto/CMakeLists.darwin-x86_64.txt b/ydb/library/ydb_issue/proto/CMakeLists.darwin-x86_64.txt index d4c186028bc5..169ed2ccaea8 100644 --- a/ydb/library/ydb_issue/proto/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/ydb_issue/proto/CMakeLists.darwin-x86_64.txt @@ -39,6 +39,10 @@ target_link_libraries(library-ydb_issue-proto PUBLIC target_proto_messages(library-ydb_issue-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/ydb_issue/proto/issue_id.proto ) +target_sources(library-ydb_issue-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/ydb_issue/proto/issue_id.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/ydb_issue/proto/issue_id.grpc.pb.h +) target_proto_addincls(library-ydb_issue-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/ydb_issue/proto/CMakeLists.linux-aarch64.txt b/ydb/library/ydb_issue/proto/CMakeLists.linux-aarch64.txt index d5020cdff451..352a5b9f983e 100644 --- a/ydb/library/ydb_issue/proto/CMakeLists.linux-aarch64.txt +++ b/ydb/library/ydb_issue/proto/CMakeLists.linux-aarch64.txt @@ -40,6 +40,10 @@ target_link_libraries(library-ydb_issue-proto PUBLIC target_proto_messages(library-ydb_issue-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/ydb_issue/proto/issue_id.proto ) +target_sources(library-ydb_issue-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/ydb_issue/proto/issue_id.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/ydb_issue/proto/issue_id.grpc.pb.h +) target_proto_addincls(library-ydb_issue-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/ydb_issue/proto/CMakeLists.linux-x86_64.txt b/ydb/library/ydb_issue/proto/CMakeLists.linux-x86_64.txt index d5020cdff451..352a5b9f983e 100644 --- a/ydb/library/ydb_issue/proto/CMakeLists.linux-x86_64.txt +++ b/ydb/library/ydb_issue/proto/CMakeLists.linux-x86_64.txt @@ -40,6 +40,10 @@ target_link_libraries(library-ydb_issue-proto PUBLIC target_proto_messages(library-ydb_issue-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/ydb_issue/proto/issue_id.proto ) +target_sources(library-ydb_issue-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/ydb_issue/proto/issue_id.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/ydb_issue/proto/issue_id.grpc.pb.h +) target_proto_addincls(library-ydb_issue-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/ydb_issue/proto/CMakeLists.windows-x86_64.txt b/ydb/library/ydb_issue/proto/CMakeLists.windows-x86_64.txt index d4c186028bc5..169ed2ccaea8 100644 --- a/ydb/library/ydb_issue/proto/CMakeLists.windows-x86_64.txt +++ b/ydb/library/ydb_issue/proto/CMakeLists.windows-x86_64.txt @@ -39,6 +39,10 @@ target_link_libraries(library-ydb_issue-proto PUBLIC target_proto_messages(library-ydb_issue-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/ydb_issue/proto/issue_id.proto ) +target_sources(library-ydb_issue-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/ydb_issue/proto/issue_id.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/ydb_issue/proto/issue_id.grpc.pb.h +) target_proto_addincls(library-ydb_issue-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/CMakeLists.darwin-arm64.txt b/ydb/library/yql/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..7f41afad8ef3 --- /dev/null +++ b/ydb/library/yql/CMakeLists.darwin-arm64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ast) +add_subdirectory(core) +add_subdirectory(dq) +add_subdirectory(minikql) +add_subdirectory(parser) +add_subdirectory(protos) +add_subdirectory(providers) +add_subdirectory(public) +add_subdirectory(sql) +add_subdirectory(tools) +add_subdirectory(udfs) +add_subdirectory(utils) diff --git a/ydb/library/yql/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..7f41afad8ef3 --- /dev/null +++ b/ydb/library/yql/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ast) +add_subdirectory(core) +add_subdirectory(dq) +add_subdirectory(minikql) +add_subdirectory(parser) +add_subdirectory(protos) +add_subdirectory(providers) +add_subdirectory(public) +add_subdirectory(sql) +add_subdirectory(tools) +add_subdirectory(udfs) +add_subdirectory(utils) diff --git a/ydb/library/yql/CMakeLists.linux-aarch64.txt b/ydb/library/yql/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..f6abc3fa7fd4 --- /dev/null +++ b/ydb/library/yql/CMakeLists.linux-aarch64.txt @@ -0,0 +1,21 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ast) +add_subdirectory(core) +add_subdirectory(dq) +add_subdirectory(minikql) +add_subdirectory(parser) +add_subdirectory(protos) +add_subdirectory(providers) +add_subdirectory(public) +add_subdirectory(sql) +add_subdirectory(tools) +add_subdirectory(udfs) +add_subdirectory(utils) +add_subdirectory(yt) diff --git a/ydb/library/yql/CMakeLists.linux-x86_64.txt b/ydb/library/yql/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..f6abc3fa7fd4 --- /dev/null +++ b/ydb/library/yql/CMakeLists.linux-x86_64.txt @@ -0,0 +1,21 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ast) +add_subdirectory(core) +add_subdirectory(dq) +add_subdirectory(minikql) +add_subdirectory(parser) +add_subdirectory(protos) +add_subdirectory(providers) +add_subdirectory(public) +add_subdirectory(sql) +add_subdirectory(tools) +add_subdirectory(udfs) +add_subdirectory(utils) +add_subdirectory(yt) diff --git a/ydb/library/yql/CMakeLists.txt b/ydb/library/yql/CMakeLists.txt index 7f41afad8ef3..d863ebd18067 100644 --- a/ydb/library/yql/CMakeLists.txt +++ b/ydb/library/yql/CMakeLists.txt @@ -6,15 +6,14 @@ # original buildsystem will not be accepted. -add_subdirectory(ast) -add_subdirectory(core) -add_subdirectory(dq) -add_subdirectory(minikql) -add_subdirectory(parser) -add_subdirectory(protos) -add_subdirectory(providers) -add_subdirectory(public) -add_subdirectory(sql) -add_subdirectory(tools) -add_subdirectory(udfs) -add_subdirectory(utils) +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/CMakeLists.windows-x86_64.txt b/ydb/library/yql/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..7f41afad8ef3 --- /dev/null +++ b/ydb/library/yql/CMakeLists.windows-x86_64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ast) +add_subdirectory(core) +add_subdirectory(dq) +add_subdirectory(minikql) +add_subdirectory(parser) +add_subdirectory(protos) +add_subdirectory(providers) +add_subdirectory(public) +add_subdirectory(sql) +add_subdirectory(tools) +add_subdirectory(udfs) +add_subdirectory(utils) diff --git a/ydb/library/yql/ast/CMakeLists.darwin-arm64.txt b/ydb/library/yql/ast/CMakeLists.darwin-arm64.txt index 702a50bcc6e4..85c1c34fa320 100644 --- a/ydb/library/yql/ast/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/ast/CMakeLists.darwin-arm64.txt @@ -30,6 +30,16 @@ target_link_libraries(library-yql-ast PUBLIC api-protos ) target_sources(library-yql-ast PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_constraint.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast_annotation.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast_escaping.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_errors.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_expr.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_expr_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_expr_types.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_gc_nodes.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_type_string.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_constraint.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast_annotation.cpp diff --git a/ydb/library/yql/ast/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/ast/CMakeLists.darwin-x86_64.txt index 702a50bcc6e4..85c1c34fa320 100644 --- a/ydb/library/yql/ast/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/ast/CMakeLists.darwin-x86_64.txt @@ -30,6 +30,16 @@ target_link_libraries(library-yql-ast PUBLIC api-protos ) target_sources(library-yql-ast PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_constraint.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast_annotation.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast_escaping.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_errors.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_expr.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_expr_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_expr_types.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_gc_nodes.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_type_string.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_constraint.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast_annotation.cpp diff --git a/ydb/library/yql/ast/CMakeLists.linux-aarch64.txt b/ydb/library/yql/ast/CMakeLists.linux-aarch64.txt index 47978239dea2..821347803021 100644 --- a/ydb/library/yql/ast/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/ast/CMakeLists.linux-aarch64.txt @@ -31,6 +31,16 @@ target_link_libraries(library-yql-ast PUBLIC api-protos ) target_sources(library-yql-ast PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_constraint.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast_annotation.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast_escaping.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_errors.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_expr.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_expr_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_expr_types.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_gc_nodes.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_type_string.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_constraint.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast_annotation.cpp diff --git a/ydb/library/yql/ast/CMakeLists.linux-x86_64.txt b/ydb/library/yql/ast/CMakeLists.linux-x86_64.txt index 47978239dea2..821347803021 100644 --- a/ydb/library/yql/ast/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/ast/CMakeLists.linux-x86_64.txt @@ -31,6 +31,16 @@ target_link_libraries(library-yql-ast PUBLIC api-protos ) target_sources(library-yql-ast PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_constraint.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast_annotation.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast_escaping.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_errors.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_expr.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_expr_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_expr_types.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_gc_nodes.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_type_string.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_constraint.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast_annotation.cpp diff --git a/ydb/library/yql/ast/CMakeLists.windows-x86_64.txt b/ydb/library/yql/ast/CMakeLists.windows-x86_64.txt index 702a50bcc6e4..85c1c34fa320 100644 --- a/ydb/library/yql/ast/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/ast/CMakeLists.windows-x86_64.txt @@ -30,6 +30,16 @@ target_link_libraries(library-yql-ast PUBLIC api-protos ) target_sources(library-yql-ast PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_constraint.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast_annotation.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast_escaping.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_errors.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_expr.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_expr_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_expr_types.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_gc_nodes.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_type_string.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_constraint.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast_annotation.cpp diff --git a/ydb/library/yql/ast/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/ast/ut/CMakeLists.darwin-arm64.txt index 2d2aa39df624..91dcb2804a3e 100644 --- a/ydb/library/yql/ast/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/ast/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-library-yql-ast-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-ast-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/ast/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/ast/ut/CMakeLists.darwin-x86_64.txt index f2a870304d3f..3db5300cf8c2 100644 --- a/ydb/library/yql/ast/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/ast/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-library-yql-ast-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-ast-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/ast/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/ast/ut/CMakeLists.linux-aarch64.txt index 88624472714d..677b546d3705 100644 --- a/ydb/library/yql/ast/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/ast/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-yql-ast-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-ast-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/ast/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/ast/ut/CMakeLists.linux-x86_64.txt index 3266a9cadf3e..0d05ac7c09a3 100644 --- a/ydb/library/yql/ast/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/ast/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-yql-ast-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-ast-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/ast/yql_ast_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/ast/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/ast/ut/CMakeLists.windows-x86_64.txt index 6ba9f06eaa08..6bdc81b2ad47 100644 --- a/ydb/library/yql/ast/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/ast/ut/CMakeLists.windows-x86_64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/CMakeLists.darwin-arm64.txt index 893a2f0cff9c..6efdb3a29eb6 100644 --- a/ydb/library/yql/core/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/CMakeLists.darwin-arm64.txt @@ -17,7 +17,7 @@ add_subdirectory(facade) add_subdirectory(file_storage) add_subdirectory(issue) add_subdirectory(peephole_opt) -add_subdirectory(progress_merger) +add_subdirectory(pg_settings) add_subdirectory(services) add_subdirectory(spilling) add_subdirectory(sql_types) @@ -83,6 +83,32 @@ target_link_libraries(library-yql-core PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(library-yql-core PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_atom_enums.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_callable_transform.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_csv.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_data_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_execution.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_expr_constraint.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_expr_csee.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_expr_optimize.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_expr_type_annotation.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_gc_transformer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_graph_transformer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_holding_file_storage.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_join.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_match_recognize.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_proposed_by_data.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_range.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_rewrite_io.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_utils.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_window.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_type_annotation.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_type_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_udf_index.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_udf_index_package_set.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_udf_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_user_data.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_user_data_storage.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_aggregate_expander.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_callable_transform.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_cost_function.cpp diff --git a/ydb/library/yql/core/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/CMakeLists.darwin-x86_64.txt index 893a2f0cff9c..6efdb3a29eb6 100644 --- a/ydb/library/yql/core/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/CMakeLists.darwin-x86_64.txt @@ -17,7 +17,7 @@ add_subdirectory(facade) add_subdirectory(file_storage) add_subdirectory(issue) add_subdirectory(peephole_opt) -add_subdirectory(progress_merger) +add_subdirectory(pg_settings) add_subdirectory(services) add_subdirectory(spilling) add_subdirectory(sql_types) @@ -83,6 +83,32 @@ target_link_libraries(library-yql-core PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(library-yql-core PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_atom_enums.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_callable_transform.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_csv.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_data_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_execution.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_expr_constraint.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_expr_csee.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_expr_optimize.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_expr_type_annotation.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_gc_transformer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_graph_transformer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_holding_file_storage.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_join.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_match_recognize.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_proposed_by_data.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_range.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_rewrite_io.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_utils.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_window.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_type_annotation.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_type_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_udf_index.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_udf_index_package_set.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_udf_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_user_data.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_user_data_storage.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_aggregate_expander.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_callable_transform.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_cost_function.cpp diff --git a/ydb/library/yql/core/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/CMakeLists.linux-aarch64.txt index f947778c5f20..fd3b96d74666 100644 --- a/ydb/library/yql/core/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/CMakeLists.linux-aarch64.txt @@ -17,6 +17,7 @@ add_subdirectory(facade) add_subdirectory(file_storage) add_subdirectory(issue) add_subdirectory(peephole_opt) +add_subdirectory(pg_settings) add_subdirectory(progress_merger) add_subdirectory(services) add_subdirectory(spilling) @@ -84,6 +85,32 @@ target_link_libraries(library-yql-core PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(library-yql-core PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_atom_enums.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_callable_transform.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_csv.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_data_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_execution.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_expr_constraint.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_expr_csee.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_expr_optimize.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_expr_type_annotation.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_gc_transformer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_graph_transformer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_holding_file_storage.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_join.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_match_recognize.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_proposed_by_data.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_range.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_rewrite_io.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_utils.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_window.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_type_annotation.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_type_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_udf_index.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_udf_index_package_set.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_udf_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_user_data.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_user_data_storage.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_aggregate_expander.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_callable_transform.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_cost_function.cpp diff --git a/ydb/library/yql/core/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/CMakeLists.linux-x86_64.txt index f947778c5f20..fd3b96d74666 100644 --- a/ydb/library/yql/core/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/CMakeLists.linux-x86_64.txt @@ -17,6 +17,7 @@ add_subdirectory(facade) add_subdirectory(file_storage) add_subdirectory(issue) add_subdirectory(peephole_opt) +add_subdirectory(pg_settings) add_subdirectory(progress_merger) add_subdirectory(services) add_subdirectory(spilling) @@ -84,6 +85,32 @@ target_link_libraries(library-yql-core PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(library-yql-core PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_atom_enums.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_callable_transform.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_csv.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_data_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_execution.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_expr_constraint.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_expr_csee.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_expr_optimize.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_expr_type_annotation.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_gc_transformer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_graph_transformer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_holding_file_storage.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_join.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_match_recognize.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_proposed_by_data.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_range.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_rewrite_io.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_utils.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_window.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_type_annotation.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_type_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_udf_index.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_udf_index_package_set.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_udf_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_user_data.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_user_data_storage.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_aggregate_expander.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_callable_transform.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_cost_function.cpp diff --git a/ydb/library/yql/core/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/CMakeLists.windows-x86_64.txt index 893a2f0cff9c..6efdb3a29eb6 100644 --- a/ydb/library/yql/core/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/CMakeLists.windows-x86_64.txt @@ -17,7 +17,7 @@ add_subdirectory(facade) add_subdirectory(file_storage) add_subdirectory(issue) add_subdirectory(peephole_opt) -add_subdirectory(progress_merger) +add_subdirectory(pg_settings) add_subdirectory(services) add_subdirectory(spilling) add_subdirectory(sql_types) @@ -83,6 +83,32 @@ target_link_libraries(library-yql-core PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(library-yql-core PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_atom_enums.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_callable_transform.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_csv.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_data_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_execution.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_expr_constraint.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_expr_csee.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_expr_optimize.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_expr_type_annotation.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_gc_transformer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_graph_transformer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_holding_file_storage.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_join.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_match_recognize.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_proposed_by_data.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_range.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_rewrite_io.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_utils.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_opt_window.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_type_annotation.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_type_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_udf_index.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_udf_index_package_set.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_udf_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_user_data.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_user_data_storage.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_aggregate_expander.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_callable_transform.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/yql_cost_function.cpp diff --git a/ydb/library/yql/core/arrow_kernels/registry/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/arrow_kernels/registry/CMakeLists.darwin-arm64.txt index 6a41655bc31f..642db2f019b7 100644 --- a/ydb/library/yql/core/arrow_kernels/registry/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/arrow_kernels/registry/CMakeLists.darwin-arm64.txt @@ -16,7 +16,7 @@ target_link_libraries(core-arrow_kernels-registry PUBLIC contrib-libs-cxxsupp yutil libs-apache-arrow - minikql-computation-llvm + yql-minikql-computation ) target_sources(core-arrow_kernels-registry PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/arrow_kernels/registry/registry.cpp diff --git a/ydb/library/yql/core/arrow_kernels/registry/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/arrow_kernels/registry/CMakeLists.darwin-x86_64.txt index 6a41655bc31f..642db2f019b7 100644 --- a/ydb/library/yql/core/arrow_kernels/registry/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/arrow_kernels/registry/CMakeLists.darwin-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(core-arrow_kernels-registry PUBLIC contrib-libs-cxxsupp yutil libs-apache-arrow - minikql-computation-llvm + yql-minikql-computation ) target_sources(core-arrow_kernels-registry PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/arrow_kernels/registry/registry.cpp diff --git a/ydb/library/yql/core/arrow_kernels/registry/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/arrow_kernels/registry/CMakeLists.linux-aarch64.txt index 4ab8b48283f3..a56ede852f85 100644 --- a/ydb/library/yql/core/arrow_kernels/registry/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/arrow_kernels/registry/CMakeLists.linux-aarch64.txt @@ -17,7 +17,7 @@ target_link_libraries(core-arrow_kernels-registry PUBLIC contrib-libs-cxxsupp yutil libs-apache-arrow - minikql-computation-llvm + yql-minikql-computation ) target_sources(core-arrow_kernels-registry PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/arrow_kernels/registry/registry.cpp diff --git a/ydb/library/yql/core/arrow_kernels/registry/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/arrow_kernels/registry/CMakeLists.linux-x86_64.txt index 4ab8b48283f3..a56ede852f85 100644 --- a/ydb/library/yql/core/arrow_kernels/registry/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/arrow_kernels/registry/CMakeLists.linux-x86_64.txt @@ -17,7 +17,7 @@ target_link_libraries(core-arrow_kernels-registry PUBLIC contrib-libs-cxxsupp yutil libs-apache-arrow - minikql-computation-llvm + yql-minikql-computation ) target_sources(core-arrow_kernels-registry PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/arrow_kernels/registry/registry.cpp diff --git a/ydb/library/yql/core/arrow_kernels/registry/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/arrow_kernels/registry/CMakeLists.windows-x86_64.txt index 6a41655bc31f..642db2f019b7 100644 --- a/ydb/library/yql/core/arrow_kernels/registry/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/arrow_kernels/registry/CMakeLists.windows-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(core-arrow_kernels-registry PUBLIC contrib-libs-cxxsupp yutil libs-apache-arrow - minikql-computation-llvm + yql-minikql-computation ) target_sources(core-arrow_kernels-registry PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/arrow_kernels/registry/registry.cpp diff --git a/ydb/library/yql/core/arrow_kernels/registry/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/arrow_kernels/registry/ut/CMakeLists.darwin-arm64.txt index 7ac91512bee6..69e47ba10f8f 100644 --- a/ydb/library/yql/core/arrow_kernels/registry/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/arrow_kernels/registry/ut/CMakeLists.darwin-arm64.txt @@ -23,7 +23,7 @@ target_link_libraries(ydb-library-yql-core-arrow_kernels-registry-ut PUBLIC yql-public-udf udf-service-exception_policy yql-sql-pg_dummy - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 url_udf json2_udf ) @@ -31,8 +31,6 @@ target_link_options(ydb-library-yql-core-arrow_kernels-registry-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-core-arrow_kernels-registry-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/arrow_kernels/registry/ut/registry_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/arrow_kernels/registry/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/arrow_kernels/registry/ut/CMakeLists.darwin-x86_64.txt index db038741fe22..da212143fce1 100644 --- a/ydb/library/yql/core/arrow_kernels/registry/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/arrow_kernels/registry/ut/CMakeLists.darwin-x86_64.txt @@ -24,7 +24,7 @@ target_link_libraries(ydb-library-yql-core-arrow_kernels-registry-ut PUBLIC yql-public-udf udf-service-exception_policy yql-sql-pg_dummy - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 url_udf json2_udf ) @@ -32,8 +32,6 @@ target_link_options(ydb-library-yql-core-arrow_kernels-registry-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-core-arrow_kernels-registry-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/arrow_kernels/registry/ut/registry_ut.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/arrow_kernels/registry/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/arrow_kernels/registry/ut/CMakeLists.linux-aarch64.txt index 1fb958c08e5d..482cb40c9fd9 100644 --- a/ydb/library/yql/core/arrow_kernels/registry/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/arrow_kernels/registry/ut/CMakeLists.linux-aarch64.txt @@ -24,7 +24,7 @@ target_link_libraries(ydb-library-yql-core-arrow_kernels-registry-ut PUBLIC yql-public-udf udf-service-exception_policy yql-sql-pg_dummy - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 url_udf json2_udf ) @@ -34,9 +34,6 @@ target_link_options(ydb-library-yql-core-arrow_kernels-registry-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-core-arrow_kernels-registry-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/arrow_kernels/registry/ut/registry_ut.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/arrow_kernels/registry/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/arrow_kernels/registry/ut/CMakeLists.linux-x86_64.txt index ed330312b4eb..f095babadaed 100644 --- a/ydb/library/yql/core/arrow_kernels/registry/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/arrow_kernels/registry/ut/CMakeLists.linux-x86_64.txt @@ -25,7 +25,7 @@ target_link_libraries(ydb-library-yql-core-arrow_kernels-registry-ut PUBLIC yql-public-udf udf-service-exception_policy yql-sql-pg_dummy - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 url_udf json2_udf ) @@ -35,9 +35,6 @@ target_link_options(ydb-library-yql-core-arrow_kernels-registry-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-core-arrow_kernels-registry-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/arrow_kernels/registry/ut/registry_ut.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/arrow_kernels/registry/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/arrow_kernels/registry/ut/CMakeLists.windows-x86_64.txt index 07f9af31ae66..2a3099e3cae1 100644 --- a/ydb/library/yql/core/arrow_kernels/registry/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/arrow_kernels/registry/ut/CMakeLists.windows-x86_64.txt @@ -24,7 +24,7 @@ target_link_libraries(ydb-library-yql-core-arrow_kernels-registry-ut PUBLIC yql-public-udf udf-service-exception_policy yql-sql-pg_dummy - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 url_udf json2_udf ) @@ -56,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/cbo/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/cbo/CMakeLists.darwin-arm64.txt index a06e4ec3c652..3c3b5585055f 100644 --- a/ydb/library/yql/core/cbo/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/cbo/CMakeLists.darwin-arm64.txt @@ -16,4 +16,5 @@ target_link_libraries(yql-core-cbo PUBLIC ) target_sources(yql-core-cbo PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/cbo/cbo_optimizer.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/cbo/cbo_optimizer_new.cpp ) diff --git a/ydb/library/yql/core/cbo/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/cbo/CMakeLists.darwin-x86_64.txt index a06e4ec3c652..3c3b5585055f 100644 --- a/ydb/library/yql/core/cbo/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/cbo/CMakeLists.darwin-x86_64.txt @@ -16,4 +16,5 @@ target_link_libraries(yql-core-cbo PUBLIC ) target_sources(yql-core-cbo PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/cbo/cbo_optimizer.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/cbo/cbo_optimizer_new.cpp ) diff --git a/ydb/library/yql/core/cbo/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/cbo/CMakeLists.linux-aarch64.txt index c90606d74fbe..87ec80238957 100644 --- a/ydb/library/yql/core/cbo/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/cbo/CMakeLists.linux-aarch64.txt @@ -17,4 +17,5 @@ target_link_libraries(yql-core-cbo PUBLIC ) target_sources(yql-core-cbo PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/cbo/cbo_optimizer.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/cbo/cbo_optimizer_new.cpp ) diff --git a/ydb/library/yql/core/cbo/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/cbo/CMakeLists.linux-x86_64.txt index c90606d74fbe..87ec80238957 100644 --- a/ydb/library/yql/core/cbo/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/cbo/CMakeLists.linux-x86_64.txt @@ -17,4 +17,5 @@ target_link_libraries(yql-core-cbo PUBLIC ) target_sources(yql-core-cbo PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/cbo/cbo_optimizer.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/cbo/cbo_optimizer_new.cpp ) diff --git a/ydb/library/yql/core/cbo/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/cbo/CMakeLists.windows-x86_64.txt index a06e4ec3c652..3c3b5585055f 100644 --- a/ydb/library/yql/core/cbo/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/cbo/CMakeLists.windows-x86_64.txt @@ -16,4 +16,5 @@ target_link_libraries(yql-core-cbo PUBLIC ) target_sources(yql-core-cbo PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/cbo/cbo_optimizer.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/cbo/cbo_optimizer_new.cpp ) diff --git a/ydb/library/yql/core/cbo/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/cbo/ut/CMakeLists.darwin-arm64.txt index c693089ecfec..bbf0b63df279 100644 --- a/ydb/library/yql/core/cbo/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/cbo/ut/CMakeLists.darwin-arm64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/cbo/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/cbo/ut/CMakeLists.darwin-x86_64.txt index cb1a714c04d9..a90b8daae1f3 100644 --- a/ydb/library/yql/core/cbo/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/cbo/ut/CMakeLists.darwin-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/cbo/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/cbo/ut/CMakeLists.linux-aarch64.txt index da291f0a8c88..466bd585890f 100644 --- a/ydb/library/yql/core/cbo/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/cbo/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-yql-core-cbo-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-core-cbo-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/cbo/cbo_optimizer_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/cbo/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/cbo/ut/CMakeLists.linux-x86_64.txt index 6e505912d7f5..6abe6333d584 100644 --- a/ydb/library/yql/core/cbo/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/cbo/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-yql-core-cbo-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-core-cbo-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/cbo/cbo_optimizer_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/cbo/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/cbo/ut/CMakeLists.windows-x86_64.txt index 58b272fdf68c..1b175b9ac971 100644 --- a/ydb/library/yql/core/cbo/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/cbo/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/common_opt/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/common_opt/CMakeLists.darwin-arm64.txt index bc3eca545a3d..94ec2ebdbb51 100644 --- a/ydb/library/yql/core/common_opt/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/common_opt/CMakeLists.darwin-arm64.txt @@ -19,6 +19,9 @@ target_link_libraries(yql-core-common_opt PUBLIC yql-parser-pg_catalog ) target_sources(yql-core-common_opt PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co_pgselect.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co_transformer.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co_extr_members.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_flatmap_over_join.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co_finalizers.cpp diff --git a/ydb/library/yql/core/common_opt/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/common_opt/CMakeLists.darwin-x86_64.txt index bc3eca545a3d..94ec2ebdbb51 100644 --- a/ydb/library/yql/core/common_opt/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/common_opt/CMakeLists.darwin-x86_64.txt @@ -19,6 +19,9 @@ target_link_libraries(yql-core-common_opt PUBLIC yql-parser-pg_catalog ) target_sources(yql-core-common_opt PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co_pgselect.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co_transformer.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co_extr_members.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_flatmap_over_join.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co_finalizers.cpp diff --git a/ydb/library/yql/core/common_opt/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/common_opt/CMakeLists.linux-aarch64.txt index 35d9e8b6f7e0..bb75a6e3a5e8 100644 --- a/ydb/library/yql/core/common_opt/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/common_opt/CMakeLists.linux-aarch64.txt @@ -20,6 +20,9 @@ target_link_libraries(yql-core-common_opt PUBLIC yql-parser-pg_catalog ) target_sources(yql-core-common_opt PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co_pgselect.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co_transformer.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co_extr_members.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_flatmap_over_join.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co_finalizers.cpp diff --git a/ydb/library/yql/core/common_opt/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/common_opt/CMakeLists.linux-x86_64.txt index 35d9e8b6f7e0..bb75a6e3a5e8 100644 --- a/ydb/library/yql/core/common_opt/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/common_opt/CMakeLists.linux-x86_64.txt @@ -20,6 +20,9 @@ target_link_libraries(yql-core-common_opt PUBLIC yql-parser-pg_catalog ) target_sources(yql-core-common_opt PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co_pgselect.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co_transformer.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co_extr_members.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_flatmap_over_join.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co_finalizers.cpp diff --git a/ydb/library/yql/core/common_opt/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/common_opt/CMakeLists.windows-x86_64.txt index bc3eca545a3d..94ec2ebdbb51 100644 --- a/ydb/library/yql/core/common_opt/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/common_opt/CMakeLists.windows-x86_64.txt @@ -19,6 +19,9 @@ target_link_libraries(yql-core-common_opt PUBLIC yql-parser-pg_catalog ) target_sources(yql-core-common_opt PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co_pgselect.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co_transformer.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co_extr_members.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_flatmap_over_join.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/common_opt/yql_co_finalizers.cpp diff --git a/ydb/library/yql/core/expr_nodes/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/expr_nodes/CMakeLists.darwin-arm64.txt index 43e5158e7913..2cd1907421b3 100644 --- a/ydb/library/yql/core/expr_nodes/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/expr_nodes/CMakeLists.darwin-arm64.txt @@ -17,6 +17,10 @@ target_link_libraries(yql-core-expr_nodes PUBLIC yql-core-issue ) target_sources(yql-core-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/core/expr_nodes/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/expr_nodes/CMakeLists.darwin-x86_64.txt index 43e5158e7913..2cd1907421b3 100644 --- a/ydb/library/yql/core/expr_nodes/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/expr_nodes/CMakeLists.darwin-x86_64.txt @@ -17,6 +17,10 @@ target_link_libraries(yql-core-expr_nodes PUBLIC yql-core-issue ) target_sources(yql-core-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/core/expr_nodes/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/expr_nodes/CMakeLists.linux-aarch64.txt index 5838e737ef49..52a2ff797a29 100644 --- a/ydb/library/yql/core/expr_nodes/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/expr_nodes/CMakeLists.linux-aarch64.txt @@ -18,6 +18,10 @@ target_link_libraries(yql-core-expr_nodes PUBLIC yql-core-issue ) target_sources(yql-core-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/core/expr_nodes/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/expr_nodes/CMakeLists.linux-x86_64.txt index 5838e737ef49..52a2ff797a29 100644 --- a/ydb/library/yql/core/expr_nodes/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/expr_nodes/CMakeLists.linux-x86_64.txt @@ -18,6 +18,10 @@ target_link_libraries(yql-core-expr_nodes PUBLIC yql-core-issue ) target_sources(yql-core-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/core/expr_nodes/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/expr_nodes/CMakeLists.windows-x86_64.txt index 43e5158e7913..2cd1907421b3 100644 --- a/ydb/library/yql/core/expr_nodes/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/expr_nodes/CMakeLists.windows-x86_64.txt @@ -17,6 +17,10 @@ target_link_libraries(yql-core-expr_nodes PUBLIC yql-core-issue ) target_sources(yql-core-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/core/expr_nodes/yql_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/core/expr_nodes_gen/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/expr_nodes_gen/CMakeLists.darwin-arm64.txt index cc364257b135..74876630826f 100644 --- a/ydb/library/yql/core/expr_nodes_gen/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/expr_nodes_gen/CMakeLists.darwin-arm64.txt @@ -15,5 +15,6 @@ target_link_libraries(yql-core-expr_nodes_gen PUBLIC yql-public-udf ) target_sources(yql-core-expr_nodes_gen PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/expr_nodes_gen/yql_expr_nodes_gen.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/expr_nodes_gen/yql_expr_nodes_gen.cpp ) diff --git a/ydb/library/yql/core/expr_nodes_gen/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/expr_nodes_gen/CMakeLists.darwin-x86_64.txt index cc364257b135..74876630826f 100644 --- a/ydb/library/yql/core/expr_nodes_gen/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/expr_nodes_gen/CMakeLists.darwin-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(yql-core-expr_nodes_gen PUBLIC yql-public-udf ) target_sources(yql-core-expr_nodes_gen PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/expr_nodes_gen/yql_expr_nodes_gen.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/expr_nodes_gen/yql_expr_nodes_gen.cpp ) diff --git a/ydb/library/yql/core/expr_nodes_gen/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/expr_nodes_gen/CMakeLists.linux-aarch64.txt index cdbd4f403dae..86373eaaff9a 100644 --- a/ydb/library/yql/core/expr_nodes_gen/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/expr_nodes_gen/CMakeLists.linux-aarch64.txt @@ -16,5 +16,6 @@ target_link_libraries(yql-core-expr_nodes_gen PUBLIC yql-public-udf ) target_sources(yql-core-expr_nodes_gen PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/expr_nodes_gen/yql_expr_nodes_gen.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/expr_nodes_gen/yql_expr_nodes_gen.cpp ) diff --git a/ydb/library/yql/core/expr_nodes_gen/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/expr_nodes_gen/CMakeLists.linux-x86_64.txt index cdbd4f403dae..86373eaaff9a 100644 --- a/ydb/library/yql/core/expr_nodes_gen/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/expr_nodes_gen/CMakeLists.linux-x86_64.txt @@ -16,5 +16,6 @@ target_link_libraries(yql-core-expr_nodes_gen PUBLIC yql-public-udf ) target_sources(yql-core-expr_nodes_gen PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/expr_nodes_gen/yql_expr_nodes_gen.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/expr_nodes_gen/yql_expr_nodes_gen.cpp ) diff --git a/ydb/library/yql/core/expr_nodes_gen/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/expr_nodes_gen/CMakeLists.windows-x86_64.txt index cc364257b135..74876630826f 100644 --- a/ydb/library/yql/core/expr_nodes_gen/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/expr_nodes_gen/CMakeLists.windows-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(yql-core-expr_nodes_gen PUBLIC yql-public-udf ) target_sources(yql-core-expr_nodes_gen PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/expr_nodes_gen/yql_expr_nodes_gen.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/expr_nodes_gen/yql_expr_nodes_gen.cpp ) diff --git a/ydb/library/yql/core/extract_predicate/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/extract_predicate/CMakeLists.darwin-arm64.txt index fac989d417e2..ac57a79223b1 100644 --- a/ydb/library/yql/core/extract_predicate/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/extract_predicate/CMakeLists.darwin-arm64.txt @@ -16,8 +16,12 @@ target_link_libraries(yql-core-extract_predicate PUBLIC contrib-libs-cxxsupp yutil yql-core-services + yql-core-type_ann ) target_sources(yql-core-extract_predicate PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate_dbg.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate_dbg.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate_impl.cpp ) diff --git a/ydb/library/yql/core/extract_predicate/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/extract_predicate/CMakeLists.darwin-x86_64.txt index fac989d417e2..ac57a79223b1 100644 --- a/ydb/library/yql/core/extract_predicate/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/extract_predicate/CMakeLists.darwin-x86_64.txt @@ -16,8 +16,12 @@ target_link_libraries(yql-core-extract_predicate PUBLIC contrib-libs-cxxsupp yutil yql-core-services + yql-core-type_ann ) target_sources(yql-core-extract_predicate PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate_dbg.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate_dbg.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate_impl.cpp ) diff --git a/ydb/library/yql/core/extract_predicate/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/extract_predicate/CMakeLists.linux-aarch64.txt index cd26b7920e8e..ec164e9ef2eb 100644 --- a/ydb/library/yql/core/extract_predicate/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/extract_predicate/CMakeLists.linux-aarch64.txt @@ -17,8 +17,12 @@ target_link_libraries(yql-core-extract_predicate PUBLIC contrib-libs-cxxsupp yutil yql-core-services + yql-core-type_ann ) target_sources(yql-core-extract_predicate PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate_dbg.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate_dbg.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate_impl.cpp ) diff --git a/ydb/library/yql/core/extract_predicate/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/extract_predicate/CMakeLists.linux-x86_64.txt index cd26b7920e8e..ec164e9ef2eb 100644 --- a/ydb/library/yql/core/extract_predicate/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/extract_predicate/CMakeLists.linux-x86_64.txt @@ -17,8 +17,12 @@ target_link_libraries(yql-core-extract_predicate PUBLIC contrib-libs-cxxsupp yutil yql-core-services + yql-core-type_ann ) target_sources(yql-core-extract_predicate PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate_dbg.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate_dbg.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate_impl.cpp ) diff --git a/ydb/library/yql/core/extract_predicate/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/extract_predicate/CMakeLists.windows-x86_64.txt index fac989d417e2..ac57a79223b1 100644 --- a/ydb/library/yql/core/extract_predicate/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/extract_predicate/CMakeLists.windows-x86_64.txt @@ -16,8 +16,12 @@ target_link_libraries(yql-core-extract_predicate PUBLIC contrib-libs-cxxsupp yutil yql-core-services + yql-core-type_ann ) target_sources(yql-core-extract_predicate PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate_dbg.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate_dbg.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/extract_predicate_impl.cpp ) diff --git a/ydb/library/yql/core/extract_predicate/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/extract_predicate/ut/CMakeLists.darwin-arm64.txt index 50899006884a..31066a3229c3 100644 --- a/ydb/library/yql/core/extract_predicate/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/extract_predicate/ut/CMakeLists.darwin-arm64.txt @@ -32,14 +32,16 @@ target_link_libraries(ydb-library-yql-core-extract_predicate-ut PUBLIC providers-result-provider yt-gateway-file providers-yt-provider + yt-codec-codegen + yt-comp_nodes-llvm14 + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 yql-sql-pg ) target_link_options(ydb-library-yql-core-extract_predicate-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-core-extract_predicate-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/ut/extract_predicate_ut.cpp @@ -69,6 +71,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/extract_predicate/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/extract_predicate/ut/CMakeLists.darwin-x86_64.txt index cc3c69e8589d..f1937fd53d0a 100644 --- a/ydb/library/yql/core/extract_predicate/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/extract_predicate/ut/CMakeLists.darwin-x86_64.txt @@ -33,14 +33,16 @@ target_link_libraries(ydb-library-yql-core-extract_predicate-ut PUBLIC providers-result-provider yt-gateway-file providers-yt-provider + yt-codec-codegen + yt-comp_nodes-llvm14 + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 yql-sql-pg ) target_link_options(ydb-library-yql-core-extract_predicate-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-core-extract_predicate-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/ut/extract_predicate_ut.cpp @@ -70,6 +72,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/extract_predicate/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/extract_predicate/ut/CMakeLists.linux-aarch64.txt index 2833634a93be..0fd17e460b39 100644 --- a/ydb/library/yql/core/extract_predicate/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/extract_predicate/ut/CMakeLists.linux-aarch64.txt @@ -33,6 +33,10 @@ target_link_libraries(ydb-library-yql-core-extract_predicate-ut PUBLIC providers-result-provider yt-gateway-file providers-yt-provider + yt-codec-codegen + yt-comp_nodes-llvm14 + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 yql-sql-pg ) target_link_options(ydb-library-yql-core-extract_predicate-ut PRIVATE @@ -41,10 +45,6 @@ target_link_options(ydb-library-yql-core-extract_predicate-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(ydb-library-yql-core-extract_predicate-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/ut/extract_predicate_ut.cpp @@ -74,6 +74,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/extract_predicate/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/extract_predicate/ut/CMakeLists.linux-x86_64.txt index 2692d358a445..4a3c4483c0cf 100644 --- a/ydb/library/yql/core/extract_predicate/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/extract_predicate/ut/CMakeLists.linux-x86_64.txt @@ -34,6 +34,10 @@ target_link_libraries(ydb-library-yql-core-extract_predicate-ut PUBLIC providers-result-provider yt-gateway-file providers-yt-provider + yt-codec-codegen + yt-comp_nodes-llvm14 + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 yql-sql-pg ) target_link_options(ydb-library-yql-core-extract_predicate-ut PRIVATE @@ -42,10 +46,6 @@ target_link_options(ydb-library-yql-core-extract_predicate-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(ydb-library-yql-core-extract_predicate-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/extract_predicate/ut/extract_predicate_ut.cpp @@ -75,6 +75,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/extract_predicate/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/extract_predicate/ut/CMakeLists.windows-x86_64.txt index 5f4c8e6a53c0..8d30783b0ec5 100644 --- a/ydb/library/yql/core/extract_predicate/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/extract_predicate/ut/CMakeLists.windows-x86_64.txt @@ -33,6 +33,10 @@ target_link_libraries(ydb-library-yql-core-extract_predicate-ut PUBLIC providers-result-provider yt-gateway-file providers-yt-provider + yt-codec-codegen + yt-comp_nodes-llvm14 + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 yql-sql-pg ) target_sources(ydb-library-yql-core-extract_predicate-ut PRIVATE @@ -63,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/file_storage/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/file_storage/CMakeLists.darwin-arm64.txt index 574c5b1c75ed..884086dcb778 100644 --- a/ydb/library/yql/core/file_storage/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/file_storage/CMakeLists.darwin-arm64.txt @@ -31,6 +31,10 @@ target_link_libraries(yql-core-file_storage PUBLIC yql-utils-fetch ) target_sources(yql-core-file_storage PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/file_storage.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/sized_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/storage.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/url_meta.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/file_storage_decorator.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/file_storage.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/sized_cache.cpp diff --git a/ydb/library/yql/core/file_storage/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/file_storage/CMakeLists.darwin-x86_64.txt index 574c5b1c75ed..884086dcb778 100644 --- a/ydb/library/yql/core/file_storage/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/file_storage/CMakeLists.darwin-x86_64.txt @@ -31,6 +31,10 @@ target_link_libraries(yql-core-file_storage PUBLIC yql-utils-fetch ) target_sources(yql-core-file_storage PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/file_storage.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/sized_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/storage.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/url_meta.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/file_storage_decorator.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/file_storage.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/sized_cache.cpp diff --git a/ydb/library/yql/core/file_storage/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/file_storage/CMakeLists.linux-aarch64.txt index 479f52e981d5..77a85e938ba7 100644 --- a/ydb/library/yql/core/file_storage/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/file_storage/CMakeLists.linux-aarch64.txt @@ -32,6 +32,10 @@ target_link_libraries(yql-core-file_storage PUBLIC yql-utils-fetch ) target_sources(yql-core-file_storage PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/file_storage.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/sized_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/storage.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/url_meta.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/file_storage_decorator.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/file_storage.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/sized_cache.cpp diff --git a/ydb/library/yql/core/file_storage/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/file_storage/CMakeLists.linux-x86_64.txt index 479f52e981d5..77a85e938ba7 100644 --- a/ydb/library/yql/core/file_storage/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/file_storage/CMakeLists.linux-x86_64.txt @@ -32,6 +32,10 @@ target_link_libraries(yql-core-file_storage PUBLIC yql-utils-fetch ) target_sources(yql-core-file_storage PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/file_storage.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/sized_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/storage.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/url_meta.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/file_storage_decorator.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/file_storage.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/sized_cache.cpp diff --git a/ydb/library/yql/core/file_storage/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/file_storage/CMakeLists.windows-x86_64.txt index 574c5b1c75ed..884086dcb778 100644 --- a/ydb/library/yql/core/file_storage/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/file_storage/CMakeLists.windows-x86_64.txt @@ -31,6 +31,10 @@ target_link_libraries(yql-core-file_storage PUBLIC yql-utils-fetch ) target_sources(yql-core-file_storage PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/file_storage.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/sized_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/storage.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/url_meta.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/file_storage_decorator.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/file_storage.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/sized_cache.cpp diff --git a/ydb/library/yql/core/file_storage/http_download/proto/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/file_storage/http_download/proto/CMakeLists.darwin-arm64.txt index a162bb7e14c7..3b01134758ef 100644 --- a/ydb/library/yql/core/file_storage/http_download/proto/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/file_storage/http_download/proto/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(file_storage-http_download-proto PUBLIC target_proto_messages(file_storage-http_download-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/http_download/proto/http_download.proto ) +target_sources(file_storage-http_download-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/file_storage/http_download/proto/http_download.pb.h +) target_proto_addincls(file_storage-http_download-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/core/file_storage/http_download/proto/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/file_storage/http_download/proto/CMakeLists.darwin-x86_64.txt index a162bb7e14c7..3b01134758ef 100644 --- a/ydb/library/yql/core/file_storage/http_download/proto/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/file_storage/http_download/proto/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(file_storage-http_download-proto PUBLIC target_proto_messages(file_storage-http_download-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/http_download/proto/http_download.proto ) +target_sources(file_storage-http_download-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/file_storage/http_download/proto/http_download.pb.h +) target_proto_addincls(file_storage-http_download-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/core/file_storage/http_download/proto/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/file_storage/http_download/proto/CMakeLists.linux-aarch64.txt index bc86b2fc123e..facc9a23dd29 100644 --- a/ydb/library/yql/core/file_storage/http_download/proto/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/file_storage/http_download/proto/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(file_storage-http_download-proto PUBLIC target_proto_messages(file_storage-http_download-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/http_download/proto/http_download.proto ) +target_sources(file_storage-http_download-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/file_storage/http_download/proto/http_download.pb.h +) target_proto_addincls(file_storage-http_download-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/core/file_storage/http_download/proto/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/file_storage/http_download/proto/CMakeLists.linux-x86_64.txt index bc86b2fc123e..facc9a23dd29 100644 --- a/ydb/library/yql/core/file_storage/http_download/proto/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/file_storage/http_download/proto/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(file_storage-http_download-proto PUBLIC target_proto_messages(file_storage-http_download-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/http_download/proto/http_download.proto ) +target_sources(file_storage-http_download-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/file_storage/http_download/proto/http_download.pb.h +) target_proto_addincls(file_storage-http_download-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/core/file_storage/http_download/proto/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/file_storage/http_download/proto/CMakeLists.windows-x86_64.txt index a162bb7e14c7..3b01134758ef 100644 --- a/ydb/library/yql/core/file_storage/http_download/proto/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/file_storage/http_download/proto/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(file_storage-http_download-proto PUBLIC target_proto_messages(file_storage-http_download-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/http_download/proto/http_download.proto ) +target_sources(file_storage-http_download-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/file_storage/http_download/proto/http_download.pb.h +) target_proto_addincls(file_storage-http_download-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/core/file_storage/proto/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/file_storage/proto/CMakeLists.darwin-arm64.txt index 2f9785282f06..55fdc4cecdd5 100644 --- a/ydb/library/yql/core/file_storage/proto/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/file_storage/proto/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(core-file_storage-proto PUBLIC target_proto_messages(core-file_storage-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/proto/file_storage.proto ) +target_sources(core-file_storage-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/file_storage/proto/file_storage.pb.h +) target_proto_addincls(core-file_storage-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/core/file_storage/proto/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/file_storage/proto/CMakeLists.darwin-x86_64.txt index 2f9785282f06..55fdc4cecdd5 100644 --- a/ydb/library/yql/core/file_storage/proto/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/file_storage/proto/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(core-file_storage-proto PUBLIC target_proto_messages(core-file_storage-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/proto/file_storage.proto ) +target_sources(core-file_storage-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/file_storage/proto/file_storage.pb.h +) target_proto_addincls(core-file_storage-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/core/file_storage/proto/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/file_storage/proto/CMakeLists.linux-aarch64.txt index b93e2f129a5f..1e420642b495 100644 --- a/ydb/library/yql/core/file_storage/proto/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/file_storage/proto/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(core-file_storage-proto PUBLIC target_proto_messages(core-file_storage-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/proto/file_storage.proto ) +target_sources(core-file_storage-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/file_storage/proto/file_storage.pb.h +) target_proto_addincls(core-file_storage-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/core/file_storage/proto/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/file_storage/proto/CMakeLists.linux-x86_64.txt index b93e2f129a5f..1e420642b495 100644 --- a/ydb/library/yql/core/file_storage/proto/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/file_storage/proto/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(core-file_storage-proto PUBLIC target_proto_messages(core-file_storage-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/proto/file_storage.proto ) +target_sources(core-file_storage-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/file_storage/proto/file_storage.pb.h +) target_proto_addincls(core-file_storage-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/core/file_storage/proto/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/file_storage/proto/CMakeLists.windows-x86_64.txt index 2f9785282f06..55fdc4cecdd5 100644 --- a/ydb/library/yql/core/file_storage/proto/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/file_storage/proto/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(core-file_storage-proto PUBLIC target_proto_messages(core-file_storage-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/proto/file_storage.proto ) +target_sources(core-file_storage-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/file_storage/proto/file_storage.pb.h +) target_proto_addincls(core-file_storage-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/core/file_storage/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/file_storage/ut/CMakeLists.darwin-arm64.txt index 841ea954e0ad..dc5ef69af419 100644 --- a/ydb/library/yql/core/file_storage/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/file_storage/ut/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-library-yql-core-file_storage-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-core-file_storage-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/file_storage_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/file_storage/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/file_storage/ut/CMakeLists.darwin-x86_64.txt index d059e1301cfa..aafac6a701e4 100644 --- a/ydb/library/yql/core/file_storage/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/file_storage/ut/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-library-yql-core-file_storage-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-core-file_storage-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/file_storage_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/file_storage/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/file_storage/ut/CMakeLists.linux-aarch64.txt index 3f6887b081d9..ce8e3d47e6d4 100644 --- a/ydb/library/yql/core/file_storage/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/file_storage/ut/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-library-yql-core-file_storage-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-core-file_storage-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/file_storage_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/file_storage/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/file_storage/ut/CMakeLists.linux-x86_64.txt index 52e9877be018..96aa7d66803f 100644 --- a/ydb/library/yql/core/file_storage/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/file_storage/ut/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-library-yql-core-file_storage-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-core-file_storage-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/file_storage/file_storage_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/file_storage/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/file_storage/ut/CMakeLists.windows-x86_64.txt index b3da167e1c2c..8307421400fe 100644 --- a/ydb/library/yql/core/file_storage/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/file_storage/ut/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/issue/protos/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/issue/protos/CMakeLists.darwin-arm64.txt index 1cc572225f45..ba9974219624 100644 --- a/ydb/library/yql/core/issue/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/issue/protos/CMakeLists.darwin-arm64.txt @@ -29,6 +29,9 @@ target_link_libraries(core-issue-protos PUBLIC target_proto_messages(core-issue-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/issue/protos/issue_id.proto ) +target_sources(core-issue-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/issue/protos/issue_id.pb.h +) target_proto_addincls(core-issue-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/core/issue/protos/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/issue/protos/CMakeLists.darwin-x86_64.txt index 1cc572225f45..ba9974219624 100644 --- a/ydb/library/yql/core/issue/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/issue/protos/CMakeLists.darwin-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(core-issue-protos PUBLIC target_proto_messages(core-issue-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/issue/protos/issue_id.proto ) +target_sources(core-issue-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/issue/protos/issue_id.pb.h +) target_proto_addincls(core-issue-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/core/issue/protos/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/issue/protos/CMakeLists.linux-aarch64.txt index 77f8a56e52df..b9593e586356 100644 --- a/ydb/library/yql/core/issue/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/issue/protos/CMakeLists.linux-aarch64.txt @@ -30,6 +30,9 @@ target_link_libraries(core-issue-protos PUBLIC target_proto_messages(core-issue-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/issue/protos/issue_id.proto ) +target_sources(core-issue-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/issue/protos/issue_id.pb.h +) target_proto_addincls(core-issue-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/core/issue/protos/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/issue/protos/CMakeLists.linux-x86_64.txt index 77f8a56e52df..b9593e586356 100644 --- a/ydb/library/yql/core/issue/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/issue/protos/CMakeLists.linux-x86_64.txt @@ -30,6 +30,9 @@ target_link_libraries(core-issue-protos PUBLIC target_proto_messages(core-issue-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/issue/protos/issue_id.proto ) +target_sources(core-issue-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/issue/protos/issue_id.pb.h +) target_proto_addincls(core-issue-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/core/issue/protos/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/issue/protos/CMakeLists.windows-x86_64.txt index 1cc572225f45..ba9974219624 100644 --- a/ydb/library/yql/core/issue/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/issue/protos/CMakeLists.windows-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(core-issue-protos PUBLIC target_proto_messages(core-issue-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/issue/protos/issue_id.proto ) +target_sources(core-issue-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/core/issue/protos/issue_id.pb.h +) target_proto_addincls(core-issue-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/core/issue/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/issue/ut/CMakeLists.darwin-arm64.txt index 69d0a2b9e4b0..fe5312676e95 100644 --- a/ydb/library/yql/core/issue/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/issue/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-library-yql-core-issue-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-core-issue-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/issue/yql_issue_ut.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/issue/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/issue/ut/CMakeLists.darwin-x86_64.txt index 7a53efee2b2e..22e48d5fe5bf 100644 --- a/ydb/library/yql/core/issue/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/issue/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-library-yql-core-issue-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-core-issue-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/issue/yql_issue_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/issue/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/issue/ut/CMakeLists.linux-aarch64.txt index 1f2d4a182e63..1f0be0cfad28 100644 --- a/ydb/library/yql/core/issue/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/issue/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-yql-core-issue-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-core-issue-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/issue/yql_issue_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/issue/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/issue/ut/CMakeLists.linux-x86_64.txt index 2f7f1d1c96e3..d15494fe9aed 100644 --- a/ydb/library/yql/core/issue/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/issue/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-yql-core-issue-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-core-issue-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/issue/yql_issue_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/issue/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/issue/ut/CMakeLists.windows-x86_64.txt index bc433fad6d20..dee7e469c53b 100644 --- a/ydb/library/yql/core/issue/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/issue/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/peephole_opt/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/peephole_opt/CMakeLists.darwin-arm64.txt index 294ed16d9b6f..999b43c5f021 100644 --- a/ydb/library/yql/core/peephole_opt/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/peephole_opt/CMakeLists.darwin-arm64.txt @@ -19,6 +19,8 @@ target_link_libraries(yql-core-peephole_opt PUBLIC yql-core-type_ann ) target_sources(yql-core-peephole_opt PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/peephole_opt/yql_opt_json_peephole_physical.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/peephole_opt/yql_opt_peephole_physical.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/peephole_opt/yql_opt_json_peephole_physical.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/peephole_opt/yql_opt_peephole_physical.cpp ) diff --git a/ydb/library/yql/core/peephole_opt/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/peephole_opt/CMakeLists.darwin-x86_64.txt index 294ed16d9b6f..999b43c5f021 100644 --- a/ydb/library/yql/core/peephole_opt/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/peephole_opt/CMakeLists.darwin-x86_64.txt @@ -19,6 +19,8 @@ target_link_libraries(yql-core-peephole_opt PUBLIC yql-core-type_ann ) target_sources(yql-core-peephole_opt PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/peephole_opt/yql_opt_json_peephole_physical.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/peephole_opt/yql_opt_peephole_physical.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/peephole_opt/yql_opt_json_peephole_physical.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/peephole_opt/yql_opt_peephole_physical.cpp ) diff --git a/ydb/library/yql/core/peephole_opt/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/peephole_opt/CMakeLists.linux-aarch64.txt index 36a6bbe0897b..f5e2726fec8c 100644 --- a/ydb/library/yql/core/peephole_opt/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/peephole_opt/CMakeLists.linux-aarch64.txt @@ -20,6 +20,8 @@ target_link_libraries(yql-core-peephole_opt PUBLIC yql-core-type_ann ) target_sources(yql-core-peephole_opt PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/peephole_opt/yql_opt_json_peephole_physical.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/peephole_opt/yql_opt_peephole_physical.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/peephole_opt/yql_opt_json_peephole_physical.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/peephole_opt/yql_opt_peephole_physical.cpp ) diff --git a/ydb/library/yql/core/peephole_opt/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/peephole_opt/CMakeLists.linux-x86_64.txt index 36a6bbe0897b..f5e2726fec8c 100644 --- a/ydb/library/yql/core/peephole_opt/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/peephole_opt/CMakeLists.linux-x86_64.txt @@ -20,6 +20,8 @@ target_link_libraries(yql-core-peephole_opt PUBLIC yql-core-type_ann ) target_sources(yql-core-peephole_opt PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/peephole_opt/yql_opt_json_peephole_physical.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/peephole_opt/yql_opt_peephole_physical.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/peephole_opt/yql_opt_json_peephole_physical.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/peephole_opt/yql_opt_peephole_physical.cpp ) diff --git a/ydb/library/yql/core/peephole_opt/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/peephole_opt/CMakeLists.windows-x86_64.txt index 294ed16d9b6f..999b43c5f021 100644 --- a/ydb/library/yql/core/peephole_opt/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/peephole_opt/CMakeLists.windows-x86_64.txt @@ -19,6 +19,8 @@ target_link_libraries(yql-core-peephole_opt PUBLIC yql-core-type_ann ) target_sources(yql-core-peephole_opt PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/peephole_opt/yql_opt_json_peephole_physical.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/peephole_opt/yql_opt_peephole_physical.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/peephole_opt/yql_opt_json_peephole_physical.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/peephole_opt/yql_opt_peephole_physical.cpp ) diff --git a/ydb/library/yql/core/pg_settings/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/pg_settings/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..a09e8279c47a --- /dev/null +++ b/ydb/library/yql/core/pg_settings/CMakeLists.darwin-arm64.txt @@ -0,0 +1,17 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yql-core-pg_settings) +target_link_libraries(yql-core-pg_settings PUBLIC + contrib-libs-cxxsupp + yutil +) +target_sources(yql-core-pg_settings PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/pg_settings/guc_settings.cpp +) diff --git a/ydb/library/yql/core/pg_settings/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/pg_settings/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..a09e8279c47a --- /dev/null +++ b/ydb/library/yql/core/pg_settings/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,17 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yql-core-pg_settings) +target_link_libraries(yql-core-pg_settings PUBLIC + contrib-libs-cxxsupp + yutil +) +target_sources(yql-core-pg_settings PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/pg_settings/guc_settings.cpp +) diff --git a/ydb/library/yql/core/pg_settings/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/pg_settings/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..ca7642ae8214 --- /dev/null +++ b/ydb/library/yql/core/pg_settings/CMakeLists.linux-aarch64.txt @@ -0,0 +1,18 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yql-core-pg_settings) +target_link_libraries(yql-core-pg_settings PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil +) +target_sources(yql-core-pg_settings PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/pg_settings/guc_settings.cpp +) diff --git a/ydb/library/yql/core/pg_settings/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/pg_settings/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..ca7642ae8214 --- /dev/null +++ b/ydb/library/yql/core/pg_settings/CMakeLists.linux-x86_64.txt @@ -0,0 +1,18 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yql-core-pg_settings) +target_link_libraries(yql-core-pg_settings PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil +) +target_sources(yql-core-pg_settings PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/pg_settings/guc_settings.cpp +) diff --git a/ydb/library/yql/core/pg_settings/CMakeLists.txt b/ydb/library/yql/core/pg_settings/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/core/pg_settings/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/core/pg_settings/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/pg_settings/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..a09e8279c47a --- /dev/null +++ b/ydb/library/yql/core/pg_settings/CMakeLists.windows-x86_64.txt @@ -0,0 +1,17 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yql-core-pg_settings) +target_link_libraries(yql-core-pg_settings PUBLIC + contrib-libs-cxxsupp + yutil +) +target_sources(yql-core-pg_settings PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/pg_settings/guc_settings.cpp +) diff --git a/ydb/library/yql/core/progress_merger/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/progress_merger/CMakeLists.linux-aarch64.txt index a70e77328078..8509c8729c6b 100644 --- a/ydb/library/yql/core/progress_merger/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/progress_merger/CMakeLists.linux-aarch64.txt @@ -15,5 +15,6 @@ target_link_libraries(yql-core-progress_merger PUBLIC library-yql-core ) target_sources(yql-core-progress_merger PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/progress_merger/progress_merger.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/progress_merger/progress_merger.cpp ) diff --git a/ydb/library/yql/core/progress_merger/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/progress_merger/CMakeLists.linux-x86_64.txt index a70e77328078..8509c8729c6b 100644 --- a/ydb/library/yql/core/progress_merger/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/progress_merger/CMakeLists.linux-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(yql-core-progress_merger PUBLIC library-yql-core ) target_sources(yql-core-progress_merger PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/progress_merger/progress_merger.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/progress_merger/progress_merger.cpp ) diff --git a/ydb/library/yql/core/progress_merger/CMakeLists.txt b/ydb/library/yql/core/progress_merger/CMakeLists.txt index d863ebd18067..d6c5c0bbeb44 100644 --- a/ydb/library/yql/core/progress_merger/CMakeLists.txt +++ b/ydb/library/yql/core/progress_merger/CMakeLists.txt @@ -10,10 +10,4 @@ if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_ include(CMakeLists.linux-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) endif() diff --git a/ydb/library/yql/core/services/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/services/CMakeLists.darwin-arm64.txt index 6d3aac4b3077..1b443fd65ddb 100644 --- a/ydb/library/yql/core/services/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/services/CMakeLists.darwin-arm64.txt @@ -32,6 +32,12 @@ target_link_libraries(yql-core-services PUBLIC providers-result-expr_nodes ) target_sources(yql-core-services PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_eval_expr.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_eval_params.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_out_transformers.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_lineage.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_plan.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_transform_pipeline.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_eval_expr.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_eval_params.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_out_transformers.cpp diff --git a/ydb/library/yql/core/services/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/services/CMakeLists.darwin-x86_64.txt index 6d3aac4b3077..1b443fd65ddb 100644 --- a/ydb/library/yql/core/services/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/services/CMakeLists.darwin-x86_64.txt @@ -32,6 +32,12 @@ target_link_libraries(yql-core-services PUBLIC providers-result-expr_nodes ) target_sources(yql-core-services PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_eval_expr.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_eval_params.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_out_transformers.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_lineage.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_plan.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_transform_pipeline.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_eval_expr.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_eval_params.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_out_transformers.cpp diff --git a/ydb/library/yql/core/services/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/services/CMakeLists.linux-aarch64.txt index ea6113708ef0..d7af7db5b0d3 100644 --- a/ydb/library/yql/core/services/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/services/CMakeLists.linux-aarch64.txt @@ -33,6 +33,12 @@ target_link_libraries(yql-core-services PUBLIC providers-result-expr_nodes ) target_sources(yql-core-services PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_eval_expr.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_eval_params.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_out_transformers.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_lineage.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_plan.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_transform_pipeline.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_eval_expr.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_eval_params.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_out_transformers.cpp diff --git a/ydb/library/yql/core/services/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/services/CMakeLists.linux-x86_64.txt index ea6113708ef0..d7af7db5b0d3 100644 --- a/ydb/library/yql/core/services/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/services/CMakeLists.linux-x86_64.txt @@ -33,6 +33,12 @@ target_link_libraries(yql-core-services PUBLIC providers-result-expr_nodes ) target_sources(yql-core-services PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_eval_expr.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_eval_params.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_out_transformers.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_lineage.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_plan.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_transform_pipeline.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_eval_expr.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_eval_params.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_out_transformers.cpp diff --git a/ydb/library/yql/core/services/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/services/CMakeLists.windows-x86_64.txt index 6d3aac4b3077..1b443fd65ddb 100644 --- a/ydb/library/yql/core/services/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/services/CMakeLists.windows-x86_64.txt @@ -32,6 +32,12 @@ target_link_libraries(yql-core-services PUBLIC providers-result-expr_nodes ) target_sources(yql-core-services PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_eval_expr.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_eval_params.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_out_transformers.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_lineage.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_plan.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_transform_pipeline.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_eval_expr.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_eval_params.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/yql_out_transformers.cpp diff --git a/ydb/library/yql/core/services/mounts/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/services/mounts/CMakeLists.darwin-arm64.txt index 656e2bf4a60b..b31254321e94 100644 --- a/ydb/library/yql/core/services/mounts/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/services/mounts/CMakeLists.darwin-arm64.txt @@ -25,6 +25,7 @@ target_link_libraries(core-services-mounts PUBLIC library-yql-core ) target_sources(core-services-mounts PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/mounts/yql_mounts.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/mounts/yql_mounts.cpp ) diff --git a/ydb/library/yql/core/services/mounts/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/services/mounts/CMakeLists.darwin-x86_64.txt index 656e2bf4a60b..b31254321e94 100644 --- a/ydb/library/yql/core/services/mounts/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/services/mounts/CMakeLists.darwin-x86_64.txt @@ -25,6 +25,7 @@ target_link_libraries(core-services-mounts PUBLIC library-yql-core ) target_sources(core-services-mounts PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/mounts/yql_mounts.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/mounts/yql_mounts.cpp ) diff --git a/ydb/library/yql/core/services/mounts/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/services/mounts/CMakeLists.linux-aarch64.txt index 336f24123f03..170c6cac621e 100644 --- a/ydb/library/yql/core/services/mounts/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/services/mounts/CMakeLists.linux-aarch64.txt @@ -26,6 +26,7 @@ target_link_libraries(core-services-mounts PUBLIC library-yql-core ) target_sources(core-services-mounts PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/mounts/yql_mounts.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/mounts/yql_mounts.cpp ) diff --git a/ydb/library/yql/core/services/mounts/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/services/mounts/CMakeLists.linux-x86_64.txt index 336f24123f03..170c6cac621e 100644 --- a/ydb/library/yql/core/services/mounts/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/services/mounts/CMakeLists.linux-x86_64.txt @@ -26,6 +26,7 @@ target_link_libraries(core-services-mounts PUBLIC library-yql-core ) target_sources(core-services-mounts PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/mounts/yql_mounts.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/mounts/yql_mounts.cpp ) diff --git a/ydb/library/yql/core/services/mounts/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/services/mounts/CMakeLists.windows-x86_64.txt index 656e2bf4a60b..b31254321e94 100644 --- a/ydb/library/yql/core/services/mounts/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/services/mounts/CMakeLists.windows-x86_64.txt @@ -25,6 +25,7 @@ target_link_libraries(core-services-mounts PUBLIC library-yql-core ) target_sources(core-services-mounts PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/mounts/yql_mounts.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/services/mounts/yql_mounts.cpp ) diff --git a/ydb/library/yql/core/spilling/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/spilling/CMakeLists.darwin-arm64.txt index e222b22bb9b9..6ffeea308ef6 100644 --- a/ydb/library/yql/core/spilling/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/spilling/CMakeLists.darwin-arm64.txt @@ -22,15 +22,13 @@ target_link_libraries(yql-core-spilling PUBLIC library-yql-utils yql-utils-log core-spilling-storage - yql-minikql-codegen - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO ) target_sources(yql-core-spilling PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/spilling_imp.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/namespaces_list.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/namespace_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/interface/spilling.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/storage.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/spilling_imp.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/namespaces_list.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/namespace_cache.cpp diff --git a/ydb/library/yql/core/spilling/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/spilling/CMakeLists.darwin-x86_64.txt index e222b22bb9b9..6ffeea308ef6 100644 --- a/ydb/library/yql/core/spilling/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/spilling/CMakeLists.darwin-x86_64.txt @@ -22,15 +22,13 @@ target_link_libraries(yql-core-spilling PUBLIC library-yql-utils yql-utils-log core-spilling-storage - yql-minikql-codegen - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO ) target_sources(yql-core-spilling PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/spilling_imp.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/namespaces_list.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/namespace_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/interface/spilling.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/storage.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/spilling_imp.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/namespaces_list.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/namespace_cache.cpp diff --git a/ydb/library/yql/core/spilling/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/spilling/CMakeLists.linux-aarch64.txt index de3eadabe428..6fae6a4d1cb9 100644 --- a/ydb/library/yql/core/spilling/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/spilling/CMakeLists.linux-aarch64.txt @@ -23,15 +23,13 @@ target_link_libraries(yql-core-spilling PUBLIC library-yql-utils yql-utils-log core-spilling-storage - yql-minikql-codegen - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO ) target_sources(yql-core-spilling PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/spilling_imp.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/namespaces_list.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/namespace_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/interface/spilling.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/storage.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/spilling_imp.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/namespaces_list.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/namespace_cache.cpp diff --git a/ydb/library/yql/core/spilling/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/spilling/CMakeLists.linux-x86_64.txt index de3eadabe428..6fae6a4d1cb9 100644 --- a/ydb/library/yql/core/spilling/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/spilling/CMakeLists.linux-x86_64.txt @@ -23,15 +23,13 @@ target_link_libraries(yql-core-spilling PUBLIC library-yql-utils yql-utils-log core-spilling-storage - yql-minikql-codegen - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO ) target_sources(yql-core-spilling PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/spilling_imp.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/namespaces_list.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/namespace_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/interface/spilling.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/storage.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/spilling_imp.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/namespaces_list.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/namespace_cache.cpp diff --git a/ydb/library/yql/core/spilling/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/spilling/CMakeLists.windows-x86_64.txt index e222b22bb9b9..6ffeea308ef6 100644 --- a/ydb/library/yql/core/spilling/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/spilling/CMakeLists.windows-x86_64.txt @@ -22,15 +22,13 @@ target_link_libraries(yql-core-spilling PUBLIC library-yql-utils yql-utils-log core-spilling-storage - yql-minikql-codegen - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO ) target_sources(yql-core-spilling PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/spilling_imp.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/namespaces_list.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/namespace_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/interface/spilling.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/storage.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/spilling_imp.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/namespaces_list.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/namespace_cache.cpp diff --git a/ydb/library/yql/core/spilling/storage/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/spilling/storage/CMakeLists.darwin-arm64.txt index cd28502e3b34..2ba443623143 100644 --- a/ydb/library/yql/core/spilling/storage/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/spilling/storage/CMakeLists.darwin-arm64.txt @@ -18,14 +18,8 @@ target_link_libraries(core-spilling-storage PUBLIC contrib-libs-cxxsupp yutil spilling-storage-file_storage - yql-minikql-codegen - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO ) target_sources(core-spilling-storage PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/storage.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/storage.cpp ) diff --git a/ydb/library/yql/core/spilling/storage/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/spilling/storage/CMakeLists.darwin-x86_64.txt index cd28502e3b34..2ba443623143 100644 --- a/ydb/library/yql/core/spilling/storage/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/spilling/storage/CMakeLists.darwin-x86_64.txt @@ -18,14 +18,8 @@ target_link_libraries(core-spilling-storage PUBLIC contrib-libs-cxxsupp yutil spilling-storage-file_storage - yql-minikql-codegen - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO ) target_sources(core-spilling-storage PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/storage.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/storage.cpp ) diff --git a/ydb/library/yql/core/spilling/storage/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/spilling/storage/CMakeLists.linux-aarch64.txt index 4150b7499b73..23d52c9c37c9 100644 --- a/ydb/library/yql/core/spilling/storage/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/spilling/storage/CMakeLists.linux-aarch64.txt @@ -19,14 +19,8 @@ target_link_libraries(core-spilling-storage PUBLIC contrib-libs-cxxsupp yutil spilling-storage-file_storage - yql-minikql-codegen - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO ) target_sources(core-spilling-storage PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/storage.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/storage.cpp ) diff --git a/ydb/library/yql/core/spilling/storage/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/spilling/storage/CMakeLists.linux-x86_64.txt index 4150b7499b73..23d52c9c37c9 100644 --- a/ydb/library/yql/core/spilling/storage/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/spilling/storage/CMakeLists.linux-x86_64.txt @@ -19,14 +19,8 @@ target_link_libraries(core-spilling-storage PUBLIC contrib-libs-cxxsupp yutil spilling-storage-file_storage - yql-minikql-codegen - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO ) target_sources(core-spilling-storage PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/storage.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/storage.cpp ) diff --git a/ydb/library/yql/core/spilling/storage/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/spilling/storage/CMakeLists.windows-x86_64.txt index cd28502e3b34..2ba443623143 100644 --- a/ydb/library/yql/core/spilling/storage/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/spilling/storage/CMakeLists.windows-x86_64.txt @@ -18,14 +18,8 @@ target_link_libraries(core-spilling-storage PUBLIC contrib-libs-cxxsupp yutil spilling-storage-file_storage - yql-minikql-codegen - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO ) target_sources(core-spilling-storage PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/storage.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/storage.cpp ) diff --git a/ydb/library/yql/core/spilling/storage/file_storage/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/spilling/storage/file_storage/CMakeLists.darwin-arm64.txt index 9028583a24d2..c74f29bea054 100644 --- a/ydb/library/yql/core/spilling/storage/file_storage/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/spilling/storage/file_storage/CMakeLists.darwin-arm64.txt @@ -16,13 +16,6 @@ target_link_libraries(spilling-storage-file_storage PUBLIC contrib-libs-cxxsupp yutil yql-utils-log - yql-minikql-codegen - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO ) target_sources(spilling-storage-file_storage PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/file_storage/file_storage.cpp diff --git a/ydb/library/yql/core/spilling/storage/file_storage/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/spilling/storage/file_storage/CMakeLists.darwin-x86_64.txt index 9028583a24d2..c74f29bea054 100644 --- a/ydb/library/yql/core/spilling/storage/file_storage/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/spilling/storage/file_storage/CMakeLists.darwin-x86_64.txt @@ -16,13 +16,6 @@ target_link_libraries(spilling-storage-file_storage PUBLIC contrib-libs-cxxsupp yutil yql-utils-log - yql-minikql-codegen - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO ) target_sources(spilling-storage-file_storage PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/file_storage/file_storage.cpp diff --git a/ydb/library/yql/core/spilling/storage/file_storage/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/spilling/storage/file_storage/CMakeLists.linux-aarch64.txt index e86132790a7c..c23ae3d5c886 100644 --- a/ydb/library/yql/core/spilling/storage/file_storage/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/spilling/storage/file_storage/CMakeLists.linux-aarch64.txt @@ -17,13 +17,6 @@ target_link_libraries(spilling-storage-file_storage PUBLIC contrib-libs-cxxsupp yutil yql-utils-log - yql-minikql-codegen - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO ) target_sources(spilling-storage-file_storage PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/file_storage/file_storage.cpp diff --git a/ydb/library/yql/core/spilling/storage/file_storage/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/spilling/storage/file_storage/CMakeLists.linux-x86_64.txt index e86132790a7c..c23ae3d5c886 100644 --- a/ydb/library/yql/core/spilling/storage/file_storage/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/spilling/storage/file_storage/CMakeLists.linux-x86_64.txt @@ -17,13 +17,6 @@ target_link_libraries(spilling-storage-file_storage PUBLIC contrib-libs-cxxsupp yutil yql-utils-log - yql-minikql-codegen - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO ) target_sources(spilling-storage-file_storage PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/file_storage/file_storage.cpp diff --git a/ydb/library/yql/core/spilling/storage/file_storage/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/spilling/storage/file_storage/CMakeLists.windows-x86_64.txt index 9028583a24d2..c74f29bea054 100644 --- a/ydb/library/yql/core/spilling/storage/file_storage/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/spilling/storage/file_storage/CMakeLists.windows-x86_64.txt @@ -16,13 +16,6 @@ target_link_libraries(spilling-storage-file_storage PUBLIC contrib-libs-cxxsupp yutil yql-utils-log - yql-minikql-codegen - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO ) target_sources(spilling-storage-file_storage PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/file_storage/file_storage.cpp diff --git a/ydb/library/yql/core/spilling/storage/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/spilling/storage/ut/CMakeLists.darwin-arm64.txt index 38f8aecb242f..bb7257a31d98 100644 --- a/ydb/library/yql/core/spilling/storage/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/spilling/storage/ut/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-library-yql-core-spilling-storage-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-core-spilling-storage-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/ut/storage_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/spilling/storage/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/spilling/storage/ut/CMakeLists.darwin-x86_64.txt index 649467a4f98a..ca612a280a3b 100644 --- a/ydb/library/yql/core/spilling/storage/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/spilling/storage/ut/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-library-yql-core-spilling-storage-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-core-spilling-storage-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/ut/storage_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/spilling/storage/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/spilling/storage/ut/CMakeLists.linux-aarch64.txt index 44f49c0573da..ae30581790d8 100644 --- a/ydb/library/yql/core/spilling/storage/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/spilling/storage/ut/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-library-yql-core-spilling-storage-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-core-spilling-storage-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/ut/storage_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/spilling/storage/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/spilling/storage/ut/CMakeLists.linux-x86_64.txt index 3d9aeb7cdefd..8087d7cab073 100644 --- a/ydb/library/yql/core/spilling/storage/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/spilling/storage/ut/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-library-yql-core-spilling-storage-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-core-spilling-storage-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/storage/ut/storage_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/spilling/storage/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/spilling/storage/ut/CMakeLists.windows-x86_64.txt index 0185830a78a4..b8fc03cf23d2 100644 --- a/ydb/library/yql/core/spilling/storage/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/spilling/storage/ut/CMakeLists.windows-x86_64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/spilling/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/spilling/ut/CMakeLists.darwin-arm64.txt index c7f991250288..e095a24412f5 100644 --- a/ydb/library/yql/core/spilling/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/spilling/ut/CMakeLists.darwin-arm64.txt @@ -21,13 +21,12 @@ target_link_libraries(ydb-library-yql-core-spilling-ut PUBLIC yql-core-spilling yql-public-udf udf-service-exception_policy + yql-sql-pg_dummy ) target_link_options(ydb-library-yql-core-spilling-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-core-spilling-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/ut/spilling_ut.cpp @@ -57,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/spilling/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/spilling/ut/CMakeLists.darwin-x86_64.txt index ba4e853e58fd..cc634319260a 100644 --- a/ydb/library/yql/core/spilling/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/spilling/ut/CMakeLists.darwin-x86_64.txt @@ -22,13 +22,12 @@ target_link_libraries(ydb-library-yql-core-spilling-ut PUBLIC yql-core-spilling yql-public-udf udf-service-exception_policy + yql-sql-pg_dummy ) target_link_options(ydb-library-yql-core-spilling-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-core-spilling-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/ut/spilling_ut.cpp @@ -58,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/spilling/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/spilling/ut/CMakeLists.linux-aarch64.txt index 0fe44c249675..1414a8fd277f 100644 --- a/ydb/library/yql/core/spilling/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/spilling/ut/CMakeLists.linux-aarch64.txt @@ -22,6 +22,7 @@ target_link_libraries(ydb-library-yql-core-spilling-ut PUBLIC yql-core-spilling yql-public-udf udf-service-exception_policy + yql-sql-pg_dummy ) target_link_options(ydb-library-yql-core-spilling-ut PRIVATE -ldl @@ -29,9 +30,6 @@ target_link_options(ydb-library-yql-core-spilling-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-core-spilling-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/ut/spilling_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/spilling/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/spilling/ut/CMakeLists.linux-x86_64.txt index 33abfe68c084..73b7fb6fca5b 100644 --- a/ydb/library/yql/core/spilling/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/spilling/ut/CMakeLists.linux-x86_64.txt @@ -23,6 +23,7 @@ target_link_libraries(ydb-library-yql-core-spilling-ut PUBLIC yql-core-spilling yql-public-udf udf-service-exception_policy + yql-sql-pg_dummy ) target_link_options(ydb-library-yql-core-spilling-ut PRIVATE -ldl @@ -30,9 +31,6 @@ target_link_options(ydb-library-yql-core-spilling-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-core-spilling-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/ut/spilling_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/spilling/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/spilling/ut/CMakeLists.windows-x86_64.txt index 6d5ce50c09b8..9203c2457c79 100644 --- a/ydb/library/yql/core/spilling/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/spilling/ut/CMakeLists.windows-x86_64.txt @@ -22,6 +22,7 @@ target_link_libraries(ydb-library-yql-core-spilling-ut PUBLIC yql-core-spilling yql-public-udf udf-service-exception_policy + yql-sql-pg_dummy ) target_sources(ydb-library-yql-core-spilling-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/spilling/ut/spilling_ut.cpp @@ -51,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/sql_types/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/sql_types/CMakeLists.darwin-arm64.txt index 5d0fdac0e62e..d8ce4682fd79 100644 --- a/ydb/library/yql/core/sql_types/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/sql_types/CMakeLists.darwin-arm64.txt @@ -21,6 +21,8 @@ target_link_libraries(yql-core-sql_types PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(yql-core-sql_types PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/sql_types/match_recognize.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/sql_types/simple_types.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/sql_types/match_recognize.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/sql_types/simple_types.cpp ) diff --git a/ydb/library/yql/core/sql_types/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/sql_types/CMakeLists.darwin-x86_64.txt index 5d0fdac0e62e..d8ce4682fd79 100644 --- a/ydb/library/yql/core/sql_types/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/sql_types/CMakeLists.darwin-x86_64.txt @@ -21,6 +21,8 @@ target_link_libraries(yql-core-sql_types PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(yql-core-sql_types PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/sql_types/match_recognize.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/sql_types/simple_types.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/sql_types/match_recognize.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/sql_types/simple_types.cpp ) diff --git a/ydb/library/yql/core/sql_types/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/sql_types/CMakeLists.linux-aarch64.txt index f709108d6b24..5fe55bef62aa 100644 --- a/ydb/library/yql/core/sql_types/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/sql_types/CMakeLists.linux-aarch64.txt @@ -22,6 +22,8 @@ target_link_libraries(yql-core-sql_types PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(yql-core-sql_types PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/sql_types/match_recognize.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/sql_types/simple_types.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/sql_types/match_recognize.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/sql_types/simple_types.cpp ) diff --git a/ydb/library/yql/core/sql_types/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/sql_types/CMakeLists.linux-x86_64.txt index f709108d6b24..5fe55bef62aa 100644 --- a/ydb/library/yql/core/sql_types/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/sql_types/CMakeLists.linux-x86_64.txt @@ -22,6 +22,8 @@ target_link_libraries(yql-core-sql_types PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(yql-core-sql_types PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/sql_types/match_recognize.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/sql_types/simple_types.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/sql_types/match_recognize.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/sql_types/simple_types.cpp ) diff --git a/ydb/library/yql/core/sql_types/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/sql_types/CMakeLists.windows-x86_64.txt index 5d0fdac0e62e..d8ce4682fd79 100644 --- a/ydb/library/yql/core/sql_types/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/sql_types/CMakeLists.windows-x86_64.txt @@ -21,6 +21,8 @@ target_link_libraries(yql-core-sql_types PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(yql-core-sql_types PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/sql_types/match_recognize.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/sql_types/simple_types.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/sql_types/match_recognize.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/sql_types/simple_types.cpp ) diff --git a/ydb/library/yql/core/sql_types/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/sql_types/ut/CMakeLists.darwin-arm64.txt index 9728ef45fd4f..dac0ee6867ab 100644 --- a/ydb/library/yql/core/sql_types/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/sql_types/ut/CMakeLists.darwin-arm64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/sql_types/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/sql_types/ut/CMakeLists.darwin-x86_64.txt index f48e3fb51862..dc276458c32a 100644 --- a/ydb/library/yql/core/sql_types/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/sql_types/ut/CMakeLists.darwin-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/sql_types/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/sql_types/ut/CMakeLists.linux-aarch64.txt index 4e43cbcc6d30..0a136c1682fc 100644 --- a/ydb/library/yql/core/sql_types/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/sql_types/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-yql-core-sql_types-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-core-sql_types-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/sql_types/match_recognize_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/sql_types/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/sql_types/ut/CMakeLists.linux-x86_64.txt index c360cf201275..f3c6fef9671f 100644 --- a/ydb/library/yql/core/sql_types/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/sql_types/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-yql-core-sql_types-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-core-sql_types-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/sql_types/match_recognize_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/sql_types/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/sql_types/ut/CMakeLists.windows-x86_64.txt index 6e38dd6b7b6b..d5d8dff029d8 100644 --- a/ydb/library/yql/core/sql_types/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/sql_types/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/type_ann/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/type_ann/CMakeLists.darwin-arm64.txt index 53f3b17275e8..a71929e6f70f 100644 --- a/ydb/library/yql/core/type_ann/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/type_ann/CMakeLists.darwin-arm64.txt @@ -28,6 +28,15 @@ target_link_libraries(yql-core-type_ann PUBLIC parser-pg_wrapper-interface ) target_sources(yql-core-type_ann PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_blocks.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_columnorder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_core.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_expr.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_list.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_pg.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_types.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_wide.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_blocks.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_columnorder.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_core.cpp diff --git a/ydb/library/yql/core/type_ann/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/type_ann/CMakeLists.darwin-x86_64.txt index 53f3b17275e8..a71929e6f70f 100644 --- a/ydb/library/yql/core/type_ann/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/type_ann/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,15 @@ target_link_libraries(yql-core-type_ann PUBLIC parser-pg_wrapper-interface ) target_sources(yql-core-type_ann PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_blocks.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_columnorder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_core.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_expr.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_list.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_pg.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_types.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_wide.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_blocks.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_columnorder.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_core.cpp diff --git a/ydb/library/yql/core/type_ann/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/type_ann/CMakeLists.linux-aarch64.txt index f4447a3d10e4..575af294e4bc 100644 --- a/ydb/library/yql/core/type_ann/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/type_ann/CMakeLists.linux-aarch64.txt @@ -29,6 +29,15 @@ target_link_libraries(yql-core-type_ann PUBLIC parser-pg_wrapper-interface ) target_sources(yql-core-type_ann PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_blocks.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_columnorder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_core.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_expr.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_list.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_pg.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_types.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_wide.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_blocks.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_columnorder.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_core.cpp diff --git a/ydb/library/yql/core/type_ann/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/type_ann/CMakeLists.linux-x86_64.txt index f4447a3d10e4..575af294e4bc 100644 --- a/ydb/library/yql/core/type_ann/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/type_ann/CMakeLists.linux-x86_64.txt @@ -29,6 +29,15 @@ target_link_libraries(yql-core-type_ann PUBLIC parser-pg_wrapper-interface ) target_sources(yql-core-type_ann PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_blocks.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_columnorder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_core.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_expr.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_list.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_pg.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_types.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_wide.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_blocks.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_columnorder.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_core.cpp diff --git a/ydb/library/yql/core/type_ann/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/type_ann/CMakeLists.windows-x86_64.txt index 53f3b17275e8..a71929e6f70f 100644 --- a/ydb/library/yql/core/type_ann/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/type_ann/CMakeLists.windows-x86_64.txt @@ -28,6 +28,15 @@ target_link_libraries(yql-core-type_ann PUBLIC parser-pg_wrapper-interface ) target_sources(yql-core-type_ann PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_blocks.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_columnorder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_core.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_expr.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_list.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_pg.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_types.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_wide.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_blocks.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_columnorder.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/type_ann/type_ann_core.cpp diff --git a/ydb/library/yql/core/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/ut/CMakeLists.darwin-arm64.txt index cd9565c10210..56c24ed6d6a6 100644 --- a/ydb/library/yql/core/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/ut/CMakeLists.darwin-arm64.txt @@ -32,14 +32,16 @@ target_link_libraries(ydb-library-yql-core-ut PUBLIC providers-result-provider yt-gateway-file providers-yt-provider + yt-codec-codegen + yt-comp_nodes-llvm14 + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 yql-sql-pg ) target_link_options(ydb-library-yql-core-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-core-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/ut/yql_csv_ut.cpp @@ -78,6 +80,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/ut/CMakeLists.darwin-x86_64.txt index 8ec2ef772a44..3fa786bcd4df 100644 --- a/ydb/library/yql/core/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/ut/CMakeLists.darwin-x86_64.txt @@ -33,14 +33,16 @@ target_link_libraries(ydb-library-yql-core-ut PUBLIC providers-result-provider yt-gateway-file providers-yt-provider + yt-codec-codegen + yt-comp_nodes-llvm14 + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 yql-sql-pg ) target_link_options(ydb-library-yql-core-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-core-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/ut/yql_csv_ut.cpp @@ -79,6 +81,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/ut/CMakeLists.linux-aarch64.txt index 3e71688c69b1..730f02642725 100644 --- a/ydb/library/yql/core/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/ut/CMakeLists.linux-aarch64.txt @@ -33,6 +33,10 @@ target_link_libraries(ydb-library-yql-core-ut PUBLIC providers-result-provider yt-gateway-file providers-yt-provider + yt-codec-codegen + yt-comp_nodes-llvm14 + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 yql-sql-pg ) target_link_options(ydb-library-yql-core-ut PRIVATE @@ -41,10 +45,6 @@ target_link_options(ydb-library-yql-core-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(ydb-library-yql-core-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/ut/yql_csv_ut.cpp @@ -83,6 +83,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/ut/CMakeLists.linux-x86_64.txt index 70924389ddaf..810574924ccb 100644 --- a/ydb/library/yql/core/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/ut/CMakeLists.linux-x86_64.txt @@ -34,6 +34,10 @@ target_link_libraries(ydb-library-yql-core-ut PUBLIC providers-result-provider yt-gateway-file providers-yt-provider + yt-codec-codegen + yt-comp_nodes-llvm14 + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 yql-sql-pg ) target_link_options(ydb-library-yql-core-ut PRIVATE @@ -42,10 +46,6 @@ target_link_options(ydb-library-yql-core-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(ydb-library-yql-core-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/ut/yql_csv_ut.cpp @@ -84,6 +84,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/ut/CMakeLists.windows-x86_64.txt index 193dc53ccd59..b9efa7546a26 100644 --- a/ydb/library/yql/core/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/ut/CMakeLists.windows-x86_64.txt @@ -33,6 +33,10 @@ target_link_libraries(ydb-library-yql-core-ut PUBLIC providers-result-provider yt-gateway-file providers-yt-provider + yt-codec-codegen + yt-comp_nodes-llvm14 + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 yql-sql-pg ) target_sources(ydb-library-yql-core-ut PRIVATE @@ -72,6 +76,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/core/ut_common/CMakeLists.darwin-arm64.txt b/ydb/library/yql/core/ut_common/CMakeLists.darwin-arm64.txt index 0ffc0edcc656..44ed6c93b849 100644 --- a/ydb/library/yql/core/ut_common/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/core/ut_common/CMakeLists.darwin-arm64.txt @@ -20,5 +20,6 @@ target_link_libraries(yql-core-ut_common PUBLIC yql-dq-expr_nodes ) target_sources(yql-core-ut_common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/ut_common/yql_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/ut_common/yql_ut_common.cpp ) diff --git a/ydb/library/yql/core/ut_common/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/core/ut_common/CMakeLists.darwin-x86_64.txt index 0ffc0edcc656..44ed6c93b849 100644 --- a/ydb/library/yql/core/ut_common/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/core/ut_common/CMakeLists.darwin-x86_64.txt @@ -20,5 +20,6 @@ target_link_libraries(yql-core-ut_common PUBLIC yql-dq-expr_nodes ) target_sources(yql-core-ut_common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/ut_common/yql_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/ut_common/yql_ut_common.cpp ) diff --git a/ydb/library/yql/core/ut_common/CMakeLists.linux-aarch64.txt b/ydb/library/yql/core/ut_common/CMakeLists.linux-aarch64.txt index 8eb14de93b0c..8bb79a153761 100644 --- a/ydb/library/yql/core/ut_common/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/core/ut_common/CMakeLists.linux-aarch64.txt @@ -21,5 +21,6 @@ target_link_libraries(yql-core-ut_common PUBLIC yql-dq-expr_nodes ) target_sources(yql-core-ut_common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/ut_common/yql_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/ut_common/yql_ut_common.cpp ) diff --git a/ydb/library/yql/core/ut_common/CMakeLists.linux-x86_64.txt b/ydb/library/yql/core/ut_common/CMakeLists.linux-x86_64.txt index 8eb14de93b0c..8bb79a153761 100644 --- a/ydb/library/yql/core/ut_common/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/core/ut_common/CMakeLists.linux-x86_64.txt @@ -21,5 +21,6 @@ target_link_libraries(yql-core-ut_common PUBLIC yql-dq-expr_nodes ) target_sources(yql-core-ut_common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/ut_common/yql_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/ut_common/yql_ut_common.cpp ) diff --git a/ydb/library/yql/core/ut_common/CMakeLists.windows-x86_64.txt b/ydb/library/yql/core/ut_common/CMakeLists.windows-x86_64.txt index 0ffc0edcc656..44ed6c93b849 100644 --- a/ydb/library/yql/core/ut_common/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/core/ut_common/CMakeLists.windows-x86_64.txt @@ -20,5 +20,6 @@ target_link_libraries(yql-core-ut_common PUBLIC yql-dq-expr_nodes ) target_sources(yql-core-ut_common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/ut_common/yql_ut_common.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/core/ut_common/yql_ut_common.cpp ) diff --git a/ydb/library/yql/dq/actors/compute/CMakeLists.darwin-arm64.txt b/ydb/library/yql/dq/actors/compute/CMakeLists.darwin-arm64.txt index 4b7f57da1caa..c70ae888be5a 100644 --- a/ydb/library/yql/dq/actors/compute/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/dq/actors/compute/CMakeLists.darwin-arm64.txt @@ -24,11 +24,12 @@ target_link_libraries(dq-actors-compute PUBLIC yql-dq-runtime yql-dq-tasks dq-actors-spilling - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-public-issue core-quoter-public ) target_sources(dq-actors-compute PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/dq_request_context.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/dq_task_runner_exec_ctx.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/dq_async_compute_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/dq_compute_actor_async_io_factory.cpp diff --git a/ydb/library/yql/dq/actors/compute/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/dq/actors/compute/CMakeLists.darwin-x86_64.txt index 4b7f57da1caa..c70ae888be5a 100644 --- a/ydb/library/yql/dq/actors/compute/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/dq/actors/compute/CMakeLists.darwin-x86_64.txt @@ -24,11 +24,12 @@ target_link_libraries(dq-actors-compute PUBLIC yql-dq-runtime yql-dq-tasks dq-actors-spilling - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-public-issue core-quoter-public ) target_sources(dq-actors-compute PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/dq_request_context.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/dq_task_runner_exec_ctx.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/dq_async_compute_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/dq_compute_actor_async_io_factory.cpp diff --git a/ydb/library/yql/dq/actors/compute/CMakeLists.linux-aarch64.txt b/ydb/library/yql/dq/actors/compute/CMakeLists.linux-aarch64.txt index 522fa2af6065..12e2d1839399 100644 --- a/ydb/library/yql/dq/actors/compute/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/dq/actors/compute/CMakeLists.linux-aarch64.txt @@ -25,11 +25,12 @@ target_link_libraries(dq-actors-compute PUBLIC yql-dq-runtime yql-dq-tasks dq-actors-spilling - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-public-issue core-quoter-public ) target_sources(dq-actors-compute PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/dq_request_context.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/dq_task_runner_exec_ctx.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/dq_async_compute_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/dq_compute_actor_async_io_factory.cpp diff --git a/ydb/library/yql/dq/actors/compute/CMakeLists.linux-x86_64.txt b/ydb/library/yql/dq/actors/compute/CMakeLists.linux-x86_64.txt index 522fa2af6065..12e2d1839399 100644 --- a/ydb/library/yql/dq/actors/compute/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/dq/actors/compute/CMakeLists.linux-x86_64.txt @@ -25,11 +25,12 @@ target_link_libraries(dq-actors-compute PUBLIC yql-dq-runtime yql-dq-tasks dq-actors-spilling - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-public-issue core-quoter-public ) target_sources(dq-actors-compute PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/dq_request_context.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/dq_task_runner_exec_ctx.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/dq_async_compute_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/dq_compute_actor_async_io_factory.cpp diff --git a/ydb/library/yql/dq/actors/compute/CMakeLists.windows-x86_64.txt b/ydb/library/yql/dq/actors/compute/CMakeLists.windows-x86_64.txt index 4b7f57da1caa..c70ae888be5a 100644 --- a/ydb/library/yql/dq/actors/compute/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/dq/actors/compute/CMakeLists.windows-x86_64.txt @@ -24,11 +24,12 @@ target_link_libraries(dq-actors-compute PUBLIC yql-dq-runtime yql-dq-tasks dq-actors-spilling - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-public-issue core-quoter-public ) target_sources(dq-actors-compute PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/dq_request_context.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/dq_task_runner_exec_ctx.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/dq_async_compute_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/dq_compute_actor_async_io_factory.cpp diff --git a/ydb/library/yql/dq/actors/compute/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/dq/actors/compute/ut/CMakeLists.darwin-arm64.txt index 417e0022accc..f2cdb3d5c831 100644 --- a/ydb/library/yql/dq/actors/compute/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/dq/actors/compute/ut/CMakeLists.darwin-arm64.txt @@ -8,6 +8,9 @@ add_executable(ydb-library-yql-dq-actors-compute-ut) +target_compile_options(ydb-library-yql-dq-actors-compute-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) target_include_directories(ydb-library-yql-dq-actors-compute-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute ) @@ -25,10 +28,9 @@ target_link_options(ydb-library-yql-dq-actors-compute-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-dq-actors-compute-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/ut/dq_compute_actor_async_input_helper_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/ut/dq_compute_issues_buffer_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/ut/dq_source_watermark_tracker_ut.cpp ) @@ -57,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/actors/compute/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/dq/actors/compute/ut/CMakeLists.darwin-x86_64.txt index 7390a114e67d..b4f735e0e32d 100644 --- a/ydb/library/yql/dq/actors/compute/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/dq/actors/compute/ut/CMakeLists.darwin-x86_64.txt @@ -8,6 +8,9 @@ add_executable(ydb-library-yql-dq-actors-compute-ut) +target_compile_options(ydb-library-yql-dq-actors-compute-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) target_include_directories(ydb-library-yql-dq-actors-compute-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute ) @@ -26,10 +29,9 @@ target_link_options(ydb-library-yql-dq-actors-compute-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-dq-actors-compute-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/ut/dq_compute_actor_async_input_helper_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/ut/dq_compute_issues_buffer_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/ut/dq_source_watermark_tracker_ut.cpp ) @@ -58,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/actors/compute/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/dq/actors/compute/ut/CMakeLists.linux-aarch64.txt index 54d71189fe83..9f358b31d1e2 100644 --- a/ydb/library/yql/dq/actors/compute/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/dq/actors/compute/ut/CMakeLists.linux-aarch64.txt @@ -8,6 +8,9 @@ add_executable(ydb-library-yql-dq-actors-compute-ut) +target_compile_options(ydb-library-yql-dq-actors-compute-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) target_include_directories(ydb-library-yql-dq-actors-compute-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute ) @@ -28,11 +31,9 @@ target_link_options(ydb-library-yql-dq-actors-compute-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-dq-actors-compute-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/ut/dq_compute_actor_async_input_helper_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/ut/dq_compute_issues_buffer_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/ut/dq_source_watermark_tracker_ut.cpp ) @@ -61,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/actors/compute/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/dq/actors/compute/ut/CMakeLists.linux-x86_64.txt index b7d0ce21486f..a31e86665e83 100644 --- a/ydb/library/yql/dq/actors/compute/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/dq/actors/compute/ut/CMakeLists.linux-x86_64.txt @@ -8,6 +8,9 @@ add_executable(ydb-library-yql-dq-actors-compute-ut) +target_compile_options(ydb-library-yql-dq-actors-compute-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) target_include_directories(ydb-library-yql-dq-actors-compute-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute ) @@ -29,11 +32,9 @@ target_link_options(ydb-library-yql-dq-actors-compute-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-dq-actors-compute-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/ut/dq_compute_actor_async_input_helper_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/ut/dq_compute_issues_buffer_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/ut/dq_source_watermark_tracker_ut.cpp ) @@ -62,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/actors/compute/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/dq/actors/compute/ut/CMakeLists.windows-x86_64.txt index dffae7cf8362..e0cf29135468 100644 --- a/ydb/library/yql/dq/actors/compute/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/dq/actors/compute/ut/CMakeLists.windows-x86_64.txt @@ -8,6 +8,9 @@ add_executable(ydb-library-yql-dq-actors-compute-ut) +target_compile_options(ydb-library-yql-dq-actors-compute-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) target_include_directories(ydb-library-yql-dq-actors-compute-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute ) @@ -23,6 +26,7 @@ target_link_libraries(ydb-library-yql-dq-actors-compute-ut PUBLIC yql-sql-pg_dummy ) target_sources(ydb-library-yql-dq-actors-compute-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/ut/dq_compute_actor_async_input_helper_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/ut/dq_compute_issues_buffer_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/compute/ut/dq_source_watermark_tracker_ut.cpp ) @@ -51,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/actors/protos/CMakeLists.darwin-arm64.txt b/ydb/library/yql/dq/actors/protos/CMakeLists.darwin-arm64.txt index e9f86e283882..9f1e583ed559 100644 --- a/ydb/library/yql/dq/actors/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/dq/actors/protos/CMakeLists.darwin-arm64.txt @@ -60,6 +60,11 @@ target_proto_messages(dq-actors-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/protos/dq_stats.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/protos/dq_status_codes.proto ) +target_sources(dq-actors-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/actors/protos/dq_events.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/actors/protos/dq_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/actors/protos/dq_status_codes.pb.h +) target_proto_addincls(dq-actors-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/dq/actors/protos/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/dq/actors/protos/CMakeLists.darwin-x86_64.txt index e9f86e283882..9f1e583ed559 100644 --- a/ydb/library/yql/dq/actors/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/dq/actors/protos/CMakeLists.darwin-x86_64.txt @@ -60,6 +60,11 @@ target_proto_messages(dq-actors-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/protos/dq_stats.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/protos/dq_status_codes.proto ) +target_sources(dq-actors-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/actors/protos/dq_events.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/actors/protos/dq_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/actors/protos/dq_status_codes.pb.h +) target_proto_addincls(dq-actors-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/dq/actors/protos/CMakeLists.linux-aarch64.txt b/ydb/library/yql/dq/actors/protos/CMakeLists.linux-aarch64.txt index 48cc28edfe98..1d75333772f6 100644 --- a/ydb/library/yql/dq/actors/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/dq/actors/protos/CMakeLists.linux-aarch64.txt @@ -61,6 +61,11 @@ target_proto_messages(dq-actors-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/protos/dq_stats.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/protos/dq_status_codes.proto ) +target_sources(dq-actors-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/actors/protos/dq_events.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/actors/protos/dq_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/actors/protos/dq_status_codes.pb.h +) target_proto_addincls(dq-actors-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/dq/actors/protos/CMakeLists.linux-x86_64.txt b/ydb/library/yql/dq/actors/protos/CMakeLists.linux-x86_64.txt index 48cc28edfe98..1d75333772f6 100644 --- a/ydb/library/yql/dq/actors/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/dq/actors/protos/CMakeLists.linux-x86_64.txt @@ -61,6 +61,11 @@ target_proto_messages(dq-actors-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/protos/dq_stats.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/protos/dq_status_codes.proto ) +target_sources(dq-actors-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/actors/protos/dq_events.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/actors/protos/dq_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/actors/protos/dq_status_codes.pb.h +) target_proto_addincls(dq-actors-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/dq/actors/protos/CMakeLists.windows-x86_64.txt b/ydb/library/yql/dq/actors/protos/CMakeLists.windows-x86_64.txt index e9f86e283882..9f1e583ed559 100644 --- a/ydb/library/yql/dq/actors/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/dq/actors/protos/CMakeLists.windows-x86_64.txt @@ -60,6 +60,11 @@ target_proto_messages(dq-actors-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/protos/dq_stats.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/protos/dq_status_codes.proto ) +target_sources(dq-actors-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/actors/protos/dq_events.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/actors/protos/dq_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/actors/protos/dq_status_codes.pb.h +) target_proto_addincls(dq-actors-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/dq/actors/spilling/CMakeLists.darwin-arm64.txt b/ydb/library/yql/dq/actors/spilling/CMakeLists.darwin-arm64.txt index 3bdf4877d9e6..2cfea5d7a504 100644 --- a/ydb/library/yql/dq/actors/spilling/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/dq/actors/spilling/CMakeLists.darwin-arm64.txt @@ -26,6 +26,7 @@ target_link_libraries(dq-actors-spilling PUBLIC monlib-service-pages ) target_sources(dq-actors-spilling PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/channel_storage_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/channel_storage.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/spilling_counters.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/spilling_file.cpp diff --git a/ydb/library/yql/dq/actors/spilling/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/dq/actors/spilling/CMakeLists.darwin-x86_64.txt index 3bdf4877d9e6..2cfea5d7a504 100644 --- a/ydb/library/yql/dq/actors/spilling/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/dq/actors/spilling/CMakeLists.darwin-x86_64.txt @@ -26,6 +26,7 @@ target_link_libraries(dq-actors-spilling PUBLIC monlib-service-pages ) target_sources(dq-actors-spilling PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/channel_storage_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/channel_storage.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/spilling_counters.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/spilling_file.cpp diff --git a/ydb/library/yql/dq/actors/spilling/CMakeLists.linux-aarch64.txt b/ydb/library/yql/dq/actors/spilling/CMakeLists.linux-aarch64.txt index ab63187e9538..f63a3cf01d89 100644 --- a/ydb/library/yql/dq/actors/spilling/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/dq/actors/spilling/CMakeLists.linux-aarch64.txt @@ -27,6 +27,7 @@ target_link_libraries(dq-actors-spilling PUBLIC monlib-service-pages ) target_sources(dq-actors-spilling PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/channel_storage_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/channel_storage.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/spilling_counters.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/spilling_file.cpp diff --git a/ydb/library/yql/dq/actors/spilling/CMakeLists.linux-x86_64.txt b/ydb/library/yql/dq/actors/spilling/CMakeLists.linux-x86_64.txt index ab63187e9538..f63a3cf01d89 100644 --- a/ydb/library/yql/dq/actors/spilling/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/dq/actors/spilling/CMakeLists.linux-x86_64.txt @@ -27,6 +27,7 @@ target_link_libraries(dq-actors-spilling PUBLIC monlib-service-pages ) target_sources(dq-actors-spilling PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/channel_storage_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/channel_storage.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/spilling_counters.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/spilling_file.cpp diff --git a/ydb/library/yql/dq/actors/spilling/CMakeLists.windows-x86_64.txt b/ydb/library/yql/dq/actors/spilling/CMakeLists.windows-x86_64.txt index 3bdf4877d9e6..2cfea5d7a504 100644 --- a/ydb/library/yql/dq/actors/spilling/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/dq/actors/spilling/CMakeLists.windows-x86_64.txt @@ -26,6 +26,7 @@ target_link_libraries(dq-actors-spilling PUBLIC monlib-service-pages ) target_sources(dq-actors-spilling PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/channel_storage_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/channel_storage.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/spilling_counters.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/spilling_file.cpp diff --git a/ydb/library/yql/dq/actors/spilling/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/dq/actors/spilling/ut/CMakeLists.darwin-arm64.txt index 17bf3ddfc89e..0511eb8fafe8 100644 --- a/ydb/library/yql/dq/actors/spilling/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/dq/actors/spilling/ut/CMakeLists.darwin-arm64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-library-yql-dq-actors-spilling-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-dq-actors-spilling-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/spilling_file_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/actors/spilling/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/dq/actors/spilling/ut/CMakeLists.darwin-x86_64.txt index b35e50368a1b..c5b023a863a6 100644 --- a/ydb/library/yql/dq/actors/spilling/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/dq/actors/spilling/ut/CMakeLists.darwin-x86_64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-library-yql-dq-actors-spilling-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-dq-actors-spilling-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/spilling_file_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/actors/spilling/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/dq/actors/spilling/ut/CMakeLists.linux-aarch64.txt index a57b12e6e8da..ee46e1db3900 100644 --- a/ydb/library/yql/dq/actors/spilling/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/dq/actors/spilling/ut/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-library-yql-dq-actors-spilling-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-dq-actors-spilling-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/spilling_file_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/actors/spilling/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/dq/actors/spilling/ut/CMakeLists.linux-x86_64.txt index 887cf5e772b8..af6cf030590e 100644 --- a/ydb/library/yql/dq/actors/spilling/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/dq/actors/spilling/ut/CMakeLists.linux-x86_64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-library-yql-dq-actors-spilling-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-dq-actors-spilling-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/actors/spilling/spilling_file_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/actors/spilling/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/dq/actors/spilling/ut/CMakeLists.windows-x86_64.txt index 04251cab16a6..dca545cd2ca6 100644 --- a/ydb/library/yql/dq/actors/spilling/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/dq/actors/spilling/ut/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/actors/task_runner/CMakeLists.darwin-arm64.txt b/ydb/library/yql/dq/actors/task_runner/CMakeLists.darwin-arm64.txt index a3cf76d6ba55..2a60001374d4 100644 --- a/ydb/library/yql/dq/actors/task_runner/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/dq/actors/task_runner/CMakeLists.darwin-arm64.txt @@ -18,7 +18,7 @@ target_link_libraries(dq-actors-task_runner PUBLIC yql-dq-runtime yql-dq-common yql-dq-proto - minikql-computation-llvm + yql-minikql-computation yql-utils-actors ydb-library-services ) diff --git a/ydb/library/yql/dq/actors/task_runner/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/dq/actors/task_runner/CMakeLists.darwin-x86_64.txt index a3cf76d6ba55..2a60001374d4 100644 --- a/ydb/library/yql/dq/actors/task_runner/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/dq/actors/task_runner/CMakeLists.darwin-x86_64.txt @@ -18,7 +18,7 @@ target_link_libraries(dq-actors-task_runner PUBLIC yql-dq-runtime yql-dq-common yql-dq-proto - minikql-computation-llvm + yql-minikql-computation yql-utils-actors ydb-library-services ) diff --git a/ydb/library/yql/dq/actors/task_runner/CMakeLists.linux-aarch64.txt b/ydb/library/yql/dq/actors/task_runner/CMakeLists.linux-aarch64.txt index 999caf7750c4..f34265ab3ff1 100644 --- a/ydb/library/yql/dq/actors/task_runner/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/dq/actors/task_runner/CMakeLists.linux-aarch64.txt @@ -19,7 +19,7 @@ target_link_libraries(dq-actors-task_runner PUBLIC yql-dq-runtime yql-dq-common yql-dq-proto - minikql-computation-llvm + yql-minikql-computation yql-utils-actors ydb-library-services ) diff --git a/ydb/library/yql/dq/actors/task_runner/CMakeLists.linux-x86_64.txt b/ydb/library/yql/dq/actors/task_runner/CMakeLists.linux-x86_64.txt index 999caf7750c4..f34265ab3ff1 100644 --- a/ydb/library/yql/dq/actors/task_runner/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/dq/actors/task_runner/CMakeLists.linux-x86_64.txt @@ -19,7 +19,7 @@ target_link_libraries(dq-actors-task_runner PUBLIC yql-dq-runtime yql-dq-common yql-dq-proto - minikql-computation-llvm + yql-minikql-computation yql-utils-actors ydb-library-services ) diff --git a/ydb/library/yql/dq/actors/task_runner/CMakeLists.windows-x86_64.txt b/ydb/library/yql/dq/actors/task_runner/CMakeLists.windows-x86_64.txt index a3cf76d6ba55..2a60001374d4 100644 --- a/ydb/library/yql/dq/actors/task_runner/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/dq/actors/task_runner/CMakeLists.windows-x86_64.txt @@ -18,7 +18,7 @@ target_link_libraries(dq-actors-task_runner PUBLIC yql-dq-runtime yql-dq-common yql-dq-proto - minikql-computation-llvm + yql-minikql-computation yql-utils-actors ydb-library-services ) diff --git a/ydb/library/yql/dq/common/CMakeLists.darwin-arm64.txt b/ydb/library/yql/dq/common/CMakeLists.darwin-arm64.txt index b2e012b9b9e5..4218b550f0a9 100644 --- a/ydb/library/yql/dq/common/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/dq/common/CMakeLists.darwin-arm64.txt @@ -25,6 +25,7 @@ target_link_libraries(yql-dq-common PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(yql-dq-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/common/dq_resource_quoter.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/common/dq_common.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/common/dq_value.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/common/dq_serialized_batch.cpp diff --git a/ydb/library/yql/dq/common/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/dq/common/CMakeLists.darwin-x86_64.txt index b2e012b9b9e5..4218b550f0a9 100644 --- a/ydb/library/yql/dq/common/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/dq/common/CMakeLists.darwin-x86_64.txt @@ -25,6 +25,7 @@ target_link_libraries(yql-dq-common PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(yql-dq-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/common/dq_resource_quoter.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/common/dq_common.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/common/dq_value.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/common/dq_serialized_batch.cpp diff --git a/ydb/library/yql/dq/common/CMakeLists.linux-aarch64.txt b/ydb/library/yql/dq/common/CMakeLists.linux-aarch64.txt index c884eaf66eab..187cfe27afd9 100644 --- a/ydb/library/yql/dq/common/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/dq/common/CMakeLists.linux-aarch64.txt @@ -26,6 +26,7 @@ target_link_libraries(yql-dq-common PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(yql-dq-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/common/dq_resource_quoter.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/common/dq_common.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/common/dq_value.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/common/dq_serialized_batch.cpp diff --git a/ydb/library/yql/dq/common/CMakeLists.linux-x86_64.txt b/ydb/library/yql/dq/common/CMakeLists.linux-x86_64.txt index c884eaf66eab..187cfe27afd9 100644 --- a/ydb/library/yql/dq/common/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/dq/common/CMakeLists.linux-x86_64.txt @@ -26,6 +26,7 @@ target_link_libraries(yql-dq-common PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(yql-dq-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/common/dq_resource_quoter.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/common/dq_common.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/common/dq_value.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/common/dq_serialized_batch.cpp diff --git a/ydb/library/yql/dq/common/CMakeLists.windows-x86_64.txt b/ydb/library/yql/dq/common/CMakeLists.windows-x86_64.txt index b2e012b9b9e5..4218b550f0a9 100644 --- a/ydb/library/yql/dq/common/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/dq/common/CMakeLists.windows-x86_64.txt @@ -25,6 +25,7 @@ target_link_libraries(yql-dq-common PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(yql-dq-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/common/dq_resource_quoter.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/common/dq_common.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/common/dq_value.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/common/dq_serialized_batch.cpp diff --git a/ydb/library/yql/dq/comp_nodes/CMakeLists.darwin-arm64.txt b/ydb/library/yql/dq/comp_nodes/CMakeLists.darwin-arm64.txt index 8f8d5acd6021..191c9c835777 100644 --- a/ydb/library/yql/dq/comp_nodes/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/dq/comp_nodes/CMakeLists.darwin-arm64.txt @@ -16,7 +16,7 @@ target_link_libraries(yql-dq-comp_nodes PUBLIC yutil library-actors-core dq-actors-compute - minikql-computation-llvm + yql-minikql-computation library-yql-utils ) target_sources(yql-dq-comp_nodes PRIVATE diff --git a/ydb/library/yql/dq/comp_nodes/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/dq/comp_nodes/CMakeLists.darwin-x86_64.txt index 8f8d5acd6021..191c9c835777 100644 --- a/ydb/library/yql/dq/comp_nodes/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/dq/comp_nodes/CMakeLists.darwin-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(yql-dq-comp_nodes PUBLIC yutil library-actors-core dq-actors-compute - minikql-computation-llvm + yql-minikql-computation library-yql-utils ) target_sources(yql-dq-comp_nodes PRIVATE diff --git a/ydb/library/yql/dq/comp_nodes/CMakeLists.linux-aarch64.txt b/ydb/library/yql/dq/comp_nodes/CMakeLists.linux-aarch64.txt index 52bbbf0e046c..a1da8e4b9f06 100644 --- a/ydb/library/yql/dq/comp_nodes/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/dq/comp_nodes/CMakeLists.linux-aarch64.txt @@ -17,7 +17,7 @@ target_link_libraries(yql-dq-comp_nodes PUBLIC yutil library-actors-core dq-actors-compute - minikql-computation-llvm + yql-minikql-computation library-yql-utils ) target_sources(yql-dq-comp_nodes PRIVATE diff --git a/ydb/library/yql/dq/comp_nodes/CMakeLists.linux-x86_64.txt b/ydb/library/yql/dq/comp_nodes/CMakeLists.linux-x86_64.txt index 52bbbf0e046c..a1da8e4b9f06 100644 --- a/ydb/library/yql/dq/comp_nodes/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/dq/comp_nodes/CMakeLists.linux-x86_64.txt @@ -17,7 +17,7 @@ target_link_libraries(yql-dq-comp_nodes PUBLIC yutil library-actors-core dq-actors-compute - minikql-computation-llvm + yql-minikql-computation library-yql-utils ) target_sources(yql-dq-comp_nodes PRIVATE diff --git a/ydb/library/yql/dq/comp_nodes/CMakeLists.windows-x86_64.txt b/ydb/library/yql/dq/comp_nodes/CMakeLists.windows-x86_64.txt index 8f8d5acd6021..191c9c835777 100644 --- a/ydb/library/yql/dq/comp_nodes/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/dq/comp_nodes/CMakeLists.windows-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(yql-dq-comp_nodes PUBLIC yutil library-actors-core dq-actors-compute - minikql-computation-llvm + yql-minikql-computation library-yql-utils ) target_sources(yql-dq-comp_nodes PRIVATE diff --git a/ydb/library/yql/dq/expr_nodes/CMakeLists.darwin-arm64.txt b/ydb/library/yql/dq/expr_nodes/CMakeLists.darwin-arm64.txt index d81b9b9d6904..e7d16fb66831 100644 --- a/ydb/library/yql/dq/expr_nodes/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/dq/expr_nodes/CMakeLists.darwin-arm64.txt @@ -21,6 +21,10 @@ target_sources(yql-dq-expr_nodes PRIVATE ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.decl.inl.h ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.defs.inl.h ) add_custom_command( OUTPUT diff --git a/ydb/library/yql/dq/expr_nodes/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/dq/expr_nodes/CMakeLists.darwin-x86_64.txt index d81b9b9d6904..e7d16fb66831 100644 --- a/ydb/library/yql/dq/expr_nodes/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/dq/expr_nodes/CMakeLists.darwin-x86_64.txt @@ -21,6 +21,10 @@ target_sources(yql-dq-expr_nodes PRIVATE ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.decl.inl.h ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.defs.inl.h ) add_custom_command( OUTPUT diff --git a/ydb/library/yql/dq/expr_nodes/CMakeLists.linux-aarch64.txt b/ydb/library/yql/dq/expr_nodes/CMakeLists.linux-aarch64.txt index 2f618c2bd20f..0fadeb467bef 100644 --- a/ydb/library/yql/dq/expr_nodes/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/dq/expr_nodes/CMakeLists.linux-aarch64.txt @@ -22,6 +22,10 @@ target_sources(yql-dq-expr_nodes PRIVATE ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.decl.inl.h ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.defs.inl.h ) add_custom_command( OUTPUT diff --git a/ydb/library/yql/dq/expr_nodes/CMakeLists.linux-x86_64.txt b/ydb/library/yql/dq/expr_nodes/CMakeLists.linux-x86_64.txt index 2f618c2bd20f..0fadeb467bef 100644 --- a/ydb/library/yql/dq/expr_nodes/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/dq/expr_nodes/CMakeLists.linux-x86_64.txt @@ -22,6 +22,10 @@ target_sources(yql-dq-expr_nodes PRIVATE ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.decl.inl.h ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.defs.inl.h ) add_custom_command( OUTPUT diff --git a/ydb/library/yql/dq/expr_nodes/CMakeLists.windows-x86_64.txt b/ydb/library/yql/dq/expr_nodes/CMakeLists.windows-x86_64.txt index d81b9b9d6904..e7d16fb66831 100644 --- a/ydb/library/yql/dq/expr_nodes/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/dq/expr_nodes/CMakeLists.windows-x86_64.txt @@ -21,6 +21,10 @@ target_sources(yql-dq-expr_nodes PRIVATE ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.decl.inl.h ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/expr_nodes/dq_expr_nodes.defs.inl.h ) add_custom_command( OUTPUT diff --git a/ydb/library/yql/dq/opt/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/dq/opt/ut/CMakeLists.darwin-arm64.txt index 0a7f35da124a..42686752c339 100644 --- a/ydb/library/yql/dq/opt/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/dq/opt/ut/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-library-yql-dq-opt-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-dq-opt-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/opt/dq_cbo_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/opt/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/dq/opt/ut/CMakeLists.darwin-x86_64.txt index 692c17ce3d07..b8b4a8828616 100644 --- a/ydb/library/yql/dq/opt/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/dq/opt/ut/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-library-yql-dq-opt-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-dq-opt-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/opt/dq_cbo_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/opt/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/dq/opt/ut/CMakeLists.linux-aarch64.txt index 07b6d1728abf..56bc8cf69248 100644 --- a/ydb/library/yql/dq/opt/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/dq/opt/ut/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-library-yql-dq-opt-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-dq-opt-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/opt/dq_cbo_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/opt/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/dq/opt/ut/CMakeLists.linux-x86_64.txt index 93b94a42a7c4..2ac280e9fb2d 100644 --- a/ydb/library/yql/dq/opt/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/dq/opt/ut/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-library-yql-dq-opt-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-dq-opt-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/opt/dq_cbo_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/opt/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/dq/opt/ut/CMakeLists.windows-x86_64.txt index b024a91e9858..5d120ad27fdb 100644 --- a/ydb/library/yql/dq/opt/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/dq/opt/ut/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/proto/CMakeLists.darwin-arm64.txt b/ydb/library/yql/dq/proto/CMakeLists.darwin-arm64.txt index c186b980f875..f7cd95a51c50 100644 --- a/ydb/library/yql/dq/proto/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/dq/proto/CMakeLists.darwin-arm64.txt @@ -68,6 +68,12 @@ target_proto_messages(yql-dq-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/proto/dq_tasks.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/proto/dq_transport.proto ) +target_sources(yql-dq-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/proto/dq_checkpoint.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/proto/dq_state_load_plan.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/proto/dq_tasks.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/proto/dq_transport.pb.h +) target_proto_addincls(yql-dq-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/dq/proto/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/dq/proto/CMakeLists.darwin-x86_64.txt index c186b980f875..f7cd95a51c50 100644 --- a/ydb/library/yql/dq/proto/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/dq/proto/CMakeLists.darwin-x86_64.txt @@ -68,6 +68,12 @@ target_proto_messages(yql-dq-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/proto/dq_tasks.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/proto/dq_transport.proto ) +target_sources(yql-dq-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/proto/dq_checkpoint.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/proto/dq_state_load_plan.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/proto/dq_tasks.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/proto/dq_transport.pb.h +) target_proto_addincls(yql-dq-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/dq/proto/CMakeLists.linux-aarch64.txt b/ydb/library/yql/dq/proto/CMakeLists.linux-aarch64.txt index 83444232de28..a57f7c5381ba 100644 --- a/ydb/library/yql/dq/proto/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/dq/proto/CMakeLists.linux-aarch64.txt @@ -69,6 +69,12 @@ target_proto_messages(yql-dq-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/proto/dq_tasks.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/proto/dq_transport.proto ) +target_sources(yql-dq-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/proto/dq_checkpoint.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/proto/dq_state_load_plan.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/proto/dq_tasks.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/proto/dq_transport.pb.h +) target_proto_addincls(yql-dq-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/dq/proto/CMakeLists.linux-x86_64.txt b/ydb/library/yql/dq/proto/CMakeLists.linux-x86_64.txt index 83444232de28..a57f7c5381ba 100644 --- a/ydb/library/yql/dq/proto/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/dq/proto/CMakeLists.linux-x86_64.txt @@ -69,6 +69,12 @@ target_proto_messages(yql-dq-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/proto/dq_tasks.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/proto/dq_transport.proto ) +target_sources(yql-dq-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/proto/dq_checkpoint.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/proto/dq_state_load_plan.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/proto/dq_tasks.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/proto/dq_transport.pb.h +) target_proto_addincls(yql-dq-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/dq/proto/CMakeLists.windows-x86_64.txt b/ydb/library/yql/dq/proto/CMakeLists.windows-x86_64.txt index c186b980f875..f7cd95a51c50 100644 --- a/ydb/library/yql/dq/proto/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/dq/proto/CMakeLists.windows-x86_64.txt @@ -68,6 +68,12 @@ target_proto_messages(yql-dq-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/proto/dq_tasks.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/proto/dq_transport.proto ) +target_sources(yql-dq-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/proto/dq_checkpoint.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/proto/dq_state_load_plan.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/proto/dq_tasks.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/dq/proto/dq_transport.pb.h +) target_proto_addincls(yql-dq-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/dq/runtime/CMakeLists.darwin-arm64.txt b/ydb/library/yql/dq/runtime/CMakeLists.darwin-arm64.txt index 73291cdd0510..6bf5756e622d 100644 --- a/ydb/library/yql/dq/runtime/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/dq/runtime/CMakeLists.darwin-arm64.txt @@ -24,7 +24,7 @@ target_link_libraries(yql-dq-runtime PUBLIC libs-apache-arrow ydb-library-yverify_stream ydb-library-mkql_proto - minikql-comp_nodes-llvm + yql-minikql-comp_nodes parser-pg_wrapper-interface yql-public-udf dq-actors-protos diff --git a/ydb/library/yql/dq/runtime/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/dq/runtime/CMakeLists.darwin-x86_64.txt index 73291cdd0510..6bf5756e622d 100644 --- a/ydb/library/yql/dq/runtime/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/dq/runtime/CMakeLists.darwin-x86_64.txt @@ -24,7 +24,7 @@ target_link_libraries(yql-dq-runtime PUBLIC libs-apache-arrow ydb-library-yverify_stream ydb-library-mkql_proto - minikql-comp_nodes-llvm + yql-minikql-comp_nodes parser-pg_wrapper-interface yql-public-udf dq-actors-protos diff --git a/ydb/library/yql/dq/runtime/CMakeLists.linux-aarch64.txt b/ydb/library/yql/dq/runtime/CMakeLists.linux-aarch64.txt index b92bafba8a05..1e697633e6eb 100644 --- a/ydb/library/yql/dq/runtime/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/dq/runtime/CMakeLists.linux-aarch64.txt @@ -25,7 +25,7 @@ target_link_libraries(yql-dq-runtime PUBLIC libs-apache-arrow ydb-library-yverify_stream ydb-library-mkql_proto - minikql-comp_nodes-llvm + yql-minikql-comp_nodes parser-pg_wrapper-interface yql-public-udf dq-actors-protos diff --git a/ydb/library/yql/dq/runtime/CMakeLists.linux-x86_64.txt b/ydb/library/yql/dq/runtime/CMakeLists.linux-x86_64.txt index b92bafba8a05..1e697633e6eb 100644 --- a/ydb/library/yql/dq/runtime/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/dq/runtime/CMakeLists.linux-x86_64.txt @@ -25,7 +25,7 @@ target_link_libraries(yql-dq-runtime PUBLIC libs-apache-arrow ydb-library-yverify_stream ydb-library-mkql_proto - minikql-comp_nodes-llvm + yql-minikql-comp_nodes parser-pg_wrapper-interface yql-public-udf dq-actors-protos diff --git a/ydb/library/yql/dq/runtime/CMakeLists.windows-x86_64.txt b/ydb/library/yql/dq/runtime/CMakeLists.windows-x86_64.txt index 73291cdd0510..6bf5756e622d 100644 --- a/ydb/library/yql/dq/runtime/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/dq/runtime/CMakeLists.windows-x86_64.txt @@ -24,7 +24,7 @@ target_link_libraries(yql-dq-runtime PUBLIC libs-apache-arrow ydb-library-yverify_stream ydb-library-mkql_proto - minikql-comp_nodes-llvm + yql-minikql-comp_nodes parser-pg_wrapper-interface yql-public-udf dq-actors-protos diff --git a/ydb/library/yql/dq/runtime/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/dq/runtime/ut/CMakeLists.darwin-arm64.txt index ae3fff8b8917..4f4b10a83806 100644 --- a/ydb/library/yql/dq/runtime/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/dq/runtime/ut/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-library-yql-dq-runtime-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-dq-runtime-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/runtime/dq_arrow_helpers_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/runtime/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/dq/runtime/ut/CMakeLists.darwin-x86_64.txt index 8b442c978b56..4b443b22b22b 100644 --- a/ydb/library/yql/dq/runtime/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/dq/runtime/ut/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-library-yql-dq-runtime-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-dq-runtime-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/runtime/dq_arrow_helpers_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/runtime/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/dq/runtime/ut/CMakeLists.linux-aarch64.txt index fcf0bf185c4a..dfc2cce11cb5 100644 --- a/ydb/library/yql/dq/runtime/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/dq/runtime/ut/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-library-yql-dq-runtime-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-dq-runtime-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/runtime/dq_arrow_helpers_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/runtime/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/dq/runtime/ut/CMakeLists.linux-x86_64.txt index 44b0a77bf272..cb5b639f421e 100644 --- a/ydb/library/yql/dq/runtime/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/dq/runtime/ut/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-library-yql-dq-runtime-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-dq-runtime-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/runtime/dq_arrow_helpers_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/runtime/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/dq/runtime/ut/CMakeLists.windows-x86_64.txt index 818b387e26dc..cc6b415c0177 100644 --- a/ydb/library/yql/dq/runtime/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/dq/runtime/ut/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/state/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/dq/state/ut/CMakeLists.darwin-arm64.txt index 1e72b3b74f5b..3ce6ef92a8a2 100644 --- a/ydb/library/yql/dq/state/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/dq/state/ut/CMakeLists.darwin-arm64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-library-yql-dq-state-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-dq-state-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/state/ut/dq_state_load_plan_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/state/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/dq/state/ut/CMakeLists.darwin-x86_64.txt index 68592dfce43f..298c90e8509c 100644 --- a/ydb/library/yql/dq/state/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/dq/state/ut/CMakeLists.darwin-x86_64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-library-yql-dq-state-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-dq-state-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/state/ut/dq_state_load_plan_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/state/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/dq/state/ut/CMakeLists.linux-aarch64.txt index 7896f185e772..b99b9eed7989 100644 --- a/ydb/library/yql/dq/state/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/dq/state/ut/CMakeLists.linux-aarch64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-library-yql-dq-state-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-dq-state-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/state/ut/dq_state_load_plan_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/state/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/dq/state/ut/CMakeLists.linux-x86_64.txt index dbc040cc6476..1964a88e2677 100644 --- a/ydb/library/yql/dq/state/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/dq/state/ut/CMakeLists.linux-x86_64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-library-yql-dq-state-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-dq-state-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/dq/state/ut/dq_state_load_plan_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/state/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/dq/state/ut/CMakeLists.windows-x86_64.txt index c5621bd199c7..26e9b3986f95 100644 --- a/ydb/library/yql/dq/state/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/dq/state/ut/CMakeLists.windows-x86_64.txt @@ -49,6 +49,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/dq/transform/CMakeLists.darwin-arm64.txt b/ydb/library/yql/dq/transform/CMakeLists.darwin-arm64.txt index c95225936df7..de72a077e7ba 100644 --- a/ydb/library/yql/dq/transform/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/dq/transform/CMakeLists.darwin-arm64.txt @@ -16,7 +16,7 @@ target_link_libraries(yql-dq-transform PUBLIC yutil library-actors-core dq-integration-transform - minikql-computation-llvm + yql-minikql-computation library-yql-utils ) target_sources(yql-dq-transform PRIVATE diff --git a/ydb/library/yql/dq/transform/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/dq/transform/CMakeLists.darwin-x86_64.txt index c95225936df7..de72a077e7ba 100644 --- a/ydb/library/yql/dq/transform/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/dq/transform/CMakeLists.darwin-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(yql-dq-transform PUBLIC yutil library-actors-core dq-integration-transform - minikql-computation-llvm + yql-minikql-computation library-yql-utils ) target_sources(yql-dq-transform PRIVATE diff --git a/ydb/library/yql/dq/transform/CMakeLists.linux-aarch64.txt b/ydb/library/yql/dq/transform/CMakeLists.linux-aarch64.txt index 0a649727a46e..8c5aba692ae7 100644 --- a/ydb/library/yql/dq/transform/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/dq/transform/CMakeLists.linux-aarch64.txt @@ -17,7 +17,7 @@ target_link_libraries(yql-dq-transform PUBLIC yutil library-actors-core dq-integration-transform - minikql-computation-llvm + yql-minikql-computation library-yql-utils ) target_sources(yql-dq-transform PRIVATE diff --git a/ydb/library/yql/dq/transform/CMakeLists.linux-x86_64.txt b/ydb/library/yql/dq/transform/CMakeLists.linux-x86_64.txt index 0a649727a46e..8c5aba692ae7 100644 --- a/ydb/library/yql/dq/transform/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/dq/transform/CMakeLists.linux-x86_64.txt @@ -17,7 +17,7 @@ target_link_libraries(yql-dq-transform PUBLIC yutil library-actors-core dq-integration-transform - minikql-computation-llvm + yql-minikql-computation library-yql-utils ) target_sources(yql-dq-transform PRIVATE diff --git a/ydb/library/yql/dq/transform/CMakeLists.windows-x86_64.txt b/ydb/library/yql/dq/transform/CMakeLists.windows-x86_64.txt index c95225936df7..de72a077e7ba 100644 --- a/ydb/library/yql/dq/transform/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/dq/transform/CMakeLists.windows-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(yql-dq-transform PUBLIC yutil library-actors-core dq-integration-transform - minikql-computation-llvm + yql-minikql-computation library-yql-utils ) target_sources(yql-dq-transform PRIVATE diff --git a/ydb/library/yql/minikql/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/CMakeLists.darwin-arm64.txt index 80c4f99c0153..57c1508ea08f 100644 --- a/ydb/library/yql/minikql/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/CMakeLists.darwin-arm64.txt @@ -48,6 +48,30 @@ target_link_libraries(library-yql-minikql PUBLIC public-lib-scheme_types ) target_sources(library-yql-minikql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/aligned_page_pool.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/compact_hash.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_buffer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_function_metadata.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_function_registry.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_cast.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_printer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_serialization.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_visitor.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_opt_literal.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_program_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_runtime_version.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_string_util.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_terminator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_type_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_type_ops.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_watermark.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_unboxed_value_stream.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/pack_num.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/primes.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/watermark_tracker.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/aligned_page_pool.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/compact_hash.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_alloc.cpp diff --git a/ydb/library/yql/minikql/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/CMakeLists.darwin-x86_64.txt index 80c4f99c0153..57c1508ea08f 100644 --- a/ydb/library/yql/minikql/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/CMakeLists.darwin-x86_64.txt @@ -48,6 +48,30 @@ target_link_libraries(library-yql-minikql PUBLIC public-lib-scheme_types ) target_sources(library-yql-minikql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/aligned_page_pool.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/compact_hash.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_buffer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_function_metadata.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_function_registry.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_cast.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_printer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_serialization.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_visitor.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_opt_literal.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_program_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_runtime_version.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_string_util.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_terminator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_type_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_type_ops.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_watermark.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_unboxed_value_stream.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/pack_num.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/primes.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/watermark_tracker.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/aligned_page_pool.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/compact_hash.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_alloc.cpp diff --git a/ydb/library/yql/minikql/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/CMakeLists.linux-aarch64.txt index b9f012a26fd4..77940a5889ae 100644 --- a/ydb/library/yql/minikql/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/CMakeLists.linux-aarch64.txt @@ -49,6 +49,30 @@ target_link_libraries(library-yql-minikql PUBLIC public-lib-scheme_types ) target_sources(library-yql-minikql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/aligned_page_pool.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/compact_hash.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_buffer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_function_metadata.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_function_registry.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_cast.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_printer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_serialization.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_visitor.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_opt_literal.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_program_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_runtime_version.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_string_util.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_terminator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_type_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_type_ops.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_watermark.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_unboxed_value_stream.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/pack_num.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/primes.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/watermark_tracker.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/aligned_page_pool.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/compact_hash.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_alloc.cpp diff --git a/ydb/library/yql/minikql/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/CMakeLists.linux-x86_64.txt index b9f012a26fd4..77940a5889ae 100644 --- a/ydb/library/yql/minikql/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/CMakeLists.linux-x86_64.txt @@ -49,6 +49,30 @@ target_link_libraries(library-yql-minikql PUBLIC public-lib-scheme_types ) target_sources(library-yql-minikql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/aligned_page_pool.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/compact_hash.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_buffer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_function_metadata.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_function_registry.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_cast.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_printer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_serialization.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_visitor.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_opt_literal.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_program_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_runtime_version.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_string_util.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_terminator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_type_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_type_ops.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_watermark.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_unboxed_value_stream.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/pack_num.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/primes.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/watermark_tracker.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/aligned_page_pool.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/compact_hash.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_alloc.cpp diff --git a/ydb/library/yql/minikql/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/CMakeLists.windows-x86_64.txt index 80c4f99c0153..57c1508ea08f 100644 --- a/ydb/library/yql/minikql/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/minikql/CMakeLists.windows-x86_64.txt @@ -48,6 +48,30 @@ target_link_libraries(library-yql-minikql PUBLIC public-lib-scheme_types ) target_sources(library-yql-minikql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/aligned_page_pool.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/compact_hash.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/defs.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_buffer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_function_metadata.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_function_registry.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_cast.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_printer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_serialization.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_node_visitor.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_opt_literal.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_program_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_runtime_version.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_string_util.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_terminator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_type_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_type_ops.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_watermark.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_unboxed_value_stream.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/pack_num.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/primes.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/watermark_tracker.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/aligned_page_pool.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/compact_hash.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/mkql_alloc.cpp diff --git a/ydb/library/yql/minikql/arrow/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/arrow/ut/CMakeLists.darwin-arm64.txt index 1b3f2b2ff92e..7faba0fc81bc 100644 --- a/ydb/library/yql/minikql/arrow/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/arrow/ut/CMakeLists.darwin-arm64.txt @@ -22,14 +22,12 @@ target_link_libraries(ydb-library-yql-minikql-arrow-ut PUBLIC yql-public-udf udf-service-exception_policy yql-sql-pg_dummy - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 ) target_link_options(ydb-library-yql-minikql-arrow-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-minikql-arrow-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/arrow/mkql_functions_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/arrow/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/arrow/ut/CMakeLists.darwin-x86_64.txt index 245ab8c1813d..28afac4ac741 100644 --- a/ydb/library/yql/minikql/arrow/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/arrow/ut/CMakeLists.darwin-x86_64.txt @@ -23,14 +23,12 @@ target_link_libraries(ydb-library-yql-minikql-arrow-ut PUBLIC yql-public-udf udf-service-exception_policy yql-sql-pg_dummy - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 ) target_link_options(ydb-library-yql-minikql-arrow-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-minikql-arrow-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/arrow/mkql_functions_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/arrow/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/arrow/ut/CMakeLists.linux-aarch64.txt index 719f38573938..6f0dba6e8516 100644 --- a/ydb/library/yql/minikql/arrow/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/arrow/ut/CMakeLists.linux-aarch64.txt @@ -23,7 +23,7 @@ target_link_libraries(ydb-library-yql-minikql-arrow-ut PUBLIC yql-public-udf udf-service-exception_policy yql-sql-pg_dummy - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 ) target_link_options(ydb-library-yql-minikql-arrow-ut PRIVATE -ldl @@ -31,9 +31,6 @@ target_link_options(ydb-library-yql-minikql-arrow-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-minikql-arrow-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/arrow/mkql_functions_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/arrow/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/arrow/ut/CMakeLists.linux-x86_64.txt index d5e533c7bd52..465e6e4861ea 100644 --- a/ydb/library/yql/minikql/arrow/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/arrow/ut/CMakeLists.linux-x86_64.txt @@ -24,7 +24,7 @@ target_link_libraries(ydb-library-yql-minikql-arrow-ut PUBLIC yql-public-udf udf-service-exception_policy yql-sql-pg_dummy - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 ) target_link_options(ydb-library-yql-minikql-arrow-ut PRIVATE -ldl @@ -32,9 +32,6 @@ target_link_options(ydb-library-yql-minikql-arrow-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-minikql-arrow-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/arrow/mkql_functions_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/arrow/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/arrow/ut/CMakeLists.windows-x86_64.txt index 55cf43ffb113..c7e4d8ab99f0 100644 --- a/ydb/library/yql/minikql/arrow/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/minikql/arrow/ut/CMakeLists.windows-x86_64.txt @@ -23,7 +23,7 @@ target_link_libraries(ydb-library-yql-minikql-arrow-ut PUBLIC yql-public-udf udf-service-exception_policy yql-sql-pg_dummy - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 ) target_sources(ydb-library-yql-minikql-arrow-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/arrow/mkql_functions_ut.cpp @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/benchmark/pack_num/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/benchmark/pack_num/CMakeLists.darwin-arm64.txt index e35d174b82dd..78647abad81c 100644 --- a/ydb/library/yql/minikql/benchmark/pack_num/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/benchmark/pack_num/CMakeLists.darwin-arm64.txt @@ -19,8 +19,6 @@ target_link_options(pack_num PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(pack_num PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/benchmark/pack_num/pack.cpp diff --git a/ydb/library/yql/minikql/benchmark/pack_num/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/benchmark/pack_num/CMakeLists.darwin-x86_64.txt index 0e2991b9aeb7..7edab544e202 100644 --- a/ydb/library/yql/minikql/benchmark/pack_num/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/benchmark/pack_num/CMakeLists.darwin-x86_64.txt @@ -20,8 +20,6 @@ target_link_options(pack_num PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(pack_num PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/benchmark/pack_num/pack.cpp diff --git a/ydb/library/yql/minikql/benchmark/pack_num/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/benchmark/pack_num/CMakeLists.linux-aarch64.txt index 8689949aac33..ea9d4a3cad4d 100644 --- a/ydb/library/yql/minikql/benchmark/pack_num/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/benchmark/pack_num/CMakeLists.linux-aarch64.txt @@ -22,9 +22,6 @@ target_link_options(pack_num PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(pack_num PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/benchmark/pack_num/pack.cpp diff --git a/ydb/library/yql/minikql/benchmark/pack_num/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/benchmark/pack_num/CMakeLists.linux-x86_64.txt index c13a87236043..d4fc578a3eb6 100644 --- a/ydb/library/yql/minikql/benchmark/pack_num/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/benchmark/pack_num/CMakeLists.linux-x86_64.txt @@ -23,9 +23,6 @@ target_link_options(pack_num PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(pack_num PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/benchmark/pack_num/pack.cpp diff --git a/ydb/library/yql/minikql/codegen/CMakeLists.txt b/ydb/library/yql/minikql/codegen/CMakeLists.txt index d863ebd18067..a76928d6bb44 100644 --- a/ydb/library/yql/minikql/codegen/CMakeLists.txt +++ b/ydb/library/yql/minikql/codegen/CMakeLists.txt @@ -6,14 +6,6 @@ # original buildsystem will not be accepted. -if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) - include(CMakeLists.linux-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) - include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) -endif() +add_subdirectory(llvm) +add_subdirectory(llvm14) +add_subdirectory(no_llvm) diff --git a/ydb/library/yql/minikql/codegen/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/codegen/llvm/CMakeLists.darwin-arm64.txt similarity index 51% rename from ydb/library/yql/minikql/codegen/CMakeLists.darwin-arm64.txt rename to ydb/library/yql/minikql/codegen/llvm/CMakeLists.darwin-arm64.txt index 377a730d286a..e241474379a8 100644 --- a/ydb/library/yql/minikql/codegen/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/codegen/llvm/CMakeLists.darwin-arm64.txt @@ -8,15 +8,14 @@ add_subdirectory(ut) -add_library(yql-minikql-codegen) -target_compile_options(yql-minikql-codegen PRIVATE - $,,-Wno-everything> +add_library(minikql-codegen-llvm) +target_include_directories(minikql-codegen-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen ) -target_link_libraries(yql-minikql-codegen PUBLIC +target_link_libraries(minikql-codegen-llvm PUBLIC contrib-libs-cxxsupp yutil - libs-cxxsupp-builtins - contrib-libs-re2 llvm12-lib-IR lib-ExecutionEngine-MCJIT llvm12-lib-Linker @@ -25,7 +24,18 @@ target_link_libraries(yql-minikql-codegen PUBLIC Target-X86-Disassembler lib-Transforms-IPO lib-Transforms-ObjCARC + libs-cxxsupp-builtins + contrib-libs-re2 +) +target_sources(minikql-codegen-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/codegen_llvm_deps.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/codegen.cpp +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_llvm_deps.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/codegen_llvm_deps.h ) -target_sources(yql-minikql-codegen PRIVATE +copy_file( ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/codegen.cpp ) diff --git a/ydb/library/yql/minikql/codegen/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/codegen/llvm/CMakeLists.darwin-x86_64.txt similarity index 51% rename from ydb/library/yql/minikql/codegen/CMakeLists.darwin-x86_64.txt rename to ydb/library/yql/minikql/codegen/llvm/CMakeLists.darwin-x86_64.txt index 377a730d286a..e241474379a8 100644 --- a/ydb/library/yql/minikql/codegen/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/codegen/llvm/CMakeLists.darwin-x86_64.txt @@ -8,15 +8,14 @@ add_subdirectory(ut) -add_library(yql-minikql-codegen) -target_compile_options(yql-minikql-codegen PRIVATE - $,,-Wno-everything> +add_library(minikql-codegen-llvm) +target_include_directories(minikql-codegen-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen ) -target_link_libraries(yql-minikql-codegen PUBLIC +target_link_libraries(minikql-codegen-llvm PUBLIC contrib-libs-cxxsupp yutil - libs-cxxsupp-builtins - contrib-libs-re2 llvm12-lib-IR lib-ExecutionEngine-MCJIT llvm12-lib-Linker @@ -25,7 +24,18 @@ target_link_libraries(yql-minikql-codegen PUBLIC Target-X86-Disassembler lib-Transforms-IPO lib-Transforms-ObjCARC + libs-cxxsupp-builtins + contrib-libs-re2 +) +target_sources(minikql-codegen-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/codegen_llvm_deps.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/codegen.cpp +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_llvm_deps.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/codegen_llvm_deps.h ) -target_sources(yql-minikql-codegen PRIVATE +copy_file( ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/codegen.cpp ) diff --git a/ydb/library/yql/minikql/codegen/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/codegen/llvm/CMakeLists.linux-aarch64.txt similarity index 53% rename from ydb/library/yql/minikql/codegen/CMakeLists.linux-aarch64.txt rename to ydb/library/yql/minikql/codegen/llvm/CMakeLists.linux-aarch64.txt index 6a23884af5a9..71b083074f2d 100644 --- a/ydb/library/yql/minikql/codegen/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/codegen/llvm/CMakeLists.linux-aarch64.txt @@ -8,16 +8,15 @@ add_subdirectory(ut) -add_library(yql-minikql-codegen) -target_compile_options(yql-minikql-codegen PRIVATE - $,,-Wno-everything> +add_library(minikql-codegen-llvm) +target_include_directories(minikql-codegen-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen ) -target_link_libraries(yql-minikql-codegen PUBLIC +target_link_libraries(minikql-codegen-llvm PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - libs-cxxsupp-builtins - contrib-libs-re2 llvm12-lib-IR lib-ExecutionEngine-MCJIT llvm12-lib-Linker @@ -27,7 +26,18 @@ target_link_libraries(yql-minikql-codegen PUBLIC lib-Transforms-IPO lib-Transforms-ObjCARC lib-ExecutionEngine-PerfJITEvents + libs-cxxsupp-builtins + contrib-libs-re2 +) +target_sources(minikql-codegen-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/codegen_llvm_deps.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/codegen.cpp +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_llvm_deps.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/codegen_llvm_deps.h ) -target_sources(yql-minikql-codegen PRIVATE +copy_file( ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/codegen.cpp ) diff --git a/ydb/library/yql/minikql/codegen/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/codegen/llvm/CMakeLists.linux-x86_64.txt similarity index 53% rename from ydb/library/yql/minikql/codegen/CMakeLists.linux-x86_64.txt rename to ydb/library/yql/minikql/codegen/llvm/CMakeLists.linux-x86_64.txt index 6a23884af5a9..71b083074f2d 100644 --- a/ydb/library/yql/minikql/codegen/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/codegen/llvm/CMakeLists.linux-x86_64.txt @@ -8,16 +8,15 @@ add_subdirectory(ut) -add_library(yql-minikql-codegen) -target_compile_options(yql-minikql-codegen PRIVATE - $,,-Wno-everything> +add_library(minikql-codegen-llvm) +target_include_directories(minikql-codegen-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen ) -target_link_libraries(yql-minikql-codegen PUBLIC +target_link_libraries(minikql-codegen-llvm PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - libs-cxxsupp-builtins - contrib-libs-re2 llvm12-lib-IR lib-ExecutionEngine-MCJIT llvm12-lib-Linker @@ -27,7 +26,18 @@ target_link_libraries(yql-minikql-codegen PUBLIC lib-Transforms-IPO lib-Transforms-ObjCARC lib-ExecutionEngine-PerfJITEvents + libs-cxxsupp-builtins + contrib-libs-re2 +) +target_sources(minikql-codegen-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/codegen_llvm_deps.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/codegen.cpp +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_llvm_deps.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/codegen_llvm_deps.h ) -target_sources(yql-minikql-codegen PRIVATE +copy_file( ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/codegen.cpp ) diff --git a/ydb/library/yql/minikql/codegen/llvm/CMakeLists.txt b/ydb/library/yql/minikql/codegen/llvm/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/minikql/codegen/llvm/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/minikql/codegen/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/codegen/llvm/CMakeLists.windows-x86_64.txt similarity index 51% rename from ydb/library/yql/minikql/codegen/CMakeLists.windows-x86_64.txt rename to ydb/library/yql/minikql/codegen/llvm/CMakeLists.windows-x86_64.txt index 7fdb97049bc0..dcd37d84aaf9 100644 --- a/ydb/library/yql/minikql/codegen/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/minikql/codegen/llvm/CMakeLists.windows-x86_64.txt @@ -8,15 +8,14 @@ add_subdirectory(ut) -add_library(yql-minikql-codegen) -target_compile_options(yql-minikql-codegen PRIVATE - $,,-Wno-everything> +add_library(minikql-codegen-llvm) +target_include_directories(minikql-codegen-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen ) -target_link_libraries(yql-minikql-codegen PUBLIC +target_link_libraries(minikql-codegen-llvm PUBLIC contrib-libs-cxxsupp yutil - yql-public-decimal - contrib-libs-re2 llvm12-lib-IR lib-ExecutionEngine-MCJIT llvm12-lib-Linker @@ -25,7 +24,18 @@ target_link_libraries(yql-minikql-codegen PUBLIC Target-X86-Disassembler lib-Transforms-IPO lib-Transforms-ObjCARC + yql-public-decimal + contrib-libs-re2 +) +target_sources(minikql-codegen-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/codegen_llvm_deps.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/codegen.cpp +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_llvm_deps.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/codegen_llvm_deps.h ) -target_sources(yql-minikql-codegen PRIVATE +copy_file( ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/codegen.cpp ) diff --git a/ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..86685c436863 --- /dev/null +++ b/ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.darwin-arm64.txt @@ -0,0 +1,82 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-codegen-llvm-ut) +target_include_directories(ydb-library-yql-minikql-codegen-llvm-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut +) +target_link_libraries(ydb-library-yql-minikql-codegen-llvm-ut PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + Target-X86-Disassembler + lib-Transforms-IPO + lib-Transforms-ObjCARC + minikql-codegen-llvm +) +target_link_options(ydb-library-yql-minikql-codegen-llvm-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-codegen-llvm-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut/codegen_ut_llvm_deps.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut/codegen_ut.cpp +) +set_property( + TARGET + ydb-library-yql-minikql-codegen-llvm-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-minikql-codegen-llvm-ut + TEST_TARGET + ydb-library-yql-minikql-codegen-llvm-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-codegen-llvm-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-codegen-llvm-ut + PROPERTY + PROCESSORS + 1 +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_ut.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut/codegen_ut.cpp +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_ut_llvm_deps.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut/codegen_ut_llvm_deps.h +) +target_allocator(ydb-library-yql-minikql-codegen-llvm-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-codegen-llvm-ut) diff --git a/ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..4544c770a4f3 --- /dev/null +++ b/ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,83 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-codegen-llvm-ut) +target_include_directories(ydb-library-yql-minikql-codegen-llvm-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut +) +target_link_libraries(ydb-library-yql-minikql-codegen-llvm-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + Target-X86-Disassembler + lib-Transforms-IPO + lib-Transforms-ObjCARC + minikql-codegen-llvm +) +target_link_options(ydb-library-yql-minikql-codegen-llvm-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-codegen-llvm-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut/codegen_ut_llvm_deps.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut/codegen_ut.cpp +) +set_property( + TARGET + ydb-library-yql-minikql-codegen-llvm-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-minikql-codegen-llvm-ut + TEST_TARGET + ydb-library-yql-minikql-codegen-llvm-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-codegen-llvm-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-codegen-llvm-ut + PROPERTY + PROCESSORS + 1 +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_ut.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut/codegen_ut.cpp +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_ut_llvm_deps.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut/codegen_ut_llvm_deps.h +) +target_allocator(ydb-library-yql-minikql-codegen-llvm-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-codegen-llvm-ut) diff --git a/ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..53ceef668751 --- /dev/null +++ b/ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.linux-aarch64.txt @@ -0,0 +1,86 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-codegen-llvm-ut) +target_include_directories(ydb-library-yql-minikql-codegen-llvm-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut +) +target_link_libraries(ydb-library-yql-minikql-codegen-llvm-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + Target-X86-Disassembler + lib-Transforms-IPO + lib-Transforms-ObjCARC + lib-ExecutionEngine-PerfJITEvents + minikql-codegen-llvm +) +target_link_options(ydb-library-yql-minikql-codegen-llvm-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-codegen-llvm-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut/codegen_ut_llvm_deps.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut/codegen_ut.cpp +) +set_property( + TARGET + ydb-library-yql-minikql-codegen-llvm-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-minikql-codegen-llvm-ut + TEST_TARGET + ydb-library-yql-minikql-codegen-llvm-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-codegen-llvm-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-codegen-llvm-ut + PROPERTY + PROCESSORS + 1 +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_ut.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut/codegen_ut.cpp +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_ut_llvm_deps.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut/codegen_ut_llvm_deps.h +) +target_allocator(ydb-library-yql-minikql-codegen-llvm-ut + cpp-malloc-jemalloc +) +vcs_info(ydb-library-yql-minikql-codegen-llvm-ut) diff --git a/ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..e4ee4ab6a3d7 --- /dev/null +++ b/ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.linux-x86_64.txt @@ -0,0 +1,88 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-codegen-llvm-ut) +target_include_directories(ydb-library-yql-minikql-codegen-llvm-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut +) +target_link_libraries(ydb-library-yql-minikql-codegen-llvm-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + Target-X86-Disassembler + lib-Transforms-IPO + lib-Transforms-ObjCARC + lib-ExecutionEngine-PerfJITEvents + minikql-codegen-llvm +) +target_link_options(ydb-library-yql-minikql-codegen-llvm-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-codegen-llvm-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut/codegen_ut_llvm_deps.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut/codegen_ut.cpp +) +set_property( + TARGET + ydb-library-yql-minikql-codegen-llvm-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-minikql-codegen-llvm-ut + TEST_TARGET + ydb-library-yql-minikql-codegen-llvm-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-codegen-llvm-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-codegen-llvm-ut + PROPERTY + PROCESSORS + 1 +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_ut.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut/codegen_ut.cpp +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_ut_llvm_deps.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut/codegen_ut_llvm_deps.h +) +target_allocator(ydb-library-yql-minikql-codegen-llvm-ut + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(ydb-library-yql-minikql-codegen-llvm-ut) diff --git a/ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.txt b/ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..3ffef7b5bd09 --- /dev/null +++ b/ydb/library/yql/minikql/codegen/llvm/ut/CMakeLists.windows-x86_64.txt @@ -0,0 +1,78 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-codegen-llvm-ut) +target_include_directories(ydb-library-yql-minikql-codegen-llvm-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut +) +target_link_libraries(ydb-library-yql-minikql-codegen-llvm-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + Target-X86-Disassembler + lib-Transforms-IPO + lib-Transforms-ObjCARC + minikql-codegen-llvm +) +target_sources(ydb-library-yql-minikql-codegen-llvm-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut/codegen_ut_llvm_deps.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut/codegen_ut.cpp +) +set_property( + TARGET + ydb-library-yql-minikql-codegen-llvm-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-minikql-codegen-llvm-ut + TEST_TARGET + ydb-library-yql-minikql-codegen-llvm-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-codegen-llvm-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-codegen-llvm-ut + PROPERTY + PROCESSORS + 1 +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_ut.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut/codegen_ut.cpp +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_ut_llvm_deps.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm/ut/codegen_ut_llvm_deps.h +) +target_allocator(ydb-library-yql-minikql-codegen-llvm-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-codegen-llvm-ut) diff --git a/ydb/library/yql/minikql/codegen/llvm14/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/codegen/llvm14/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..d390a4b51126 --- /dev/null +++ b/ydb/library/yql/minikql/codegen/llvm14/CMakeLists.darwin-arm64.txt @@ -0,0 +1,41 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(minikql-codegen-llvm14) +target_include_directories(minikql-codegen-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14 + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen +) +target_link_libraries(minikql-codegen-llvm14 PUBLIC + contrib-libs-cxxsupp + yutil + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + Target-X86-Disassembler + lib-Transforms-IPO + lib-Transforms-ObjCARC + libs-cxxsupp-builtins + contrib-libs-re2 +) +target_sources(minikql-codegen-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/codegen_llvm_deps.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/codegen.cpp +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_llvm_deps.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/codegen_llvm_deps.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/codegen.cpp +) diff --git a/ydb/library/yql/minikql/codegen/llvm14/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/codegen/llvm14/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..d390a4b51126 --- /dev/null +++ b/ydb/library/yql/minikql/codegen/llvm14/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,41 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(minikql-codegen-llvm14) +target_include_directories(minikql-codegen-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14 + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen +) +target_link_libraries(minikql-codegen-llvm14 PUBLIC + contrib-libs-cxxsupp + yutil + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + Target-X86-Disassembler + lib-Transforms-IPO + lib-Transforms-ObjCARC + libs-cxxsupp-builtins + contrib-libs-re2 +) +target_sources(minikql-codegen-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/codegen_llvm_deps.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/codegen.cpp +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_llvm_deps.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/codegen_llvm_deps.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/codegen.cpp +) diff --git a/ydb/library/yql/minikql/codegen/llvm14/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/codegen/llvm14/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..9fb37b7db02d --- /dev/null +++ b/ydb/library/yql/minikql/codegen/llvm14/CMakeLists.linux-aarch64.txt @@ -0,0 +1,43 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(minikql-codegen-llvm14) +target_include_directories(minikql-codegen-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14 + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen +) +target_link_libraries(minikql-codegen-llvm14 PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + Target-X86-Disassembler + lib-Transforms-IPO + lib-Transforms-ObjCARC + lib-ExecutionEngine-PerfJITEvents + libs-cxxsupp-builtins + contrib-libs-re2 +) +target_sources(minikql-codegen-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/codegen_llvm_deps.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/codegen.cpp +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_llvm_deps.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/codegen_llvm_deps.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/codegen.cpp +) diff --git a/ydb/library/yql/minikql/codegen/llvm14/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/codegen/llvm14/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..9fb37b7db02d --- /dev/null +++ b/ydb/library/yql/minikql/codegen/llvm14/CMakeLists.linux-x86_64.txt @@ -0,0 +1,43 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(minikql-codegen-llvm14) +target_include_directories(minikql-codegen-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14 + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen +) +target_link_libraries(minikql-codegen-llvm14 PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + Target-X86-Disassembler + lib-Transforms-IPO + lib-Transforms-ObjCARC + lib-ExecutionEngine-PerfJITEvents + libs-cxxsupp-builtins + contrib-libs-re2 +) +target_sources(minikql-codegen-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/codegen_llvm_deps.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/codegen.cpp +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_llvm_deps.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/codegen_llvm_deps.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/codegen.cpp +) diff --git a/ydb/library/yql/minikql/codegen/llvm14/CMakeLists.txt b/ydb/library/yql/minikql/codegen/llvm14/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/minikql/codegen/llvm14/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/minikql/codegen/llvm14/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/codegen/llvm14/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..8980bdee22ca --- /dev/null +++ b/ydb/library/yql/minikql/codegen/llvm14/CMakeLists.windows-x86_64.txt @@ -0,0 +1,41 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(minikql-codegen-llvm14) +target_include_directories(minikql-codegen-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14 + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen +) +target_link_libraries(minikql-codegen-llvm14 PUBLIC + contrib-libs-cxxsupp + yutil + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + Target-X86-Disassembler + lib-Transforms-IPO + lib-Transforms-ObjCARC + yql-public-decimal + contrib-libs-re2 +) +target_sources(minikql-codegen-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/codegen_llvm_deps.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/codegen.cpp +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_llvm_deps.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/codegen_llvm_deps.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/codegen.cpp +) diff --git a/ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..828d561059c4 --- /dev/null +++ b/ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.darwin-arm64.txt @@ -0,0 +1,82 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-codegen-llvm14-ut) +target_include_directories(ydb-library-yql-minikql-codegen-llvm14-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut +) +target_link_libraries(ydb-library-yql-minikql-codegen-llvm14-ut PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + Target-X86-Disassembler + lib-Transforms-IPO + lib-Transforms-ObjCARC + minikql-codegen-llvm14 +) +target_link_options(ydb-library-yql-minikql-codegen-llvm14-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-codegen-llvm14-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut/codegen_ut_llvm_deps.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut/codegen_ut.cpp +) +set_property( + TARGET + ydb-library-yql-minikql-codegen-llvm14-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-minikql-codegen-llvm14-ut + TEST_TARGET + ydb-library-yql-minikql-codegen-llvm14-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-codegen-llvm14-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-codegen-llvm14-ut + PROPERTY + PROCESSORS + 1 +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_ut.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut/codegen_ut.cpp +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_ut_llvm_deps.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut/codegen_ut_llvm_deps.h +) +target_allocator(ydb-library-yql-minikql-codegen-llvm14-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-codegen-llvm14-ut) diff --git a/ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..17043c8d5be3 --- /dev/null +++ b/ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,83 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-codegen-llvm14-ut) +target_include_directories(ydb-library-yql-minikql-codegen-llvm14-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut +) +target_link_libraries(ydb-library-yql-minikql-codegen-llvm14-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + Target-X86-Disassembler + lib-Transforms-IPO + lib-Transforms-ObjCARC + minikql-codegen-llvm14 +) +target_link_options(ydb-library-yql-minikql-codegen-llvm14-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-codegen-llvm14-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut/codegen_ut_llvm_deps.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut/codegen_ut.cpp +) +set_property( + TARGET + ydb-library-yql-minikql-codegen-llvm14-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-minikql-codegen-llvm14-ut + TEST_TARGET + ydb-library-yql-minikql-codegen-llvm14-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-codegen-llvm14-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-codegen-llvm14-ut + PROPERTY + PROCESSORS + 1 +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_ut.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut/codegen_ut.cpp +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_ut_llvm_deps.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut/codegen_ut_llvm_deps.h +) +target_allocator(ydb-library-yql-minikql-codegen-llvm14-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-codegen-llvm14-ut) diff --git a/ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..cd4d90176b39 --- /dev/null +++ b/ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.linux-aarch64.txt @@ -0,0 +1,86 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-codegen-llvm14-ut) +target_include_directories(ydb-library-yql-minikql-codegen-llvm14-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut +) +target_link_libraries(ydb-library-yql-minikql-codegen-llvm14-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + Target-X86-Disassembler + lib-Transforms-IPO + lib-Transforms-ObjCARC + lib-ExecutionEngine-PerfJITEvents + minikql-codegen-llvm14 +) +target_link_options(ydb-library-yql-minikql-codegen-llvm14-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-codegen-llvm14-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut/codegen_ut_llvm_deps.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut/codegen_ut.cpp +) +set_property( + TARGET + ydb-library-yql-minikql-codegen-llvm14-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-minikql-codegen-llvm14-ut + TEST_TARGET + ydb-library-yql-minikql-codegen-llvm14-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-codegen-llvm14-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-codegen-llvm14-ut + PROPERTY + PROCESSORS + 1 +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_ut.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut/codegen_ut.cpp +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_ut_llvm_deps.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut/codegen_ut_llvm_deps.h +) +target_allocator(ydb-library-yql-minikql-codegen-llvm14-ut + cpp-malloc-jemalloc +) +vcs_info(ydb-library-yql-minikql-codegen-llvm14-ut) diff --git a/ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..faacb2e3e02a --- /dev/null +++ b/ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.linux-x86_64.txt @@ -0,0 +1,88 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-codegen-llvm14-ut) +target_include_directories(ydb-library-yql-minikql-codegen-llvm14-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut +) +target_link_libraries(ydb-library-yql-minikql-codegen-llvm14-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + Target-X86-Disassembler + lib-Transforms-IPO + lib-Transforms-ObjCARC + lib-ExecutionEngine-PerfJITEvents + minikql-codegen-llvm14 +) +target_link_options(ydb-library-yql-minikql-codegen-llvm14-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-codegen-llvm14-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut/codegen_ut_llvm_deps.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut/codegen_ut.cpp +) +set_property( + TARGET + ydb-library-yql-minikql-codegen-llvm14-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-minikql-codegen-llvm14-ut + TEST_TARGET + ydb-library-yql-minikql-codegen-llvm14-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-codegen-llvm14-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-codegen-llvm14-ut + PROPERTY + PROCESSORS + 1 +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_ut.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut/codegen_ut.cpp +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_ut_llvm_deps.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut/codegen_ut_llvm_deps.h +) +target_allocator(ydb-library-yql-minikql-codegen-llvm14-ut + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(ydb-library-yql-minikql-codegen-llvm14-ut) diff --git a/ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.txt b/ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..45de7172ab94 --- /dev/null +++ b/ydb/library/yql/minikql/codegen/llvm14/ut/CMakeLists.windows-x86_64.txt @@ -0,0 +1,78 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-codegen-llvm14-ut) +target_include_directories(ydb-library-yql-minikql-codegen-llvm14-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut +) +target_link_libraries(ydb-library-yql-minikql-codegen-llvm14-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + Target-X86-Disassembler + lib-Transforms-IPO + lib-Transforms-ObjCARC + minikql-codegen-llvm14 +) +target_sources(ydb-library-yql-minikql-codegen-llvm14-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut/codegen_ut_llvm_deps.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut/codegen_ut.cpp +) +set_property( + TARGET + ydb-library-yql-minikql-codegen-llvm14-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-minikql-codegen-llvm14-ut + TEST_TARGET + ydb-library-yql-minikql-codegen-llvm14-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-codegen-llvm14-ut + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-codegen-llvm14-ut + PROPERTY + PROCESSORS + 1 +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_ut.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut/codegen_ut.cpp +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/codegen_ut_llvm_deps.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/codegen/llvm14/ut/codegen_ut_llvm_deps.h +) +target_allocator(ydb-library-yql-minikql-codegen-llvm14-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-codegen-llvm14-ut) diff --git a/ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..780102078882 --- /dev/null +++ b/ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.darwin-arm64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(minikql-codegen-no_llvm) +target_include_directories(minikql-codegen-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen +) +target_link_libraries(minikql-codegen-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil +) +target_sources(minikql-codegen-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/no_llvm/codegen_dummy.cpp +) diff --git a/ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..780102078882 --- /dev/null +++ b/ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(minikql-codegen-no_llvm) +target_include_directories(minikql-codegen-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen +) +target_link_libraries(minikql-codegen-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil +) +target_sources(minikql-codegen-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/no_llvm/codegen_dummy.cpp +) diff --git a/ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..f67d25468858 --- /dev/null +++ b/ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.linux-aarch64.txt @@ -0,0 +1,21 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(minikql-codegen-no_llvm) +target_include_directories(minikql-codegen-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen +) +target_link_libraries(minikql-codegen-no_llvm PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil +) +target_sources(minikql-codegen-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/no_llvm/codegen_dummy.cpp +) diff --git a/ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..f67d25468858 --- /dev/null +++ b/ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.linux-x86_64.txt @@ -0,0 +1,21 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(minikql-codegen-no_llvm) +target_include_directories(minikql-codegen-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen +) +target_link_libraries(minikql-codegen-no_llvm PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil +) +target_sources(minikql-codegen-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/no_llvm/codegen_dummy.cpp +) diff --git a/ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.txt b/ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..780102078882 --- /dev/null +++ b/ydb/library/yql/minikql/codegen/no_llvm/CMakeLists.windows-x86_64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(minikql-codegen-no_llvm) +target_include_directories(minikql-codegen-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen +) +target_link_libraries(minikql-codegen-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil +) +target_sources(minikql-codegen-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/no_llvm/codegen_dummy.cpp +) diff --git a/ydb/core/kqp/ut/federated_query/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/comp_nodes/CMakeLists.darwin-arm64.txt similarity index 66% rename from ydb/core/kqp/ut/federated_query/CMakeLists.darwin-arm64.txt rename to ydb/library/yql/minikql/comp_nodes/CMakeLists.darwin-arm64.txt index 8985a38071fd..dadbbe0dee41 100644 --- a/ydb/core/kqp/ut/federated_query/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/comp_nodes/CMakeLists.darwin-arm64.txt @@ -6,7 +6,12 @@ # original buildsystem will not be accepted. -add_subdirectory(common) -add_subdirectory(generic) -add_subdirectory(generic_ut) -add_subdirectory(s3) +add_subdirectory(llvm) +add_subdirectory(llvm14) +add_subdirectory(no_llvm) + +add_library(yql-minikql-comp_nodes INTERFACE) +target_link_libraries(yql-minikql-comp_nodes INTERFACE + contrib-libs-cxxsupp + yutil +) diff --git a/ydb/core/kqp/ut/federated_query/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/comp_nodes/CMakeLists.darwin-x86_64.txt similarity index 66% rename from ydb/core/kqp/ut/federated_query/CMakeLists.darwin-x86_64.txt rename to ydb/library/yql/minikql/comp_nodes/CMakeLists.darwin-x86_64.txt index 8985a38071fd..dadbbe0dee41 100644 --- a/ydb/core/kqp/ut/federated_query/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/comp_nodes/CMakeLists.darwin-x86_64.txt @@ -6,7 +6,12 @@ # original buildsystem will not be accepted. -add_subdirectory(common) -add_subdirectory(generic) -add_subdirectory(generic_ut) -add_subdirectory(s3) +add_subdirectory(llvm) +add_subdirectory(llvm14) +add_subdirectory(no_llvm) + +add_library(yql-minikql-comp_nodes INTERFACE) +target_link_libraries(yql-minikql-comp_nodes INTERFACE + contrib-libs-cxxsupp + yutil +) diff --git a/ydb/core/kqp/ut/federated_query/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/comp_nodes/CMakeLists.linux-aarch64.txt similarity index 63% rename from ydb/core/kqp/ut/federated_query/CMakeLists.linux-aarch64.txt rename to ydb/library/yql/minikql/comp_nodes/CMakeLists.linux-aarch64.txt index 8985a38071fd..d2d1cfa06128 100644 --- a/ydb/core/kqp/ut/federated_query/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/comp_nodes/CMakeLists.linux-aarch64.txt @@ -6,7 +6,13 @@ # original buildsystem will not be accepted. -add_subdirectory(common) -add_subdirectory(generic) -add_subdirectory(generic_ut) -add_subdirectory(s3) +add_subdirectory(llvm) +add_subdirectory(llvm14) +add_subdirectory(no_llvm) + +add_library(yql-minikql-comp_nodes INTERFACE) +target_link_libraries(yql-minikql-comp_nodes INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil +) diff --git a/ydb/core/kqp/ut/federated_query/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/comp_nodes/CMakeLists.linux-x86_64.txt similarity index 63% rename from ydb/core/kqp/ut/federated_query/CMakeLists.linux-x86_64.txt rename to ydb/library/yql/minikql/comp_nodes/CMakeLists.linux-x86_64.txt index 8985a38071fd..d2d1cfa06128 100644 --- a/ydb/core/kqp/ut/federated_query/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/comp_nodes/CMakeLists.linux-x86_64.txt @@ -6,7 +6,13 @@ # original buildsystem will not be accepted. -add_subdirectory(common) -add_subdirectory(generic) -add_subdirectory(generic_ut) -add_subdirectory(s3) +add_subdirectory(llvm) +add_subdirectory(llvm14) +add_subdirectory(no_llvm) + +add_library(yql-minikql-comp_nodes INTERFACE) +target_link_libraries(yql-minikql-comp_nodes INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil +) diff --git a/ydb/library/yql/minikql/comp_nodes/CMakeLists.txt b/ydb/library/yql/minikql/comp_nodes/CMakeLists.txt index 4716de1ef37a..d863ebd18067 100644 --- a/ydb/library/yql/minikql/comp_nodes/CMakeLists.txt +++ b/ydb/library/yql/minikql/comp_nodes/CMakeLists.txt @@ -6,6 +6,14 @@ # original buildsystem will not be accepted. -add_subdirectory(llvm) -add_subdirectory(no_llvm) -add_subdirectory(ut) +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/kqp/ut/federated_query/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/comp_nodes/CMakeLists.windows-x86_64.txt similarity index 66% rename from ydb/core/kqp/ut/federated_query/CMakeLists.windows-x86_64.txt rename to ydb/library/yql/minikql/comp_nodes/CMakeLists.windows-x86_64.txt index 3eb3aa480665..dadbbe0dee41 100644 --- a/ydb/core/kqp/ut/federated_query/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/minikql/comp_nodes/CMakeLists.windows-x86_64.txt @@ -6,6 +6,12 @@ # original buildsystem will not be accepted. -add_subdirectory(common) -add_subdirectory(generic_ut) -add_subdirectory(s3) +add_subdirectory(llvm) +add_subdirectory(llvm14) +add_subdirectory(no_llvm) + +add_library(yql-minikql-comp_nodes INTERFACE) +target_link_libraries(yql-minikql-comp_nodes INTERFACE + contrib-libs-cxxsupp + yutil +) diff --git a/ydb/library/yql/minikql/comp_nodes/llvm/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/comp_nodes/llvm/CMakeLists.darwin-arm64.txt index 6a486585d431..72a31e460303 100644 --- a/ydb/library/yql/minikql/comp_nodes/llvm/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/comp_nodes/llvm/CMakeLists.darwin-arm64.txt @@ -6,17 +6,29 @@ # original buildsystem will not be accepted. +add_subdirectory(ut) -add_library(minikql-comp_nodes-llvm) +add_library(minikql-comp_nodes-llvm STATIC) +set_property(TARGET minikql-comp_nodes-llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-comp_nodes-llvm PRIVATE -mprfchw -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> +) +target_include_directories(minikql-comp_nodes-llvm PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-comp_nodes-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes ) target_link_libraries(minikql-comp_nodes-llvm PUBLIC contrib-libs-cxxsupp yutil - yql-minikql-codegen + minikql-codegen-llvm minikql-invoke_builtins-llvm llvm12-lib-IR lib-ExecutionEngine-MCJIT @@ -32,130 +44,32 @@ target_link_libraries(minikql-comp_nodes-llvm PUBLIC parser-pg_wrapper-interface library-yql-utils library-actors-core + public-issue-protos ) target_sources(minikql-comp_nodes-llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_addmember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_aggrcount.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_append.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_apply.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_count.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_factory.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_minmax.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_some.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_sum.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_coalesce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_if.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_just.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_logical.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_compress.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_func.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_skiptake.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_top.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_tuple.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_blocks.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_callable.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chain_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chain1_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_check_args.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chopper.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_coalesce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_collect.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_combine.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_contains.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_div.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_mod.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_mul.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_dictitems.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_discard.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_element.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_ensure.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_enumerate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_exists.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_extend.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_factory.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_filter.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_flatmap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_flow.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fold.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fold1.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_frombytes.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fromstring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fromyson.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_group.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_grace_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_grace_join_imp.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_guess.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_hasitems.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_heap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_hopping.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_if.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_ifpresent.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_invoke.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_iterable.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_iterator.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_join_dict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_lazy_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_length.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_listfromrange.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_logical.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_lookup.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_mapnext.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_map_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_match_recognize.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_multihopping.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_multimap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_next_value.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_nop.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_now.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_null.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_pickle.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_prepend.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_queue.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_random.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_range.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_reduce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_removemember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_replicate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_reverse.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_rh_hash.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_round.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_safe_circular_buffer.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_scalar_apply.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_seq.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_size.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_skip.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_sort.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_source.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_squeeze_state.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_squeeze_to_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_condense.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_condense1.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_switch.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_take.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_time_order_recover.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_timezone.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tobytes.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_todict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_toindexdict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tooptional.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tostring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_udf.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_unwrap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_varitem.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_visitall.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_way.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_weakmember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_while.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_chain_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_chopper.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_combine.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_condense.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_filter.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_top_sort.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_withcontext.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_zip.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h ) diff --git a/ydb/library/yql/minikql/comp_nodes/llvm/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/comp_nodes/llvm/CMakeLists.darwin-x86_64.txt index 6a486585d431..72a31e460303 100644 --- a/ydb/library/yql/minikql/comp_nodes/llvm/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/comp_nodes/llvm/CMakeLists.darwin-x86_64.txt @@ -6,17 +6,29 @@ # original buildsystem will not be accepted. +add_subdirectory(ut) -add_library(minikql-comp_nodes-llvm) +add_library(minikql-comp_nodes-llvm STATIC) +set_property(TARGET minikql-comp_nodes-llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-comp_nodes-llvm PRIVATE -mprfchw -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> +) +target_include_directories(minikql-comp_nodes-llvm PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-comp_nodes-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes ) target_link_libraries(minikql-comp_nodes-llvm PUBLIC contrib-libs-cxxsupp yutil - yql-minikql-codegen + minikql-codegen-llvm minikql-invoke_builtins-llvm llvm12-lib-IR lib-ExecutionEngine-MCJIT @@ -32,130 +44,32 @@ target_link_libraries(minikql-comp_nodes-llvm PUBLIC parser-pg_wrapper-interface library-yql-utils library-actors-core + public-issue-protos ) target_sources(minikql-comp_nodes-llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_addmember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_aggrcount.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_append.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_apply.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_count.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_factory.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_minmax.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_some.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_sum.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_coalesce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_if.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_just.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_logical.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_compress.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_func.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_skiptake.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_top.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_tuple.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_blocks.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_callable.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chain_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chain1_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_check_args.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chopper.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_coalesce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_collect.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_combine.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_contains.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_div.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_mod.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_mul.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_dictitems.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_discard.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_element.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_ensure.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_enumerate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_exists.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_extend.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_factory.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_filter.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_flatmap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_flow.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fold.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fold1.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_frombytes.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fromstring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fromyson.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_group.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_grace_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_grace_join_imp.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_guess.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_hasitems.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_heap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_hopping.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_if.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_ifpresent.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_invoke.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_iterable.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_iterator.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_join_dict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_lazy_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_length.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_listfromrange.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_logical.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_lookup.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_mapnext.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_map_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_match_recognize.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_multihopping.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_multimap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_next_value.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_nop.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_now.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_null.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_pickle.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_prepend.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_queue.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_random.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_range.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_reduce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_removemember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_replicate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_reverse.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_rh_hash.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_round.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_safe_circular_buffer.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_scalar_apply.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_seq.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_size.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_skip.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_sort.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_source.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_squeeze_state.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_squeeze_to_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_condense.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_condense1.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_switch.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_take.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_time_order_recover.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_timezone.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tobytes.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_todict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_toindexdict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tooptional.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tostring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_udf.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_unwrap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_varitem.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_visitall.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_way.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_weakmember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_while.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_chain_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_chopper.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_combine.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_condense.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_filter.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_top_sort.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_withcontext.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_zip.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h ) diff --git a/ydb/library/yql/minikql/comp_nodes/llvm/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/comp_nodes/llvm/CMakeLists.linux-aarch64.txt index 33e04096ee46..87c5da0f3716 100644 --- a/ydb/library/yql/minikql/comp_nodes/llvm/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/comp_nodes/llvm/CMakeLists.linux-aarch64.txt @@ -6,18 +6,30 @@ # original buildsystem will not be accepted. +add_subdirectory(ut) -add_library(minikql-comp_nodes-llvm) +add_library(minikql-comp_nodes-llvm STATIC) +set_property(TARGET minikql-comp_nodes-llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-comp_nodes-llvm PRIVATE -mprfchw -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> +) +target_include_directories(minikql-comp_nodes-llvm PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-comp_nodes-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes ) target_link_libraries(minikql-comp_nodes-llvm PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - yql-minikql-codegen + minikql-codegen-llvm minikql-invoke_builtins-llvm llvm12-lib-IR lib-ExecutionEngine-MCJIT @@ -33,130 +45,32 @@ target_link_libraries(minikql-comp_nodes-llvm PUBLIC parser-pg_wrapper-interface library-yql-utils library-actors-core + public-issue-protos ) target_sources(minikql-comp_nodes-llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_addmember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_aggrcount.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_append.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_apply.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_count.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_factory.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_minmax.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_some.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_sum.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_coalesce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_if.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_just.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_logical.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_compress.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_func.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_skiptake.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_top.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_tuple.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_blocks.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_callable.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chain_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chain1_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_check_args.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chopper.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_coalesce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_collect.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_combine.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_contains.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_div.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_mod.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_mul.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_dictitems.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_discard.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_element.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_ensure.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_enumerate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_exists.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_extend.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_factory.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_filter.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_flatmap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_flow.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fold.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fold1.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_frombytes.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fromstring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fromyson.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_group.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_grace_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_grace_join_imp.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_guess.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_hasitems.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_heap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_hopping.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_if.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_ifpresent.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_invoke.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_iterable.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_iterator.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_join_dict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_lazy_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_length.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_listfromrange.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_logical.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_lookup.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_mapnext.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_map_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_match_recognize.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_multihopping.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_multimap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_next_value.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_nop.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_now.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_null.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_pickle.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_prepend.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_queue.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_random.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_range.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_reduce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_removemember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_replicate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_reverse.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_rh_hash.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_round.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_safe_circular_buffer.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_scalar_apply.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_seq.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_size.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_skip.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_sort.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_source.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_squeeze_state.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_squeeze_to_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_condense.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_condense1.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_switch.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_take.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_time_order_recover.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_timezone.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tobytes.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_todict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_toindexdict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tooptional.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tostring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_udf.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_unwrap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_varitem.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_visitall.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_way.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_weakmember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_while.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_chain_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_chopper.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_combine.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_condense.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_filter.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_top_sort.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_withcontext.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_zip.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h ) diff --git a/ydb/library/yql/minikql/comp_nodes/llvm/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/comp_nodes/llvm/CMakeLists.linux-x86_64.txt index 33e04096ee46..87c5da0f3716 100644 --- a/ydb/library/yql/minikql/comp_nodes/llvm/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/comp_nodes/llvm/CMakeLists.linux-x86_64.txt @@ -6,18 +6,30 @@ # original buildsystem will not be accepted. +add_subdirectory(ut) -add_library(minikql-comp_nodes-llvm) +add_library(minikql-comp_nodes-llvm STATIC) +set_property(TARGET minikql-comp_nodes-llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-comp_nodes-llvm PRIVATE -mprfchw -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> +) +target_include_directories(minikql-comp_nodes-llvm PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-comp_nodes-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes ) target_link_libraries(minikql-comp_nodes-llvm PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - yql-minikql-codegen + minikql-codegen-llvm minikql-invoke_builtins-llvm llvm12-lib-IR lib-ExecutionEngine-MCJIT @@ -33,130 +45,32 @@ target_link_libraries(minikql-comp_nodes-llvm PUBLIC parser-pg_wrapper-interface library-yql-utils library-actors-core + public-issue-protos ) target_sources(minikql-comp_nodes-llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_addmember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_aggrcount.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_append.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_apply.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_count.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_factory.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_minmax.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_some.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_sum.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_coalesce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_if.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_just.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_logical.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_compress.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_func.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_skiptake.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_top.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_tuple.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_blocks.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_callable.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chain_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chain1_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_check_args.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chopper.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_coalesce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_collect.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_combine.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_contains.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_div.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_mod.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_mul.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_dictitems.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_discard.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_element.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_ensure.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_enumerate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_exists.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_extend.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_factory.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_filter.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_flatmap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_flow.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fold.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fold1.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_frombytes.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fromstring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fromyson.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_group.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_grace_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_grace_join_imp.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_guess.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_hasitems.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_heap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_hopping.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_if.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_ifpresent.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_invoke.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_iterable.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_iterator.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_join_dict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_lazy_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_length.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_listfromrange.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_logical.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_lookup.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_mapnext.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_map_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_match_recognize.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_multihopping.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_multimap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_next_value.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_nop.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_now.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_null.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_pickle.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_prepend.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_queue.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_random.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_range.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_reduce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_removemember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_replicate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_reverse.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_rh_hash.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_round.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_safe_circular_buffer.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_scalar_apply.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_seq.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_size.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_skip.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_sort.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_source.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_squeeze_state.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_squeeze_to_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_condense.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_condense1.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_switch.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_take.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_time_order_recover.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_timezone.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tobytes.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_todict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_toindexdict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tooptional.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tostring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_udf.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_unwrap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_varitem.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_visitall.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_way.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_weakmember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_while.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_chain_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_chopper.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_combine.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_condense.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_filter.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_top_sort.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_withcontext.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_zip.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h ) diff --git a/ydb/library/yql/minikql/comp_nodes/llvm/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/comp_nodes/llvm/CMakeLists.windows-x86_64.txt index 6a486585d431..72a31e460303 100644 --- a/ydb/library/yql/minikql/comp_nodes/llvm/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/minikql/comp_nodes/llvm/CMakeLists.windows-x86_64.txt @@ -6,17 +6,29 @@ # original buildsystem will not be accepted. +add_subdirectory(ut) -add_library(minikql-comp_nodes-llvm) +add_library(minikql-comp_nodes-llvm STATIC) +set_property(TARGET minikql-comp_nodes-llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-comp_nodes-llvm PRIVATE -mprfchw -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> +) +target_include_directories(minikql-comp_nodes-llvm PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-comp_nodes-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes ) target_link_libraries(minikql-comp_nodes-llvm PUBLIC contrib-libs-cxxsupp yutil - yql-minikql-codegen + minikql-codegen-llvm minikql-invoke_builtins-llvm llvm12-lib-IR lib-ExecutionEngine-MCJIT @@ -32,130 +44,32 @@ target_link_libraries(minikql-comp_nodes-llvm PUBLIC parser-pg_wrapper-interface library-yql-utils library-actors-core + public-issue-protos ) target_sources(minikql-comp_nodes-llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_addmember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_aggrcount.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_append.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_apply.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_count.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_factory.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_minmax.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_some.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_sum.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_coalesce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_if.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_just.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_logical.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_compress.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_func.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_skiptake.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_top.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_tuple.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_blocks.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_callable.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chain_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chain1_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_check_args.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chopper.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_coalesce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_collect.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_combine.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_contains.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_div.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_mod.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_mul.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_dictitems.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_discard.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_element.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_ensure.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_enumerate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_exists.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_extend.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_factory.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_filter.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_flatmap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_flow.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fold.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fold1.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_frombytes.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fromstring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fromyson.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_group.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_grace_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_grace_join_imp.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_guess.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_hasitems.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_heap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_hopping.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_if.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_ifpresent.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_invoke.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_iterable.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_iterator.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_join_dict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_lazy_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_length.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_listfromrange.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_logical.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_lookup.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_mapnext.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_map_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_match_recognize.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_multihopping.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_multimap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_next_value.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_nop.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_now.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_null.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_pickle.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_prepend.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_queue.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_random.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_range.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_reduce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_removemember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_replicate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_reverse.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_rh_hash.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_round.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_safe_circular_buffer.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_scalar_apply.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_seq.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_size.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_skip.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_sort.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_source.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_squeeze_state.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_squeeze_to_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_condense.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_condense1.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_switch.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_take.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_time_order_recover.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_timezone.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tobytes.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_todict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_toindexdict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tooptional.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tostring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_udf.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_unwrap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_varitem.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_visitall.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_way.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_weakmember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_while.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_chain_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_chopper.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_combine.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_condense.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_filter.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_top_sort.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_withcontext.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_zip.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h ) diff --git a/ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..a7da3e7c1526 --- /dev/null +++ b/ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.darwin-arm64.txt @@ -0,0 +1,114 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-comp_nodes-llvm-ut) +target_compile_options(ydb-library-yql-minikql-comp_nodes-llvm-ut PRIVATE + -mprfchw + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-minikql-comp_nodes-llvm-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/ut +) +target_link_libraries(ydb-library-yql-minikql-comp_nodes-llvm-ut PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + minikql-codegen-llvm + minikql-comp_nodes-llvm + minikql-invoke_builtins-llvm + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + yql-public-udf + public-udf-arrow + udf-service-exception_policy + yql-sql-pg_dummy +) +target_link_options(ydb-library-yql-minikql-comp_nodes-llvm-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-comp_nodes-llvm-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +set_property( + TARGET + ydb-library-yql-minikql-comp_nodes-llvm-ut + PROPERTY + SPLIT_FACTOR + 60 +) +add_yunittest( + NAME + ydb-library-yql-minikql-comp_nodes-llvm-ut + TEST_TARGET + ydb-library-yql-minikql-comp_nodes-llvm-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm-ut + PROPERTY + TIMEOUT + 600 +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +target_allocator(ydb-library-yql-minikql-comp_nodes-llvm-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-comp_nodes-llvm-ut) diff --git a/ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..3ff64f241acb --- /dev/null +++ b/ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,115 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-comp_nodes-llvm-ut) +target_compile_options(ydb-library-yql-minikql-comp_nodes-llvm-ut PRIVATE + -mprfchw + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-minikql-comp_nodes-llvm-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/ut +) +target_link_libraries(ydb-library-yql-minikql-comp_nodes-llvm-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + minikql-codegen-llvm + minikql-comp_nodes-llvm + minikql-invoke_builtins-llvm + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + yql-public-udf + public-udf-arrow + udf-service-exception_policy + yql-sql-pg_dummy +) +target_link_options(ydb-library-yql-minikql-comp_nodes-llvm-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-comp_nodes-llvm-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +set_property( + TARGET + ydb-library-yql-minikql-comp_nodes-llvm-ut + PROPERTY + SPLIT_FACTOR + 60 +) +add_yunittest( + NAME + ydb-library-yql-minikql-comp_nodes-llvm-ut + TEST_TARGET + ydb-library-yql-minikql-comp_nodes-llvm-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm-ut + PROPERTY + TIMEOUT + 600 +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +target_allocator(ydb-library-yql-minikql-comp_nodes-llvm-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-comp_nodes-llvm-ut) diff --git a/ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..f029d14f4a39 --- /dev/null +++ b/ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.linux-aarch64.txt @@ -0,0 +1,117 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-comp_nodes-llvm-ut) +target_compile_options(ydb-library-yql-minikql-comp_nodes-llvm-ut PRIVATE + -mprfchw + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-minikql-comp_nodes-llvm-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/ut +) +target_link_libraries(ydb-library-yql-minikql-comp_nodes-llvm-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + minikql-codegen-llvm + minikql-comp_nodes-llvm + minikql-invoke_builtins-llvm + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + yql-public-udf + public-udf-arrow + udf-service-exception_policy + yql-sql-pg_dummy +) +target_link_options(ydb-library-yql-minikql-comp_nodes-llvm-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-comp_nodes-llvm-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +set_property( + TARGET + ydb-library-yql-minikql-comp_nodes-llvm-ut + PROPERTY + SPLIT_FACTOR + 60 +) +add_yunittest( + NAME + ydb-library-yql-minikql-comp_nodes-llvm-ut + TEST_TARGET + ydb-library-yql-minikql-comp_nodes-llvm-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm-ut + PROPERTY + TIMEOUT + 600 +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +target_allocator(ydb-library-yql-minikql-comp_nodes-llvm-ut + cpp-malloc-jemalloc +) +vcs_info(ydb-library-yql-minikql-comp_nodes-llvm-ut) diff --git a/ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..c5412ccbe060 --- /dev/null +++ b/ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.linux-x86_64.txt @@ -0,0 +1,119 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-comp_nodes-llvm-ut) +target_compile_options(ydb-library-yql-minikql-comp_nodes-llvm-ut PRIVATE + -mprfchw + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-minikql-comp_nodes-llvm-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/ut +) +target_link_libraries(ydb-library-yql-minikql-comp_nodes-llvm-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + minikql-codegen-llvm + minikql-comp_nodes-llvm + minikql-invoke_builtins-llvm + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + yql-public-udf + public-udf-arrow + udf-service-exception_policy + yql-sql-pg_dummy +) +target_link_options(ydb-library-yql-minikql-comp_nodes-llvm-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-comp_nodes-llvm-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +set_property( + TARGET + ydb-library-yql-minikql-comp_nodes-llvm-ut + PROPERTY + SPLIT_FACTOR + 60 +) +add_yunittest( + NAME + ydb-library-yql-minikql-comp_nodes-llvm-ut + TEST_TARGET + ydb-library-yql-minikql-comp_nodes-llvm-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm-ut + PROPERTY + TIMEOUT + 600 +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +target_allocator(ydb-library-yql-minikql-comp_nodes-llvm-ut + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(ydb-library-yql-minikql-comp_nodes-llvm-ut) diff --git a/ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.txt b/ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..7301dcccefe8 --- /dev/null +++ b/ydb/library/yql/minikql/comp_nodes/llvm/ut/CMakeLists.windows-x86_64.txt @@ -0,0 +1,110 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-comp_nodes-llvm-ut) +target_compile_options(ydb-library-yql-minikql-comp_nodes-llvm-ut PRIVATE + -mprfchw + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-minikql-comp_nodes-llvm-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/ut +) +target_link_libraries(ydb-library-yql-minikql-comp_nodes-llvm-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + minikql-codegen-llvm + minikql-comp_nodes-llvm + minikql-invoke_builtins-llvm + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + yql-public-udf + public-udf-arrow + udf-service-exception_policy + yql-sql-pg_dummy +) +target_sources(ydb-library-yql-minikql-comp_nodes-llvm-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +set_property( + TARGET + ydb-library-yql-minikql-comp_nodes-llvm-ut + PROPERTY + SPLIT_FACTOR + 60 +) +add_yunittest( + NAME + ydb-library-yql-minikql-comp_nodes-llvm-ut + TEST_TARGET + ydb-library-yql-minikql-comp_nodes-llvm-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm-ut + PROPERTY + TIMEOUT + 600 +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +target_allocator(ydb-library-yql-minikql-comp_nodes-llvm-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-comp_nodes-llvm-ut) diff --git a/ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..8e76ec9b50c9 --- /dev/null +++ b/ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.darwin-arm64.txt @@ -0,0 +1,75 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(minikql-comp_nodes-llvm14 STATIC) +set_property(TARGET minikql-comp_nodes-llvm14 PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(minikql-comp_nodes-llvm14 PRIVATE + -mprfchw + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(minikql-comp_nodes-llvm14 PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14 + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-comp_nodes-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes +) +target_link_libraries(minikql-comp_nodes-llvm14 PUBLIC + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm14 + minikql-invoke_builtins-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + libs-apache-arrow + ydb-library-binary_json + library-yql-minikql + yql-minikql-arrow + public-udf-arrow + parser-pg_wrapper-interface + library-yql-utils + library-actors-core + public-issue-protos +) +target_sources(minikql-comp_nodes-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..8e76ec9b50c9 --- /dev/null +++ b/ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,75 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(minikql-comp_nodes-llvm14 STATIC) +set_property(TARGET minikql-comp_nodes-llvm14 PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(minikql-comp_nodes-llvm14 PRIVATE + -mprfchw + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(minikql-comp_nodes-llvm14 PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14 + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-comp_nodes-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes +) +target_link_libraries(minikql-comp_nodes-llvm14 PUBLIC + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm14 + minikql-invoke_builtins-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + libs-apache-arrow + ydb-library-binary_json + library-yql-minikql + yql-minikql-arrow + public-udf-arrow + parser-pg_wrapper-interface + library-yql-utils + library-actors-core + public-issue-protos +) +target_sources(minikql-comp_nodes-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..abff2108199d --- /dev/null +++ b/ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.linux-aarch64.txt @@ -0,0 +1,76 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(minikql-comp_nodes-llvm14 STATIC) +set_property(TARGET minikql-comp_nodes-llvm14 PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(minikql-comp_nodes-llvm14 PRIVATE + -mprfchw + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(minikql-comp_nodes-llvm14 PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14 + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-comp_nodes-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes +) +target_link_libraries(minikql-comp_nodes-llvm14 PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm14 + minikql-invoke_builtins-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + libs-apache-arrow + ydb-library-binary_json + library-yql-minikql + yql-minikql-arrow + public-udf-arrow + parser-pg_wrapper-interface + library-yql-utils + library-actors-core + public-issue-protos +) +target_sources(minikql-comp_nodes-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..abff2108199d --- /dev/null +++ b/ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.linux-x86_64.txt @@ -0,0 +1,76 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(minikql-comp_nodes-llvm14 STATIC) +set_property(TARGET minikql-comp_nodes-llvm14 PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(minikql-comp_nodes-llvm14 PRIVATE + -mprfchw + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(minikql-comp_nodes-llvm14 PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14 + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-comp_nodes-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes +) +target_link_libraries(minikql-comp_nodes-llvm14 PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm14 + minikql-invoke_builtins-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + libs-apache-arrow + ydb-library-binary_json + library-yql-minikql + yql-minikql-arrow + public-udf-arrow + parser-pg_wrapper-interface + library-yql-utils + library-actors-core + public-issue-protos +) +target_sources(minikql-comp_nodes-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.txt b/ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..8e76ec9b50c9 --- /dev/null +++ b/ydb/library/yql/minikql/comp_nodes/llvm14/CMakeLists.windows-x86_64.txt @@ -0,0 +1,75 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(minikql-comp_nodes-llvm14 STATIC) +set_property(TARGET minikql-comp_nodes-llvm14 PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(minikql-comp_nodes-llvm14 PRIVATE + -mprfchw + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(minikql-comp_nodes-llvm14 PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14 + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-comp_nodes-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes +) +target_link_libraries(minikql-comp_nodes-llvm14 PUBLIC + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm14 + minikql-invoke_builtins-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + libs-apache-arrow + ydb-library-binary_json + library-yql-minikql + yql-minikql-arrow + public-udf-arrow + parser-pg_wrapper-interface + library-yql-utils + library-actors-core + public-issue-protos +) +target_sources(minikql-comp_nodes-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..0691284ee0a3 --- /dev/null +++ b/ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.darwin-arm64.txt @@ -0,0 +1,114 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-comp_nodes-llvm14-ut) +target_compile_options(ydb-library-yql-minikql-comp_nodes-llvm14-ut PRIVATE + -mprfchw + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-minikql-comp_nodes-llvm14-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/ut +) +target_link_libraries(ydb-library-yql-minikql-comp_nodes-llvm14-ut PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + minikql-codegen-llvm14 + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + yql-public-udf + public-udf-arrow + udf-service-exception_policy + yql-sql-pg_dummy +) +target_link_options(ydb-library-yql-minikql-comp_nodes-llvm14-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-comp_nodes-llvm14-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +set_property( + TARGET + ydb-library-yql-minikql-comp_nodes-llvm14-ut + PROPERTY + SPLIT_FACTOR + 60 +) +add_yunittest( + NAME + ydb-library-yql-minikql-comp_nodes-llvm14-ut + TEST_TARGET + ydb-library-yql-minikql-comp_nodes-llvm14-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm14-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm14-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm14-ut + PROPERTY + TIMEOUT + 600 +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +target_allocator(ydb-library-yql-minikql-comp_nodes-llvm14-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-comp_nodes-llvm14-ut) diff --git a/ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..db2b71f81d3b --- /dev/null +++ b/ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,115 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-comp_nodes-llvm14-ut) +target_compile_options(ydb-library-yql-minikql-comp_nodes-llvm14-ut PRIVATE + -mprfchw + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-minikql-comp_nodes-llvm14-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/ut +) +target_link_libraries(ydb-library-yql-minikql-comp_nodes-llvm14-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + minikql-codegen-llvm14 + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + yql-public-udf + public-udf-arrow + udf-service-exception_policy + yql-sql-pg_dummy +) +target_link_options(ydb-library-yql-minikql-comp_nodes-llvm14-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-comp_nodes-llvm14-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +set_property( + TARGET + ydb-library-yql-minikql-comp_nodes-llvm14-ut + PROPERTY + SPLIT_FACTOR + 60 +) +add_yunittest( + NAME + ydb-library-yql-minikql-comp_nodes-llvm14-ut + TEST_TARGET + ydb-library-yql-minikql-comp_nodes-llvm14-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm14-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm14-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm14-ut + PROPERTY + TIMEOUT + 600 +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +target_allocator(ydb-library-yql-minikql-comp_nodes-llvm14-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-comp_nodes-llvm14-ut) diff --git a/ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..1d109229c787 --- /dev/null +++ b/ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.linux-aarch64.txt @@ -0,0 +1,117 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-comp_nodes-llvm14-ut) +target_compile_options(ydb-library-yql-minikql-comp_nodes-llvm14-ut PRIVATE + -mprfchw + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-minikql-comp_nodes-llvm14-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/ut +) +target_link_libraries(ydb-library-yql-minikql-comp_nodes-llvm14-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + minikql-codegen-llvm14 + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + yql-public-udf + public-udf-arrow + udf-service-exception_policy + yql-sql-pg_dummy +) +target_link_options(ydb-library-yql-minikql-comp_nodes-llvm14-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-comp_nodes-llvm14-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +set_property( + TARGET + ydb-library-yql-minikql-comp_nodes-llvm14-ut + PROPERTY + SPLIT_FACTOR + 60 +) +add_yunittest( + NAME + ydb-library-yql-minikql-comp_nodes-llvm14-ut + TEST_TARGET + ydb-library-yql-minikql-comp_nodes-llvm14-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm14-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm14-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm14-ut + PROPERTY + TIMEOUT + 600 +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +target_allocator(ydb-library-yql-minikql-comp_nodes-llvm14-ut + cpp-malloc-jemalloc +) +vcs_info(ydb-library-yql-minikql-comp_nodes-llvm14-ut) diff --git a/ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..5f03ad797e34 --- /dev/null +++ b/ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.linux-x86_64.txt @@ -0,0 +1,119 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-comp_nodes-llvm14-ut) +target_compile_options(ydb-library-yql-minikql-comp_nodes-llvm14-ut PRIVATE + -mprfchw + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-minikql-comp_nodes-llvm14-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/ut +) +target_link_libraries(ydb-library-yql-minikql-comp_nodes-llvm14-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + minikql-codegen-llvm14 + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + yql-public-udf + public-udf-arrow + udf-service-exception_policy + yql-sql-pg_dummy +) +target_link_options(ydb-library-yql-minikql-comp_nodes-llvm14-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-comp_nodes-llvm14-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +set_property( + TARGET + ydb-library-yql-minikql-comp_nodes-llvm14-ut + PROPERTY + SPLIT_FACTOR + 60 +) +add_yunittest( + NAME + ydb-library-yql-minikql-comp_nodes-llvm14-ut + TEST_TARGET + ydb-library-yql-minikql-comp_nodes-llvm14-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm14-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm14-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm14-ut + PROPERTY + TIMEOUT + 600 +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +target_allocator(ydb-library-yql-minikql-comp_nodes-llvm14-ut + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(ydb-library-yql-minikql-comp_nodes-llvm14-ut) diff --git a/ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.txt b/ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..0d518c52d0cd --- /dev/null +++ b/ydb/library/yql/minikql/comp_nodes/llvm14/ut/CMakeLists.windows-x86_64.txt @@ -0,0 +1,110 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-comp_nodes-llvm14-ut) +target_compile_options(ydb-library-yql-minikql-comp_nodes-llvm14-ut PRIVATE + -mprfchw + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-minikql-comp_nodes-llvm14-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/ut +) +target_link_libraries(ydb-library-yql-minikql-comp_nodes-llvm14-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + minikql-codegen-llvm14 + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + yql-public-udf + public-udf-arrow + udf-service-exception_policy + yql-sql-pg_dummy +) +target_sources(ydb-library-yql-minikql-comp_nodes-llvm14-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +set_property( + TARGET + ydb-library-yql-minikql-comp_nodes-llvm14-ut + PROPERTY + SPLIT_FACTOR + 60 +) +add_yunittest( + NAME + ydb-library-yql-minikql-comp_nodes-llvm14-ut + TEST_TARGET + ydb-library-yql-minikql-comp_nodes-llvm14-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm14-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm14-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-comp_nodes-llvm14-ut + PROPERTY + TIMEOUT + 600 +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/llvm14/ut/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +target_allocator(ydb-library-yql-minikql-comp_nodes-llvm14-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-comp_nodes-llvm14-ut) diff --git a/ydb/library/yql/minikql/comp_nodes/no_llvm/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/comp_nodes/no_llvm/CMakeLists.darwin-arm64.txt index f8f0fbbc1e57..d4e7ad812c30 100644 --- a/ydb/library/yql/minikql/comp_nodes/no_llvm/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/comp_nodes/no_llvm/CMakeLists.darwin-arm64.txt @@ -7,7 +7,10 @@ -add_library(minikql-comp_nodes-no_llvm) +add_library(minikql-comp_nodes-no_llvm STATIC) +set_property(TARGET minikql-comp_nodes-no_llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-comp_nodes-no_llvm PRIVATE -mprfchw -DMKQL_DISABLE_CODEGEN @@ -15,6 +18,13 @@ target_compile_options(minikql-comp_nodes-no_llvm PRIVATE ) target_include_directories(minikql-comp_nodes-no_llvm PUBLIC ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/llvm_stub + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-comp_nodes-no_llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes ) target_link_libraries(minikql-comp_nodes-no_llvm PUBLIC contrib-libs-cxxsupp @@ -27,131 +37,33 @@ target_link_libraries(minikql-comp_nodes-no_llvm PUBLIC parser-pg_wrapper-interface library-yql-utils library-actors-core + public-issue-protos minikql-invoke_builtins-no_llvm ) target_sources(minikql-comp_nodes-no_llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_addmember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_aggrcount.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_append.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_apply.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_count.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_factory.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_minmax.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_some.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_sum.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_coalesce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_if.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_just.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_logical.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_compress.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_func.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_skiptake.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_top.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_tuple.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_blocks.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_callable.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chain_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chain1_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_check_args.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chopper.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_coalesce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_collect.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_combine.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_contains.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_div.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_mod.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_mul.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_dictitems.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_discard.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_element.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_ensure.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_enumerate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_exists.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_extend.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_factory.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_filter.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_flatmap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_flow.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fold.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fold1.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_frombytes.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fromstring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fromyson.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_group.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_grace_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_grace_join_imp.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_guess.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_hasitems.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_heap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_hopping.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_if.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_ifpresent.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_invoke.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_iterable.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_iterator.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_join_dict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_lazy_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_length.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_listfromrange.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_logical.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_lookup.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_mapnext.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_map_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_match_recognize.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_multihopping.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_multimap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_next_value.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_nop.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_now.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_null.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_pickle.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_prepend.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_queue.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_random.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_range.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_reduce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_removemember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_replicate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_reverse.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_rh_hash.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_round.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_safe_circular_buffer.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_scalar_apply.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_seq.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_size.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_skip.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_sort.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_source.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_squeeze_state.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_squeeze_to_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_condense.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_condense1.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_switch.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_take.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_time_order_recover.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_timezone.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tobytes.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_todict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_toindexdict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tooptional.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tostring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_udf.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_unwrap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_varitem.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_visitall.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_way.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_weakmember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_while.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_chain_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_chopper.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_combine.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_condense.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_filter.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_top_sort.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_withcontext.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_zip.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h ) diff --git a/ydb/library/yql/minikql/comp_nodes/no_llvm/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/comp_nodes/no_llvm/CMakeLists.darwin-x86_64.txt index f8f0fbbc1e57..d4e7ad812c30 100644 --- a/ydb/library/yql/minikql/comp_nodes/no_llvm/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/comp_nodes/no_llvm/CMakeLists.darwin-x86_64.txt @@ -7,7 +7,10 @@ -add_library(minikql-comp_nodes-no_llvm) +add_library(minikql-comp_nodes-no_llvm STATIC) +set_property(TARGET minikql-comp_nodes-no_llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-comp_nodes-no_llvm PRIVATE -mprfchw -DMKQL_DISABLE_CODEGEN @@ -15,6 +18,13 @@ target_compile_options(minikql-comp_nodes-no_llvm PRIVATE ) target_include_directories(minikql-comp_nodes-no_llvm PUBLIC ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/llvm_stub + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-comp_nodes-no_llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes ) target_link_libraries(minikql-comp_nodes-no_llvm PUBLIC contrib-libs-cxxsupp @@ -27,131 +37,33 @@ target_link_libraries(minikql-comp_nodes-no_llvm PUBLIC parser-pg_wrapper-interface library-yql-utils library-actors-core + public-issue-protos minikql-invoke_builtins-no_llvm ) target_sources(minikql-comp_nodes-no_llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_addmember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_aggrcount.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_append.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_apply.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_count.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_factory.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_minmax.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_some.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_sum.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_coalesce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_if.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_just.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_logical.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_compress.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_func.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_skiptake.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_top.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_tuple.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_blocks.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_callable.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chain_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chain1_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_check_args.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chopper.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_coalesce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_collect.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_combine.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_contains.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_div.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_mod.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_mul.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_dictitems.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_discard.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_element.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_ensure.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_enumerate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_exists.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_extend.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_factory.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_filter.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_flatmap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_flow.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fold.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fold1.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_frombytes.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fromstring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fromyson.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_group.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_grace_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_grace_join_imp.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_guess.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_hasitems.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_heap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_hopping.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_if.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_ifpresent.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_invoke.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_iterable.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_iterator.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_join_dict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_lazy_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_length.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_listfromrange.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_logical.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_lookup.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_mapnext.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_map_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_match_recognize.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_multihopping.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_multimap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_next_value.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_nop.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_now.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_null.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_pickle.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_prepend.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_queue.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_random.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_range.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_reduce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_removemember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_replicate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_reverse.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_rh_hash.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_round.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_safe_circular_buffer.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_scalar_apply.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_seq.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_size.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_skip.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_sort.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_source.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_squeeze_state.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_squeeze_to_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_condense.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_condense1.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_switch.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_take.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_time_order_recover.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_timezone.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tobytes.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_todict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_toindexdict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tooptional.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tostring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_udf.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_unwrap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_varitem.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_visitall.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_way.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_weakmember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_while.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_chain_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_chopper.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_combine.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_condense.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_filter.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_top_sort.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_withcontext.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_zip.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h ) diff --git a/ydb/library/yql/minikql/comp_nodes/no_llvm/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/comp_nodes/no_llvm/CMakeLists.linux-aarch64.txt index 3064042982b3..4d9ca7300298 100644 --- a/ydb/library/yql/minikql/comp_nodes/no_llvm/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/comp_nodes/no_llvm/CMakeLists.linux-aarch64.txt @@ -7,7 +7,10 @@ -add_library(minikql-comp_nodes-no_llvm) +add_library(minikql-comp_nodes-no_llvm STATIC) +set_property(TARGET minikql-comp_nodes-no_llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-comp_nodes-no_llvm PRIVATE -mprfchw -DMKQL_DISABLE_CODEGEN @@ -15,6 +18,13 @@ target_compile_options(minikql-comp_nodes-no_llvm PRIVATE ) target_include_directories(minikql-comp_nodes-no_llvm PUBLIC ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/llvm_stub + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-comp_nodes-no_llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes ) target_link_libraries(minikql-comp_nodes-no_llvm PUBLIC contrib-libs-linux-headers @@ -28,131 +38,33 @@ target_link_libraries(minikql-comp_nodes-no_llvm PUBLIC parser-pg_wrapper-interface library-yql-utils library-actors-core + public-issue-protos minikql-invoke_builtins-no_llvm ) target_sources(minikql-comp_nodes-no_llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_addmember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_aggrcount.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_append.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_apply.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_count.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_factory.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_minmax.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_some.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_sum.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_coalesce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_if.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_just.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_logical.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_compress.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_func.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_skiptake.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_top.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_tuple.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_blocks.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_callable.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chain_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chain1_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_check_args.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chopper.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_coalesce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_collect.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_combine.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_contains.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_div.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_mod.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_mul.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_dictitems.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_discard.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_element.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_ensure.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_enumerate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_exists.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_extend.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_factory.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_filter.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_flatmap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_flow.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fold.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fold1.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_frombytes.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fromstring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fromyson.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_group.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_grace_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_grace_join_imp.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_guess.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_hasitems.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_heap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_hopping.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_if.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_ifpresent.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_invoke.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_iterable.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_iterator.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_join_dict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_lazy_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_length.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_listfromrange.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_logical.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_lookup.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_mapnext.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_map_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_match_recognize.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_multihopping.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_multimap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_next_value.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_nop.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_now.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_null.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_pickle.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_prepend.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_queue.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_random.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_range.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_reduce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_removemember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_replicate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_reverse.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_rh_hash.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_round.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_safe_circular_buffer.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_scalar_apply.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_seq.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_size.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_skip.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_sort.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_source.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_squeeze_state.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_squeeze_to_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_condense.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_condense1.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_switch.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_take.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_time_order_recover.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_timezone.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tobytes.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_todict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_toindexdict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tooptional.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tostring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_udf.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_unwrap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_varitem.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_visitall.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_way.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_weakmember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_while.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_chain_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_chopper.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_combine.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_condense.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_filter.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_top_sort.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_withcontext.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_zip.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h ) diff --git a/ydb/library/yql/minikql/comp_nodes/no_llvm/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/comp_nodes/no_llvm/CMakeLists.linux-x86_64.txt index 3064042982b3..4d9ca7300298 100644 --- a/ydb/library/yql/minikql/comp_nodes/no_llvm/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/comp_nodes/no_llvm/CMakeLists.linux-x86_64.txt @@ -7,7 +7,10 @@ -add_library(minikql-comp_nodes-no_llvm) +add_library(minikql-comp_nodes-no_llvm STATIC) +set_property(TARGET minikql-comp_nodes-no_llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-comp_nodes-no_llvm PRIVATE -mprfchw -DMKQL_DISABLE_CODEGEN @@ -15,6 +18,13 @@ target_compile_options(minikql-comp_nodes-no_llvm PRIVATE ) target_include_directories(minikql-comp_nodes-no_llvm PUBLIC ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/llvm_stub + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-comp_nodes-no_llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes ) target_link_libraries(minikql-comp_nodes-no_llvm PUBLIC contrib-libs-linux-headers @@ -28,131 +38,33 @@ target_link_libraries(minikql-comp_nodes-no_llvm PUBLIC parser-pg_wrapper-interface library-yql-utils library-actors-core + public-issue-protos minikql-invoke_builtins-no_llvm ) target_sources(minikql-comp_nodes-no_llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_addmember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_aggrcount.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_append.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_apply.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_count.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_factory.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_minmax.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_some.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_sum.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_coalesce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_if.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_just.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_logical.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_compress.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_func.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_skiptake.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_top.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_tuple.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_blocks.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_callable.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chain_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chain1_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_check_args.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chopper.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_coalesce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_collect.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_combine.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_contains.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_div.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_mod.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_mul.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_dictitems.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_discard.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_element.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_ensure.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_enumerate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_exists.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_extend.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_factory.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_filter.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_flatmap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_flow.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fold.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fold1.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_frombytes.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fromstring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fromyson.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_group.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_grace_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_grace_join_imp.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_guess.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_hasitems.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_heap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_hopping.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_if.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_ifpresent.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_invoke.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_iterable.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_iterator.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_join_dict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_lazy_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_length.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_listfromrange.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_logical.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_lookup.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_mapnext.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_map_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_match_recognize.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_multihopping.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_multimap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_next_value.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_nop.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_now.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_null.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_pickle.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_prepend.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_queue.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_random.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_range.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_reduce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_removemember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_replicate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_reverse.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_rh_hash.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_round.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_safe_circular_buffer.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_scalar_apply.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_seq.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_size.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_skip.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_sort.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_source.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_squeeze_state.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_squeeze_to_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_condense.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_condense1.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_switch.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_take.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_time_order_recover.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_timezone.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tobytes.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_todict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_toindexdict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tooptional.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tostring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_udf.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_unwrap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_varitem.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_visitall.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_way.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_weakmember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_while.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_chain_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_chopper.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_combine.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_condense.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_filter.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_top_sort.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_withcontext.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_zip.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h ) diff --git a/ydb/library/yql/minikql/comp_nodes/no_llvm/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/comp_nodes/no_llvm/CMakeLists.windows-x86_64.txt index f8f0fbbc1e57..d4e7ad812c30 100644 --- a/ydb/library/yql/minikql/comp_nodes/no_llvm/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/minikql/comp_nodes/no_llvm/CMakeLists.windows-x86_64.txt @@ -7,7 +7,10 @@ -add_library(minikql-comp_nodes-no_llvm) +add_library(minikql-comp_nodes-no_llvm STATIC) +set_property(TARGET minikql-comp_nodes-no_llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-comp_nodes-no_llvm PRIVATE -mprfchw -DMKQL_DISABLE_CODEGEN @@ -15,6 +18,13 @@ target_compile_options(minikql-comp_nodes-no_llvm PRIVATE ) target_include_directories(minikql-comp_nodes-no_llvm PUBLIC ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/llvm_stub + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-comp_nodes-no_llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes ) target_link_libraries(minikql-comp_nodes-no_llvm PUBLIC contrib-libs-cxxsupp @@ -27,131 +37,33 @@ target_link_libraries(minikql-comp_nodes-no_llvm PUBLIC parser-pg_wrapper-interface library-yql-utils library-actors-core + public-issue-protos minikql-invoke_builtins-no_llvm ) target_sources(minikql-comp_nodes-no_llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_addmember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_aggrcount.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_append.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_apply.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_count.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_factory.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_minmax.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_some.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_agg_sum.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_coalesce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_if.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_just.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_logical.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_compress.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_func.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_skiptake.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_top.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_block_tuple.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_blocks.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_callable.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chain_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chain1_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_check_args.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_chopper.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_coalesce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_collect.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_combine.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_contains.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_div.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_mod.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_decimal_mul.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_dictitems.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_discard.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_element.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_ensure.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_enumerate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_exists.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_extend.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_factory.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_filter.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_flatmap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_flow.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fold.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fold1.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_frombytes.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fromstring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_fromyson.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_group.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_grace_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_grace_join_imp.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_guess.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_hasitems.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_heap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_hopping.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_if.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_ifpresent.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_invoke.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_iterable.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_iterator.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_join_dict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_lazy_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_length.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_listfromrange.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_logical.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_lookup.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_mapnext.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_map_join.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_match_recognize.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_multihopping.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_multimap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_next_value.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_nop.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_now.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_null.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_pickle.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_prepend.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_queue.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_random.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_range.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_reduce.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_removemember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_replicate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_reverse.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_rh_hash.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_round.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_safe_circular_buffer.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_scalar_apply.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_seq.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_size.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_skip.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_sort.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_source.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_squeeze_state.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_squeeze_to_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_condense.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_condense1.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_switch.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_take.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_time_order_recover.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_timezone.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tobytes.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_todict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_toindexdict.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tooptional.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_tostring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_udf.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_unwrap.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_varitem.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_visitall.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_way.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_weakmember.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_while.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_chain_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_chopper.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_combine.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_condense.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_filter.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_map.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_wide_top_sort.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_withcontext.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/comp_nodes/mkql_zip.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h ) diff --git a/ydb/library/yql/minikql/computation/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/computation/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..8e29fab24ddc --- /dev/null +++ b/ydb/library/yql/minikql/computation/CMakeLists.darwin-arm64.txt @@ -0,0 +1,41 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(llvm) +add_subdirectory(llvm14) +add_subdirectory(no_llvm) + +add_library(yql-minikql-computation) +target_compile_options(yql-minikql-computation PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(yql-minikql-computation PUBLIC + contrib-libs-cxxsupp + yutil + libs-apache-arrow + yql-public-types + parser-pg_wrapper-interface + yql-public-udf + yql-minikql-arrow +) +target_sources(yql-minikql-computation PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_builder.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_impl.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_reader.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_transport.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_holders.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_impl.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_impl.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_custom_list.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort.cpp +) diff --git a/ydb/library/yql/minikql/computation/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/computation/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..8e29fab24ddc --- /dev/null +++ b/ydb/library/yql/minikql/computation/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,41 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(llvm) +add_subdirectory(llvm14) +add_subdirectory(no_llvm) + +add_library(yql-minikql-computation) +target_compile_options(yql-minikql-computation PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(yql-minikql-computation PUBLIC + contrib-libs-cxxsupp + yutil + libs-apache-arrow + yql-public-types + parser-pg_wrapper-interface + yql-public-udf + yql-minikql-arrow +) +target_sources(yql-minikql-computation PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_builder.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_impl.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_reader.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_transport.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_holders.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_impl.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_impl.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_custom_list.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort.cpp +) diff --git a/ydb/library/yql/minikql/computation/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/computation/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..d81565f71139 --- /dev/null +++ b/ydb/library/yql/minikql/computation/CMakeLists.linux-aarch64.txt @@ -0,0 +1,42 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(llvm) +add_subdirectory(llvm14) +add_subdirectory(no_llvm) + +add_library(yql-minikql-computation) +target_compile_options(yql-minikql-computation PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(yql-minikql-computation PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + libs-apache-arrow + yql-public-types + parser-pg_wrapper-interface + yql-public-udf + yql-minikql-arrow +) +target_sources(yql-minikql-computation PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_builder.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_impl.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_reader.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_transport.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_holders.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_impl.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_impl.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_custom_list.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort.cpp +) diff --git a/ydb/library/yql/minikql/computation/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/computation/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..d81565f71139 --- /dev/null +++ b/ydb/library/yql/minikql/computation/CMakeLists.linux-x86_64.txt @@ -0,0 +1,42 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(llvm) +add_subdirectory(llvm14) +add_subdirectory(no_llvm) + +add_library(yql-minikql-computation) +target_compile_options(yql-minikql-computation PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(yql-minikql-computation PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + libs-apache-arrow + yql-public-types + parser-pg_wrapper-interface + yql-public-udf + yql-minikql-arrow +) +target_sources(yql-minikql-computation PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_builder.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_impl.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_reader.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_transport.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_holders.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_impl.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_impl.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_custom_list.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort.cpp +) diff --git a/ydb/library/yql/minikql/computation/CMakeLists.txt b/ydb/library/yql/minikql/computation/CMakeLists.txt index 4716de1ef37a..d863ebd18067 100644 --- a/ydb/library/yql/minikql/computation/CMakeLists.txt +++ b/ydb/library/yql/minikql/computation/CMakeLists.txt @@ -6,6 +6,14 @@ # original buildsystem will not be accepted. -add_subdirectory(llvm) -add_subdirectory(no_llvm) -add_subdirectory(ut) +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/minikql/computation/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/computation/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..8e29fab24ddc --- /dev/null +++ b/ydb/library/yql/minikql/computation/CMakeLists.windows-x86_64.txt @@ -0,0 +1,41 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(llvm) +add_subdirectory(llvm14) +add_subdirectory(no_llvm) + +add_library(yql-minikql-computation) +target_compile_options(yql-minikql-computation PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(yql-minikql-computation PUBLIC + contrib-libs-cxxsupp + yutil + libs-apache-arrow + yql-public-types + parser-pg_wrapper-interface + yql-public-udf + yql-minikql-arrow +) +target_sources(yql-minikql-computation PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_builder.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_impl.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_reader.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_transport.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_holders.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_impl.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_impl.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_custom_list.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort.cpp +) diff --git a/ydb/library/yql/minikql/computation/llvm/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/computation/llvm/CMakeLists.darwin-arm64.txt index 61856a13c457..188ae0b8b636 100644 --- a/ydb/library/yql/minikql/computation/llvm/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/computation/llvm/CMakeLists.darwin-arm64.txt @@ -6,16 +6,26 @@ # original buildsystem will not be accepted. +add_subdirectory(ut) -add_library(minikql-computation-llvm) +add_library(minikql-computation-llvm STATIC) +set_property(TARGET minikql-computation-llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-computation-llvm PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> +) +target_include_directories(minikql-computation-llvm PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-computation-llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation ) target_link_libraries(minikql-computation-llvm PUBLIC contrib-libs-cxxsupp yutil - yql-minikql-codegen + minikql-codegen-llvm llvm12-lib-IR lib-ExecutionEngine-MCJIT llvm12-lib-Linker @@ -30,28 +40,16 @@ target_link_libraries(minikql-computation-llvm PUBLIC library-cpp-time_provider library-yql-minikql yql-minikql-arrow + yql-minikql-computation parser-pg_wrapper-interface yql-public-udf library-yql-utils cpp-threading-future ) target_sources(minikql-computation-llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_builder.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_reader.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_transport.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph_saveload.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_holders.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_custom_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_llvm_base.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h ) diff --git a/ydb/library/yql/minikql/computation/llvm/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/computation/llvm/CMakeLists.darwin-x86_64.txt index 61856a13c457..188ae0b8b636 100644 --- a/ydb/library/yql/minikql/computation/llvm/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/computation/llvm/CMakeLists.darwin-x86_64.txt @@ -6,16 +6,26 @@ # original buildsystem will not be accepted. +add_subdirectory(ut) -add_library(minikql-computation-llvm) +add_library(minikql-computation-llvm STATIC) +set_property(TARGET minikql-computation-llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-computation-llvm PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> +) +target_include_directories(minikql-computation-llvm PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-computation-llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation ) target_link_libraries(minikql-computation-llvm PUBLIC contrib-libs-cxxsupp yutil - yql-minikql-codegen + minikql-codegen-llvm llvm12-lib-IR lib-ExecutionEngine-MCJIT llvm12-lib-Linker @@ -30,28 +40,16 @@ target_link_libraries(minikql-computation-llvm PUBLIC library-cpp-time_provider library-yql-minikql yql-minikql-arrow + yql-minikql-computation parser-pg_wrapper-interface yql-public-udf library-yql-utils cpp-threading-future ) target_sources(minikql-computation-llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_builder.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_reader.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_transport.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph_saveload.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_holders.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_custom_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_llvm_base.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h ) diff --git a/ydb/library/yql/minikql/computation/llvm/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/computation/llvm/CMakeLists.linux-aarch64.txt index 35d3e1a93f2a..eb90eb50d3e8 100644 --- a/ydb/library/yql/minikql/computation/llvm/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/computation/llvm/CMakeLists.linux-aarch64.txt @@ -6,17 +6,27 @@ # original buildsystem will not be accepted. +add_subdirectory(ut) -add_library(minikql-computation-llvm) +add_library(minikql-computation-llvm STATIC) +set_property(TARGET minikql-computation-llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-computation-llvm PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> +) +target_include_directories(minikql-computation-llvm PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-computation-llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation ) target_link_libraries(minikql-computation-llvm PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - yql-minikql-codegen + minikql-codegen-llvm llvm12-lib-IR lib-ExecutionEngine-MCJIT llvm12-lib-Linker @@ -31,28 +41,16 @@ target_link_libraries(minikql-computation-llvm PUBLIC library-cpp-time_provider library-yql-minikql yql-minikql-arrow + yql-minikql-computation parser-pg_wrapper-interface yql-public-udf library-yql-utils cpp-threading-future ) target_sources(minikql-computation-llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_builder.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_reader.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_transport.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph_saveload.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_holders.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_custom_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_llvm_base.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h ) diff --git a/ydb/library/yql/minikql/computation/llvm/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/computation/llvm/CMakeLists.linux-x86_64.txt index 35d3e1a93f2a..eb90eb50d3e8 100644 --- a/ydb/library/yql/minikql/computation/llvm/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/computation/llvm/CMakeLists.linux-x86_64.txt @@ -6,17 +6,27 @@ # original buildsystem will not be accepted. +add_subdirectory(ut) -add_library(minikql-computation-llvm) +add_library(minikql-computation-llvm STATIC) +set_property(TARGET minikql-computation-llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-computation-llvm PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> +) +target_include_directories(minikql-computation-llvm PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-computation-llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation ) target_link_libraries(minikql-computation-llvm PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - yql-minikql-codegen + minikql-codegen-llvm llvm12-lib-IR lib-ExecutionEngine-MCJIT llvm12-lib-Linker @@ -31,28 +41,16 @@ target_link_libraries(minikql-computation-llvm PUBLIC library-cpp-time_provider library-yql-minikql yql-minikql-arrow + yql-minikql-computation parser-pg_wrapper-interface yql-public-udf library-yql-utils cpp-threading-future ) target_sources(minikql-computation-llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_builder.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_reader.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_transport.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph_saveload.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_holders.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_custom_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_llvm_base.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h ) diff --git a/ydb/library/yql/minikql/computation/llvm/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/computation/llvm/CMakeLists.windows-x86_64.txt index 61856a13c457..188ae0b8b636 100644 --- a/ydb/library/yql/minikql/computation/llvm/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/minikql/computation/llvm/CMakeLists.windows-x86_64.txt @@ -6,16 +6,26 @@ # original buildsystem will not be accepted. +add_subdirectory(ut) -add_library(minikql-computation-llvm) +add_library(minikql-computation-llvm STATIC) +set_property(TARGET minikql-computation-llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-computation-llvm PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> +) +target_include_directories(minikql-computation-llvm PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-computation-llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation ) target_link_libraries(minikql-computation-llvm PUBLIC contrib-libs-cxxsupp yutil - yql-minikql-codegen + minikql-codegen-llvm llvm12-lib-IR lib-ExecutionEngine-MCJIT llvm12-lib-Linker @@ -30,28 +40,16 @@ target_link_libraries(minikql-computation-llvm PUBLIC library-cpp-time_provider library-yql-minikql yql-minikql-arrow + yql-minikql-computation parser-pg_wrapper-interface yql-public-udf library-yql-utils cpp-threading-future ) target_sources(minikql-computation-llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_builder.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_reader.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_transport.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph_saveload.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_holders.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_custom_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_llvm_base.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h ) diff --git a/ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..c4666963c996 --- /dev/null +++ b/ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.darwin-arm64.txt @@ -0,0 +1,92 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-computation-llvm-ut) +target_compile_options(ydb-library-yql-minikql-computation-llvm-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-library-yql-minikql-computation-llvm-ut PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + minikql-codegen-llvm + minikql-computation-llvm + minikql-comp_nodes-llvm + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + libs-apache-arrow + cpp-threading-local_executor + yql-parser-pg_wrapper + udf-service-exception_policy + yql-dq-proto +) +target_link_options(ydb-library-yql-minikql-computation-llvm-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-computation-llvm-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_list_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_dict_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph_saveload_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort_ut.cpp +) +set_property( + TARGET + ydb-library-yql-minikql-computation-llvm-ut + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-library-yql-minikql-computation-llvm-ut + TEST_TARGET + ydb-library-yql-minikql-computation-llvm-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm-ut + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-library-yql-minikql-computation-llvm-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-computation-llvm-ut) diff --git a/ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..290f62618d3f --- /dev/null +++ b/ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,93 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-computation-llvm-ut) +target_compile_options(ydb-library-yql-minikql-computation-llvm-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-library-yql-minikql-computation-llvm-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + minikql-codegen-llvm + minikql-computation-llvm + minikql-comp_nodes-llvm + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + libs-apache-arrow + cpp-threading-local_executor + yql-parser-pg_wrapper + udf-service-exception_policy + yql-dq-proto +) +target_link_options(ydb-library-yql-minikql-computation-llvm-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-computation-llvm-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_list_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_dict_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph_saveload_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort_ut.cpp +) +set_property( + TARGET + ydb-library-yql-minikql-computation-llvm-ut + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-library-yql-minikql-computation-llvm-ut + TEST_TARGET + ydb-library-yql-minikql-computation-llvm-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm-ut + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-library-yql-minikql-computation-llvm-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-computation-llvm-ut) diff --git a/ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..38554e4098f4 --- /dev/null +++ b/ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.linux-aarch64.txt @@ -0,0 +1,95 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-computation-llvm-ut) +target_compile_options(ydb-library-yql-minikql-computation-llvm-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-library-yql-minikql-computation-llvm-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + minikql-codegen-llvm + minikql-computation-llvm + minikql-comp_nodes-llvm + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + libs-apache-arrow + cpp-threading-local_executor + yql-parser-pg_wrapper + udf-service-exception_policy + yql-dq-proto +) +target_link_options(ydb-library-yql-minikql-computation-llvm-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-computation-llvm-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_list_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_dict_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph_saveload_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort_ut.cpp +) +set_property( + TARGET + ydb-library-yql-minikql-computation-llvm-ut + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-library-yql-minikql-computation-llvm-ut + TEST_TARGET + ydb-library-yql-minikql-computation-llvm-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm-ut + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-library-yql-minikql-computation-llvm-ut + cpp-malloc-jemalloc +) +vcs_info(ydb-library-yql-minikql-computation-llvm-ut) diff --git a/ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..ab5ce02b7eb7 --- /dev/null +++ b/ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.linux-x86_64.txt @@ -0,0 +1,97 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-computation-llvm-ut) +target_compile_options(ydb-library-yql-minikql-computation-llvm-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-library-yql-minikql-computation-llvm-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + minikql-codegen-llvm + minikql-computation-llvm + minikql-comp_nodes-llvm + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + libs-apache-arrow + cpp-threading-local_executor + yql-parser-pg_wrapper + udf-service-exception_policy + yql-dq-proto +) +target_link_options(ydb-library-yql-minikql-computation-llvm-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-computation-llvm-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_list_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_dict_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph_saveload_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort_ut.cpp +) +set_property( + TARGET + ydb-library-yql-minikql-computation-llvm-ut + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-library-yql-minikql-computation-llvm-ut + TEST_TARGET + ydb-library-yql-minikql-computation-llvm-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm-ut + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-library-yql-minikql-computation-llvm-ut + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(ydb-library-yql-minikql-computation-llvm-ut) diff --git a/ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.txt b/ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..0fbe9897eeb4 --- /dev/null +++ b/ydb/library/yql/minikql/computation/llvm/ut/CMakeLists.windows-x86_64.txt @@ -0,0 +1,88 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-computation-llvm-ut) +target_compile_options(ydb-library-yql-minikql-computation-llvm-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-library-yql-minikql-computation-llvm-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + minikql-codegen-llvm + minikql-computation-llvm + minikql-comp_nodes-llvm + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + libs-apache-arrow + cpp-threading-local_executor + yql-parser-pg_wrapper + udf-service-exception_policy + yql-dq-proto +) +target_sources(ydb-library-yql-minikql-computation-llvm-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_list_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_dict_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph_saveload_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort_ut.cpp +) +set_property( + TARGET + ydb-library-yql-minikql-computation-llvm-ut + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-library-yql-minikql-computation-llvm-ut + TEST_TARGET + ydb-library-yql-minikql-computation-llvm-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm-ut + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-library-yql-minikql-computation-llvm-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-computation-llvm-ut) diff --git a/ydb/library/yql/minikql/computation/llvm14/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/computation/llvm14/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..e7ec6019b29b --- /dev/null +++ b/ydb/library/yql/minikql/computation/llvm14/CMakeLists.darwin-arm64.txt @@ -0,0 +1,55 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(minikql-computation-llvm14 STATIC) +set_property(TARGET minikql-computation-llvm14 PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(minikql-computation-llvm14 PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(minikql-computation-llvm14 PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm14 + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm14/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-computation-llvm14 PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation +) +target_link_libraries(minikql-computation-llvm14 PUBLIC + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + libs-apache-arrow + library-actors-util + library-cpp-enumbitset + library-cpp-packedtypes + library-cpp-random_provider + library-cpp-time_provider + library-yql-minikql + yql-minikql-arrow + yql-minikql-computation + parser-pg_wrapper-interface + yql-public-udf + library-yql-utils + cpp-threading-future +) +target_sources(minikql-computation-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) diff --git a/ydb/library/yql/minikql/computation/llvm14/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/computation/llvm14/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..e7ec6019b29b --- /dev/null +++ b/ydb/library/yql/minikql/computation/llvm14/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,55 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(minikql-computation-llvm14 STATIC) +set_property(TARGET minikql-computation-llvm14 PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(minikql-computation-llvm14 PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(minikql-computation-llvm14 PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm14 + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm14/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-computation-llvm14 PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation +) +target_link_libraries(minikql-computation-llvm14 PUBLIC + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + libs-apache-arrow + library-actors-util + library-cpp-enumbitset + library-cpp-packedtypes + library-cpp-random_provider + library-cpp-time_provider + library-yql-minikql + yql-minikql-arrow + yql-minikql-computation + parser-pg_wrapper-interface + yql-public-udf + library-yql-utils + cpp-threading-future +) +target_sources(minikql-computation-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) diff --git a/ydb/library/yql/minikql/computation/llvm14/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/computation/llvm14/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..1536df10b75a --- /dev/null +++ b/ydb/library/yql/minikql/computation/llvm14/CMakeLists.linux-aarch64.txt @@ -0,0 +1,56 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(minikql-computation-llvm14 STATIC) +set_property(TARGET minikql-computation-llvm14 PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(minikql-computation-llvm14 PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(minikql-computation-llvm14 PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm14 + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm14/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-computation-llvm14 PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation +) +target_link_libraries(minikql-computation-llvm14 PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + libs-apache-arrow + library-actors-util + library-cpp-enumbitset + library-cpp-packedtypes + library-cpp-random_provider + library-cpp-time_provider + library-yql-minikql + yql-minikql-arrow + yql-minikql-computation + parser-pg_wrapper-interface + yql-public-udf + library-yql-utils + cpp-threading-future +) +target_sources(minikql-computation-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) diff --git a/ydb/library/yql/minikql/computation/llvm14/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/computation/llvm14/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..1536df10b75a --- /dev/null +++ b/ydb/library/yql/minikql/computation/llvm14/CMakeLists.linux-x86_64.txt @@ -0,0 +1,56 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(minikql-computation-llvm14 STATIC) +set_property(TARGET minikql-computation-llvm14 PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(minikql-computation-llvm14 PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(minikql-computation-llvm14 PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm14 + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm14/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-computation-llvm14 PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation +) +target_link_libraries(minikql-computation-llvm14 PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + libs-apache-arrow + library-actors-util + library-cpp-enumbitset + library-cpp-packedtypes + library-cpp-random_provider + library-cpp-time_provider + library-yql-minikql + yql-minikql-arrow + yql-minikql-computation + parser-pg_wrapper-interface + yql-public-udf + library-yql-utils + cpp-threading-future +) +target_sources(minikql-computation-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) diff --git a/ydb/library/yql/minikql/computation/llvm14/CMakeLists.txt b/ydb/library/yql/minikql/computation/llvm14/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/minikql/computation/llvm14/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/minikql/computation/llvm14/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/computation/llvm14/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..e7ec6019b29b --- /dev/null +++ b/ydb/library/yql/minikql/computation/llvm14/CMakeLists.windows-x86_64.txt @@ -0,0 +1,55 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(minikql-computation-llvm14 STATIC) +set_property(TARGET minikql-computation-llvm14 PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(minikql-computation-llvm14 PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(minikql-computation-llvm14 PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm14 + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm14/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-computation-llvm14 PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation +) +target_link_libraries(minikql-computation-llvm14 PUBLIC + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + libs-apache-arrow + library-actors-util + library-cpp-enumbitset + library-cpp-packedtypes + library-cpp-random_provider + library-cpp-time_provider + library-yql-minikql + yql-minikql-arrow + yql-minikql-computation + parser-pg_wrapper-interface + yql-public-udf + library-yql-utils + cpp-threading-future +) +target_sources(minikql-computation-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) diff --git a/ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..7b5290660bc8 --- /dev/null +++ b/ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.darwin-arm64.txt @@ -0,0 +1,92 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-computation-llvm14-ut) +target_compile_options(ydb-library-yql-minikql-computation-llvm14-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-library-yql-minikql-computation-llvm14-ut PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + minikql-codegen-llvm14 + minikql-computation-llvm14 + minikql-comp_nodes-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + libs-apache-arrow + cpp-threading-local_executor + yql-parser-pg_wrapper + udf-service-exception_policy + yql-dq-proto +) +target_link_options(ydb-library-yql-minikql-computation-llvm14-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-computation-llvm14-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_list_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_dict_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph_saveload_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort_ut.cpp +) +set_property( + TARGET + ydb-library-yql-minikql-computation-llvm14-ut + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-library-yql-minikql-computation-llvm14-ut + TEST_TARGET + ydb-library-yql-minikql-computation-llvm14-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm14-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm14-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm14-ut + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-library-yql-minikql-computation-llvm14-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-computation-llvm14-ut) diff --git a/ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..d721312fa5f4 --- /dev/null +++ b/ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,93 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-computation-llvm14-ut) +target_compile_options(ydb-library-yql-minikql-computation-llvm14-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-library-yql-minikql-computation-llvm14-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + minikql-codegen-llvm14 + minikql-computation-llvm14 + minikql-comp_nodes-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + libs-apache-arrow + cpp-threading-local_executor + yql-parser-pg_wrapper + udf-service-exception_policy + yql-dq-proto +) +target_link_options(ydb-library-yql-minikql-computation-llvm14-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-computation-llvm14-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_list_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_dict_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph_saveload_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort_ut.cpp +) +set_property( + TARGET + ydb-library-yql-minikql-computation-llvm14-ut + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-library-yql-minikql-computation-llvm14-ut + TEST_TARGET + ydb-library-yql-minikql-computation-llvm14-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm14-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm14-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm14-ut + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-library-yql-minikql-computation-llvm14-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-computation-llvm14-ut) diff --git a/ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..ffb925a0d790 --- /dev/null +++ b/ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.linux-aarch64.txt @@ -0,0 +1,95 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-computation-llvm14-ut) +target_compile_options(ydb-library-yql-minikql-computation-llvm14-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-library-yql-minikql-computation-llvm14-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + minikql-codegen-llvm14 + minikql-computation-llvm14 + minikql-comp_nodes-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + libs-apache-arrow + cpp-threading-local_executor + yql-parser-pg_wrapper + udf-service-exception_policy + yql-dq-proto +) +target_link_options(ydb-library-yql-minikql-computation-llvm14-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-computation-llvm14-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_list_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_dict_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph_saveload_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort_ut.cpp +) +set_property( + TARGET + ydb-library-yql-minikql-computation-llvm14-ut + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-library-yql-minikql-computation-llvm14-ut + TEST_TARGET + ydb-library-yql-minikql-computation-llvm14-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm14-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm14-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm14-ut + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-library-yql-minikql-computation-llvm14-ut + cpp-malloc-jemalloc +) +vcs_info(ydb-library-yql-minikql-computation-llvm14-ut) diff --git a/ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..13bb21ce3a04 --- /dev/null +++ b/ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.linux-x86_64.txt @@ -0,0 +1,97 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-computation-llvm14-ut) +target_compile_options(ydb-library-yql-minikql-computation-llvm14-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-library-yql-minikql-computation-llvm14-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + minikql-codegen-llvm14 + minikql-computation-llvm14 + minikql-comp_nodes-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + libs-apache-arrow + cpp-threading-local_executor + yql-parser-pg_wrapper + udf-service-exception_policy + yql-dq-proto +) +target_link_options(ydb-library-yql-minikql-computation-llvm14-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-library-yql-minikql-computation-llvm14-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_list_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_dict_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph_saveload_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort_ut.cpp +) +set_property( + TARGET + ydb-library-yql-minikql-computation-llvm14-ut + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-library-yql-minikql-computation-llvm14-ut + TEST_TARGET + ydb-library-yql-minikql-computation-llvm14-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm14-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm14-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm14-ut + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-library-yql-minikql-computation-llvm14-ut + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(ydb-library-yql-minikql-computation-llvm14-ut) diff --git a/ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.txt b/ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..96bb2bcc6a2a --- /dev/null +++ b/ydb/library/yql/minikql/computation/llvm14/ut/CMakeLists.windows-x86_64.txt @@ -0,0 +1,88 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-computation-llvm14-ut) +target_compile_options(ydb-library-yql-minikql-computation-llvm14-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-library-yql-minikql-computation-llvm14-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + minikql-codegen-llvm14 + minikql-computation-llvm14 + minikql-comp_nodes-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + libs-apache-arrow + cpp-threading-local_executor + yql-parser-pg_wrapper + udf-service-exception_policy + yql-dq-proto +) +target_sources(ydb-library-yql-minikql-computation-llvm14-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_list_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_dict_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph_saveload_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder_ut.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort_ut.cpp +) +set_property( + TARGET + ydb-library-yql-minikql-computation-llvm14-ut + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-library-yql-minikql-computation-llvm14-ut + TEST_TARGET + ydb-library-yql-minikql-computation-llvm14-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm14-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm14-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-computation-llvm14-ut + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-library-yql-minikql-computation-llvm14-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-computation-llvm14-ut) diff --git a/ydb/library/yql/minikql/computation/no_llvm/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/computation/no_llvm/CMakeLists.darwin-arm64.txt index 1758ce1eba3e..2bcc37d366f8 100644 --- a/ydb/library/yql/minikql/computation/no_llvm/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/computation/no_llvm/CMakeLists.darwin-arm64.txt @@ -7,13 +7,21 @@ -add_library(minikql-computation-no_llvm) +add_library(minikql-computation-no_llvm STATIC) +set_property(TARGET minikql-computation-no_llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-computation-no_llvm PRIVATE -DMKQL_DISABLE_CODEGEN -DUSE_CURRENT_UDF_ABI_VERSION ) target_include_directories(minikql-computation-no_llvm PUBLIC ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/llvm_stub + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/no_llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/no_llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-computation-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation ) target_link_libraries(minikql-computation-no_llvm PUBLIC contrib-libs-cxxsupp @@ -26,28 +34,16 @@ target_link_libraries(minikql-computation-no_llvm PUBLIC library-cpp-time_provider library-yql-minikql yql-minikql-arrow + yql-minikql-computation parser-pg_wrapper-interface yql-public-udf library-yql-utils cpp-threading-future ) target_sources(minikql-computation-no_llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_builder.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_reader.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_transport.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph_saveload.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_holders.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_custom_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_llvm_base.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h ) diff --git a/ydb/library/yql/minikql/computation/no_llvm/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/computation/no_llvm/CMakeLists.darwin-x86_64.txt index 1758ce1eba3e..2bcc37d366f8 100644 --- a/ydb/library/yql/minikql/computation/no_llvm/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/computation/no_llvm/CMakeLists.darwin-x86_64.txt @@ -7,13 +7,21 @@ -add_library(minikql-computation-no_llvm) +add_library(minikql-computation-no_llvm STATIC) +set_property(TARGET minikql-computation-no_llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-computation-no_llvm PRIVATE -DMKQL_DISABLE_CODEGEN -DUSE_CURRENT_UDF_ABI_VERSION ) target_include_directories(minikql-computation-no_llvm PUBLIC ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/llvm_stub + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/no_llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/no_llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-computation-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation ) target_link_libraries(minikql-computation-no_llvm PUBLIC contrib-libs-cxxsupp @@ -26,28 +34,16 @@ target_link_libraries(minikql-computation-no_llvm PUBLIC library-cpp-time_provider library-yql-minikql yql-minikql-arrow + yql-minikql-computation parser-pg_wrapper-interface yql-public-udf library-yql-utils cpp-threading-future ) target_sources(minikql-computation-no_llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_builder.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_reader.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_transport.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph_saveload.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_holders.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_custom_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_llvm_base.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h ) diff --git a/ydb/library/yql/minikql/computation/no_llvm/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/computation/no_llvm/CMakeLists.linux-aarch64.txt index 36cd2a43c7e0..af6df73b4e40 100644 --- a/ydb/library/yql/minikql/computation/no_llvm/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/computation/no_llvm/CMakeLists.linux-aarch64.txt @@ -7,13 +7,21 @@ -add_library(minikql-computation-no_llvm) +add_library(minikql-computation-no_llvm STATIC) +set_property(TARGET minikql-computation-no_llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-computation-no_llvm PRIVATE -DMKQL_DISABLE_CODEGEN -DUSE_CURRENT_UDF_ABI_VERSION ) target_include_directories(minikql-computation-no_llvm PUBLIC ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/llvm_stub + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/no_llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/no_llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-computation-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation ) target_link_libraries(minikql-computation-no_llvm PUBLIC contrib-libs-linux-headers @@ -27,28 +35,16 @@ target_link_libraries(minikql-computation-no_llvm PUBLIC library-cpp-time_provider library-yql-minikql yql-minikql-arrow + yql-minikql-computation parser-pg_wrapper-interface yql-public-udf library-yql-utils cpp-threading-future ) target_sources(minikql-computation-no_llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_builder.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_reader.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_transport.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph_saveload.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_holders.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_custom_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_llvm_base.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h ) diff --git a/ydb/library/yql/minikql/computation/no_llvm/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/computation/no_llvm/CMakeLists.linux-x86_64.txt index 36cd2a43c7e0..af6df73b4e40 100644 --- a/ydb/library/yql/minikql/computation/no_llvm/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/computation/no_llvm/CMakeLists.linux-x86_64.txt @@ -7,13 +7,21 @@ -add_library(minikql-computation-no_llvm) +add_library(minikql-computation-no_llvm STATIC) +set_property(TARGET minikql-computation-no_llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-computation-no_llvm PRIVATE -DMKQL_DISABLE_CODEGEN -DUSE_CURRENT_UDF_ABI_VERSION ) target_include_directories(minikql-computation-no_llvm PUBLIC ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/llvm_stub + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/no_llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/no_llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-computation-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation ) target_link_libraries(minikql-computation-no_llvm PUBLIC contrib-libs-linux-headers @@ -27,28 +35,16 @@ target_link_libraries(minikql-computation-no_llvm PUBLIC library-cpp-time_provider library-yql-minikql yql-minikql-arrow + yql-minikql-computation parser-pg_wrapper-interface yql-public-udf library-yql-utils cpp-threading-future ) target_sources(minikql-computation-no_llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_builder.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_reader.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_transport.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph_saveload.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_holders.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_custom_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_llvm_base.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h ) diff --git a/ydb/library/yql/minikql/computation/no_llvm/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/computation/no_llvm/CMakeLists.windows-x86_64.txt index 1758ce1eba3e..2bcc37d366f8 100644 --- a/ydb/library/yql/minikql/computation/no_llvm/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/minikql/computation/no_llvm/CMakeLists.windows-x86_64.txt @@ -7,13 +7,21 @@ -add_library(minikql-computation-no_llvm) +add_library(minikql-computation-no_llvm STATIC) +set_property(TARGET minikql-computation-no_llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-computation-no_llvm PRIVATE -DMKQL_DISABLE_CODEGEN -DUSE_CURRENT_UDF_ABI_VERSION ) target_include_directories(minikql-computation-no_llvm PUBLIC ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/llvm_stub + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/no_llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/no_llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-computation-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation ) target_link_libraries(minikql-computation-no_llvm PUBLIC contrib-libs-cxxsupp @@ -26,28 +34,16 @@ target_link_libraries(minikql-computation-no_llvm PUBLIC library-cpp-time_provider library-yql-minikql yql-minikql-arrow + yql-minikql-computation parser-pg_wrapper-interface yql-public-udf library-yql-utils cpp-threading-future ) target_sources(minikql-computation-no_llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_builder.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_reader.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_block_transport.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_graph_saveload.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_holders.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_pack_impl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_custom_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_llvm_base.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_validate.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_value_builder.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_pattern_cache.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/presort.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/computation/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h ) diff --git a/ydb/library/yql/minikql/datetime/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/datetime/CMakeLists.darwin-arm64.txt index 02f6f2595657..f34ab37d1e0a 100644 --- a/ydb/library/yql/minikql/datetime/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/datetime/CMakeLists.darwin-arm64.txt @@ -14,7 +14,7 @@ target_compile_options(yql-minikql-datetime PRIVATE target_link_libraries(yql-minikql-datetime PUBLIC contrib-libs-cxxsupp yutil - minikql-computation-llvm + yql-minikql-computation ) target_sources(yql-minikql-datetime PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/datetime/datetime.cpp diff --git a/ydb/library/yql/minikql/datetime/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/datetime/CMakeLists.darwin-x86_64.txt index 02f6f2595657..f34ab37d1e0a 100644 --- a/ydb/library/yql/minikql/datetime/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/datetime/CMakeLists.darwin-x86_64.txt @@ -14,7 +14,7 @@ target_compile_options(yql-minikql-datetime PRIVATE target_link_libraries(yql-minikql-datetime PUBLIC contrib-libs-cxxsupp yutil - minikql-computation-llvm + yql-minikql-computation ) target_sources(yql-minikql-datetime PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/datetime/datetime.cpp diff --git a/ydb/library/yql/minikql/datetime/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/datetime/CMakeLists.linux-aarch64.txt index a0b8d3ef22d3..f0f965f43639 100644 --- a/ydb/library/yql/minikql/datetime/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/datetime/CMakeLists.linux-aarch64.txt @@ -15,7 +15,7 @@ target_link_libraries(yql-minikql-datetime PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - minikql-computation-llvm + yql-minikql-computation ) target_sources(yql-minikql-datetime PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/datetime/datetime.cpp diff --git a/ydb/library/yql/minikql/datetime/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/datetime/CMakeLists.linux-x86_64.txt index a0b8d3ef22d3..f0f965f43639 100644 --- a/ydb/library/yql/minikql/datetime/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/datetime/CMakeLists.linux-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(yql-minikql-datetime PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - minikql-computation-llvm + yql-minikql-computation ) target_sources(yql-minikql-datetime PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/datetime/datetime.cpp diff --git a/ydb/library/yql/minikql/datetime/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/datetime/CMakeLists.windows-x86_64.txt index 02f6f2595657..f34ab37d1e0a 100644 --- a/ydb/library/yql/minikql/datetime/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/minikql/datetime/CMakeLists.windows-x86_64.txt @@ -14,7 +14,7 @@ target_compile_options(yql-minikql-datetime PRIVATE target_link_libraries(yql-minikql-datetime PUBLIC contrib-libs-cxxsupp yutil - minikql-computation-llvm + yql-minikql-computation ) target_sources(yql-minikql-datetime PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/datetime/datetime.cpp diff --git a/ydb/library/yql/minikql/dom/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/dom/ut/CMakeLists.darwin-arm64.txt index 9354d5a677af..d86d382c78a9 100644 --- a/ydb/library/yql/minikql/dom/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/dom/ut/CMakeLists.darwin-arm64.txt @@ -19,7 +19,7 @@ target_link_libraries(ydb-library-yql-minikql-dom-ut PUBLIC yutil cpp-testing-unittest_main yql-minikql-dom - minikql-computation-llvm + minikql-computation-llvm14 udf-service-exception_policy yql-sql-pg_dummy ) @@ -27,8 +27,6 @@ target_link_options(ydb-library-yql-minikql-dom-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-minikql-dom-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/dom/ut/yson_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/dom/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/dom/ut/CMakeLists.darwin-x86_64.txt index 81df648f141d..d59e3dceeecd 100644 --- a/ydb/library/yql/minikql/dom/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/dom/ut/CMakeLists.darwin-x86_64.txt @@ -20,7 +20,7 @@ target_link_libraries(ydb-library-yql-minikql-dom-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main yql-minikql-dom - minikql-computation-llvm + minikql-computation-llvm14 udf-service-exception_policy yql-sql-pg_dummy ) @@ -28,8 +28,6 @@ target_link_options(ydb-library-yql-minikql-dom-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-minikql-dom-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/dom/ut/yson_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/dom/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/dom/ut/CMakeLists.linux-aarch64.txt index 547435dce67f..c49460542215 100644 --- a/ydb/library/yql/minikql/dom/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/dom/ut/CMakeLists.linux-aarch64.txt @@ -20,7 +20,7 @@ target_link_libraries(ydb-library-yql-minikql-dom-ut PUBLIC yutil cpp-testing-unittest_main yql-minikql-dom - minikql-computation-llvm + minikql-computation-llvm14 udf-service-exception_policy yql-sql-pg_dummy ) @@ -30,9 +30,6 @@ target_link_options(ydb-library-yql-minikql-dom-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-minikql-dom-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/dom/ut/yson_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/dom/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/dom/ut/CMakeLists.linux-x86_64.txt index bec27f0e7ebe..c1242ce21acc 100644 --- a/ydb/library/yql/minikql/dom/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/dom/ut/CMakeLists.linux-x86_64.txt @@ -21,7 +21,7 @@ target_link_libraries(ydb-library-yql-minikql-dom-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main yql-minikql-dom - minikql-computation-llvm + minikql-computation-llvm14 udf-service-exception_policy yql-sql-pg_dummy ) @@ -31,9 +31,6 @@ target_link_options(ydb-library-yql-minikql-dom-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-minikql-dom-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/dom/ut/yson_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/invoke_builtins/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/invoke_builtins/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..eb7aee3e35f8 --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/CMakeLists.darwin-arm64.txt @@ -0,0 +1,17 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(llvm) +add_subdirectory(llvm14) +add_subdirectory(no_llvm) + +add_library(yql-minikql-invoke_builtins INTERFACE) +target_link_libraries(yql-minikql-invoke_builtins INTERFACE + contrib-libs-cxxsupp + yutil +) diff --git a/ydb/library/yql/minikql/invoke_builtins/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/invoke_builtins/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..eb7aee3e35f8 --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,17 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(llvm) +add_subdirectory(llvm14) +add_subdirectory(no_llvm) + +add_library(yql-minikql-invoke_builtins INTERFACE) +target_link_libraries(yql-minikql-invoke_builtins INTERFACE + contrib-libs-cxxsupp + yutil +) diff --git a/ydb/library/yql/minikql/invoke_builtins/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/invoke_builtins/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..7b34147ab0ae --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/CMakeLists.linux-aarch64.txt @@ -0,0 +1,18 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(llvm) +add_subdirectory(llvm14) +add_subdirectory(no_llvm) + +add_library(yql-minikql-invoke_builtins INTERFACE) +target_link_libraries(yql-minikql-invoke_builtins INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil +) diff --git a/ydb/library/yql/minikql/invoke_builtins/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/invoke_builtins/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..7b34147ab0ae --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/CMakeLists.linux-x86_64.txt @@ -0,0 +1,18 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(llvm) +add_subdirectory(llvm14) +add_subdirectory(no_llvm) + +add_library(yql-minikql-invoke_builtins INTERFACE) +target_link_libraries(yql-minikql-invoke_builtins INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil +) diff --git a/ydb/library/yql/minikql/invoke_builtins/CMakeLists.txt b/ydb/library/yql/minikql/invoke_builtins/CMakeLists.txt index 4716de1ef37a..d863ebd18067 100644 --- a/ydb/library/yql/minikql/invoke_builtins/CMakeLists.txt +++ b/ydb/library/yql/minikql/invoke_builtins/CMakeLists.txt @@ -6,6 +6,14 @@ # original buildsystem will not be accepted. -add_subdirectory(llvm) -add_subdirectory(no_llvm) -add_subdirectory(ut) +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/minikql/invoke_builtins/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/invoke_builtins/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..eb7aee3e35f8 --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/CMakeLists.windows-x86_64.txt @@ -0,0 +1,17 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(llvm) +add_subdirectory(llvm14) +add_subdirectory(no_llvm) + +add_library(yql-minikql-invoke_builtins INTERFACE) +target_link_libraries(yql-minikql-invoke_builtins INTERFACE + contrib-libs-cxxsupp + yutil +) diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/invoke_builtins/llvm/CMakeLists.darwin-arm64.txt index 751b74412234..5b36d0c8f9e4 100644 --- a/ydb/library/yql/minikql/invoke_builtins/llvm/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/invoke_builtins/llvm/CMakeLists.darwin-arm64.txt @@ -6,16 +6,27 @@ # original buildsystem will not be accepted. +add_subdirectory(ut) -add_library(minikql-invoke_builtins-llvm) +add_library(minikql-invoke_builtins-llvm STATIC) +set_property(TARGET minikql-invoke_builtins-llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-invoke_builtins-llvm PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> +) +target_include_directories(minikql-invoke_builtins-llvm PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-invoke_builtins-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins ) target_link_libraries(minikql-invoke_builtins-llvm PUBLIC contrib-libs-cxxsupp yutil - yql-minikql-codegen + minikql-codegen-llvm minikql-computation-llvm llvm12-lib-IR lib-ExecutionEngine-MCJIT @@ -31,43 +42,29 @@ target_link_libraries(minikql-invoke_builtins-llvm PUBLIC libs-apache-arrow ) target_sources(minikql-invoke_builtins-llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_abs.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_add.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitand.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitnot.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitor.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitxor.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_byteat.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_concat.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_convert.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_countbits.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_dec.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_div.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_find.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_inc.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_invprestr.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_max.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_min.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_minus.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_mod.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_mul.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_nanvl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_plus.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_rotleft.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_rotright.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_shiftleft.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_shiftright.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_string_kernels.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_sub.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_substring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_with.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_equals.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_not_equals.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_less.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_less_or_equal.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_greater.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_greater_or_equal.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h ) diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/invoke_builtins/llvm/CMakeLists.darwin-x86_64.txt index 751b74412234..5b36d0c8f9e4 100644 --- a/ydb/library/yql/minikql/invoke_builtins/llvm/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/invoke_builtins/llvm/CMakeLists.darwin-x86_64.txt @@ -6,16 +6,27 @@ # original buildsystem will not be accepted. +add_subdirectory(ut) -add_library(minikql-invoke_builtins-llvm) +add_library(minikql-invoke_builtins-llvm STATIC) +set_property(TARGET minikql-invoke_builtins-llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-invoke_builtins-llvm PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> +) +target_include_directories(minikql-invoke_builtins-llvm PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-invoke_builtins-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins ) target_link_libraries(minikql-invoke_builtins-llvm PUBLIC contrib-libs-cxxsupp yutil - yql-minikql-codegen + minikql-codegen-llvm minikql-computation-llvm llvm12-lib-IR lib-ExecutionEngine-MCJIT @@ -31,43 +42,29 @@ target_link_libraries(minikql-invoke_builtins-llvm PUBLIC libs-apache-arrow ) target_sources(minikql-invoke_builtins-llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_abs.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_add.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitand.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitnot.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitor.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitxor.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_byteat.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_concat.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_convert.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_countbits.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_dec.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_div.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_find.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_inc.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_invprestr.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_max.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_min.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_minus.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_mod.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_mul.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_nanvl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_plus.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_rotleft.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_rotright.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_shiftleft.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_shiftright.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_string_kernels.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_sub.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_substring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_with.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_equals.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_not_equals.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_less.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_less_or_equal.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_greater.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_greater_or_equal.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h ) diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/invoke_builtins/llvm/CMakeLists.linux-aarch64.txt index 7f52dde17d52..6eff594cd231 100644 --- a/ydb/library/yql/minikql/invoke_builtins/llvm/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/invoke_builtins/llvm/CMakeLists.linux-aarch64.txt @@ -6,17 +6,28 @@ # original buildsystem will not be accepted. +add_subdirectory(ut) -add_library(minikql-invoke_builtins-llvm) +add_library(minikql-invoke_builtins-llvm STATIC) +set_property(TARGET minikql-invoke_builtins-llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-invoke_builtins-llvm PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> +) +target_include_directories(minikql-invoke_builtins-llvm PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-invoke_builtins-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins ) target_link_libraries(minikql-invoke_builtins-llvm PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - yql-minikql-codegen + minikql-codegen-llvm minikql-computation-llvm llvm12-lib-IR lib-ExecutionEngine-MCJIT @@ -32,43 +43,29 @@ target_link_libraries(minikql-invoke_builtins-llvm PUBLIC libs-apache-arrow ) target_sources(minikql-invoke_builtins-llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_abs.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_add.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitand.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitnot.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitor.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitxor.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_byteat.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_concat.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_convert.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_countbits.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_dec.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_div.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_find.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_inc.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_invprestr.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_max.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_min.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_minus.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_mod.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_mul.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_nanvl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_plus.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_rotleft.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_rotright.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_shiftleft.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_shiftright.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_string_kernels.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_sub.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_substring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_with.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_equals.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_not_equals.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_less.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_less_or_equal.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_greater.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_greater_or_equal.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h ) diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/invoke_builtins/llvm/CMakeLists.linux-x86_64.txt index 7f52dde17d52..6eff594cd231 100644 --- a/ydb/library/yql/minikql/invoke_builtins/llvm/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/invoke_builtins/llvm/CMakeLists.linux-x86_64.txt @@ -6,17 +6,28 @@ # original buildsystem will not be accepted. +add_subdirectory(ut) -add_library(minikql-invoke_builtins-llvm) +add_library(minikql-invoke_builtins-llvm STATIC) +set_property(TARGET minikql-invoke_builtins-llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-invoke_builtins-llvm PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> +) +target_include_directories(minikql-invoke_builtins-llvm PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-invoke_builtins-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins ) target_link_libraries(minikql-invoke_builtins-llvm PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - yql-minikql-codegen + minikql-codegen-llvm minikql-computation-llvm llvm12-lib-IR lib-ExecutionEngine-MCJIT @@ -32,43 +43,29 @@ target_link_libraries(minikql-invoke_builtins-llvm PUBLIC libs-apache-arrow ) target_sources(minikql-invoke_builtins-llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_abs.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_add.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitand.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitnot.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitor.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitxor.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_byteat.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_concat.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_convert.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_countbits.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_dec.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_div.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_find.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_inc.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_invprestr.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_max.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_min.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_minus.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_mod.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_mul.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_nanvl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_plus.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_rotleft.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_rotright.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_shiftleft.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_shiftright.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_string_kernels.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_sub.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_substring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_with.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_equals.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_not_equals.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_less.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_less_or_equal.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_greater.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_greater_or_equal.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h ) diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/invoke_builtins/llvm/CMakeLists.windows-x86_64.txt index 751b74412234..5b36d0c8f9e4 100644 --- a/ydb/library/yql/minikql/invoke_builtins/llvm/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/minikql/invoke_builtins/llvm/CMakeLists.windows-x86_64.txt @@ -6,16 +6,27 @@ # original buildsystem will not be accepted. +add_subdirectory(ut) -add_library(minikql-invoke_builtins-llvm) +add_library(minikql-invoke_builtins-llvm STATIC) +set_property(TARGET minikql-invoke_builtins-llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-invoke_builtins-llvm PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> +) +target_include_directories(minikql-invoke_builtins-llvm PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-invoke_builtins-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins ) target_link_libraries(minikql-invoke_builtins-llvm PUBLIC contrib-libs-cxxsupp yutil - yql-minikql-codegen + minikql-codegen-llvm minikql-computation-llvm llvm12-lib-IR lib-ExecutionEngine-MCJIT @@ -31,43 +42,29 @@ target_link_libraries(minikql-invoke_builtins-llvm PUBLIC libs-apache-arrow ) target_sources(minikql-invoke_builtins-llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_abs.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_add.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitand.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitnot.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitor.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitxor.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_byteat.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_concat.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_convert.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_countbits.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_dec.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_div.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_find.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_inc.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_invprestr.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_max.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_min.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_minus.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_mod.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_mul.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_nanvl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_plus.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_rotleft.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_rotright.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_shiftleft.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_shiftright.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_string_kernels.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_sub.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_substring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_with.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_equals.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_not_equals.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_less.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_less_or_equal.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_greater.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_greater_or_equal.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h ) diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..0d269564b6c9 --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.darwin-arm64.txt @@ -0,0 +1,83 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-invoke_builtins-llvm-ut) +target_compile_options(ydb-library-yql-minikql-invoke_builtins-llvm-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-minikql-invoke_builtins-llvm-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins +) +target_link_libraries(ydb-library-yql-minikql-invoke_builtins-llvm-ut PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + minikql-codegen-llvm + minikql-invoke_builtins-llvm + minikql-computation-llvm + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + yql-public-udf + udf-service-exception_policy + yql-sql-pg_dummy +) +target_link_options(ydb-library-yql-minikql-invoke_builtins-llvm-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +set_property( + TARGET + ydb-library-yql-minikql-invoke_builtins-llvm-ut + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-library-yql-minikql-invoke_builtins-llvm-ut + TEST_TARGET + ydb-library-yql-minikql-invoke_builtins-llvm-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm-ut + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-library-yql-minikql-invoke_builtins-llvm-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-invoke_builtins-llvm-ut) diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..9ffb3ce5bf6b --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,84 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-invoke_builtins-llvm-ut) +target_compile_options(ydb-library-yql-minikql-invoke_builtins-llvm-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-minikql-invoke_builtins-llvm-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins +) +target_link_libraries(ydb-library-yql-minikql-invoke_builtins-llvm-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + minikql-codegen-llvm + minikql-invoke_builtins-llvm + minikql-computation-llvm + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + yql-public-udf + udf-service-exception_policy + yql-sql-pg_dummy +) +target_link_options(ydb-library-yql-minikql-invoke_builtins-llvm-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +set_property( + TARGET + ydb-library-yql-minikql-invoke_builtins-llvm-ut + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-library-yql-minikql-invoke_builtins-llvm-ut + TEST_TARGET + ydb-library-yql-minikql-invoke_builtins-llvm-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm-ut + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-library-yql-minikql-invoke_builtins-llvm-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-invoke_builtins-llvm-ut) diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..bae55d16d3fb --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.linux-aarch64.txt @@ -0,0 +1,86 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-invoke_builtins-llvm-ut) +target_compile_options(ydb-library-yql-minikql-invoke_builtins-llvm-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-minikql-invoke_builtins-llvm-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins +) +target_link_libraries(ydb-library-yql-minikql-invoke_builtins-llvm-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + minikql-codegen-llvm + minikql-invoke_builtins-llvm + minikql-computation-llvm + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + yql-public-udf + udf-service-exception_policy + yql-sql-pg_dummy +) +target_link_options(ydb-library-yql-minikql-invoke_builtins-llvm-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +set_property( + TARGET + ydb-library-yql-minikql-invoke_builtins-llvm-ut + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-library-yql-minikql-invoke_builtins-llvm-ut + TEST_TARGET + ydb-library-yql-minikql-invoke_builtins-llvm-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm-ut + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-library-yql-minikql-invoke_builtins-llvm-ut + cpp-malloc-jemalloc +) +vcs_info(ydb-library-yql-minikql-invoke_builtins-llvm-ut) diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..719ed36f6b75 --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.linux-x86_64.txt @@ -0,0 +1,88 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-invoke_builtins-llvm-ut) +target_compile_options(ydb-library-yql-minikql-invoke_builtins-llvm-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-minikql-invoke_builtins-llvm-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins +) +target_link_libraries(ydb-library-yql-minikql-invoke_builtins-llvm-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + minikql-codegen-llvm + minikql-invoke_builtins-llvm + minikql-computation-llvm + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + yql-public-udf + udf-service-exception_policy + yql-sql-pg_dummy +) +target_link_options(ydb-library-yql-minikql-invoke_builtins-llvm-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +set_property( + TARGET + ydb-library-yql-minikql-invoke_builtins-llvm-ut + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-library-yql-minikql-invoke_builtins-llvm-ut + TEST_TARGET + ydb-library-yql-minikql-invoke_builtins-llvm-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm-ut + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-library-yql-minikql-invoke_builtins-llvm-ut + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(ydb-library-yql-minikql-invoke_builtins-llvm-ut) diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.txt b/ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..f718f3824e5d --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/llvm/ut/CMakeLists.windows-x86_64.txt @@ -0,0 +1,79 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-invoke_builtins-llvm-ut) +target_compile_options(ydb-library-yql-minikql-invoke_builtins-llvm-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-minikql-invoke_builtins-llvm-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins +) +target_link_libraries(ydb-library-yql-minikql-invoke_builtins-llvm-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + minikql-codegen-llvm + minikql-invoke_builtins-llvm + minikql-computation-llvm + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + yql-public-udf + udf-service-exception_policy + yql-sql-pg_dummy +) +set_property( + TARGET + ydb-library-yql-minikql-invoke_builtins-llvm-ut + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-library-yql-minikql-invoke_builtins-llvm-ut + TEST_TARGET + ydb-library-yql-minikql-invoke_builtins-llvm-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm-ut + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-library-yql-minikql-invoke_builtins-llvm-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-invoke_builtins-llvm-ut) diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..988e90519329 --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.darwin-arm64.txt @@ -0,0 +1,70 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(minikql-invoke_builtins-llvm14 STATIC) +set_property(TARGET minikql-invoke_builtins-llvm14 PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(minikql-invoke_builtins-llvm14 PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(minikql-invoke_builtins-llvm14 PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14 + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-invoke_builtins-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins +) +target_link_libraries(minikql-invoke_builtins-llvm14 PUBLIC + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm14 + minikql-computation-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + library-cpp-pop_count + ydb-library-binary_json + library-yql-minikql + yql-minikql-arrow + yql-public-udf + libs-apache-arrow +) +target_sources(minikql-invoke_builtins-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..988e90519329 --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,70 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(minikql-invoke_builtins-llvm14 STATIC) +set_property(TARGET minikql-invoke_builtins-llvm14 PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(minikql-invoke_builtins-llvm14 PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(minikql-invoke_builtins-llvm14 PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14 + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-invoke_builtins-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins +) +target_link_libraries(minikql-invoke_builtins-llvm14 PUBLIC + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm14 + minikql-computation-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + library-cpp-pop_count + ydb-library-binary_json + library-yql-minikql + yql-minikql-arrow + yql-public-udf + libs-apache-arrow +) +target_sources(minikql-invoke_builtins-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..c8f14ea587b0 --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.linux-aarch64.txt @@ -0,0 +1,71 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(minikql-invoke_builtins-llvm14 STATIC) +set_property(TARGET minikql-invoke_builtins-llvm14 PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(minikql-invoke_builtins-llvm14 PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(minikql-invoke_builtins-llvm14 PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14 + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-invoke_builtins-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins +) +target_link_libraries(minikql-invoke_builtins-llvm14 PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm14 + minikql-computation-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + library-cpp-pop_count + ydb-library-binary_json + library-yql-minikql + yql-minikql-arrow + yql-public-udf + libs-apache-arrow +) +target_sources(minikql-invoke_builtins-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..c8f14ea587b0 --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.linux-x86_64.txt @@ -0,0 +1,71 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(minikql-invoke_builtins-llvm14 STATIC) +set_property(TARGET minikql-invoke_builtins-llvm14 PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(minikql-invoke_builtins-llvm14 PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(minikql-invoke_builtins-llvm14 PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14 + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-invoke_builtins-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins +) +target_link_libraries(minikql-invoke_builtins-llvm14 PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm14 + minikql-computation-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + library-cpp-pop_count + ydb-library-binary_json + library-yql-minikql + yql-minikql-arrow + yql-public-udf + libs-apache-arrow +) +target_sources(minikql-invoke_builtins-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.txt b/ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..988e90519329 --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/llvm14/CMakeLists.windows-x86_64.txt @@ -0,0 +1,70 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(ut) + +add_library(minikql-invoke_builtins-llvm14 STATIC) +set_property(TARGET minikql-invoke_builtins-llvm14 PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(minikql-invoke_builtins-llvm14 PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(minikql-invoke_builtins-llvm14 PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14 + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-invoke_builtins-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins +) +target_link_libraries(minikql-invoke_builtins-llvm14 PUBLIC + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm14 + minikql-computation-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + library-cpp-pop_count + ydb-library-binary_json + library-yql-minikql + yql-minikql-arrow + yql-public-udf + libs-apache-arrow +) +target_sources(minikql-invoke_builtins-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..00b73893cfa6 --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.darwin-arm64.txt @@ -0,0 +1,83 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-invoke_builtins-llvm14-ut) +target_compile_options(ydb-library-yql-minikql-invoke_builtins-llvm14-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-minikql-invoke_builtins-llvm14-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins +) +target_link_libraries(ydb-library-yql-minikql-invoke_builtins-llvm14-ut PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + minikql-codegen-llvm14 + minikql-invoke_builtins-llvm14 + minikql-computation-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + yql-public-udf + udf-service-exception_policy + yql-sql-pg_dummy +) +target_link_options(ydb-library-yql-minikql-invoke_builtins-llvm14-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +set_property( + TARGET + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + TEST_TARGET + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-library-yql-minikql-invoke_builtins-llvm14-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-invoke_builtins-llvm14-ut) diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..7bb751e09284 --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,84 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-invoke_builtins-llvm14-ut) +target_compile_options(ydb-library-yql-minikql-invoke_builtins-llvm14-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-minikql-invoke_builtins-llvm14-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins +) +target_link_libraries(ydb-library-yql-minikql-invoke_builtins-llvm14-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + minikql-codegen-llvm14 + minikql-invoke_builtins-llvm14 + minikql-computation-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + yql-public-udf + udf-service-exception_policy + yql-sql-pg_dummy +) +target_link_options(ydb-library-yql-minikql-invoke_builtins-llvm14-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +set_property( + TARGET + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + TEST_TARGET + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-library-yql-minikql-invoke_builtins-llvm14-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-invoke_builtins-llvm14-ut) diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..7314ccf32bf4 --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.linux-aarch64.txt @@ -0,0 +1,86 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-invoke_builtins-llvm14-ut) +target_compile_options(ydb-library-yql-minikql-invoke_builtins-llvm14-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-minikql-invoke_builtins-llvm14-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins +) +target_link_libraries(ydb-library-yql-minikql-invoke_builtins-llvm14-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + minikql-codegen-llvm14 + minikql-invoke_builtins-llvm14 + minikql-computation-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + yql-public-udf + udf-service-exception_policy + yql-sql-pg_dummy +) +target_link_options(ydb-library-yql-minikql-invoke_builtins-llvm14-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +set_property( + TARGET + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + TEST_TARGET + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-library-yql-minikql-invoke_builtins-llvm14-ut + cpp-malloc-jemalloc +) +vcs_info(ydb-library-yql-minikql-invoke_builtins-llvm14-ut) diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..27a33e2a3fdc --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.linux-x86_64.txt @@ -0,0 +1,88 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-invoke_builtins-llvm14-ut) +target_compile_options(ydb-library-yql-minikql-invoke_builtins-llvm14-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-minikql-invoke_builtins-llvm14-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins +) +target_link_libraries(ydb-library-yql-minikql-invoke_builtins-llvm14-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + minikql-codegen-llvm14 + minikql-invoke_builtins-llvm14 + minikql-computation-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + yql-public-udf + udf-service-exception_policy + yql-sql-pg_dummy +) +target_link_options(ydb-library-yql-minikql-invoke_builtins-llvm14-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +set_property( + TARGET + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + TEST_TARGET + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-library-yql-minikql-invoke_builtins-llvm14-ut + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(ydb-library-yql-minikql-invoke_builtins-llvm14-ut) diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.txt b/ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..3ae112edeba4 --- /dev/null +++ b/ydb/library/yql/minikql/invoke_builtins/llvm14/ut/CMakeLists.windows-x86_64.txt @@ -0,0 +1,79 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-minikql-invoke_builtins-llvm14-ut) +target_compile_options(ydb-library-yql-minikql-invoke_builtins-llvm14-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-minikql-invoke_builtins-llvm14-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins +) +target_link_libraries(ydb-library-yql-minikql-invoke_builtins-llvm14-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + minikql-codegen-llvm14 + minikql-invoke_builtins-llvm14 + minikql-computation-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + yql-public-udf + udf-service-exception_policy + yql-sql-pg_dummy +) +set_property( + TARGET + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + PROPERTY + SPLIT_FACTOR + 10 +) +add_yunittest( + NAME + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + TEST_TARGET + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-minikql-invoke_builtins-llvm14-ut + PROPERTY + TIMEOUT + 600 +) +target_allocator(ydb-library-yql-minikql-invoke_builtins-llvm14-ut + system_allocator +) +vcs_info(ydb-library-yql-minikql-invoke_builtins-llvm14-ut) diff --git a/ydb/library/yql/minikql/invoke_builtins/no_llvm/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/invoke_builtins/no_llvm/CMakeLists.darwin-arm64.txt index cd35db266b6c..2c8d4f8ac3e3 100644 --- a/ydb/library/yql/minikql/invoke_builtins/no_llvm/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/invoke_builtins/no_llvm/CMakeLists.darwin-arm64.txt @@ -7,13 +7,22 @@ -add_library(minikql-invoke_builtins-no_llvm) +add_library(minikql-invoke_builtins-no_llvm STATIC) +set_property(TARGET minikql-invoke_builtins-no_llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-invoke_builtins-no_llvm PRIVATE -DMKQL_DISABLE_CODEGEN -DUSE_CURRENT_UDF_ABI_VERSION ) target_include_directories(minikql-invoke_builtins-no_llvm PUBLIC ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/llvm_stub + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-invoke_builtins-no_llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins ) target_link_libraries(minikql-invoke_builtins-no_llvm PUBLIC contrib-libs-cxxsupp @@ -27,43 +36,29 @@ target_link_libraries(minikql-invoke_builtins-no_llvm PUBLIC minikql-computation-no_llvm ) target_sources(minikql-invoke_builtins-no_llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_abs.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_add.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitand.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitnot.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitor.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitxor.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_byteat.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_concat.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_convert.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_countbits.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_dec.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_div.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_find.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_inc.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_invprestr.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_max.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_min.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_minus.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_mod.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_mul.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_nanvl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_plus.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_rotleft.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_rotright.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_shiftleft.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_shiftright.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_string_kernels.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_sub.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_substring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_with.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_equals.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_not_equals.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_less.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_less_or_equal.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_greater.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_greater_or_equal.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h ) diff --git a/ydb/library/yql/minikql/invoke_builtins/no_llvm/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/invoke_builtins/no_llvm/CMakeLists.darwin-x86_64.txt index cd35db266b6c..2c8d4f8ac3e3 100644 --- a/ydb/library/yql/minikql/invoke_builtins/no_llvm/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/invoke_builtins/no_llvm/CMakeLists.darwin-x86_64.txt @@ -7,13 +7,22 @@ -add_library(minikql-invoke_builtins-no_llvm) +add_library(minikql-invoke_builtins-no_llvm STATIC) +set_property(TARGET minikql-invoke_builtins-no_llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-invoke_builtins-no_llvm PRIVATE -DMKQL_DISABLE_CODEGEN -DUSE_CURRENT_UDF_ABI_VERSION ) target_include_directories(minikql-invoke_builtins-no_llvm PUBLIC ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/llvm_stub + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-invoke_builtins-no_llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins ) target_link_libraries(minikql-invoke_builtins-no_llvm PUBLIC contrib-libs-cxxsupp @@ -27,43 +36,29 @@ target_link_libraries(minikql-invoke_builtins-no_llvm PUBLIC minikql-computation-no_llvm ) target_sources(minikql-invoke_builtins-no_llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_abs.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_add.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitand.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitnot.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitor.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitxor.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_byteat.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_concat.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_convert.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_countbits.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_dec.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_div.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_find.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_inc.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_invprestr.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_max.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_min.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_minus.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_mod.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_mul.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_nanvl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_plus.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_rotleft.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_rotright.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_shiftleft.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_shiftright.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_string_kernels.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_sub.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_substring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_with.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_equals.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_not_equals.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_less.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_less_or_equal.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_greater.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_greater_or_equal.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h ) diff --git a/ydb/library/yql/minikql/invoke_builtins/no_llvm/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/invoke_builtins/no_llvm/CMakeLists.linux-aarch64.txt index c71c6c41366b..effd9efd7e56 100644 --- a/ydb/library/yql/minikql/invoke_builtins/no_llvm/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/invoke_builtins/no_llvm/CMakeLists.linux-aarch64.txt @@ -7,13 +7,22 @@ -add_library(minikql-invoke_builtins-no_llvm) +add_library(minikql-invoke_builtins-no_llvm STATIC) +set_property(TARGET minikql-invoke_builtins-no_llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-invoke_builtins-no_llvm PRIVATE -DMKQL_DISABLE_CODEGEN -DUSE_CURRENT_UDF_ABI_VERSION ) target_include_directories(minikql-invoke_builtins-no_llvm PUBLIC ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/llvm_stub + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-invoke_builtins-no_llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins ) target_link_libraries(minikql-invoke_builtins-no_llvm PUBLIC contrib-libs-linux-headers @@ -28,43 +37,29 @@ target_link_libraries(minikql-invoke_builtins-no_llvm PUBLIC minikql-computation-no_llvm ) target_sources(minikql-invoke_builtins-no_llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_abs.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_add.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitand.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitnot.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitor.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitxor.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_byteat.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_concat.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_convert.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_countbits.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_dec.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_div.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_find.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_inc.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_invprestr.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_max.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_min.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_minus.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_mod.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_mul.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_nanvl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_plus.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_rotleft.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_rotright.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_shiftleft.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_shiftright.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_string_kernels.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_sub.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_substring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_with.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_equals.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_not_equals.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_less.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_less_or_equal.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_greater.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_greater_or_equal.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h ) diff --git a/ydb/library/yql/minikql/invoke_builtins/no_llvm/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/invoke_builtins/no_llvm/CMakeLists.linux-x86_64.txt index c71c6c41366b..effd9efd7e56 100644 --- a/ydb/library/yql/minikql/invoke_builtins/no_llvm/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/invoke_builtins/no_llvm/CMakeLists.linux-x86_64.txt @@ -7,13 +7,22 @@ -add_library(minikql-invoke_builtins-no_llvm) +add_library(minikql-invoke_builtins-no_llvm STATIC) +set_property(TARGET minikql-invoke_builtins-no_llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-invoke_builtins-no_llvm PRIVATE -DMKQL_DISABLE_CODEGEN -DUSE_CURRENT_UDF_ABI_VERSION ) target_include_directories(minikql-invoke_builtins-no_llvm PUBLIC ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/llvm_stub + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-invoke_builtins-no_llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins ) target_link_libraries(minikql-invoke_builtins-no_llvm PUBLIC contrib-libs-linux-headers @@ -28,43 +37,29 @@ target_link_libraries(minikql-invoke_builtins-no_llvm PUBLIC minikql-computation-no_llvm ) target_sources(minikql-invoke_builtins-no_llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_abs.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_add.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitand.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitnot.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitor.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitxor.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_byteat.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_concat.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_convert.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_countbits.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_dec.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_div.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_find.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_inc.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_invprestr.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_max.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_min.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_minus.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_mod.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_mul.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_nanvl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_plus.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_rotleft.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_rotright.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_shiftleft.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_shiftright.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_string_kernels.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_sub.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_substring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_with.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_equals.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_not_equals.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_less.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_less_or_equal.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_greater.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_greater_or_equal.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h ) diff --git a/ydb/library/yql/minikql/invoke_builtins/no_llvm/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/invoke_builtins/no_llvm/CMakeLists.windows-x86_64.txt index cd35db266b6c..2c8d4f8ac3e3 100644 --- a/ydb/library/yql/minikql/invoke_builtins/no_llvm/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/minikql/invoke_builtins/no_llvm/CMakeLists.windows-x86_64.txt @@ -7,13 +7,22 @@ -add_library(minikql-invoke_builtins-no_llvm) +add_library(minikql-invoke_builtins-no_llvm STATIC) +set_property(TARGET minikql-invoke_builtins-no_llvm PROPERTY + LINKER_LANGUAGE CXX +) target_compile_options(minikql-invoke_builtins-no_llvm PRIVATE -DMKQL_DISABLE_CODEGEN -DUSE_CURRENT_UDF_ABI_VERSION ) target_include_directories(minikql-invoke_builtins-no_llvm PUBLIC ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/llvm_stub + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/computation +) +target_include_directories(minikql-invoke_builtins-no_llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins ) target_link_libraries(minikql-invoke_builtins-no_llvm PUBLIC contrib-libs-cxxsupp @@ -27,43 +36,29 @@ target_link_libraries(minikql-invoke_builtins-no_llvm PUBLIC minikql-computation-no_llvm ) target_sources(minikql-invoke_builtins-no_llvm PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_abs.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_add.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitand.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitnot.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitor.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_bitxor.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_byteat.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_concat.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_convert.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_countbits.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_dec.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_div.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_find.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_inc.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_invprestr.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_max.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_min.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_minus.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_mod.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_mul.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_nanvl.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_plus.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_rotleft.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_rotright.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_shiftleft.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_shiftright.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_string_kernels.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_sub.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_substring.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_with.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_equals.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_not_equals.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_less.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_less_or_equal.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_greater.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_greater_or_equal.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/invoke_builtins/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h ) diff --git a/ydb/library/yql/minikql/jsonpath/benchmark/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/jsonpath/benchmark/CMakeLists.darwin-arm64.txt index 015d905da372..833a353fa55a 100644 --- a/ydb/library/yql/minikql/jsonpath/benchmark/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/jsonpath/benchmark/CMakeLists.darwin-arm64.txt @@ -17,7 +17,7 @@ target_link_libraries(jsonpath-benchmark PUBLIC testing-benchmark-main library-cpp-json yql-minikql-dom - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 yql-minikql-jsonpath yql-public-issue udf-service-exception_policy @@ -27,8 +27,6 @@ target_link_options(jsonpath-benchmark PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(jsonpath-benchmark PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/jsonpath/benchmark/main.cpp diff --git a/ydb/library/yql/minikql/jsonpath/benchmark/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/jsonpath/benchmark/CMakeLists.darwin-x86_64.txt index 7a04e74528f9..ff0d9cdcf2f6 100644 --- a/ydb/library/yql/minikql/jsonpath/benchmark/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/jsonpath/benchmark/CMakeLists.darwin-x86_64.txt @@ -18,7 +18,7 @@ target_link_libraries(jsonpath-benchmark PUBLIC testing-benchmark-main library-cpp-json yql-minikql-dom - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 yql-minikql-jsonpath yql-public-issue udf-service-exception_policy @@ -28,8 +28,6 @@ target_link_options(jsonpath-benchmark PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(jsonpath-benchmark PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/jsonpath/benchmark/main.cpp diff --git a/ydb/library/yql/minikql/jsonpath/benchmark/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/jsonpath/benchmark/CMakeLists.linux-aarch64.txt index 13503cbcf8d0..efc72d08cca2 100644 --- a/ydb/library/yql/minikql/jsonpath/benchmark/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/jsonpath/benchmark/CMakeLists.linux-aarch64.txt @@ -18,7 +18,7 @@ target_link_libraries(jsonpath-benchmark PUBLIC testing-benchmark-main library-cpp-json yql-minikql-dom - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 yql-minikql-jsonpath yql-public-issue udf-service-exception_policy @@ -30,9 +30,6 @@ target_link_options(jsonpath-benchmark PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(jsonpath-benchmark PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/jsonpath/benchmark/main.cpp diff --git a/ydb/library/yql/minikql/jsonpath/benchmark/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/jsonpath/benchmark/CMakeLists.linux-x86_64.txt index e88fac42ff8c..8928826ae7f5 100644 --- a/ydb/library/yql/minikql/jsonpath/benchmark/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/jsonpath/benchmark/CMakeLists.linux-x86_64.txt @@ -19,7 +19,7 @@ target_link_libraries(jsonpath-benchmark PUBLIC testing-benchmark-main library-cpp-json yql-minikql-dom - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 yql-minikql-jsonpath yql-public-issue udf-service-exception_policy @@ -31,9 +31,6 @@ target_link_options(jsonpath-benchmark PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(jsonpath-benchmark PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/jsonpath/benchmark/main.cpp diff --git a/ydb/library/yql/minikql/jsonpath/benchmark/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/jsonpath/benchmark/CMakeLists.windows-x86_64.txt index 471eec5852b5..232dfba1644c 100644 --- a/ydb/library/yql/minikql/jsonpath/benchmark/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/minikql/jsonpath/benchmark/CMakeLists.windows-x86_64.txt @@ -18,7 +18,7 @@ target_link_libraries(jsonpath-benchmark PUBLIC testing-benchmark-main library-cpp-json yql-minikql-dom - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 yql-minikql-jsonpath yql-public-issue udf-service-exception_policy diff --git a/ydb/library/yql/minikql/jsonpath/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/jsonpath/ut/CMakeLists.darwin-arm64.txt index 9aedea06f4b2..be16b99d7939 100644 --- a/ydb/library/yql/minikql/jsonpath/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/jsonpath/ut/CMakeLists.darwin-arm64.txt @@ -22,9 +22,9 @@ target_link_libraries(ydb-library-yql-minikql-jsonpath-ut PUBLIC library-cpp-json ydb-library-binary_json library-yql-minikql - minikql-computation-llvm + minikql-computation-llvm14 yql-minikql-dom - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 udf-service-exception_policy core-issue-protos yql-sql-pg_dummy @@ -33,8 +33,6 @@ target_link_options(ydb-library-yql-minikql-jsonpath-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-minikql-jsonpath-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/jsonpath/ut/common_ut.cpp @@ -69,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/jsonpath/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/jsonpath/ut/CMakeLists.darwin-x86_64.txt index d130b466d351..b90e2de511bc 100644 --- a/ydb/library/yql/minikql/jsonpath/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/jsonpath/ut/CMakeLists.darwin-x86_64.txt @@ -23,9 +23,9 @@ target_link_libraries(ydb-library-yql-minikql-jsonpath-ut PUBLIC library-cpp-json ydb-library-binary_json library-yql-minikql - minikql-computation-llvm + minikql-computation-llvm14 yql-minikql-dom - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 udf-service-exception_policy core-issue-protos yql-sql-pg_dummy @@ -34,8 +34,6 @@ target_link_options(ydb-library-yql-minikql-jsonpath-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-minikql-jsonpath-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/jsonpath/ut/common_ut.cpp @@ -70,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/jsonpath/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/jsonpath/ut/CMakeLists.linux-aarch64.txt index da30de491418..471e79e75ae5 100644 --- a/ydb/library/yql/minikql/jsonpath/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/jsonpath/ut/CMakeLists.linux-aarch64.txt @@ -23,9 +23,9 @@ target_link_libraries(ydb-library-yql-minikql-jsonpath-ut PUBLIC library-cpp-json ydb-library-binary_json library-yql-minikql - minikql-computation-llvm + minikql-computation-llvm14 yql-minikql-dom - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 udf-service-exception_policy core-issue-protos yql-sql-pg_dummy @@ -36,9 +36,6 @@ target_link_options(ydb-library-yql-minikql-jsonpath-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-minikql-jsonpath-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/jsonpath/ut/common_ut.cpp @@ -73,6 +70,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/jsonpath/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/jsonpath/ut/CMakeLists.linux-x86_64.txt index a9532bd37b2c..1c3db09f21ba 100644 --- a/ydb/library/yql/minikql/jsonpath/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/jsonpath/ut/CMakeLists.linux-x86_64.txt @@ -24,9 +24,9 @@ target_link_libraries(ydb-library-yql-minikql-jsonpath-ut PUBLIC library-cpp-json ydb-library-binary_json library-yql-minikql - minikql-computation-llvm + minikql-computation-llvm14 yql-minikql-dom - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 udf-service-exception_policy core-issue-protos yql-sql-pg_dummy @@ -37,9 +37,6 @@ target_link_options(ydb-library-yql-minikql-jsonpath-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-minikql-jsonpath-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/jsonpath/ut/common_ut.cpp @@ -74,6 +71,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/jsonpath/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/jsonpath/ut/CMakeLists.windows-x86_64.txt index 4c482b6b1dfc..3c5209c5c5e3 100644 --- a/ydb/library/yql/minikql/jsonpath/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/minikql/jsonpath/ut/CMakeLists.windows-x86_64.txt @@ -23,9 +23,9 @@ target_link_libraries(ydb-library-yql-minikql-jsonpath-ut PUBLIC library-cpp-json ydb-library-binary_json library-yql-minikql - minikql-computation-llvm + minikql-computation-llvm14 yql-minikql-dom - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 udf-service-exception_policy core-issue-protos yql-sql-pg_dummy @@ -63,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/perf/alloc/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/perf/alloc/CMakeLists.darwin-arm64.txt index 3cf27097e3fe..9461f19a6eb4 100644 --- a/ydb/library/yql/minikql/perf/alloc/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/perf/alloc/CMakeLists.darwin-arm64.txt @@ -23,8 +23,6 @@ target_link_options(alloc PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(alloc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/alloc/alloc.cpp diff --git a/ydb/library/yql/minikql/perf/alloc/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/perf/alloc/CMakeLists.darwin-x86_64.txt index d8685ed67157..31f9fbd35e33 100644 --- a/ydb/library/yql/minikql/perf/alloc/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/perf/alloc/CMakeLists.darwin-x86_64.txt @@ -24,8 +24,6 @@ target_link_options(alloc PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(alloc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/alloc/alloc.cpp diff --git a/ydb/library/yql/minikql/perf/alloc/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/perf/alloc/CMakeLists.linux-aarch64.txt index 18593395ac07..39448a7ae303 100644 --- a/ydb/library/yql/minikql/perf/alloc/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/perf/alloc/CMakeLists.linux-aarch64.txt @@ -26,9 +26,6 @@ target_link_options(alloc PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(alloc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/alloc/alloc.cpp diff --git a/ydb/library/yql/minikql/perf/alloc/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/perf/alloc/CMakeLists.linux-x86_64.txt index 57a3bf9ac9b9..f66e0a01ee7b 100644 --- a/ydb/library/yql/minikql/perf/alloc/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/perf/alloc/CMakeLists.linux-x86_64.txt @@ -27,9 +27,6 @@ target_link_options(alloc PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(alloc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/alloc/alloc.cpp diff --git a/ydb/library/yql/minikql/perf/block_groupby/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/perf/block_groupby/CMakeLists.darwin-arm64.txt index 0e390eb77053..84019c2b9a96 100644 --- a/ydb/library/yql/minikql/perf/block_groupby/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/perf/block_groupby/CMakeLists.darwin-arm64.txt @@ -16,7 +16,7 @@ target_link_libraries(block_groupby PUBLIC yutil libs-apache-arrow yql-minikql-arrow - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy @@ -26,8 +26,6 @@ target_link_options(block_groupby PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(block_groupby PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/block_groupby/block_groupby.cpp diff --git a/ydb/library/yql/minikql/perf/block_groupby/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/perf/block_groupby/CMakeLists.darwin-x86_64.txt index 2363b25d5719..30d224c7350a 100644 --- a/ydb/library/yql/minikql/perf/block_groupby/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/perf/block_groupby/CMakeLists.darwin-x86_64.txt @@ -17,7 +17,7 @@ target_link_libraries(block_groupby PUBLIC library-cpp-cpuid_check libs-apache-arrow yql-minikql-arrow - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy @@ -27,8 +27,6 @@ target_link_options(block_groupby PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(block_groupby PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/block_groupby/block_groupby.cpp diff --git a/ydb/library/yql/minikql/perf/block_groupby/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/perf/block_groupby/CMakeLists.linux-aarch64.txt index 5990139b8f4e..ad807559716a 100644 --- a/ydb/library/yql/minikql/perf/block_groupby/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/perf/block_groupby/CMakeLists.linux-aarch64.txt @@ -17,7 +17,7 @@ target_link_libraries(block_groupby PUBLIC yutil libs-apache-arrow yql-minikql-arrow - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy @@ -29,9 +29,6 @@ target_link_options(block_groupby PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(block_groupby PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/block_groupby/block_groupby.cpp diff --git a/ydb/library/yql/minikql/perf/block_groupby/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/perf/block_groupby/CMakeLists.linux-x86_64.txt index 6d662c8956c9..a63a43578bbd 100644 --- a/ydb/library/yql/minikql/perf/block_groupby/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/perf/block_groupby/CMakeLists.linux-x86_64.txt @@ -18,7 +18,7 @@ target_link_libraries(block_groupby PUBLIC library-cpp-cpuid_check libs-apache-arrow yql-minikql-arrow - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy @@ -30,9 +30,6 @@ target_link_options(block_groupby PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(block_groupby PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/block_groupby/block_groupby.cpp diff --git a/ydb/library/yql/minikql/perf/block_groupby/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/perf/block_groupby/CMakeLists.windows-x86_64.txt index e869124c08ff..0108db7b9128 100644 --- a/ydb/library/yql/minikql/perf/block_groupby/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/minikql/perf/block_groupby/CMakeLists.windows-x86_64.txt @@ -17,7 +17,7 @@ target_link_libraries(block_groupby PUBLIC library-cpp-cpuid_check libs-apache-arrow yql-minikql-arrow - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy diff --git a/ydb/library/yql/minikql/perf/mprefetch/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/perf/mprefetch/CMakeLists.linux-aarch64.txt index 318241f220ee..6f2f1ac90590 100644 --- a/ydb/library/yql/minikql/perf/mprefetch/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/perf/mprefetch/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(mprefetch PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(mprefetch PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/mprefetch/mprefetch.cpp diff --git a/ydb/library/yql/minikql/perf/mprefetch/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/perf/mprefetch/CMakeLists.linux-x86_64.txt index bd71fd7c81f3..af281f4e90b8 100644 --- a/ydb/library/yql/minikql/perf/mprefetch/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/perf/mprefetch/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(mprefetch PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(mprefetch PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/mprefetch/mprefetch.cpp diff --git a/ydb/library/yql/minikql/perf/mt_param/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/perf/mt_param/CMakeLists.darwin-arm64.txt index fede79848617..3d9ff191325c 100644 --- a/ydb/library/yql/minikql/perf/mt_param/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/perf/mt_param/CMakeLists.darwin-arm64.txt @@ -14,7 +14,7 @@ target_compile_options(mt_param PRIVATE target_link_libraries(mt_param PUBLIC contrib-libs-cxxsupp yutil - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy @@ -23,8 +23,6 @@ target_link_options(mt_param PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(mt_param PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/mt_param/mt_param.cpp diff --git a/ydb/library/yql/minikql/perf/mt_param/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/perf/mt_param/CMakeLists.darwin-x86_64.txt index 02fb9e6311b2..71d01912965f 100644 --- a/ydb/library/yql/minikql/perf/mt_param/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/perf/mt_param/CMakeLists.darwin-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(mt_param PUBLIC contrib-libs-cxxsupp yutil library-cpp-cpuid_check - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy @@ -24,8 +24,6 @@ target_link_options(mt_param PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(mt_param PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/mt_param/mt_param.cpp diff --git a/ydb/library/yql/minikql/perf/mt_param/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/perf/mt_param/CMakeLists.linux-aarch64.txt index 3ad79a7d6db2..0aebd50d8e55 100644 --- a/ydb/library/yql/minikql/perf/mt_param/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/perf/mt_param/CMakeLists.linux-aarch64.txt @@ -15,7 +15,7 @@ target_link_libraries(mt_param PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy @@ -26,9 +26,6 @@ target_link_options(mt_param PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(mt_param PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/mt_param/mt_param.cpp diff --git a/ydb/library/yql/minikql/perf/mt_param/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/perf/mt_param/CMakeLists.linux-x86_64.txt index 293cdde74948..63e35247f7e3 100644 --- a/ydb/library/yql/minikql/perf/mt_param/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/perf/mt_param/CMakeLists.linux-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(mt_param PUBLIC contrib-libs-cxxsupp yutil library-cpp-cpuid_check - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy @@ -27,9 +27,6 @@ target_link_options(mt_param PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(mt_param PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/mt_param/mt_param.cpp diff --git a/ydb/library/yql/minikql/perf/mt_param/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/perf/mt_param/CMakeLists.windows-x86_64.txt index ff14b61361f7..a4fcda15d565 100644 --- a/ydb/library/yql/minikql/perf/mt_param/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/minikql/perf/mt_param/CMakeLists.windows-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(mt_param PUBLIC contrib-libs-cxxsupp yutil library-cpp-cpuid_check - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy diff --git a/ydb/library/yql/minikql/perf/packer/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/perf/packer/CMakeLists.darwin-arm64.txt index 9d63daebb7a2..845237fbf5fb 100644 --- a/ydb/library/yql/minikql/perf/packer/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/perf/packer/CMakeLists.darwin-arm64.txt @@ -14,7 +14,7 @@ target_compile_options(packer PRIVATE target_link_libraries(packer PUBLIC contrib-libs-cxxsupp yutil - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy @@ -23,8 +23,6 @@ target_link_options(packer PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(packer PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/packer/packer.cpp diff --git a/ydb/library/yql/minikql/perf/packer/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/perf/packer/CMakeLists.darwin-x86_64.txt index 6a0ae062bffa..9712e7ee3471 100644 --- a/ydb/library/yql/minikql/perf/packer/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/perf/packer/CMakeLists.darwin-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(packer PUBLIC contrib-libs-cxxsupp yutil library-cpp-cpuid_check - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy @@ -24,8 +24,6 @@ target_link_options(packer PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(packer PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/packer/packer.cpp diff --git a/ydb/library/yql/minikql/perf/packer/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/perf/packer/CMakeLists.linux-aarch64.txt index a2d48e9620a6..2478b88d8c4d 100644 --- a/ydb/library/yql/minikql/perf/packer/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/perf/packer/CMakeLists.linux-aarch64.txt @@ -15,7 +15,7 @@ target_link_libraries(packer PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy @@ -26,9 +26,6 @@ target_link_options(packer PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(packer PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/packer/packer.cpp diff --git a/ydb/library/yql/minikql/perf/packer/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/perf/packer/CMakeLists.linux-x86_64.txt index 1211b8af4964..c66c2ce85f0b 100644 --- a/ydb/library/yql/minikql/perf/packer/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/perf/packer/CMakeLists.linux-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(packer PUBLIC contrib-libs-cxxsupp yutil library-cpp-cpuid_check - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy @@ -27,9 +27,6 @@ target_link_options(packer PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(packer PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/packer/packer.cpp diff --git a/ydb/library/yql/minikql/perf/packer/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/perf/packer/CMakeLists.windows-x86_64.txt index 0a35ea888792..6565a0a9e936 100644 --- a/ydb/library/yql/minikql/perf/packer/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/minikql/perf/packer/CMakeLists.windows-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(packer PUBLIC contrib-libs-cxxsupp yutil library-cpp-cpuid_check - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy diff --git a/ydb/library/yql/minikql/perf/param/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/perf/param/CMakeLists.darwin-arm64.txt index 3583196ad480..a9fee91ff3ae 100644 --- a/ydb/library/yql/minikql/perf/param/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/perf/param/CMakeLists.darwin-arm64.txt @@ -14,7 +14,7 @@ target_compile_options(param PRIVATE target_link_libraries(param PUBLIC contrib-libs-cxxsupp yutil - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy @@ -23,8 +23,6 @@ target_link_options(param PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(param PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/param/param.cpp diff --git a/ydb/library/yql/minikql/perf/param/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/perf/param/CMakeLists.darwin-x86_64.txt index 25626b17c5a9..171adad35f53 100644 --- a/ydb/library/yql/minikql/perf/param/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/perf/param/CMakeLists.darwin-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(param PUBLIC contrib-libs-cxxsupp yutil library-cpp-cpuid_check - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy @@ -24,8 +24,6 @@ target_link_options(param PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(param PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/param/param.cpp diff --git a/ydb/library/yql/minikql/perf/param/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/perf/param/CMakeLists.linux-aarch64.txt index 1cf4b96b65cc..8a51f5921079 100644 --- a/ydb/library/yql/minikql/perf/param/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/perf/param/CMakeLists.linux-aarch64.txt @@ -15,7 +15,7 @@ target_link_libraries(param PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy @@ -26,9 +26,6 @@ target_link_options(param PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(param PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/param/param.cpp diff --git a/ydb/library/yql/minikql/perf/param/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/perf/param/CMakeLists.linux-x86_64.txt index 7da21a6edd2a..4a9e81bb38ca 100644 --- a/ydb/library/yql/minikql/perf/param/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/perf/param/CMakeLists.linux-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(param PUBLIC contrib-libs-cxxsupp yutil library-cpp-cpuid_check - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy @@ -27,9 +27,6 @@ target_link_options(param PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(param PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/param/param.cpp diff --git a/ydb/library/yql/minikql/perf/param/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/perf/param/CMakeLists.windows-x86_64.txt index 7f5a2cee9de0..bc8127193b54 100644 --- a/ydb/library/yql/minikql/perf/param/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/minikql/perf/param/CMakeLists.windows-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(param PUBLIC contrib-libs-cxxsupp yutil library-cpp-cpuid_check - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy diff --git a/ydb/library/yql/minikql/perf/presort/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/perf/presort/CMakeLists.darwin-arm64.txt index 54db3d281aab..ac4c895db761 100644 --- a/ydb/library/yql/minikql/perf/presort/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/perf/presort/CMakeLists.darwin-arm64.txt @@ -15,7 +15,7 @@ target_link_libraries(presort PUBLIC contrib-libs-cxxsupp yutil library-cpp-presort - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy @@ -24,8 +24,6 @@ target_link_options(presort PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(presort PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/presort/presort.cpp diff --git a/ydb/library/yql/minikql/perf/presort/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/perf/presort/CMakeLists.darwin-x86_64.txt index eb5f43031d18..861430949497 100644 --- a/ydb/library/yql/minikql/perf/presort/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/perf/presort/CMakeLists.darwin-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(presort PUBLIC yutil library-cpp-cpuid_check library-cpp-presort - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy @@ -25,8 +25,6 @@ target_link_options(presort PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(presort PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/presort/presort.cpp diff --git a/ydb/library/yql/minikql/perf/presort/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/perf/presort/CMakeLists.linux-aarch64.txt index 6ad9ca9b3e30..6ec6b149bcfd 100644 --- a/ydb/library/yql/minikql/perf/presort/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/perf/presort/CMakeLists.linux-aarch64.txt @@ -16,7 +16,7 @@ target_link_libraries(presort PUBLIC contrib-libs-cxxsupp yutil library-cpp-presort - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy @@ -27,9 +27,6 @@ target_link_options(presort PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(presort PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/presort/presort.cpp diff --git a/ydb/library/yql/minikql/perf/presort/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/perf/presort/CMakeLists.linux-x86_64.txt index bb15a8ed3458..3385e161717c 100644 --- a/ydb/library/yql/minikql/perf/presort/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/perf/presort/CMakeLists.linux-x86_64.txt @@ -17,7 +17,7 @@ target_link_libraries(presort PUBLIC yutil library-cpp-cpuid_check library-cpp-presort - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy @@ -28,9 +28,6 @@ target_link_options(presort PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(presort PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/perf/presort/presort.cpp diff --git a/ydb/library/yql/minikql/perf/presort/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/perf/presort/CMakeLists.windows-x86_64.txt index 0fee1072da98..e75e6ceb5b9d 100644 --- a/ydb/library/yql/minikql/perf/presort/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/minikql/perf/presort/CMakeLists.windows-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(presort PUBLIC yutil library-cpp-cpuid_check library-cpp-presort - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 yql-public-udf udf-service-exception_policy yql-sql-pg_dummy diff --git a/ydb/library/yql/minikql/protobuf_udf/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/protobuf_udf/ut/CMakeLists.darwin-arm64.txt index 5157cd41655c..e3895f440a82 100644 --- a/ydb/library/yql/minikql/protobuf_udf/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/protobuf_udf/ut/CMakeLists.darwin-arm64.txt @@ -44,13 +44,12 @@ target_link_options(ydb-library-yql-minikql-protobuf_udf-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_proto_messages(ydb-library-yql-minikql-protobuf_udf-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/protobuf_udf/ut/protobuf_ut.proto ) target_sources(ydb-library-yql-minikql-protobuf_udf-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/protobuf_udf/ut/protobuf_ut.pb.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/protobuf_udf/ut/type_builder_ut.cpp ) set_property( @@ -78,6 +77,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/protobuf_udf/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/protobuf_udf/ut/CMakeLists.darwin-x86_64.txt index 0ee35f2aad5b..24f396583b50 100644 --- a/ydb/library/yql/minikql/protobuf_udf/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/protobuf_udf/ut/CMakeLists.darwin-x86_64.txt @@ -45,13 +45,12 @@ target_link_options(ydb-library-yql-minikql-protobuf_udf-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_proto_messages(ydb-library-yql-minikql-protobuf_udf-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/protobuf_udf/ut/protobuf_ut.proto ) target_sources(ydb-library-yql-minikql-protobuf_udf-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/protobuf_udf/ut/protobuf_ut.pb.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/protobuf_udf/ut/type_builder_ut.cpp ) set_property( @@ -79,6 +78,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/protobuf_udf/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/protobuf_udf/ut/CMakeLists.linux-aarch64.txt index aa54aec6a184..c9d01bd1e3c6 100644 --- a/ydb/library/yql/minikql/protobuf_udf/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/protobuf_udf/ut/CMakeLists.linux-aarch64.txt @@ -47,14 +47,12 @@ target_link_options(ydb-library-yql-minikql-protobuf_udf-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_proto_messages(ydb-library-yql-minikql-protobuf_udf-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/protobuf_udf/ut/protobuf_ut.proto ) target_sources(ydb-library-yql-minikql-protobuf_udf-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/protobuf_udf/ut/protobuf_ut.pb.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/protobuf_udf/ut/type_builder_ut.cpp ) set_property( @@ -82,6 +80,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/protobuf_udf/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/protobuf_udf/ut/CMakeLists.linux-x86_64.txt index 81dc00151bb3..d60ba25153b9 100644 --- a/ydb/library/yql/minikql/protobuf_udf/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/protobuf_udf/ut/CMakeLists.linux-x86_64.txt @@ -48,14 +48,12 @@ target_link_options(ydb-library-yql-minikql-protobuf_udf-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_proto_messages(ydb-library-yql-minikql-protobuf_udf-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/protobuf_udf/ut/protobuf_ut.proto ) target_sources(ydb-library-yql-minikql-protobuf_udf-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/protobuf_udf/ut/protobuf_ut.pb.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/protobuf_udf/ut/type_builder_ut.cpp ) set_property( @@ -83,6 +81,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/protobuf_udf/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/protobuf_udf/ut/CMakeLists.windows-x86_64.txt index 829f4837e633..b0bb4cb5266f 100644 --- a/ydb/library/yql/minikql/protobuf_udf/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/minikql/protobuf_udf/ut/CMakeLists.windows-x86_64.txt @@ -45,6 +45,7 @@ target_proto_messages(ydb-library-yql-minikql-protobuf_udf-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/protobuf_udf/ut/protobuf_ut.proto ) target_sources(ydb-library-yql-minikql-protobuf_udf-ut PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/minikql/protobuf_udf/ut/protobuf_ut.pb.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/protobuf_udf/ut/type_builder_ut.cpp ) set_property( @@ -72,6 +73,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/minikql/ut/CMakeLists.darwin-arm64.txt index 0f29860544a6..efee5ff36efb 100644 --- a/ydb/library/yql/minikql/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/minikql/ut/CMakeLists.darwin-arm64.txt @@ -13,6 +13,7 @@ target_compile_options(ydb-library-yql-minikql-ut PRIVATE ) target_include_directories(ydb-library-yql-minikql-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/include ) target_link_libraries(ydb-library-yql-minikql-ut PUBLIC contrib-libs-cxxsupp @@ -20,7 +21,7 @@ target_link_libraries(ydb-library-yql-minikql-ut PUBLIC cpp-testing-unittest_main library-yql-minikql libs-apache-arrow - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 yql-parser-pg_wrapper udf-service-exception_policy ) @@ -28,8 +29,6 @@ target_link_options(ydb-library-yql-minikql-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-minikql-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/aligned_page_pool_ut.cpp @@ -72,6 +71,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/minikql/ut/CMakeLists.darwin-x86_64.txt index 04c6363899a0..227985ad6d73 100644 --- a/ydb/library/yql/minikql/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/minikql/ut/CMakeLists.darwin-x86_64.txt @@ -13,6 +13,7 @@ target_compile_options(ydb-library-yql-minikql-ut PRIVATE ) target_include_directories(ydb-library-yql-minikql-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/include ) target_link_libraries(ydb-library-yql-minikql-ut PUBLIC contrib-libs-cxxsupp @@ -21,7 +22,7 @@ target_link_libraries(ydb-library-yql-minikql-ut PUBLIC cpp-testing-unittest_main library-yql-minikql libs-apache-arrow - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 yql-parser-pg_wrapper udf-service-exception_policy ) @@ -29,8 +30,6 @@ target_link_options(ydb-library-yql-minikql-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-minikql-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/aligned_page_pool_ut.cpp @@ -73,6 +72,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/minikql/ut/CMakeLists.linux-aarch64.txt index debeb23a6c1c..12d52710e9dc 100644 --- a/ydb/library/yql/minikql/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/minikql/ut/CMakeLists.linux-aarch64.txt @@ -13,6 +13,7 @@ target_compile_options(ydb-library-yql-minikql-ut PRIVATE ) target_include_directories(ydb-library-yql-minikql-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/include ) target_link_libraries(ydb-library-yql-minikql-ut PUBLIC contrib-libs-linux-headers @@ -21,7 +22,7 @@ target_link_libraries(ydb-library-yql-minikql-ut PUBLIC cpp-testing-unittest_main library-yql-minikql libs-apache-arrow - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 yql-parser-pg_wrapper udf-service-exception_policy ) @@ -31,9 +32,6 @@ target_link_options(ydb-library-yql-minikql-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-minikql-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/aligned_page_pool_ut.cpp @@ -76,6 +74,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/minikql/ut/CMakeLists.linux-x86_64.txt index 3e006b3a97c5..5a70d0764775 100644 --- a/ydb/library/yql/minikql/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/minikql/ut/CMakeLists.linux-x86_64.txt @@ -13,6 +13,7 @@ target_compile_options(ydb-library-yql-minikql-ut PRIVATE ) target_include_directories(ydb-library-yql-minikql-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/include ) target_link_libraries(ydb-library-yql-minikql-ut PUBLIC contrib-libs-linux-headers @@ -22,7 +23,7 @@ target_link_libraries(ydb-library-yql-minikql-ut PUBLIC cpp-testing-unittest_main library-yql-minikql libs-apache-arrow - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 yql-parser-pg_wrapper udf-service-exception_policy ) @@ -32,9 +33,6 @@ target_link_options(ydb-library-yql-minikql-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-minikql-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/aligned_page_pool_ut.cpp @@ -77,6 +75,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/minikql/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/minikql/ut/CMakeLists.windows-x86_64.txt index 9580b9893855..3fd6781c532d 100644 --- a/ydb/library/yql/minikql/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/minikql/ut/CMakeLists.windows-x86_64.txt @@ -13,6 +13,7 @@ target_compile_options(ydb-library-yql-minikql-ut PRIVATE ) target_include_directories(ydb-library-yql-minikql-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/include ) target_link_libraries(ydb-library-yql-minikql-ut PUBLIC contrib-libs-cxxsupp @@ -21,7 +22,7 @@ target_link_libraries(ydb-library-yql-minikql-ut PUBLIC cpp-testing-unittest_main library-yql-minikql libs-apache-arrow - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 yql-parser-pg_wrapper udf-service-exception_policy ) @@ -66,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/parser/lexer_common/CMakeLists.darwin-arm64.txt b/ydb/library/yql/parser/lexer_common/CMakeLists.darwin-arm64.txt index 89fc8b0b018c..cc571c89b6a1 100644 --- a/ydb/library/yql/parser/lexer_common/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/parser/lexer_common/CMakeLists.darwin-arm64.txt @@ -15,6 +15,9 @@ target_link_libraries(yql-parser-lexer_common PUBLIC yql-public-issue ) target_sources(yql-parser-lexer_common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/lexer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/hints.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/parse_hints_impl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/tokens.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/hints.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/parse_hints_impl.cpp diff --git a/ydb/library/yql/parser/lexer_common/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/parser/lexer_common/CMakeLists.darwin-x86_64.txt index 89fc8b0b018c..cc571c89b6a1 100644 --- a/ydb/library/yql/parser/lexer_common/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/parser/lexer_common/CMakeLists.darwin-x86_64.txt @@ -15,6 +15,9 @@ target_link_libraries(yql-parser-lexer_common PUBLIC yql-public-issue ) target_sources(yql-parser-lexer_common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/lexer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/hints.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/parse_hints_impl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/tokens.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/hints.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/parse_hints_impl.cpp diff --git a/ydb/library/yql/parser/lexer_common/CMakeLists.linux-aarch64.txt b/ydb/library/yql/parser/lexer_common/CMakeLists.linux-aarch64.txt index 040e95b049d3..90a68c772152 100644 --- a/ydb/library/yql/parser/lexer_common/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/parser/lexer_common/CMakeLists.linux-aarch64.txt @@ -16,6 +16,9 @@ target_link_libraries(yql-parser-lexer_common PUBLIC yql-public-issue ) target_sources(yql-parser-lexer_common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/lexer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/hints.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/parse_hints_impl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/tokens.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/hints.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/parse_hints_impl.cpp diff --git a/ydb/library/yql/parser/lexer_common/CMakeLists.linux-x86_64.txt b/ydb/library/yql/parser/lexer_common/CMakeLists.linux-x86_64.txt index 040e95b049d3..90a68c772152 100644 --- a/ydb/library/yql/parser/lexer_common/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/parser/lexer_common/CMakeLists.linux-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(yql-parser-lexer_common PUBLIC yql-public-issue ) target_sources(yql-parser-lexer_common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/lexer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/hints.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/parse_hints_impl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/tokens.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/hints.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/parse_hints_impl.cpp diff --git a/ydb/library/yql/parser/lexer_common/CMakeLists.windows-x86_64.txt b/ydb/library/yql/parser/lexer_common/CMakeLists.windows-x86_64.txt index 89fc8b0b018c..cc571c89b6a1 100644 --- a/ydb/library/yql/parser/lexer_common/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/parser/lexer_common/CMakeLists.windows-x86_64.txt @@ -15,6 +15,9 @@ target_link_libraries(yql-parser-lexer_common PUBLIC yql-public-issue ) target_sources(yql-parser-lexer_common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/lexer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/hints.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/parse_hints_impl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/tokens.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/hints.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/parse_hints_impl.cpp diff --git a/ydb/library/yql/parser/lexer_common/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/parser/lexer_common/ut/CMakeLists.darwin-arm64.txt index f16895e70ac8..0005903c5b7f 100644 --- a/ydb/library/yql/parser/lexer_common/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/parser/lexer_common/ut/CMakeLists.darwin-arm64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-library-yql-parser-lexer_common-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-parser-lexer_common-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/ut/hints_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/parser/lexer_common/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/parser/lexer_common/ut/CMakeLists.darwin-x86_64.txt index fc5a41418527..8f30881aad7b 100644 --- a/ydb/library/yql/parser/lexer_common/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/parser/lexer_common/ut/CMakeLists.darwin-x86_64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-library-yql-parser-lexer_common-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-parser-lexer_common-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/ut/hints_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/parser/lexer_common/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/parser/lexer_common/ut/CMakeLists.linux-aarch64.txt index d99f3e4b38ec..0e73b99c687c 100644 --- a/ydb/library/yql/parser/lexer_common/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/parser/lexer_common/ut/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-yql-parser-lexer_common-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-parser-lexer_common-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/ut/hints_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/parser/lexer_common/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/parser/lexer_common/ut/CMakeLists.linux-x86_64.txt index d6ae73273e4b..aa7406c9f715 100644 --- a/ydb/library/yql/parser/lexer_common/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/parser/lexer_common/ut/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-library-yql-parser-lexer_common-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-parser-lexer_common-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/lexer_common/ut/hints_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/parser/lexer_common/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/parser/lexer_common/ut/CMakeLists.windows-x86_64.txt index 8a89d0c83a8a..219ee3c4f5d3 100644 --- a/ydb/library/yql/parser/lexer_common/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/parser/lexer_common/ut/CMakeLists.windows-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/parser/pg_catalog/CMakeLists.darwin-arm64.txt b/ydb/library/yql/parser/pg_catalog/CMakeLists.darwin-arm64.txt index 91bb11a41946..ed68ccdc1e70 100644 --- a/ydb/library/yql/parser/pg_catalog/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/parser/pg_catalog/CMakeLists.darwin-arm64.txt @@ -67,6 +67,12 @@ get_built_tool_path( tools/rescompiler/bin rescompiler ) +get_built_tool_path( + TOOL_rescompiler_bin + TOOL_rescompiler_dependency + tools/rescompiler/bin + rescompiler +) add_library(yql-parser-pg_catalog) target_link_libraries(yql-parser-pg_catalog PUBLIC @@ -96,6 +102,7 @@ target_sources(yql-parser-pg_catalog.global PRIVATE ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/69148841cb58a458173a42fc4a2d34a5.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/ec0b500b671e1ef6896201d71c27c3a9.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/35d2aa467812d7360a78c1fae061c821.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/c5119519d22b2b93be0e714cfac07bca.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/d248668b32b6a4d36f76898f91cda187.cpp ) resources(yql-parser-pg_catalog.global @@ -161,6 +168,13 @@ resources(yql-parser-pg_catalog.global KEYS pg_amop.dat ) +resources(yql-parser-pg_catalog.global + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/c5119519d22b2b93be0e714cfac07bca.cpp + INPUTS + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/include/catalog/pg_am.dat + KEYS + pg_am.dat +) resources(yql-parser-pg_catalog.global ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/d248668b32b6a4d36f76898f91cda187.cpp INPUTS diff --git a/ydb/library/yql/parser/pg_catalog/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/parser/pg_catalog/CMakeLists.darwin-x86_64.txt index 91bb11a41946..ed68ccdc1e70 100644 --- a/ydb/library/yql/parser/pg_catalog/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/parser/pg_catalog/CMakeLists.darwin-x86_64.txt @@ -67,6 +67,12 @@ get_built_tool_path( tools/rescompiler/bin rescompiler ) +get_built_tool_path( + TOOL_rescompiler_bin + TOOL_rescompiler_dependency + tools/rescompiler/bin + rescompiler +) add_library(yql-parser-pg_catalog) target_link_libraries(yql-parser-pg_catalog PUBLIC @@ -96,6 +102,7 @@ target_sources(yql-parser-pg_catalog.global PRIVATE ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/69148841cb58a458173a42fc4a2d34a5.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/ec0b500b671e1ef6896201d71c27c3a9.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/35d2aa467812d7360a78c1fae061c821.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/c5119519d22b2b93be0e714cfac07bca.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/d248668b32b6a4d36f76898f91cda187.cpp ) resources(yql-parser-pg_catalog.global @@ -161,6 +168,13 @@ resources(yql-parser-pg_catalog.global KEYS pg_amop.dat ) +resources(yql-parser-pg_catalog.global + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/c5119519d22b2b93be0e714cfac07bca.cpp + INPUTS + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/include/catalog/pg_am.dat + KEYS + pg_am.dat +) resources(yql-parser-pg_catalog.global ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/d248668b32b6a4d36f76898f91cda187.cpp INPUTS diff --git a/ydb/library/yql/parser/pg_catalog/CMakeLists.linux-aarch64.txt b/ydb/library/yql/parser/pg_catalog/CMakeLists.linux-aarch64.txt index e420ebda1c46..707d1008f38a 100644 --- a/ydb/library/yql/parser/pg_catalog/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/parser/pg_catalog/CMakeLists.linux-aarch64.txt @@ -67,6 +67,12 @@ get_built_tool_path( tools/rescompiler/bin rescompiler ) +get_built_tool_path( + TOOL_rescompiler_bin + TOOL_rescompiler_dependency + tools/rescompiler/bin + rescompiler +) add_library(yql-parser-pg_catalog) target_link_libraries(yql-parser-pg_catalog PUBLIC @@ -98,6 +104,7 @@ target_sources(yql-parser-pg_catalog.global PRIVATE ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/69148841cb58a458173a42fc4a2d34a5.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/ec0b500b671e1ef6896201d71c27c3a9.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/35d2aa467812d7360a78c1fae061c821.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/c5119519d22b2b93be0e714cfac07bca.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/d248668b32b6a4d36f76898f91cda187.cpp ) resources(yql-parser-pg_catalog.global @@ -163,6 +170,13 @@ resources(yql-parser-pg_catalog.global KEYS pg_amop.dat ) +resources(yql-parser-pg_catalog.global + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/c5119519d22b2b93be0e714cfac07bca.cpp + INPUTS + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/include/catalog/pg_am.dat + KEYS + pg_am.dat +) resources(yql-parser-pg_catalog.global ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/d248668b32b6a4d36f76898f91cda187.cpp INPUTS diff --git a/ydb/library/yql/parser/pg_catalog/CMakeLists.linux-x86_64.txt b/ydb/library/yql/parser/pg_catalog/CMakeLists.linux-x86_64.txt index e420ebda1c46..707d1008f38a 100644 --- a/ydb/library/yql/parser/pg_catalog/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/parser/pg_catalog/CMakeLists.linux-x86_64.txt @@ -67,6 +67,12 @@ get_built_tool_path( tools/rescompiler/bin rescompiler ) +get_built_tool_path( + TOOL_rescompiler_bin + TOOL_rescompiler_dependency + tools/rescompiler/bin + rescompiler +) add_library(yql-parser-pg_catalog) target_link_libraries(yql-parser-pg_catalog PUBLIC @@ -98,6 +104,7 @@ target_sources(yql-parser-pg_catalog.global PRIVATE ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/69148841cb58a458173a42fc4a2d34a5.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/ec0b500b671e1ef6896201d71c27c3a9.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/35d2aa467812d7360a78c1fae061c821.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/c5119519d22b2b93be0e714cfac07bca.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/d248668b32b6a4d36f76898f91cda187.cpp ) resources(yql-parser-pg_catalog.global @@ -163,6 +170,13 @@ resources(yql-parser-pg_catalog.global KEYS pg_amop.dat ) +resources(yql-parser-pg_catalog.global + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/c5119519d22b2b93be0e714cfac07bca.cpp + INPUTS + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/include/catalog/pg_am.dat + KEYS + pg_am.dat +) resources(yql-parser-pg_catalog.global ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/d248668b32b6a4d36f76898f91cda187.cpp INPUTS diff --git a/ydb/library/yql/parser/pg_catalog/CMakeLists.windows-x86_64.txt b/ydb/library/yql/parser/pg_catalog/CMakeLists.windows-x86_64.txt index 91bb11a41946..ed68ccdc1e70 100644 --- a/ydb/library/yql/parser/pg_catalog/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/parser/pg_catalog/CMakeLists.windows-x86_64.txt @@ -67,6 +67,12 @@ get_built_tool_path( tools/rescompiler/bin rescompiler ) +get_built_tool_path( + TOOL_rescompiler_bin + TOOL_rescompiler_dependency + tools/rescompiler/bin + rescompiler +) add_library(yql-parser-pg_catalog) target_link_libraries(yql-parser-pg_catalog PUBLIC @@ -96,6 +102,7 @@ target_sources(yql-parser-pg_catalog.global PRIVATE ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/69148841cb58a458173a42fc4a2d34a5.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/ec0b500b671e1ef6896201d71c27c3a9.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/35d2aa467812d7360a78c1fae061c821.cpp + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/c5119519d22b2b93be0e714cfac07bca.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/d248668b32b6a4d36f76898f91cda187.cpp ) resources(yql-parser-pg_catalog.global @@ -161,6 +168,13 @@ resources(yql-parser-pg_catalog.global KEYS pg_amop.dat ) +resources(yql-parser-pg_catalog.global + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/c5119519d22b2b93be0e714cfac07bca.cpp + INPUTS + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/include/catalog/pg_am.dat + KEYS + pg_am.dat +) resources(yql-parser-pg_catalog.global ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_catalog/d248668b32b6a4d36f76898f91cda187.cpp INPUTS diff --git a/ydb/library/yql/parser/pg_catalog/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/parser/pg_catalog/ut/CMakeLists.darwin-arm64.txt index 130c8e86f85f..108d2610f86c 100644 --- a/ydb/library/yql/parser/pg_catalog/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/parser/pg_catalog/ut/CMakeLists.darwin-arm64.txt @@ -22,15 +22,13 @@ target_link_libraries(ydb-library-yql-parser-pg_catalog-ut PUBLIC yql-parser-pg_catalog yql-public-udf udf-service-exception_policy - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-parser-pg_wrapper ) target_link_options(ydb-library-yql-parser-pg_catalog-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-parser-pg_catalog-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_catalog/ut/catalog_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/parser/pg_catalog/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/parser/pg_catalog/ut/CMakeLists.darwin-x86_64.txt index 11b691ab52f5..7189443ba67e 100644 --- a/ydb/library/yql/parser/pg_catalog/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/parser/pg_catalog/ut/CMakeLists.darwin-x86_64.txt @@ -23,15 +23,13 @@ target_link_libraries(ydb-library-yql-parser-pg_catalog-ut PUBLIC yql-parser-pg_catalog yql-public-udf udf-service-exception_policy - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-parser-pg_wrapper ) target_link_options(ydb-library-yql-parser-pg_catalog-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-parser-pg_catalog-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_catalog/ut/catalog_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/parser/pg_catalog/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/parser/pg_catalog/ut/CMakeLists.linux-aarch64.txt index 74f201330ac0..2e25c5491c90 100644 --- a/ydb/library/yql/parser/pg_catalog/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/parser/pg_catalog/ut/CMakeLists.linux-aarch64.txt @@ -23,7 +23,7 @@ target_link_libraries(ydb-library-yql-parser-pg_catalog-ut PUBLIC yql-parser-pg_catalog yql-public-udf udf-service-exception_policy - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-parser-pg_wrapper ) target_link_options(ydb-library-yql-parser-pg_catalog-ut PRIVATE @@ -32,9 +32,6 @@ target_link_options(ydb-library-yql-parser-pg_catalog-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-parser-pg_catalog-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_catalog/ut/catalog_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/parser/pg_catalog/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/parser/pg_catalog/ut/CMakeLists.linux-x86_64.txt index c1c1a96f2f51..0b507137f265 100644 --- a/ydb/library/yql/parser/pg_catalog/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/parser/pg_catalog/ut/CMakeLists.linux-x86_64.txt @@ -24,7 +24,7 @@ target_link_libraries(ydb-library-yql-parser-pg_catalog-ut PUBLIC yql-parser-pg_catalog yql-public-udf udf-service-exception_policy - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-parser-pg_wrapper ) target_link_options(ydb-library-yql-parser-pg_catalog-ut PRIVATE @@ -33,9 +33,6 @@ target_link_options(ydb-library-yql-parser-pg_catalog-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-parser-pg_catalog-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_catalog/ut/catalog_ut.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/parser/pg_catalog/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/parser/pg_catalog/ut/CMakeLists.windows-x86_64.txt index d18edca2dfc7..2735fa1a2147 100644 --- a/ydb/library/yql/parser/pg_catalog/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/parser/pg_catalog/ut/CMakeLists.windows-x86_64.txt @@ -23,7 +23,7 @@ target_link_libraries(ydb-library-yql-parser-pg_catalog-ut PUBLIC yql-parser-pg_catalog yql-public-udf udf-service-exception_policy - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-parser-pg_wrapper ) target_sources(ydb-library-yql-parser-pg_catalog-ut PRIVATE @@ -55,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/parser/pg_wrapper/CMakeLists.darwin-arm64.txt b/ydb/library/yql/parser/pg_wrapper/CMakeLists.darwin-arm64.txt index 5a899080ef8e..ad648fb34267 100644 --- a/ydb/library/yql/parser/pg_wrapper/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/parser/pg_wrapper/CMakeLists.darwin-arm64.txt @@ -22,11 +22,13 @@ target_compile_options(yql-parser-pg_wrapper PRIVATE -Wno-duplicate-decl-specifier -Wno-unused-function -Wno-unused-variable + -Wno-unused-but-set-variable -Wno-unused-private-field -Wno-register -Wno-unguarded-availability-new -Wno-int-conversion -Wno-deprecated-declarations + -Wno-null-pointer-subtraction -Darray_length=yql_array_length -Dpg_encoding_max_length=yql_pg_encoding_max_length -Dpg_encoding_mblen=yql_pg_encoding_mblen @@ -107,8 +109,8 @@ target_compile_options(yql-parser-pg_wrapper PRIVATE -Dpg_hmac_init=yql_pg_hmac_init -Dpg_hmac_create=yql_pg_hmac_create -Dpg_pwritev_with_retry=yql_pg_pwritev_with_retry + -DMKQL_DISABLE_CODEGEN -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> ) target_include_directories(yql-parser-pg_wrapper PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/lz4 @@ -130,8 +132,9 @@ target_link_libraries(yql-parser-pg_wrapper PUBLIC library-cpp-yson library-yql-core yql-minikql-arrow - minikql-computation-llvm + yql-minikql-computation yql-parser-pg_catalog + parser-pg_wrapper-interface providers-common-codec yql-public-issue yql-public-udf @@ -157,6 +160,7 @@ target_sources(yql-parser-pg_wrapper PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/config.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/cost_mocks.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/syscache.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/pg_utils_wrappers.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/backend/access/brin/brin.c ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/backend/access/brin/brin_bloom.c ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/backend/access/brin/brin_inclusion.c @@ -932,27 +936,3 @@ target_sources(yql-parser-pg_wrapper PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/backend/port/posix_sema.c ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/backend/port/sysv_shmem.c ) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/copy_src.py - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/copy_src.py -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/copy_src.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/copy_src.sh -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/generate_kernels.py - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/generate_kernels.py -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/generate_patch.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/generate_patch.sh -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/vars.txt - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/vars.txt -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/verify.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/verify.sh -) diff --git a/ydb/library/yql/parser/pg_wrapper/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/parser/pg_wrapper/CMakeLists.darwin-x86_64.txt index d5515f04cc94..42a7d5bc6fb8 100644 --- a/ydb/library/yql/parser/pg_wrapper/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/parser/pg_wrapper/CMakeLists.darwin-x86_64.txt @@ -24,11 +24,13 @@ target_compile_options(yql-parser-pg_wrapper PRIVATE -Wno-duplicate-decl-specifier -Wno-unused-function -Wno-unused-variable + -Wno-unused-but-set-variable -Wno-unused-private-field -Wno-register -Wno-unguarded-availability-new -Wno-int-conversion -Wno-deprecated-declarations + -Wno-null-pointer-subtraction -Darray_length=yql_array_length -Dpg_encoding_max_length=yql_pg_encoding_max_length -Dpg_encoding_mblen=yql_pg_encoding_mblen @@ -109,8 +111,8 @@ target_compile_options(yql-parser-pg_wrapper PRIVATE -Dpg_hmac_init=yql_pg_hmac_init -Dpg_hmac_create=yql_pg_hmac_create -Dpg_pwritev_with_retry=yql_pg_pwritev_with_retry + -DMKQL_DISABLE_CODEGEN -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> ) target_include_directories(yql-parser-pg_wrapper PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/lz4 @@ -132,8 +134,9 @@ target_link_libraries(yql-parser-pg_wrapper PUBLIC library-cpp-yson library-yql-core yql-minikql-arrow - minikql-computation-llvm + yql-minikql-computation yql-parser-pg_catalog + parser-pg_wrapper-interface providers-common-codec yql-public-issue yql-public-udf @@ -159,6 +162,7 @@ target_sources(yql-parser-pg_wrapper PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/config.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/cost_mocks.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/syscache.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/pg_utils_wrappers.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/port/pg_crc32c_sse42.c ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/port/pg_crc32c_sse42_choose.c ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/backend/access/brin/brin.c @@ -936,27 +940,3 @@ target_sources(yql-parser-pg_wrapper PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/backend/port/posix_sema.c ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/backend/port/sysv_shmem.c ) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/copy_src.py - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/copy_src.py -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/copy_src.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/copy_src.sh -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/generate_kernels.py - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/generate_kernels.py -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/generate_patch.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/generate_patch.sh -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/vars.txt - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/vars.txt -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/verify.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/verify.sh -) diff --git a/ydb/library/yql/parser/pg_wrapper/CMakeLists.linux-aarch64.txt b/ydb/library/yql/parser/pg_wrapper/CMakeLists.linux-aarch64.txt index f877af81e35c..574f528202d0 100644 --- a/ydb/library/yql/parser/pg_wrapper/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/parser/pg_wrapper/CMakeLists.linux-aarch64.txt @@ -22,11 +22,13 @@ target_compile_options(yql-parser-pg_wrapper PRIVATE -Wno-duplicate-decl-specifier -Wno-unused-function -Wno-unused-variable + -Wno-unused-but-set-variable -Wno-unused-private-field -Wno-register -Wno-unguarded-availability-new -Wno-int-conversion -Wno-deprecated-declarations + -Wno-null-pointer-subtraction -Darray_length=yql_array_length -Dpg_encoding_max_length=yql_pg_encoding_max_length -Dpg_encoding_mblen=yql_pg_encoding_mblen @@ -107,8 +109,8 @@ target_compile_options(yql-parser-pg_wrapper PRIVATE -Dpg_hmac_init=yql_pg_hmac_init -Dpg_hmac_create=yql_pg_hmac_create -Dpg_pwritev_with_retry=yql_pg_pwritev_with_retry + -DMKQL_DISABLE_CODEGEN -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> ) target_include_directories(yql-parser-pg_wrapper PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/lz4 @@ -131,8 +133,9 @@ target_link_libraries(yql-parser-pg_wrapper PUBLIC library-cpp-yson library-yql-core yql-minikql-arrow - minikql-computation-llvm + yql-minikql-computation yql-parser-pg_catalog + parser-pg_wrapper-interface providers-common-codec yql-public-issue yql-public-udf @@ -158,6 +161,7 @@ target_sources(yql-parser-pg_wrapper PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/config.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/cost_mocks.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/syscache.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/pg_utils_wrappers.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/backend/access/brin/brin.c ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/backend/access/brin/brin_bloom.c ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/backend/access/brin/brin_inclusion.c @@ -933,27 +937,3 @@ target_sources(yql-parser-pg_wrapper PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/backend/port/posix_sema.c ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/backend/port/sysv_shmem.c ) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/copy_src.py - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/copy_src.py -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/copy_src.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/copy_src.sh -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/generate_kernels.py - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/generate_kernels.py -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/generate_patch.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/generate_patch.sh -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/vars.txt - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/vars.txt -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/verify.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/verify.sh -) diff --git a/ydb/library/yql/parser/pg_wrapper/CMakeLists.linux-x86_64.txt b/ydb/library/yql/parser/pg_wrapper/CMakeLists.linux-x86_64.txt index 5e4926b67db6..a746c07ed3d8 100644 --- a/ydb/library/yql/parser/pg_wrapper/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/parser/pg_wrapper/CMakeLists.linux-x86_64.txt @@ -24,11 +24,13 @@ target_compile_options(yql-parser-pg_wrapper PRIVATE -Wno-duplicate-decl-specifier -Wno-unused-function -Wno-unused-variable + -Wno-unused-but-set-variable -Wno-unused-private-field -Wno-register -Wno-unguarded-availability-new -Wno-int-conversion -Wno-deprecated-declarations + -Wno-null-pointer-subtraction -Darray_length=yql_array_length -Dpg_encoding_max_length=yql_pg_encoding_max_length -Dpg_encoding_mblen=yql_pg_encoding_mblen @@ -109,8 +111,8 @@ target_compile_options(yql-parser-pg_wrapper PRIVATE -Dpg_hmac_init=yql_pg_hmac_init -Dpg_hmac_create=yql_pg_hmac_create -Dpg_pwritev_with_retry=yql_pg_pwritev_with_retry + -DMKQL_DISABLE_CODEGEN -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> ) target_include_directories(yql-parser-pg_wrapper PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/lz4 @@ -133,8 +135,9 @@ target_link_libraries(yql-parser-pg_wrapper PUBLIC library-cpp-yson library-yql-core yql-minikql-arrow - minikql-computation-llvm + yql-minikql-computation yql-parser-pg_catalog + parser-pg_wrapper-interface providers-common-codec yql-public-issue yql-public-udf @@ -160,6 +163,7 @@ target_sources(yql-parser-pg_wrapper PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/config.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/cost_mocks.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/syscache.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/pg_utils_wrappers.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/port/pg_crc32c_sse42.c ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/port/pg_crc32c_sse42_choose.c ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/backend/access/brin/brin.c @@ -937,27 +941,3 @@ target_sources(yql-parser-pg_wrapper PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/backend/port/posix_sema.c ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/backend/port/sysv_shmem.c ) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/copy_src.py - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/copy_src.py -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/copy_src.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/copy_src.sh -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/generate_kernels.py - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/generate_kernels.py -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/generate_patch.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/generate_patch.sh -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/vars.txt - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/vars.txt -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/verify.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/verify.sh -) diff --git a/ydb/library/yql/parser/pg_wrapper/CMakeLists.windows-x86_64.txt b/ydb/library/yql/parser/pg_wrapper/CMakeLists.windows-x86_64.txt index 9cd9246e9aff..0d0c5c6044bc 100644 --- a/ydb/library/yql/parser/pg_wrapper/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/parser/pg_wrapper/CMakeLists.windows-x86_64.txt @@ -24,11 +24,13 @@ target_compile_options(yql-parser-pg_wrapper PRIVATE -Wno-duplicate-decl-specifier -Wno-unused-function -Wno-unused-variable + -Wno-unused-but-set-variable -Wno-unused-private-field -Wno-register -Wno-unguarded-availability-new -Wno-int-conversion -Wno-deprecated-declarations + -Wno-null-pointer-subtraction -D__thread=__declspec(thread) -Dfstat=microsoft_native_fstat -Dstat=microsoft_native_stat @@ -121,8 +123,8 @@ target_compile_options(yql-parser-pg_wrapper PRIVATE -Dpg_hmac_init=yql_pg_hmac_init -Dpg_hmac_create=yql_pg_hmac_create -Dpg_pwritev_with_retry=yql_pg_pwritev_with_retry + -DMKQL_DISABLE_CODEGEN -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> ) target_include_directories(yql-parser-pg_wrapper PRIVATE ${CMAKE_SOURCE_DIR}/contrib/libs/lz4 @@ -146,8 +148,9 @@ target_link_libraries(yql-parser-pg_wrapper PUBLIC library-cpp-yson library-yql-core yql-minikql-arrow - minikql-computation-llvm + yql-minikql-computation yql-parser-pg_catalog + parser-pg_wrapper-interface providers-common-codec yql-public-issue yql-public-udf @@ -173,6 +176,7 @@ target_sources(yql-parser-pg_wrapper PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/config.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/cost_mocks.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/syscache.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/pg_utils_wrappers.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/port/pg_crc32c_sse42.c ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/port/pg_crc32c_sse42_choose.c ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/backend/access/brin/brin.c @@ -975,27 +979,3 @@ target_sources(yql-parser-pg_wrapper PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/port/win32setlocale.c ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/port/win32stat.c ) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/copy_src.py - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/copy_src.py -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/copy_src.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/copy_src.sh -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/generate_kernels.py - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/generate_kernels.py -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/generate_patch.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/generate_patch.sh -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/vars.txt - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/vars.txt -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/verify.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/pg_wrapper/verify.sh -) diff --git a/ydb/library/yql/parser/pg_wrapper/interface/CMakeLists.darwin-arm64.txt b/ydb/library/yql/parser/pg_wrapper/interface/CMakeLists.darwin-arm64.txt index 334631913420..f11c05c58ed0 100644 --- a/ydb/library/yql/parser/pg_wrapper/interface/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/parser/pg_wrapper/interface/CMakeLists.darwin-arm64.txt @@ -20,5 +20,14 @@ target_link_libraries(parser-pg_wrapper-interface PUBLIC yql-core-cbo ) target_sources(parser-pg_wrapper-interface PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/codec.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/compare.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/comp_factory.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/context.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/interface.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/pack.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/parser.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/type_desc.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/utils.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/interface.cpp ) diff --git a/ydb/library/yql/parser/pg_wrapper/interface/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/parser/pg_wrapper/interface/CMakeLists.darwin-x86_64.txt index 334631913420..f11c05c58ed0 100644 --- a/ydb/library/yql/parser/pg_wrapper/interface/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/parser/pg_wrapper/interface/CMakeLists.darwin-x86_64.txt @@ -20,5 +20,14 @@ target_link_libraries(parser-pg_wrapper-interface PUBLIC yql-core-cbo ) target_sources(parser-pg_wrapper-interface PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/codec.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/compare.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/comp_factory.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/context.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/interface.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/pack.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/parser.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/type_desc.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/utils.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/interface.cpp ) diff --git a/ydb/library/yql/parser/pg_wrapper/interface/CMakeLists.linux-aarch64.txt b/ydb/library/yql/parser/pg_wrapper/interface/CMakeLists.linux-aarch64.txt index c3d59ce35c8a..a7585600267c 100644 --- a/ydb/library/yql/parser/pg_wrapper/interface/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/parser/pg_wrapper/interface/CMakeLists.linux-aarch64.txt @@ -21,5 +21,14 @@ target_link_libraries(parser-pg_wrapper-interface PUBLIC yql-core-cbo ) target_sources(parser-pg_wrapper-interface PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/codec.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/compare.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/comp_factory.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/context.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/interface.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/pack.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/parser.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/type_desc.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/utils.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/interface.cpp ) diff --git a/ydb/library/yql/parser/pg_wrapper/interface/CMakeLists.linux-x86_64.txt b/ydb/library/yql/parser/pg_wrapper/interface/CMakeLists.linux-x86_64.txt index c3d59ce35c8a..a7585600267c 100644 --- a/ydb/library/yql/parser/pg_wrapper/interface/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/parser/pg_wrapper/interface/CMakeLists.linux-x86_64.txt @@ -21,5 +21,14 @@ target_link_libraries(parser-pg_wrapper-interface PUBLIC yql-core-cbo ) target_sources(parser-pg_wrapper-interface PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/codec.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/compare.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/comp_factory.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/context.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/interface.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/pack.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/parser.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/type_desc.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/utils.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/interface.cpp ) diff --git a/ydb/library/yql/parser/pg_wrapper/interface/CMakeLists.windows-x86_64.txt b/ydb/library/yql/parser/pg_wrapper/interface/CMakeLists.windows-x86_64.txt index 334631913420..f11c05c58ed0 100644 --- a/ydb/library/yql/parser/pg_wrapper/interface/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/parser/pg_wrapper/interface/CMakeLists.windows-x86_64.txt @@ -20,5 +20,14 @@ target_link_libraries(parser-pg_wrapper-interface PUBLIC yql-core-cbo ) target_sources(parser-pg_wrapper-interface PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/codec.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/compare.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/comp_factory.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/context.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/interface.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/pack.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/parser.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/type_desc.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/utils.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/interface/interface.cpp ) diff --git a/ydb/library/yql/parser/pg_wrapper/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/parser/pg_wrapper/ut/CMakeLists.darwin-arm64.txt index 5512b71aec2e..80786ac229cd 100644 --- a/ydb/library/yql/parser/pg_wrapper/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/parser/pg_wrapper/ut/CMakeLists.darwin-arm64.txt @@ -19,11 +19,13 @@ target_compile_options(ydb-library-yql-parser-pg_wrapper-ut PRIVATE -Wno-duplicate-decl-specifier -Wno-unused-function -Wno-unused-variable + -Wno-unused-but-set-variable -Wno-unused-private-field -Wno-register -Wno-unguarded-availability-new -Wno-int-conversion -Wno-deprecated-declarations + -Wno-null-pointer-subtraction -Darray_length=yql_array_length -Dpg_encoding_max_length=yql_pg_encoding_max_length -Dpg_encoding_mblen=yql_pg_encoding_mblen @@ -105,7 +107,6 @@ target_compile_options(ydb-library-yql-parser-pg_wrapper-ut PRIVATE -Dpg_hmac_create=yql_pg_hmac_create -Dpg_pwritev_with_retry=yql_pg_pwritev_with_retry -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> ) target_include_directories(ydb-library-yql-parser-pg_wrapper-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper @@ -119,19 +120,18 @@ target_link_libraries(ydb-library-yql-parser-pg_wrapper-ut PUBLIC yql-minikql-arrow yql-public-udf udf-service-exception_policy - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-parser-pg_catalog - yql-minikql-codegen + minikql-codegen-llvm14 library-cpp-resource ) target_link_options(ydb-library-yql-parser-pg_wrapper-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-parser-pg_wrapper-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/ut/arrow_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/ut/codegen_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/ut/error_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/ut/parser_ut.cpp @@ -164,6 +164,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/parser/pg_wrapper/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/parser/pg_wrapper/ut/CMakeLists.darwin-x86_64.txt index 9e8faf6346f0..071d0e65e664 100644 --- a/ydb/library/yql/parser/pg_wrapper/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/parser/pg_wrapper/ut/CMakeLists.darwin-x86_64.txt @@ -19,11 +19,13 @@ target_compile_options(ydb-library-yql-parser-pg_wrapper-ut PRIVATE -Wno-duplicate-decl-specifier -Wno-unused-function -Wno-unused-variable + -Wno-unused-but-set-variable -Wno-unused-private-field -Wno-register -Wno-unguarded-availability-new -Wno-int-conversion -Wno-deprecated-declarations + -Wno-null-pointer-subtraction -Darray_length=yql_array_length -Dpg_encoding_max_length=yql_pg_encoding_max_length -Dpg_encoding_mblen=yql_pg_encoding_mblen @@ -105,7 +107,6 @@ target_compile_options(ydb-library-yql-parser-pg_wrapper-ut PRIVATE -Dpg_hmac_create=yql_pg_hmac_create -Dpg_pwritev_with_retry=yql_pg_pwritev_with_retry -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> ) target_include_directories(ydb-library-yql-parser-pg_wrapper-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper @@ -120,19 +121,18 @@ target_link_libraries(ydb-library-yql-parser-pg_wrapper-ut PUBLIC yql-minikql-arrow yql-public-udf udf-service-exception_policy - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-parser-pg_catalog - yql-minikql-codegen + minikql-codegen-llvm14 library-cpp-resource ) target_link_options(ydb-library-yql-parser-pg_wrapper-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-parser-pg_wrapper-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/ut/arrow_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/ut/codegen_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/ut/error_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/ut/parser_ut.cpp @@ -165,6 +165,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/parser/pg_wrapper/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/parser/pg_wrapper/ut/CMakeLists.linux-aarch64.txt index d87d2c915def..c5d09b265513 100644 --- a/ydb/library/yql/parser/pg_wrapper/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/parser/pg_wrapper/ut/CMakeLists.linux-aarch64.txt @@ -19,11 +19,13 @@ target_compile_options(ydb-library-yql-parser-pg_wrapper-ut PRIVATE -Wno-duplicate-decl-specifier -Wno-unused-function -Wno-unused-variable + -Wno-unused-but-set-variable -Wno-unused-private-field -Wno-register -Wno-unguarded-availability-new -Wno-int-conversion -Wno-deprecated-declarations + -Wno-null-pointer-subtraction -Darray_length=yql_array_length -Dpg_encoding_max_length=yql_pg_encoding_max_length -Dpg_encoding_mblen=yql_pg_encoding_mblen @@ -105,7 +107,6 @@ target_compile_options(ydb-library-yql-parser-pg_wrapper-ut PRIVATE -Dpg_hmac_create=yql_pg_hmac_create -Dpg_pwritev_with_retry=yql_pg_pwritev_with_retry -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> ) target_include_directories(ydb-library-yql-parser-pg_wrapper-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper @@ -120,9 +121,9 @@ target_link_libraries(ydb-library-yql-parser-pg_wrapper-ut PUBLIC yql-minikql-arrow yql-public-udf udf-service-exception_policy - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-parser-pg_catalog - yql-minikql-codegen + minikql-codegen-llvm14 library-cpp-resource ) target_link_options(ydb-library-yql-parser-pg_wrapper-ut PRIVATE @@ -131,11 +132,9 @@ target_link_options(ydb-library-yql-parser-pg_wrapper-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-parser-pg_wrapper-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/ut/arrow_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/ut/codegen_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/ut/error_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/ut/parser_ut.cpp @@ -168,6 +167,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/parser/pg_wrapper/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/parser/pg_wrapper/ut/CMakeLists.linux-x86_64.txt index 5388972443f3..749378a7f975 100644 --- a/ydb/library/yql/parser/pg_wrapper/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/parser/pg_wrapper/ut/CMakeLists.linux-x86_64.txt @@ -19,11 +19,13 @@ target_compile_options(ydb-library-yql-parser-pg_wrapper-ut PRIVATE -Wno-duplicate-decl-specifier -Wno-unused-function -Wno-unused-variable + -Wno-unused-but-set-variable -Wno-unused-private-field -Wno-register -Wno-unguarded-availability-new -Wno-int-conversion -Wno-deprecated-declarations + -Wno-null-pointer-subtraction -Darray_length=yql_array_length -Dpg_encoding_max_length=yql_pg_encoding_max_length -Dpg_encoding_mblen=yql_pg_encoding_mblen @@ -105,7 +107,6 @@ target_compile_options(ydb-library-yql-parser-pg_wrapper-ut PRIVATE -Dpg_hmac_create=yql_pg_hmac_create -Dpg_pwritev_with_retry=yql_pg_pwritev_with_retry -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> ) target_include_directories(ydb-library-yql-parser-pg_wrapper-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper @@ -121,9 +122,9 @@ target_link_libraries(ydb-library-yql-parser-pg_wrapper-ut PUBLIC yql-minikql-arrow yql-public-udf udf-service-exception_policy - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-parser-pg_catalog - yql-minikql-codegen + minikql-codegen-llvm14 library-cpp-resource ) target_link_options(ydb-library-yql-parser-pg_wrapper-ut PRIVATE @@ -132,11 +133,9 @@ target_link_options(ydb-library-yql-parser-pg_wrapper-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-parser-pg_wrapper-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/ut/arrow_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/ut/codegen_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/ut/error_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/ut/parser_ut.cpp @@ -169,6 +168,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/parser/pg_wrapper/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/parser/pg_wrapper/ut/CMakeLists.windows-x86_64.txt index cd5941ee35c2..833ce1d340f5 100644 --- a/ydb/library/yql/parser/pg_wrapper/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/parser/pg_wrapper/ut/CMakeLists.windows-x86_64.txt @@ -19,11 +19,13 @@ target_compile_options(ydb-library-yql-parser-pg_wrapper-ut PRIVATE -Wno-duplicate-decl-specifier -Wno-unused-function -Wno-unused-variable + -Wno-unused-but-set-variable -Wno-unused-private-field -Wno-register -Wno-unguarded-availability-new -Wno-int-conversion -Wno-deprecated-declarations + -Wno-null-pointer-subtraction -D__thread=__declspec(thread) -Dfstat=microsoft_native_fstat -Dstat=microsoft_native_stat @@ -117,7 +119,6 @@ target_compile_options(ydb-library-yql-parser-pg_wrapper-ut PRIVATE -Dpg_hmac_create=yql_pg_hmac_create -Dpg_pwritev_with_retry=yql_pg_pwritev_with_retry -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> ) target_include_directories(ydb-library-yql-parser-pg_wrapper-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper @@ -132,12 +133,13 @@ target_link_libraries(ydb-library-yql-parser-pg_wrapper-ut PUBLIC yql-minikql-arrow yql-public-udf udf-service-exception_policy - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 yql-parser-pg_catalog - yql-minikql-codegen + minikql-codegen-llvm14 library-cpp-resource ) target_sources(ydb-library-yql-parser-pg_wrapper-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/ut/arrow_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/ut/codegen_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/ut/error_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/ut/parser_ut.cpp @@ -170,6 +172,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/parser/proto_ast/collect_issues/CMakeLists.darwin-arm64.txt b/ydb/library/yql/parser/proto_ast/collect_issues/CMakeLists.darwin-arm64.txt index a818d5398bf8..65e9a2c7f082 100644 --- a/ydb/library/yql/parser/proto_ast/collect_issues/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/parser/proto_ast/collect_issues/CMakeLists.darwin-arm64.txt @@ -14,3 +14,6 @@ target_link_libraries(parser-proto_ast-collect_issues INTERFACE yql-public-issue yql-parser-proto_ast ) +target_sources(parser-proto_ast-collect_issues INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/collect_issues/collect_issues.h +) diff --git a/ydb/library/yql/parser/proto_ast/collect_issues/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/parser/proto_ast/collect_issues/CMakeLists.darwin-x86_64.txt index a818d5398bf8..65e9a2c7f082 100644 --- a/ydb/library/yql/parser/proto_ast/collect_issues/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/parser/proto_ast/collect_issues/CMakeLists.darwin-x86_64.txt @@ -14,3 +14,6 @@ target_link_libraries(parser-proto_ast-collect_issues INTERFACE yql-public-issue yql-parser-proto_ast ) +target_sources(parser-proto_ast-collect_issues INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/collect_issues/collect_issues.h +) diff --git a/ydb/library/yql/parser/proto_ast/collect_issues/CMakeLists.linux-aarch64.txt b/ydb/library/yql/parser/proto_ast/collect_issues/CMakeLists.linux-aarch64.txt index 05d0648d8179..e7ae7565233e 100644 --- a/ydb/library/yql/parser/proto_ast/collect_issues/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/parser/proto_ast/collect_issues/CMakeLists.linux-aarch64.txt @@ -15,3 +15,6 @@ target_link_libraries(parser-proto_ast-collect_issues INTERFACE yql-public-issue yql-parser-proto_ast ) +target_sources(parser-proto_ast-collect_issues INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/collect_issues/collect_issues.h +) diff --git a/ydb/library/yql/parser/proto_ast/collect_issues/CMakeLists.linux-x86_64.txt b/ydb/library/yql/parser/proto_ast/collect_issues/CMakeLists.linux-x86_64.txt index 05d0648d8179..e7ae7565233e 100644 --- a/ydb/library/yql/parser/proto_ast/collect_issues/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/parser/proto_ast/collect_issues/CMakeLists.linux-x86_64.txt @@ -15,3 +15,6 @@ target_link_libraries(parser-proto_ast-collect_issues INTERFACE yql-public-issue yql-parser-proto_ast ) +target_sources(parser-proto_ast-collect_issues INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/collect_issues/collect_issues.h +) diff --git a/ydb/library/yql/parser/proto_ast/collect_issues/CMakeLists.windows-x86_64.txt b/ydb/library/yql/parser/proto_ast/collect_issues/CMakeLists.windows-x86_64.txt index a818d5398bf8..65e9a2c7f082 100644 --- a/ydb/library/yql/parser/proto_ast/collect_issues/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/parser/proto_ast/collect_issues/CMakeLists.windows-x86_64.txt @@ -14,3 +14,6 @@ target_link_libraries(parser-proto_ast-collect_issues INTERFACE yql-public-issue yql-parser-proto_ast ) +target_sources(parser-proto_ast-collect_issues INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/collect_issues/collect_issues.h +) diff --git a/ydb/library/yql/parser/proto_ast/gen/CMakeLists.txt b/ydb/library/yql/parser/proto_ast/gen/CMakeLists.txt index 060018279708..c7d24086aa61 100644 --- a/ydb/library/yql/parser/proto_ast/gen/CMakeLists.txt +++ b/ydb/library/yql/parser/proto_ast/gen/CMakeLists.txt @@ -8,6 +8,7 @@ add_subdirectory(jsonpath) add_subdirectory(v0) +add_subdirectory(v0_proto_split) add_subdirectory(v1) add_subdirectory(v1_ansi) -add_subdirectory(v1_proto) +add_subdirectory(v1_proto_split) diff --git a/ydb/library/yql/parser/proto_ast/gen/jsonpath/CMakeLists.darwin-arm64.txt b/ydb/library/yql/parser/proto_ast/gen/jsonpath/CMakeLists.darwin-arm64.txt index 65d2f12e2ac0..c1a66b3e30ba 100644 --- a/ydb/library/yql/parser/proto_ast/gen/jsonpath/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/parser/proto_ast/gen/jsonpath/CMakeLists.darwin-arm64.txt @@ -34,6 +34,10 @@ set( PROTOBUF_HEADER_PATH ydb/library/yql/parser/proto_ast/gen/jsonpath ) +set( + PROTOBUF_SUFFIX_PATH + .pb.h +) add_library(proto_ast-gen-jsonpath) target_compile_options(proto_ast-gen-jsonpath PRIVATE @@ -52,6 +56,11 @@ target_proto_messages(proto_ast-gen-jsonpath PRIVATE ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathParser.proto ) target_sources(proto_ast-gen-jsonpath PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/org/antlr/codegen/templates/Cpp/Cpp.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/org/antlr/codegen/templates/protobuf/protobuf.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathParser.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathLexer.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathParser.pb.h ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathParser.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathLexer.cpp ) diff --git a/ydb/library/yql/parser/proto_ast/gen/jsonpath/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/parser/proto_ast/gen/jsonpath/CMakeLists.darwin-x86_64.txt index 65d2f12e2ac0..c1a66b3e30ba 100644 --- a/ydb/library/yql/parser/proto_ast/gen/jsonpath/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/parser/proto_ast/gen/jsonpath/CMakeLists.darwin-x86_64.txt @@ -34,6 +34,10 @@ set( PROTOBUF_HEADER_PATH ydb/library/yql/parser/proto_ast/gen/jsonpath ) +set( + PROTOBUF_SUFFIX_PATH + .pb.h +) add_library(proto_ast-gen-jsonpath) target_compile_options(proto_ast-gen-jsonpath PRIVATE @@ -52,6 +56,11 @@ target_proto_messages(proto_ast-gen-jsonpath PRIVATE ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathParser.proto ) target_sources(proto_ast-gen-jsonpath PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/org/antlr/codegen/templates/Cpp/Cpp.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/org/antlr/codegen/templates/protobuf/protobuf.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathParser.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathLexer.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathParser.pb.h ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathParser.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathLexer.cpp ) diff --git a/ydb/library/yql/parser/proto_ast/gen/jsonpath/CMakeLists.linux-aarch64.txt b/ydb/library/yql/parser/proto_ast/gen/jsonpath/CMakeLists.linux-aarch64.txt index 9b5df75f591a..7ad03356a577 100644 --- a/ydb/library/yql/parser/proto_ast/gen/jsonpath/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/parser/proto_ast/gen/jsonpath/CMakeLists.linux-aarch64.txt @@ -34,6 +34,10 @@ set( PROTOBUF_HEADER_PATH ydb/library/yql/parser/proto_ast/gen/jsonpath ) +set( + PROTOBUF_SUFFIX_PATH + .pb.h +) add_library(proto_ast-gen-jsonpath) target_compile_options(proto_ast-gen-jsonpath PRIVATE @@ -53,6 +57,11 @@ target_proto_messages(proto_ast-gen-jsonpath PRIVATE ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathParser.proto ) target_sources(proto_ast-gen-jsonpath PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/org/antlr/codegen/templates/Cpp/Cpp.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/org/antlr/codegen/templates/protobuf/protobuf.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathParser.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathLexer.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathParser.pb.h ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathParser.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathLexer.cpp ) diff --git a/ydb/library/yql/parser/proto_ast/gen/jsonpath/CMakeLists.linux-x86_64.txt b/ydb/library/yql/parser/proto_ast/gen/jsonpath/CMakeLists.linux-x86_64.txt index 9b5df75f591a..7ad03356a577 100644 --- a/ydb/library/yql/parser/proto_ast/gen/jsonpath/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/parser/proto_ast/gen/jsonpath/CMakeLists.linux-x86_64.txt @@ -34,6 +34,10 @@ set( PROTOBUF_HEADER_PATH ydb/library/yql/parser/proto_ast/gen/jsonpath ) +set( + PROTOBUF_SUFFIX_PATH + .pb.h +) add_library(proto_ast-gen-jsonpath) target_compile_options(proto_ast-gen-jsonpath PRIVATE @@ -53,6 +57,11 @@ target_proto_messages(proto_ast-gen-jsonpath PRIVATE ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathParser.proto ) target_sources(proto_ast-gen-jsonpath PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/org/antlr/codegen/templates/Cpp/Cpp.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/org/antlr/codegen/templates/protobuf/protobuf.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathParser.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathLexer.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathParser.pb.h ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathParser.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathLexer.cpp ) diff --git a/ydb/library/yql/parser/proto_ast/gen/jsonpath/CMakeLists.windows-x86_64.txt b/ydb/library/yql/parser/proto_ast/gen/jsonpath/CMakeLists.windows-x86_64.txt index 65d2f12e2ac0..c1a66b3e30ba 100644 --- a/ydb/library/yql/parser/proto_ast/gen/jsonpath/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/parser/proto_ast/gen/jsonpath/CMakeLists.windows-x86_64.txt @@ -34,6 +34,10 @@ set( PROTOBUF_HEADER_PATH ydb/library/yql/parser/proto_ast/gen/jsonpath ) +set( + PROTOBUF_SUFFIX_PATH + .pb.h +) add_library(proto_ast-gen-jsonpath) target_compile_options(proto_ast-gen-jsonpath PRIVATE @@ -52,6 +56,11 @@ target_proto_messages(proto_ast-gen-jsonpath PRIVATE ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathParser.proto ) target_sources(proto_ast-gen-jsonpath PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/org/antlr/codegen/templates/Cpp/Cpp.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/org/antlr/codegen/templates/protobuf/protobuf.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathParser.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathLexer.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathParser.pb.h ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathParser.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/jsonpath/JsonPathLexer.cpp ) diff --git a/ydb/library/yql/parser/proto_ast/gen/v0/CMakeLists.darwin-arm64.txt b/ydb/library/yql/parser/proto_ast/gen/v0/CMakeLists.darwin-arm64.txt index e46562c7d878..c3f5da17435e 100644 --- a/ydb/library/yql/parser/proto_ast/gen/v0/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/parser/proto_ast/gen/v0/CMakeLists.darwin-arm64.txt @@ -6,22 +6,6 @@ # original buildsystem will not be accepted. -get_built_tool_path( - TOOL_protoc_bin - TOOL_protoc_dependency - contrib/tools/protoc/bin - protoc -) -get_built_tool_path( - TOOL_cpp_styleguide_bin - TOOL_cpp_styleguide_dependency - contrib/tools/protoc/plugins/cpp_styleguide - cpp_styleguide -) -set( - ANTLR_PACKAGE_NAME - NSQLGenerated -) set( ANTLR_PACKAGE_NAME NSQLGenerated @@ -32,7 +16,11 @@ set( ) set( PROTOBUF_HEADER_PATH - ydb/library/yql/parser/proto_ast/gen/v0 + ydb/library/yql/parser/proto_ast/gen/v0_proto_split +) +set( + PROTOBUF_SUFFIX_PATH + .pb.main.h ) add_library(proto_ast-gen-v0) @@ -41,41 +29,19 @@ target_compile_options(proto_ast-gen-v0 PRIVATE ) target_include_directories(proto_ast-gen-v0 PUBLIC ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/Cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/protobuf ) target_link_libraries(proto_ast-gen-v0 PUBLIC contrib-libs-cxxsupp yutil - contrib-libs-protobuf -) -target_proto_messages(proto_ast-gen-v0 PRIVATE - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLParser.proto + proto_ast-gen-v0_proto_split ) target_sources(proto_ast-gen-v0 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/Cpp/Cpp.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLParser.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLLexer.h ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLParser.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLLexer.cpp ) -run_antlr( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLParser.proto - DEPENDS - ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/SQL.g - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/protobuf/protobuf.stg - WORKING_DIRECTORY - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0 - ANTLER_ARGS - ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/SQL.g - -lib - . - -fo - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0 - -language - protobuf -) -configure_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/org/antlr/codegen/templates/protobuf/protobuf.stg.in - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/protobuf/protobuf.stg -) configure_file( ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/org/antlr/codegen/templates/Cpp/Cpp.stg.in ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/Cpp/Cpp.stg @@ -98,16 +64,3 @@ run_antlr( -fo ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0 ) -target_proto_addincls(proto_ast-gen-v0 - ./ - ${CMAKE_SOURCE_DIR}/ - ${CMAKE_BINARY_DIR} - ${CMAKE_SOURCE_DIR} - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src - ${CMAKE_BINARY_DIR} - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src -) -target_proto_outs(proto_ast-gen-v0 - --cpp_out=${CMAKE_BINARY_DIR}/ - --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ -) diff --git a/ydb/library/yql/parser/proto_ast/gen/v0/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/parser/proto_ast/gen/v0/CMakeLists.darwin-x86_64.txt index e46562c7d878..c3f5da17435e 100644 --- a/ydb/library/yql/parser/proto_ast/gen/v0/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/parser/proto_ast/gen/v0/CMakeLists.darwin-x86_64.txt @@ -6,22 +6,6 @@ # original buildsystem will not be accepted. -get_built_tool_path( - TOOL_protoc_bin - TOOL_protoc_dependency - contrib/tools/protoc/bin - protoc -) -get_built_tool_path( - TOOL_cpp_styleguide_bin - TOOL_cpp_styleguide_dependency - contrib/tools/protoc/plugins/cpp_styleguide - cpp_styleguide -) -set( - ANTLR_PACKAGE_NAME - NSQLGenerated -) set( ANTLR_PACKAGE_NAME NSQLGenerated @@ -32,7 +16,11 @@ set( ) set( PROTOBUF_HEADER_PATH - ydb/library/yql/parser/proto_ast/gen/v0 + ydb/library/yql/parser/proto_ast/gen/v0_proto_split +) +set( + PROTOBUF_SUFFIX_PATH + .pb.main.h ) add_library(proto_ast-gen-v0) @@ -41,41 +29,19 @@ target_compile_options(proto_ast-gen-v0 PRIVATE ) target_include_directories(proto_ast-gen-v0 PUBLIC ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/Cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/protobuf ) target_link_libraries(proto_ast-gen-v0 PUBLIC contrib-libs-cxxsupp yutil - contrib-libs-protobuf -) -target_proto_messages(proto_ast-gen-v0 PRIVATE - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLParser.proto + proto_ast-gen-v0_proto_split ) target_sources(proto_ast-gen-v0 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/Cpp/Cpp.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLParser.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLLexer.h ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLParser.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLLexer.cpp ) -run_antlr( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLParser.proto - DEPENDS - ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/SQL.g - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/protobuf/protobuf.stg - WORKING_DIRECTORY - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0 - ANTLER_ARGS - ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/SQL.g - -lib - . - -fo - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0 - -language - protobuf -) -configure_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/org/antlr/codegen/templates/protobuf/protobuf.stg.in - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/protobuf/protobuf.stg -) configure_file( ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/org/antlr/codegen/templates/Cpp/Cpp.stg.in ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/Cpp/Cpp.stg @@ -98,16 +64,3 @@ run_antlr( -fo ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0 ) -target_proto_addincls(proto_ast-gen-v0 - ./ - ${CMAKE_SOURCE_DIR}/ - ${CMAKE_BINARY_DIR} - ${CMAKE_SOURCE_DIR} - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src - ${CMAKE_BINARY_DIR} - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src -) -target_proto_outs(proto_ast-gen-v0 - --cpp_out=${CMAKE_BINARY_DIR}/ - --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ -) diff --git a/ydb/library/yql/parser/proto_ast/gen/v0/CMakeLists.linux-aarch64.txt b/ydb/library/yql/parser/proto_ast/gen/v0/CMakeLists.linux-aarch64.txt index 906f81b5e4e4..57db8114fa4d 100644 --- a/ydb/library/yql/parser/proto_ast/gen/v0/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/parser/proto_ast/gen/v0/CMakeLists.linux-aarch64.txt @@ -6,22 +6,6 @@ # original buildsystem will not be accepted. -get_built_tool_path( - TOOL_protoc_bin - TOOL_protoc_dependency - contrib/tools/protoc/bin - protoc -) -get_built_tool_path( - TOOL_cpp_styleguide_bin - TOOL_cpp_styleguide_dependency - contrib/tools/protoc/plugins/cpp_styleguide - cpp_styleguide -) -set( - ANTLR_PACKAGE_NAME - NSQLGenerated -) set( ANTLR_PACKAGE_NAME NSQLGenerated @@ -32,7 +16,11 @@ set( ) set( PROTOBUF_HEADER_PATH - ydb/library/yql/parser/proto_ast/gen/v0 + ydb/library/yql/parser/proto_ast/gen/v0_proto_split +) +set( + PROTOBUF_SUFFIX_PATH + .pb.main.h ) add_library(proto_ast-gen-v0) @@ -41,42 +29,20 @@ target_compile_options(proto_ast-gen-v0 PRIVATE ) target_include_directories(proto_ast-gen-v0 PUBLIC ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/Cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/protobuf ) target_link_libraries(proto_ast-gen-v0 PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - contrib-libs-protobuf -) -target_proto_messages(proto_ast-gen-v0 PRIVATE - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLParser.proto + proto_ast-gen-v0_proto_split ) target_sources(proto_ast-gen-v0 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/Cpp/Cpp.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLParser.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLLexer.h ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLParser.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLLexer.cpp ) -run_antlr( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLParser.proto - DEPENDS - ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/SQL.g - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/protobuf/protobuf.stg - WORKING_DIRECTORY - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0 - ANTLER_ARGS - ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/SQL.g - -lib - . - -fo - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0 - -language - protobuf -) -configure_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/org/antlr/codegen/templates/protobuf/protobuf.stg.in - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/protobuf/protobuf.stg -) configure_file( ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/org/antlr/codegen/templates/Cpp/Cpp.stg.in ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/Cpp/Cpp.stg @@ -99,16 +65,3 @@ run_antlr( -fo ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0 ) -target_proto_addincls(proto_ast-gen-v0 - ./ - ${CMAKE_SOURCE_DIR}/ - ${CMAKE_BINARY_DIR} - ${CMAKE_SOURCE_DIR} - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src - ${CMAKE_BINARY_DIR} - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src -) -target_proto_outs(proto_ast-gen-v0 - --cpp_out=${CMAKE_BINARY_DIR}/ - --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ -) diff --git a/ydb/library/yql/parser/proto_ast/gen/v0/CMakeLists.linux-x86_64.txt b/ydb/library/yql/parser/proto_ast/gen/v0/CMakeLists.linux-x86_64.txt index 906f81b5e4e4..57db8114fa4d 100644 --- a/ydb/library/yql/parser/proto_ast/gen/v0/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/parser/proto_ast/gen/v0/CMakeLists.linux-x86_64.txt @@ -6,22 +6,6 @@ # original buildsystem will not be accepted. -get_built_tool_path( - TOOL_protoc_bin - TOOL_protoc_dependency - contrib/tools/protoc/bin - protoc -) -get_built_tool_path( - TOOL_cpp_styleguide_bin - TOOL_cpp_styleguide_dependency - contrib/tools/protoc/plugins/cpp_styleguide - cpp_styleguide -) -set( - ANTLR_PACKAGE_NAME - NSQLGenerated -) set( ANTLR_PACKAGE_NAME NSQLGenerated @@ -32,7 +16,11 @@ set( ) set( PROTOBUF_HEADER_PATH - ydb/library/yql/parser/proto_ast/gen/v0 + ydb/library/yql/parser/proto_ast/gen/v0_proto_split +) +set( + PROTOBUF_SUFFIX_PATH + .pb.main.h ) add_library(proto_ast-gen-v0) @@ -41,42 +29,20 @@ target_compile_options(proto_ast-gen-v0 PRIVATE ) target_include_directories(proto_ast-gen-v0 PUBLIC ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/Cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/protobuf ) target_link_libraries(proto_ast-gen-v0 PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - contrib-libs-protobuf -) -target_proto_messages(proto_ast-gen-v0 PRIVATE - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLParser.proto + proto_ast-gen-v0_proto_split ) target_sources(proto_ast-gen-v0 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/Cpp/Cpp.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLParser.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLLexer.h ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLParser.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLLexer.cpp ) -run_antlr( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLParser.proto - DEPENDS - ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/SQL.g - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/protobuf/protobuf.stg - WORKING_DIRECTORY - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0 - ANTLER_ARGS - ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/SQL.g - -lib - . - -fo - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0 - -language - protobuf -) -configure_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/org/antlr/codegen/templates/protobuf/protobuf.stg.in - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/protobuf/protobuf.stg -) configure_file( ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/org/antlr/codegen/templates/Cpp/Cpp.stg.in ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/Cpp/Cpp.stg @@ -99,16 +65,3 @@ run_antlr( -fo ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0 ) -target_proto_addincls(proto_ast-gen-v0 - ./ - ${CMAKE_SOURCE_DIR}/ - ${CMAKE_BINARY_DIR} - ${CMAKE_SOURCE_DIR} - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src - ${CMAKE_BINARY_DIR} - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src -) -target_proto_outs(proto_ast-gen-v0 - --cpp_out=${CMAKE_BINARY_DIR}/ - --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ -) diff --git a/ydb/library/yql/parser/proto_ast/gen/v0/CMakeLists.windows-x86_64.txt b/ydb/library/yql/parser/proto_ast/gen/v0/CMakeLists.windows-x86_64.txt index e46562c7d878..c3f5da17435e 100644 --- a/ydb/library/yql/parser/proto_ast/gen/v0/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/parser/proto_ast/gen/v0/CMakeLists.windows-x86_64.txt @@ -6,22 +6,6 @@ # original buildsystem will not be accepted. -get_built_tool_path( - TOOL_protoc_bin - TOOL_protoc_dependency - contrib/tools/protoc/bin - protoc -) -get_built_tool_path( - TOOL_cpp_styleguide_bin - TOOL_cpp_styleguide_dependency - contrib/tools/protoc/plugins/cpp_styleguide - cpp_styleguide -) -set( - ANTLR_PACKAGE_NAME - NSQLGenerated -) set( ANTLR_PACKAGE_NAME NSQLGenerated @@ -32,7 +16,11 @@ set( ) set( PROTOBUF_HEADER_PATH - ydb/library/yql/parser/proto_ast/gen/v0 + ydb/library/yql/parser/proto_ast/gen/v0_proto_split +) +set( + PROTOBUF_SUFFIX_PATH + .pb.main.h ) add_library(proto_ast-gen-v0) @@ -41,41 +29,19 @@ target_compile_options(proto_ast-gen-v0 PRIVATE ) target_include_directories(proto_ast-gen-v0 PUBLIC ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/Cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/protobuf ) target_link_libraries(proto_ast-gen-v0 PUBLIC contrib-libs-cxxsupp yutil - contrib-libs-protobuf -) -target_proto_messages(proto_ast-gen-v0 PRIVATE - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLParser.proto + proto_ast-gen-v0_proto_split ) target_sources(proto_ast-gen-v0 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/Cpp/Cpp.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLParser.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLLexer.h ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLParser.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLLexer.cpp ) -run_antlr( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/SQLParser.proto - DEPENDS - ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/SQL.g - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/protobuf/protobuf.stg - WORKING_DIRECTORY - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0 - ANTLER_ARGS - ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/SQL.g - -lib - . - -fo - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0 - -language - protobuf -) -configure_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/org/antlr/codegen/templates/protobuf/protobuf.stg.in - ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/protobuf/protobuf.stg -) configure_file( ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/org/antlr/codegen/templates/Cpp/Cpp.stg.in ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0/org/antlr/codegen/templates/Cpp/Cpp.stg @@ -98,16 +64,3 @@ run_antlr( -fo ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0 ) -target_proto_addincls(proto_ast-gen-v0 - ./ - ${CMAKE_SOURCE_DIR}/ - ${CMAKE_BINARY_DIR} - ${CMAKE_SOURCE_DIR} - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src - ${CMAKE_BINARY_DIR} - ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src -) -target_proto_outs(proto_ast-gen-v0 - --cpp_out=${CMAKE_BINARY_DIR}/ - --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ -) diff --git a/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.darwin-arm64.txt b/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..96b89f27034b --- /dev/null +++ b/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.darwin-arm64.txt @@ -0,0 +1,128 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +find_package(Python3 REQUIRED) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +set( + ANTLR_PACKAGE_NAME + NSQLGenerated +) + +add_library(proto_ast-gen-v0_proto_split) +target_include_directories(proto_ast-gen-v0_proto_split PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/org/antlr/codegen/templates/protobuf +) +target_link_libraries(proto_ast-gen-v0_proto_split PUBLIC + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf +) +target_sources(proto_ast-gen-v0_proto_split PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.main.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code0.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.main.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code1.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code2.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code3.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code4.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code5.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code6.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code7.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code8.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code9.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.data.cc +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code0.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code1.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code2.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code3.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code4.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code5.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code6.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code7.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code8.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code9.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.data.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.main.h + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.cc + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/multiproto.py + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split + COMMAND + Python3::Interpreter + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/multiproto.py + SQLParser +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.cc + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.proto + ${TOOL_protoc_bin} + ${TOOL_cpp_styleguide_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR} + COMMAND + ${TOOL_protoc_bin} + -I=${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split + -I=${CMAKE_SOURCE_DIR} + -I=${CMAKE_BINARY_DIR} + -I=${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + --cpp_out=${CMAKE_BINARY_DIR} + --cpp_styleguide_out=${CMAKE_BINARY_DIR} + --plugin=protoc-gen-cpp_styleguide=${CMAKE_BINARY_DIR}/contrib/tools/protoc/plugins/cpp_styleguide/cpp_styleguide + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.proto +) +run_antlr( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.proto + DEPENDS + ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/SQL.g + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split + ANTLER_ARGS + ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/SQL.g + -lib + . + -fo + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split + -language + protobuf +) +configure_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/org/antlr/codegen/templates/protobuf/protobuf.stg.in + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg +) +if(NOT CMAKE_CROSSCOMPILING) + add_dependencies(proto_ast-gen-v0_proto_split + cpp_styleguide + protoc +) +endif() diff --git a/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..96b89f27034b --- /dev/null +++ b/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,128 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +find_package(Python3 REQUIRED) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +set( + ANTLR_PACKAGE_NAME + NSQLGenerated +) + +add_library(proto_ast-gen-v0_proto_split) +target_include_directories(proto_ast-gen-v0_proto_split PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/org/antlr/codegen/templates/protobuf +) +target_link_libraries(proto_ast-gen-v0_proto_split PUBLIC + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf +) +target_sources(proto_ast-gen-v0_proto_split PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.main.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code0.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.main.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code1.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code2.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code3.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code4.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code5.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code6.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code7.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code8.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code9.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.data.cc +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code0.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code1.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code2.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code3.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code4.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code5.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code6.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code7.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code8.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code9.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.data.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.main.h + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.cc + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/multiproto.py + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split + COMMAND + Python3::Interpreter + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/multiproto.py + SQLParser +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.cc + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.proto + ${TOOL_protoc_bin} + ${TOOL_cpp_styleguide_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR} + COMMAND + ${TOOL_protoc_bin} + -I=${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split + -I=${CMAKE_SOURCE_DIR} + -I=${CMAKE_BINARY_DIR} + -I=${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + --cpp_out=${CMAKE_BINARY_DIR} + --cpp_styleguide_out=${CMAKE_BINARY_DIR} + --plugin=protoc-gen-cpp_styleguide=${CMAKE_BINARY_DIR}/contrib/tools/protoc/plugins/cpp_styleguide/cpp_styleguide + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.proto +) +run_antlr( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.proto + DEPENDS + ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/SQL.g + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split + ANTLER_ARGS + ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/SQL.g + -lib + . + -fo + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split + -language + protobuf +) +configure_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/org/antlr/codegen/templates/protobuf/protobuf.stg.in + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg +) +if(NOT CMAKE_CROSSCOMPILING) + add_dependencies(proto_ast-gen-v0_proto_split + cpp_styleguide + protoc +) +endif() diff --git a/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.linux-aarch64.txt b/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..62140126ba3d --- /dev/null +++ b/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.linux-aarch64.txt @@ -0,0 +1,129 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +find_package(Python3 REQUIRED) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +set( + ANTLR_PACKAGE_NAME + NSQLGenerated +) + +add_library(proto_ast-gen-v0_proto_split) +target_include_directories(proto_ast-gen-v0_proto_split PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/org/antlr/codegen/templates/protobuf +) +target_link_libraries(proto_ast-gen-v0_proto_split PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf +) +target_sources(proto_ast-gen-v0_proto_split PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.main.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code0.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.main.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code1.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code2.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code3.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code4.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code5.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code6.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code7.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code8.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code9.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.data.cc +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code0.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code1.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code2.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code3.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code4.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code5.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code6.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code7.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code8.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code9.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.data.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.main.h + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.cc + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/multiproto.py + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split + COMMAND + Python3::Interpreter + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/multiproto.py + SQLParser +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.cc + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.proto + ${TOOL_protoc_bin} + ${TOOL_cpp_styleguide_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR} + COMMAND + ${TOOL_protoc_bin} + -I=${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split + -I=${CMAKE_SOURCE_DIR} + -I=${CMAKE_BINARY_DIR} + -I=${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + --cpp_out=${CMAKE_BINARY_DIR} + --cpp_styleguide_out=${CMAKE_BINARY_DIR} + --plugin=protoc-gen-cpp_styleguide=${CMAKE_BINARY_DIR}/contrib/tools/protoc/plugins/cpp_styleguide/cpp_styleguide + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.proto +) +run_antlr( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.proto + DEPENDS + ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/SQL.g + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split + ANTLER_ARGS + ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/SQL.g + -lib + . + -fo + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split + -language + protobuf +) +configure_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/org/antlr/codegen/templates/protobuf/protobuf.stg.in + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg +) +if(NOT CMAKE_CROSSCOMPILING) + add_dependencies(proto_ast-gen-v0_proto_split + cpp_styleguide + protoc +) +endif() diff --git a/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.linux-x86_64.txt b/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..62140126ba3d --- /dev/null +++ b/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.linux-x86_64.txt @@ -0,0 +1,129 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +find_package(Python3 REQUIRED) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +set( + ANTLR_PACKAGE_NAME + NSQLGenerated +) + +add_library(proto_ast-gen-v0_proto_split) +target_include_directories(proto_ast-gen-v0_proto_split PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/org/antlr/codegen/templates/protobuf +) +target_link_libraries(proto_ast-gen-v0_proto_split PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf +) +target_sources(proto_ast-gen-v0_proto_split PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.main.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code0.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.main.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code1.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code2.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code3.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code4.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code5.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code6.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code7.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code8.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code9.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.data.cc +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code0.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code1.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code2.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code3.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code4.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code5.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code6.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code7.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code8.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code9.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.data.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.main.h + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.cc + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/multiproto.py + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split + COMMAND + Python3::Interpreter + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/multiproto.py + SQLParser +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.cc + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.proto + ${TOOL_protoc_bin} + ${TOOL_cpp_styleguide_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR} + COMMAND + ${TOOL_protoc_bin} + -I=${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split + -I=${CMAKE_SOURCE_DIR} + -I=${CMAKE_BINARY_DIR} + -I=${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + --cpp_out=${CMAKE_BINARY_DIR} + --cpp_styleguide_out=${CMAKE_BINARY_DIR} + --plugin=protoc-gen-cpp_styleguide=${CMAKE_BINARY_DIR}/contrib/tools/protoc/plugins/cpp_styleguide/cpp_styleguide + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.proto +) +run_antlr( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.proto + DEPENDS + ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/SQL.g + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split + ANTLER_ARGS + ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/SQL.g + -lib + . + -fo + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split + -language + protobuf +) +configure_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/org/antlr/codegen/templates/protobuf/protobuf.stg.in + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg +) +if(NOT CMAKE_CROSSCOMPILING) + add_dependencies(proto_ast-gen-v0_proto_split + cpp_styleguide + protoc +) +endif() diff --git a/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.txt b/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.windows-x86_64.txt b/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..14d5d5b037d5 --- /dev/null +++ b/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/CMakeLists.windows-x86_64.txt @@ -0,0 +1,128 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +find_package(Python3 REQUIRED) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +set( + ANTLR_PACKAGE_NAME + NSQLGenerated +) + +add_library(proto_ast-gen-v0_proto_split) +target_include_directories(proto_ast-gen-v0_proto_split PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/org/antlr/codegen/templates/protobuf +) +target_link_libraries(proto_ast-gen-v0_proto_split PUBLIC + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf +) +target_sources(proto_ast-gen-v0_proto_split PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.main.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code0.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.main.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code1.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code2.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code3.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code4.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code5.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code6.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code7.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code8.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code9.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.data.cc +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code0.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code1.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code2.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code3.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code4.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code5.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code6.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code7.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code8.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.code9.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.data.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.main.h + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.cc + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/multiproto.py + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split + COMMAND + Python3::Interpreter + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/multiproto.py + SQLParser +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.pb.cc + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.proto + ${TOOL_protoc_bin} + ${TOOL_cpp_styleguide_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR} + COMMAND + ${TOOL_protoc_bin} + -I=${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split + -I=${CMAKE_SOURCE_DIR} + -I=${CMAKE_BINARY_DIR} + -I=${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + --cpp_out=${CMAKE_BINARY_DIR} + --cpp_styleguide_out=${CMAKE_BINARY_DIR} + --plugin=protoc-gen-cpp_styleguide=${CMAKE_BINARY_DIR}/contrib/tools/protoc/plugins/cpp_styleguide/cpp_styleguide.exe + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.proto +) +run_antlr( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/SQLParser.proto + DEPENDS + ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/SQL.g + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split + ANTLER_ARGS + ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/SQL.g + -lib + . + -fo + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split + -language + protobuf +) +configure_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/org/antlr/codegen/templates/protobuf/protobuf.stg.in + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v0_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg +) +if(NOT CMAKE_CROSSCOMPILING) + add_dependencies(proto_ast-gen-v0_proto_split + cpp_styleguide + protoc +) +endif() diff --git a/ydb/library/yql/parser/proto_ast/gen/v1/CMakeLists.darwin-arm64.txt b/ydb/library/yql/parser/proto_ast/gen/v1/CMakeLists.darwin-arm64.txt index 02b893de3bd4..c2f457899fb1 100644 --- a/ydb/library/yql/parser/proto_ast/gen/v1/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/parser/proto_ast/gen/v1/CMakeLists.darwin-arm64.txt @@ -16,7 +16,11 @@ set( ) set( PROTOBUF_HEADER_PATH - ydb/library/yql/parser/proto_ast/gen/v1_proto + ydb/library/yql/parser/proto_ast/gen/v1_proto_split +) +set( + PROTOBUF_SUFFIX_PATH + .pb.main.h ) add_library(proto_ast-gen-v1) @@ -29,9 +33,12 @@ target_include_directories(proto_ast-gen-v1 PUBLIC target_link_libraries(proto_ast-gen-v1 PUBLIC contrib-libs-cxxsupp yutil - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split ) target_sources(proto_ast-gen-v1 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/org/antlr/codegen/templates/Cpp/Cpp.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/SQLv1Parser.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/SQLv1Lexer.h ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/SQLv1Parser.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/SQLv1Lexer.cpp ) diff --git a/ydb/library/yql/parser/proto_ast/gen/v1/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/parser/proto_ast/gen/v1/CMakeLists.darwin-x86_64.txt index 02b893de3bd4..c2f457899fb1 100644 --- a/ydb/library/yql/parser/proto_ast/gen/v1/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/parser/proto_ast/gen/v1/CMakeLists.darwin-x86_64.txt @@ -16,7 +16,11 @@ set( ) set( PROTOBUF_HEADER_PATH - ydb/library/yql/parser/proto_ast/gen/v1_proto + ydb/library/yql/parser/proto_ast/gen/v1_proto_split +) +set( + PROTOBUF_SUFFIX_PATH + .pb.main.h ) add_library(proto_ast-gen-v1) @@ -29,9 +33,12 @@ target_include_directories(proto_ast-gen-v1 PUBLIC target_link_libraries(proto_ast-gen-v1 PUBLIC contrib-libs-cxxsupp yutil - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split ) target_sources(proto_ast-gen-v1 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/org/antlr/codegen/templates/Cpp/Cpp.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/SQLv1Parser.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/SQLv1Lexer.h ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/SQLv1Parser.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/SQLv1Lexer.cpp ) diff --git a/ydb/library/yql/parser/proto_ast/gen/v1/CMakeLists.linux-aarch64.txt b/ydb/library/yql/parser/proto_ast/gen/v1/CMakeLists.linux-aarch64.txt index d1fd41654f5b..9f251fd06cd6 100644 --- a/ydb/library/yql/parser/proto_ast/gen/v1/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/parser/proto_ast/gen/v1/CMakeLists.linux-aarch64.txt @@ -16,7 +16,11 @@ set( ) set( PROTOBUF_HEADER_PATH - ydb/library/yql/parser/proto_ast/gen/v1_proto + ydb/library/yql/parser/proto_ast/gen/v1_proto_split +) +set( + PROTOBUF_SUFFIX_PATH + .pb.main.h ) add_library(proto_ast-gen-v1) @@ -30,9 +34,12 @@ target_link_libraries(proto_ast-gen-v1 PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split ) target_sources(proto_ast-gen-v1 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/org/antlr/codegen/templates/Cpp/Cpp.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/SQLv1Parser.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/SQLv1Lexer.h ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/SQLv1Parser.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/SQLv1Lexer.cpp ) diff --git a/ydb/library/yql/parser/proto_ast/gen/v1/CMakeLists.linux-x86_64.txt b/ydb/library/yql/parser/proto_ast/gen/v1/CMakeLists.linux-x86_64.txt index d1fd41654f5b..9f251fd06cd6 100644 --- a/ydb/library/yql/parser/proto_ast/gen/v1/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/parser/proto_ast/gen/v1/CMakeLists.linux-x86_64.txt @@ -16,7 +16,11 @@ set( ) set( PROTOBUF_HEADER_PATH - ydb/library/yql/parser/proto_ast/gen/v1_proto + ydb/library/yql/parser/proto_ast/gen/v1_proto_split +) +set( + PROTOBUF_SUFFIX_PATH + .pb.main.h ) add_library(proto_ast-gen-v1) @@ -30,9 +34,12 @@ target_link_libraries(proto_ast-gen-v1 PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split ) target_sources(proto_ast-gen-v1 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/org/antlr/codegen/templates/Cpp/Cpp.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/SQLv1Parser.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/SQLv1Lexer.h ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/SQLv1Parser.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/SQLv1Lexer.cpp ) diff --git a/ydb/library/yql/parser/proto_ast/gen/v1/CMakeLists.windows-x86_64.txt b/ydb/library/yql/parser/proto_ast/gen/v1/CMakeLists.windows-x86_64.txt index 02b893de3bd4..c2f457899fb1 100644 --- a/ydb/library/yql/parser/proto_ast/gen/v1/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/parser/proto_ast/gen/v1/CMakeLists.windows-x86_64.txt @@ -16,7 +16,11 @@ set( ) set( PROTOBUF_HEADER_PATH - ydb/library/yql/parser/proto_ast/gen/v1_proto + ydb/library/yql/parser/proto_ast/gen/v1_proto_split +) +set( + PROTOBUF_SUFFIX_PATH + .pb.main.h ) add_library(proto_ast-gen-v1) @@ -29,9 +33,12 @@ target_include_directories(proto_ast-gen-v1 PUBLIC target_link_libraries(proto_ast-gen-v1 PUBLIC contrib-libs-cxxsupp yutil - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split ) target_sources(proto_ast-gen-v1 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/org/antlr/codegen/templates/Cpp/Cpp.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/SQLv1Parser.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/SQLv1Lexer.h ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/SQLv1Parser.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1/SQLv1Lexer.cpp ) diff --git a/ydb/library/yql/parser/proto_ast/gen/v1_ansi/CMakeLists.darwin-arm64.txt b/ydb/library/yql/parser/proto_ast/gen/v1_ansi/CMakeLists.darwin-arm64.txt index 7ce8f04bcfac..edd040782ea0 100644 --- a/ydb/library/yql/parser/proto_ast/gen/v1_ansi/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/parser/proto_ast/gen/v1_ansi/CMakeLists.darwin-arm64.txt @@ -16,7 +16,11 @@ set( ) set( PROTOBUF_HEADER_PATH - ydb/library/yql/parser/proto_ast/gen/v1_proto + ydb/library/yql/parser/proto_ast/gen/v1_proto_split +) +set( + PROTOBUF_SUFFIX_PATH + .pb.main.h ) add_library(proto_ast-gen-v1_ansi) @@ -29,9 +33,12 @@ target_include_directories(proto_ast-gen-v1_ansi PUBLIC target_link_libraries(proto_ast-gen-v1_ansi PUBLIC contrib-libs-cxxsupp yutil - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split ) target_sources(proto_ast-gen-v1_ansi PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/org/antlr/codegen/templates/Cpp/Cpp.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/SQLv1Parser.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/SQLv1Lexer.h ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/SQLv1Parser.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/SQLv1Lexer.cpp ) diff --git a/ydb/library/yql/parser/proto_ast/gen/v1_ansi/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/parser/proto_ast/gen/v1_ansi/CMakeLists.darwin-x86_64.txt index 7ce8f04bcfac..edd040782ea0 100644 --- a/ydb/library/yql/parser/proto_ast/gen/v1_ansi/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/parser/proto_ast/gen/v1_ansi/CMakeLists.darwin-x86_64.txt @@ -16,7 +16,11 @@ set( ) set( PROTOBUF_HEADER_PATH - ydb/library/yql/parser/proto_ast/gen/v1_proto + ydb/library/yql/parser/proto_ast/gen/v1_proto_split +) +set( + PROTOBUF_SUFFIX_PATH + .pb.main.h ) add_library(proto_ast-gen-v1_ansi) @@ -29,9 +33,12 @@ target_include_directories(proto_ast-gen-v1_ansi PUBLIC target_link_libraries(proto_ast-gen-v1_ansi PUBLIC contrib-libs-cxxsupp yutil - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split ) target_sources(proto_ast-gen-v1_ansi PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/org/antlr/codegen/templates/Cpp/Cpp.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/SQLv1Parser.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/SQLv1Lexer.h ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/SQLv1Parser.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/SQLv1Lexer.cpp ) diff --git a/ydb/library/yql/parser/proto_ast/gen/v1_ansi/CMakeLists.linux-aarch64.txt b/ydb/library/yql/parser/proto_ast/gen/v1_ansi/CMakeLists.linux-aarch64.txt index b0255d7b59ca..7d0113b7b0f1 100644 --- a/ydb/library/yql/parser/proto_ast/gen/v1_ansi/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/parser/proto_ast/gen/v1_ansi/CMakeLists.linux-aarch64.txt @@ -16,7 +16,11 @@ set( ) set( PROTOBUF_HEADER_PATH - ydb/library/yql/parser/proto_ast/gen/v1_proto + ydb/library/yql/parser/proto_ast/gen/v1_proto_split +) +set( + PROTOBUF_SUFFIX_PATH + .pb.main.h ) add_library(proto_ast-gen-v1_ansi) @@ -30,9 +34,12 @@ target_link_libraries(proto_ast-gen-v1_ansi PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split ) target_sources(proto_ast-gen-v1_ansi PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/org/antlr/codegen/templates/Cpp/Cpp.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/SQLv1Parser.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/SQLv1Lexer.h ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/SQLv1Parser.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/SQLv1Lexer.cpp ) diff --git a/ydb/library/yql/parser/proto_ast/gen/v1_ansi/CMakeLists.linux-x86_64.txt b/ydb/library/yql/parser/proto_ast/gen/v1_ansi/CMakeLists.linux-x86_64.txt index b0255d7b59ca..7d0113b7b0f1 100644 --- a/ydb/library/yql/parser/proto_ast/gen/v1_ansi/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/parser/proto_ast/gen/v1_ansi/CMakeLists.linux-x86_64.txt @@ -16,7 +16,11 @@ set( ) set( PROTOBUF_HEADER_PATH - ydb/library/yql/parser/proto_ast/gen/v1_proto + ydb/library/yql/parser/proto_ast/gen/v1_proto_split +) +set( + PROTOBUF_SUFFIX_PATH + .pb.main.h ) add_library(proto_ast-gen-v1_ansi) @@ -30,9 +34,12 @@ target_link_libraries(proto_ast-gen-v1_ansi PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split ) target_sources(proto_ast-gen-v1_ansi PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/org/antlr/codegen/templates/Cpp/Cpp.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/SQLv1Parser.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/SQLv1Lexer.h ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/SQLv1Parser.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/SQLv1Lexer.cpp ) diff --git a/ydb/library/yql/parser/proto_ast/gen/v1_ansi/CMakeLists.windows-x86_64.txt b/ydb/library/yql/parser/proto_ast/gen/v1_ansi/CMakeLists.windows-x86_64.txt index 7ce8f04bcfac..edd040782ea0 100644 --- a/ydb/library/yql/parser/proto_ast/gen/v1_ansi/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/parser/proto_ast/gen/v1_ansi/CMakeLists.windows-x86_64.txt @@ -16,7 +16,11 @@ set( ) set( PROTOBUF_HEADER_PATH - ydb/library/yql/parser/proto_ast/gen/v1_proto + ydb/library/yql/parser/proto_ast/gen/v1_proto_split +) +set( + PROTOBUF_SUFFIX_PATH + .pb.main.h ) add_library(proto_ast-gen-v1_ansi) @@ -29,9 +33,12 @@ target_include_directories(proto_ast-gen-v1_ansi PUBLIC target_link_libraries(proto_ast-gen-v1_ansi PUBLIC contrib-libs-cxxsupp yutil - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split ) target_sources(proto_ast-gen-v1_ansi PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/org/antlr/codegen/templates/Cpp/Cpp.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/SQLv1Parser.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/SQLv1Lexer.h ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/SQLv1Parser.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_ansi/SQLv1Lexer.cpp ) diff --git a/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.darwin-arm64.txt b/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..5f3dd30e0bc3 --- /dev/null +++ b/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.darwin-arm64.txt @@ -0,0 +1,138 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +find_package(Python3 REQUIRED) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +set( + ANTLR_PACKAGE_NAME + NSQLv1Generated +) + +add_library(proto_ast-gen-v1_proto_split) +target_include_directories(proto_ast-gen-v1_proto_split PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/org/antlr/codegen/templates/protobuf +) +target_link_libraries(proto_ast-gen-v1_proto_split PUBLIC + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf +) +target_sources(proto_ast-gen-v1_proto_split PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.main.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code0.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.main.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code1.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code2.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code3.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code4.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code5.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code6.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code7.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code8.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code9.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.data.cc +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code0.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code1.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code2.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code3.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code4.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code5.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code6.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code7.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code8.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code9.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.data.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.main.h + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.cc + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/multiproto.py + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split + COMMAND + Python3::Interpreter + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/multiproto.py + SQLv1Parser +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.cc + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.proto + ${TOOL_protoc_bin} + ${TOOL_cpp_styleguide_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR} + COMMAND + ${TOOL_protoc_bin} + -I=${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split + -I=${CMAKE_SOURCE_DIR} + -I=${CMAKE_BINARY_DIR} + -I=${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + --cpp_out=${CMAKE_BINARY_DIR} + --cpp_styleguide_out=${CMAKE_BINARY_DIR} + --plugin=protoc-gen-cpp_styleguide=${CMAKE_BINARY_DIR}/contrib/tools/protoc/plugins/cpp_styleguide/cpp_styleguide + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.proto +) +run_antlr( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.proto + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1.g + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split + ANTLER_ARGS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1.g + -lib + . + -fo + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split + -language + protobuf +) +configure_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/org/antlr/codegen/templates/protobuf/protobuf.stg.in + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg +) +if(NOT CMAKE_CROSSCOMPILING) + add_dependencies(proto_ast-gen-v1_proto_split + cpp_styleguide + protoc +) +endif() +set(GRAMMAR_STRING_CORE_SINGLE "~(QUOTE_SINGLE | BACKSLASH) | (BACKSLASH .)") +set(GRAMMAR_STRING_CORE_DOUBLE "~(QUOTE_DOUBLE | BACKSLASH) | (BACKSLASH .)") +set(GRAMMAR_MULTILINE_COMMENT_CORE ".") + +configure_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/SQLv1.g.in + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1.g +) + + diff --git a/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..5f3dd30e0bc3 --- /dev/null +++ b/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,138 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +find_package(Python3 REQUIRED) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +set( + ANTLR_PACKAGE_NAME + NSQLv1Generated +) + +add_library(proto_ast-gen-v1_proto_split) +target_include_directories(proto_ast-gen-v1_proto_split PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/org/antlr/codegen/templates/protobuf +) +target_link_libraries(proto_ast-gen-v1_proto_split PUBLIC + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf +) +target_sources(proto_ast-gen-v1_proto_split PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.main.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code0.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.main.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code1.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code2.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code3.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code4.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code5.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code6.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code7.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code8.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code9.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.data.cc +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code0.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code1.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code2.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code3.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code4.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code5.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code6.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code7.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code8.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code9.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.data.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.main.h + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.cc + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/multiproto.py + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split + COMMAND + Python3::Interpreter + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/multiproto.py + SQLv1Parser +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.cc + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.proto + ${TOOL_protoc_bin} + ${TOOL_cpp_styleguide_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR} + COMMAND + ${TOOL_protoc_bin} + -I=${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split + -I=${CMAKE_SOURCE_DIR} + -I=${CMAKE_BINARY_DIR} + -I=${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + --cpp_out=${CMAKE_BINARY_DIR} + --cpp_styleguide_out=${CMAKE_BINARY_DIR} + --plugin=protoc-gen-cpp_styleguide=${CMAKE_BINARY_DIR}/contrib/tools/protoc/plugins/cpp_styleguide/cpp_styleguide + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.proto +) +run_antlr( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.proto + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1.g + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split + ANTLER_ARGS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1.g + -lib + . + -fo + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split + -language + protobuf +) +configure_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/org/antlr/codegen/templates/protobuf/protobuf.stg.in + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg +) +if(NOT CMAKE_CROSSCOMPILING) + add_dependencies(proto_ast-gen-v1_proto_split + cpp_styleguide + protoc +) +endif() +set(GRAMMAR_STRING_CORE_SINGLE "~(QUOTE_SINGLE | BACKSLASH) | (BACKSLASH .)") +set(GRAMMAR_STRING_CORE_DOUBLE "~(QUOTE_DOUBLE | BACKSLASH) | (BACKSLASH .)") +set(GRAMMAR_MULTILINE_COMMENT_CORE ".") + +configure_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/SQLv1.g.in + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1.g +) + + diff --git a/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.linux-aarch64.txt b/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..5e8c6e90c909 --- /dev/null +++ b/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.linux-aarch64.txt @@ -0,0 +1,139 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +find_package(Python3 REQUIRED) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +set( + ANTLR_PACKAGE_NAME + NSQLv1Generated +) + +add_library(proto_ast-gen-v1_proto_split) +target_include_directories(proto_ast-gen-v1_proto_split PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/org/antlr/codegen/templates/protobuf +) +target_link_libraries(proto_ast-gen-v1_proto_split PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf +) +target_sources(proto_ast-gen-v1_proto_split PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.main.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code0.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.main.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code1.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code2.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code3.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code4.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code5.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code6.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code7.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code8.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code9.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.data.cc +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code0.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code1.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code2.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code3.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code4.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code5.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code6.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code7.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code8.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code9.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.data.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.main.h + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.cc + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/multiproto.py + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split + COMMAND + Python3::Interpreter + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/multiproto.py + SQLv1Parser +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.cc + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.proto + ${TOOL_protoc_bin} + ${TOOL_cpp_styleguide_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR} + COMMAND + ${TOOL_protoc_bin} + -I=${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split + -I=${CMAKE_SOURCE_DIR} + -I=${CMAKE_BINARY_DIR} + -I=${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + --cpp_out=${CMAKE_BINARY_DIR} + --cpp_styleguide_out=${CMAKE_BINARY_DIR} + --plugin=protoc-gen-cpp_styleguide=${CMAKE_BINARY_DIR}/contrib/tools/protoc/plugins/cpp_styleguide/cpp_styleguide + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.proto +) +run_antlr( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.proto + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1.g + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split + ANTLER_ARGS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1.g + -lib + . + -fo + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split + -language + protobuf +) +configure_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/org/antlr/codegen/templates/protobuf/protobuf.stg.in + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg +) +if(NOT CMAKE_CROSSCOMPILING) + add_dependencies(proto_ast-gen-v1_proto_split + cpp_styleguide + protoc +) +endif() +set(GRAMMAR_STRING_CORE_SINGLE "~(QUOTE_SINGLE | BACKSLASH) | (BACKSLASH .)") +set(GRAMMAR_STRING_CORE_DOUBLE "~(QUOTE_DOUBLE | BACKSLASH) | (BACKSLASH .)") +set(GRAMMAR_MULTILINE_COMMENT_CORE ".") + +configure_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/SQLv1.g.in + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1.g +) + + diff --git a/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.linux-x86_64.txt b/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..5e8c6e90c909 --- /dev/null +++ b/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.linux-x86_64.txt @@ -0,0 +1,139 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +find_package(Python3 REQUIRED) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +set( + ANTLR_PACKAGE_NAME + NSQLv1Generated +) + +add_library(proto_ast-gen-v1_proto_split) +target_include_directories(proto_ast-gen-v1_proto_split PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/org/antlr/codegen/templates/protobuf +) +target_link_libraries(proto_ast-gen-v1_proto_split PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf +) +target_sources(proto_ast-gen-v1_proto_split PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.main.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code0.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.main.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code1.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code2.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code3.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code4.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code5.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code6.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code7.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code8.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code9.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.data.cc +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code0.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code1.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code2.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code3.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code4.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code5.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code6.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code7.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code8.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code9.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.data.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.main.h + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.cc + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/multiproto.py + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split + COMMAND + Python3::Interpreter + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/multiproto.py + SQLv1Parser +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.cc + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.proto + ${TOOL_protoc_bin} + ${TOOL_cpp_styleguide_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR} + COMMAND + ${TOOL_protoc_bin} + -I=${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split + -I=${CMAKE_SOURCE_DIR} + -I=${CMAKE_BINARY_DIR} + -I=${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + --cpp_out=${CMAKE_BINARY_DIR} + --cpp_styleguide_out=${CMAKE_BINARY_DIR} + --plugin=protoc-gen-cpp_styleguide=${CMAKE_BINARY_DIR}/contrib/tools/protoc/plugins/cpp_styleguide/cpp_styleguide + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.proto +) +run_antlr( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.proto + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1.g + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split + ANTLER_ARGS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1.g + -lib + . + -fo + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split + -language + protobuf +) +configure_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/org/antlr/codegen/templates/protobuf/protobuf.stg.in + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg +) +if(NOT CMAKE_CROSSCOMPILING) + add_dependencies(proto_ast-gen-v1_proto_split + cpp_styleguide + protoc +) +endif() +set(GRAMMAR_STRING_CORE_SINGLE "~(QUOTE_SINGLE | BACKSLASH) | (BACKSLASH .)") +set(GRAMMAR_STRING_CORE_DOUBLE "~(QUOTE_DOUBLE | BACKSLASH) | (BACKSLASH .)") +set(GRAMMAR_MULTILINE_COMMENT_CORE ".") + +configure_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/SQLv1.g.in + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1.g +) + + diff --git a/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.txt b/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.windows-x86_64.txt b/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..a5bd6e7a474b --- /dev/null +++ b/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/CMakeLists.windows-x86_64.txt @@ -0,0 +1,138 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +find_package(Python3 REQUIRED) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +set( + ANTLR_PACKAGE_NAME + NSQLv1Generated +) + +add_library(proto_ast-gen-v1_proto_split) +target_include_directories(proto_ast-gen-v1_proto_split PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/org/antlr/codegen/templates/protobuf +) +target_link_libraries(proto_ast-gen-v1_proto_split PUBLIC + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf +) +target_sources(proto_ast-gen-v1_proto_split PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.main.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code0.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.main.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code1.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code2.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code3.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code4.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code5.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code6.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code7.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code8.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code9.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.data.cc +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code0.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code1.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code2.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code3.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code4.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code5.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code6.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code7.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code8.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.code9.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.data.cc + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.classes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.main.h + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.cc + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/multiproto.py + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split + COMMAND + Python3::Interpreter + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/multiproto.py + SQLv1Parser +) +add_custom_command( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.pb.cc + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.proto + ${TOOL_protoc_bin} + ${TOOL_cpp_styleguide_bin} + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR} + COMMAND + ${TOOL_protoc_bin} + -I=${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split + -I=${CMAKE_SOURCE_DIR} + -I=${CMAKE_BINARY_DIR} + -I=${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + --cpp_out=${CMAKE_BINARY_DIR} + --cpp_styleguide_out=${CMAKE_BINARY_DIR} + --plugin=protoc-gen-cpp_styleguide=${CMAKE_BINARY_DIR}/contrib/tools/protoc/plugins/cpp_styleguide/cpp_styleguide.exe + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.proto +) +run_antlr( + OUTPUT + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1Parser.proto + DEPENDS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1.g + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg + WORKING_DIRECTORY + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split + ANTLER_ARGS + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1.g + -lib + . + -fo + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split + -language + protobuf +) +configure_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/proto_ast/org/antlr/codegen/templates/protobuf/protobuf.stg.in + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/org/antlr/codegen/templates/protobuf/protobuf.stg +) +if(NOT CMAKE_CROSSCOMPILING) + add_dependencies(proto_ast-gen-v1_proto_split + cpp_styleguide + protoc +) +endif() +set(GRAMMAR_STRING_CORE_SINGLE "~(QUOTE_SINGLE | BACKSLASH) | (BACKSLASH .)") +set(GRAMMAR_STRING_CORE_DOUBLE "~(QUOTE_DOUBLE | BACKSLASH) | (BACKSLASH .)") +set(GRAMMAR_MULTILINE_COMMENT_CORE ".") + +configure_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/SQLv1.g.in + ${CMAKE_BINARY_DIR}/ydb/library/yql/parser/proto_ast/gen/v1_proto_split/SQLv1.g +) + + diff --git a/ydb/library/yql/protos/CMakeLists.darwin-arm64.txt b/ydb/library/yql/protos/CMakeLists.darwin-arm64.txt index 3bcb29501f73..40f209f73534 100644 --- a/ydb/library/yql/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/protos/CMakeLists.darwin-arm64.txt @@ -54,6 +54,11 @@ target_proto_messages(library-yql-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/protos/yql_mount.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/protos/clickhouse.proto ) +target_sources(library-yql-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/protos/common.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/protos/yql_mount.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/protos/clickhouse.pb.h +) target_proto_addincls(library-yql-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/protos/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/protos/CMakeLists.darwin-x86_64.txt index 3bcb29501f73..40f209f73534 100644 --- a/ydb/library/yql/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/protos/CMakeLists.darwin-x86_64.txt @@ -54,6 +54,11 @@ target_proto_messages(library-yql-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/protos/yql_mount.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/protos/clickhouse.proto ) +target_sources(library-yql-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/protos/common.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/protos/yql_mount.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/protos/clickhouse.pb.h +) target_proto_addincls(library-yql-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/protos/CMakeLists.linux-aarch64.txt b/ydb/library/yql/protos/CMakeLists.linux-aarch64.txt index 1ab2ef6b31b5..dc8eb37140b8 100644 --- a/ydb/library/yql/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/protos/CMakeLists.linux-aarch64.txt @@ -55,6 +55,11 @@ target_proto_messages(library-yql-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/protos/yql_mount.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/protos/clickhouse.proto ) +target_sources(library-yql-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/protos/common.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/protos/yql_mount.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/protos/clickhouse.pb.h +) target_proto_addincls(library-yql-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/protos/CMakeLists.linux-x86_64.txt b/ydb/library/yql/protos/CMakeLists.linux-x86_64.txt index 1ab2ef6b31b5..dc8eb37140b8 100644 --- a/ydb/library/yql/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/protos/CMakeLists.linux-x86_64.txt @@ -55,6 +55,11 @@ target_proto_messages(library-yql-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/protos/yql_mount.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/protos/clickhouse.proto ) +target_sources(library-yql-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/protos/common.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/protos/yql_mount.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/protos/clickhouse.pb.h +) target_proto_addincls(library-yql-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/protos/CMakeLists.windows-x86_64.txt b/ydb/library/yql/protos/CMakeLists.windows-x86_64.txt index 3bcb29501f73..40f209f73534 100644 --- a/ydb/library/yql/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/protos/CMakeLists.windows-x86_64.txt @@ -54,6 +54,11 @@ target_proto_messages(library-yql-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/protos/yql_mount.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/protos/clickhouse.proto ) +target_sources(library-yql-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/protos/common.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/protos/yql_mount.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/protos/clickhouse.pb.h +) target_proto_addincls(library-yql-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/clickhouse/actors/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/clickhouse/actors/CMakeLists.darwin-arm64.txt index 212170609f21..477f1b913119 100644 --- a/ydb/library/yql/providers/clickhouse/actors/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/clickhouse/actors/CMakeLists.darwin-arm64.txt @@ -14,7 +14,7 @@ target_compile_options(providers-clickhouse-actors PRIVATE target_link_libraries(providers-clickhouse-actors PUBLIC contrib-libs-cxxsupp yutil - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client yql-public-types dq-actors-compute diff --git a/ydb/library/yql/providers/clickhouse/actors/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/clickhouse/actors/CMakeLists.darwin-x86_64.txt index 212170609f21..477f1b913119 100644 --- a/ydb/library/yql/providers/clickhouse/actors/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/clickhouse/actors/CMakeLists.darwin-x86_64.txt @@ -14,7 +14,7 @@ target_compile_options(providers-clickhouse-actors PRIVATE target_link_libraries(providers-clickhouse-actors PUBLIC contrib-libs-cxxsupp yutil - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client yql-public-types dq-actors-compute diff --git a/ydb/library/yql/providers/clickhouse/actors/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/clickhouse/actors/CMakeLists.linux-aarch64.txt index 15fe5e1878b0..9eae5b0a45a5 100644 --- a/ydb/library/yql/providers/clickhouse/actors/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/clickhouse/actors/CMakeLists.linux-aarch64.txt @@ -15,7 +15,7 @@ target_link_libraries(providers-clickhouse-actors PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client yql-public-types dq-actors-compute diff --git a/ydb/library/yql/providers/clickhouse/actors/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/clickhouse/actors/CMakeLists.linux-x86_64.txt index 15fe5e1878b0..9eae5b0a45a5 100644 --- a/ydb/library/yql/providers/clickhouse/actors/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/clickhouse/actors/CMakeLists.linux-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(providers-clickhouse-actors PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client yql-public-types dq-actors-compute diff --git a/ydb/library/yql/providers/clickhouse/actors/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/clickhouse/actors/CMakeLists.windows-x86_64.txt index 212170609f21..477f1b913119 100644 --- a/ydb/library/yql/providers/clickhouse/actors/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/clickhouse/actors/CMakeLists.windows-x86_64.txt @@ -14,7 +14,7 @@ target_compile_options(providers-clickhouse-actors PRIVATE target_link_libraries(providers-clickhouse-actors PUBLIC contrib-libs-cxxsupp yutil - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client yql-public-types dq-actors-compute diff --git a/ydb/library/yql/providers/clickhouse/expr_nodes/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/clickhouse/expr_nodes/CMakeLists.darwin-arm64.txt index 16666cdd9d6d..ecccf59d2204 100644 --- a/ydb/library/yql/providers/clickhouse/expr_nodes/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/clickhouse/expr_nodes/CMakeLists.darwin-arm64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-clickhouse-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-clickhouse-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/clickhouse/expr_nodes/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/clickhouse/expr_nodes/CMakeLists.darwin-x86_64.txt index 16666cdd9d6d..ecccf59d2204 100644 --- a/ydb/library/yql/providers/clickhouse/expr_nodes/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/clickhouse/expr_nodes/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-clickhouse-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-clickhouse-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/clickhouse/expr_nodes/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/clickhouse/expr_nodes/CMakeLists.linux-aarch64.txt index 03ab381c539f..8580227da022 100644 --- a/ydb/library/yql/providers/clickhouse/expr_nodes/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/clickhouse/expr_nodes/CMakeLists.linux-aarch64.txt @@ -17,6 +17,9 @@ target_link_libraries(providers-clickhouse-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-clickhouse-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/clickhouse/expr_nodes/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/clickhouse/expr_nodes/CMakeLists.linux-x86_64.txt index 03ab381c539f..8580227da022 100644 --- a/ydb/library/yql/providers/clickhouse/expr_nodes/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/clickhouse/expr_nodes/CMakeLists.linux-x86_64.txt @@ -17,6 +17,9 @@ target_link_libraries(providers-clickhouse-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-clickhouse-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/clickhouse/expr_nodes/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/clickhouse/expr_nodes/CMakeLists.windows-x86_64.txt index 16666cdd9d6d..ecccf59d2204 100644 --- a/ydb/library/yql/providers/clickhouse/expr_nodes/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/clickhouse/expr_nodes/CMakeLists.windows-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-clickhouse-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-clickhouse-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/expr_nodes/yql_clickhouse_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/clickhouse/proto/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/clickhouse/proto/CMakeLists.darwin-arm64.txt index dc1892a574f3..398e47ee3e9d 100644 --- a/ydb/library/yql/providers/clickhouse/proto/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/clickhouse/proto/CMakeLists.darwin-arm64.txt @@ -41,6 +41,10 @@ target_proto_messages(providers-clickhouse-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/proto/source.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/proto/range.proto ) +target_sources(providers-clickhouse-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/proto/source.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/proto/range.pb.h +) target_proto_addincls(providers-clickhouse-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/clickhouse/proto/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/clickhouse/proto/CMakeLists.darwin-x86_64.txt index dc1892a574f3..398e47ee3e9d 100644 --- a/ydb/library/yql/providers/clickhouse/proto/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/clickhouse/proto/CMakeLists.darwin-x86_64.txt @@ -41,6 +41,10 @@ target_proto_messages(providers-clickhouse-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/proto/source.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/proto/range.proto ) +target_sources(providers-clickhouse-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/proto/source.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/proto/range.pb.h +) target_proto_addincls(providers-clickhouse-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/clickhouse/proto/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/clickhouse/proto/CMakeLists.linux-aarch64.txt index 026f01786cb9..368b176c9f1a 100644 --- a/ydb/library/yql/providers/clickhouse/proto/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/clickhouse/proto/CMakeLists.linux-aarch64.txt @@ -42,6 +42,10 @@ target_proto_messages(providers-clickhouse-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/proto/source.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/proto/range.proto ) +target_sources(providers-clickhouse-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/proto/source.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/proto/range.pb.h +) target_proto_addincls(providers-clickhouse-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/clickhouse/proto/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/clickhouse/proto/CMakeLists.linux-x86_64.txt index 026f01786cb9..368b176c9f1a 100644 --- a/ydb/library/yql/providers/clickhouse/proto/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/clickhouse/proto/CMakeLists.linux-x86_64.txt @@ -42,6 +42,10 @@ target_proto_messages(providers-clickhouse-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/proto/source.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/proto/range.proto ) +target_sources(providers-clickhouse-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/proto/source.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/proto/range.pb.h +) target_proto_addincls(providers-clickhouse-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/clickhouse/proto/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/clickhouse/proto/CMakeLists.windows-x86_64.txt index dc1892a574f3..398e47ee3e9d 100644 --- a/ydb/library/yql/providers/clickhouse/proto/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/clickhouse/proto/CMakeLists.windows-x86_64.txt @@ -41,6 +41,10 @@ target_proto_messages(providers-clickhouse-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/proto/source.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/proto/range.proto ) +target_sources(providers-clickhouse-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/proto/source.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/clickhouse/proto/range.pb.h +) target_proto_addincls(providers-clickhouse-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/clickhouse/provider/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/clickhouse/provider/CMakeLists.darwin-arm64.txt index 0550a7bbca72..6f268269827e 100644 --- a/ydb/library/yql/providers/clickhouse/provider/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/clickhouse/provider/CMakeLists.darwin-arm64.txt @@ -18,7 +18,7 @@ target_link_libraries(providers-clickhouse-provider PUBLIC library-cpp-random_provider library-cpp-time_provider library-yql-ast - minikql-comp_nodes-llvm + yql-minikql-comp_nodes library-yql-core yql-core-type_ann yql-dq-expr_nodes @@ -37,6 +37,10 @@ target_link_libraries(providers-clickhouse-provider PUBLIC providers-dq-expr_nodes ) target_sources(providers-clickhouse-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_provider_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_settings.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_util.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_datasink.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_datasink_execution.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_datasink_type_ann.cpp diff --git a/ydb/library/yql/providers/clickhouse/provider/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/clickhouse/provider/CMakeLists.darwin-x86_64.txt index 0550a7bbca72..6f268269827e 100644 --- a/ydb/library/yql/providers/clickhouse/provider/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/clickhouse/provider/CMakeLists.darwin-x86_64.txt @@ -18,7 +18,7 @@ target_link_libraries(providers-clickhouse-provider PUBLIC library-cpp-random_provider library-cpp-time_provider library-yql-ast - minikql-comp_nodes-llvm + yql-minikql-comp_nodes library-yql-core yql-core-type_ann yql-dq-expr_nodes @@ -37,6 +37,10 @@ target_link_libraries(providers-clickhouse-provider PUBLIC providers-dq-expr_nodes ) target_sources(providers-clickhouse-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_provider_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_settings.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_util.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_datasink.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_datasink_execution.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_datasink_type_ann.cpp diff --git a/ydb/library/yql/providers/clickhouse/provider/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/clickhouse/provider/CMakeLists.linux-aarch64.txt index 1cdf6bb9ddeb..19305173b996 100644 --- a/ydb/library/yql/providers/clickhouse/provider/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/clickhouse/provider/CMakeLists.linux-aarch64.txt @@ -19,7 +19,7 @@ target_link_libraries(providers-clickhouse-provider PUBLIC library-cpp-random_provider library-cpp-time_provider library-yql-ast - minikql-comp_nodes-llvm + yql-minikql-comp_nodes library-yql-core yql-core-type_ann yql-dq-expr_nodes @@ -38,6 +38,10 @@ target_link_libraries(providers-clickhouse-provider PUBLIC providers-dq-expr_nodes ) target_sources(providers-clickhouse-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_provider_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_settings.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_util.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_datasink.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_datasink_execution.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_datasink_type_ann.cpp diff --git a/ydb/library/yql/providers/clickhouse/provider/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/clickhouse/provider/CMakeLists.linux-x86_64.txt index 1cdf6bb9ddeb..19305173b996 100644 --- a/ydb/library/yql/providers/clickhouse/provider/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/clickhouse/provider/CMakeLists.linux-x86_64.txt @@ -19,7 +19,7 @@ target_link_libraries(providers-clickhouse-provider PUBLIC library-cpp-random_provider library-cpp-time_provider library-yql-ast - minikql-comp_nodes-llvm + yql-minikql-comp_nodes library-yql-core yql-core-type_ann yql-dq-expr_nodes @@ -38,6 +38,10 @@ target_link_libraries(providers-clickhouse-provider PUBLIC providers-dq-expr_nodes ) target_sources(providers-clickhouse-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_provider_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_settings.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_util.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_datasink.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_datasink_execution.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_datasink_type_ann.cpp diff --git a/ydb/library/yql/providers/clickhouse/provider/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/clickhouse/provider/CMakeLists.windows-x86_64.txt index 0550a7bbca72..6f268269827e 100644 --- a/ydb/library/yql/providers/clickhouse/provider/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/clickhouse/provider/CMakeLists.windows-x86_64.txt @@ -18,7 +18,7 @@ target_link_libraries(providers-clickhouse-provider PUBLIC library-cpp-random_provider library-cpp-time_provider library-yql-ast - minikql-comp_nodes-llvm + yql-minikql-comp_nodes library-yql-core yql-core-type_ann yql-dq-expr_nodes @@ -37,6 +37,10 @@ target_link_libraries(providers-clickhouse-provider PUBLIC providers-dq-expr_nodes ) target_sources(providers-clickhouse-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_provider_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_settings.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_util.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_datasink.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_datasink_execution.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/clickhouse/provider/yql_clickhouse_datasink_type_ann.cpp diff --git a/ydb/library/yql/providers/common/codec/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/common/codec/CMakeLists.darwin-arm64.txt index 7555db6d199c..458eb26dc455 100644 --- a/ydb/library/yql/providers/common/codec/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/common/codec/CMakeLists.darwin-arm64.txt @@ -21,7 +21,7 @@ target_compile_options(providers-common-codec PRIVATE target_link_libraries(providers-common-codec PUBLIC contrib-libs-cxxsupp yutil - minikql-computation-llvm + yql-minikql-computation parser-pg_wrapper-interface providers-common-mkql cpp-yson-node @@ -31,6 +31,11 @@ target_link_libraries(providers-common-codec PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(providers-common-codec PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_buf.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_results.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_restricted_yson.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_type_flags.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_buf.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_results.cpp diff --git a/ydb/library/yql/providers/common/codec/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/common/codec/CMakeLists.darwin-x86_64.txt index 7555db6d199c..458eb26dc455 100644 --- a/ydb/library/yql/providers/common/codec/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/common/codec/CMakeLists.darwin-x86_64.txt @@ -21,7 +21,7 @@ target_compile_options(providers-common-codec PRIVATE target_link_libraries(providers-common-codec PUBLIC contrib-libs-cxxsupp yutil - minikql-computation-llvm + yql-minikql-computation parser-pg_wrapper-interface providers-common-mkql cpp-yson-node @@ -31,6 +31,11 @@ target_link_libraries(providers-common-codec PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(providers-common-codec PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_buf.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_results.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_restricted_yson.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_type_flags.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_buf.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_results.cpp diff --git a/ydb/library/yql/providers/common/codec/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/common/codec/CMakeLists.linux-aarch64.txt index c0402bf5275d..34e3740bcb5e 100644 --- a/ydb/library/yql/providers/common/codec/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/common/codec/CMakeLists.linux-aarch64.txt @@ -22,7 +22,7 @@ target_link_libraries(providers-common-codec PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - minikql-computation-llvm + yql-minikql-computation parser-pg_wrapper-interface providers-common-mkql cpp-yson-node @@ -32,6 +32,11 @@ target_link_libraries(providers-common-codec PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(providers-common-codec PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_buf.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_results.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_restricted_yson.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_type_flags.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_buf.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_results.cpp diff --git a/ydb/library/yql/providers/common/codec/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/common/codec/CMakeLists.linux-x86_64.txt index c0402bf5275d..34e3740bcb5e 100644 --- a/ydb/library/yql/providers/common/codec/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/common/codec/CMakeLists.linux-x86_64.txt @@ -22,7 +22,7 @@ target_link_libraries(providers-common-codec PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - minikql-computation-llvm + yql-minikql-computation parser-pg_wrapper-interface providers-common-mkql cpp-yson-node @@ -32,6 +32,11 @@ target_link_libraries(providers-common-codec PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(providers-common-codec PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_buf.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_results.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_restricted_yson.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_type_flags.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_buf.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_results.cpp diff --git a/ydb/library/yql/providers/common/codec/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/common/codec/CMakeLists.windows-x86_64.txt index 7555db6d199c..458eb26dc455 100644 --- a/ydb/library/yql/providers/common/codec/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/common/codec/CMakeLists.windows-x86_64.txt @@ -21,7 +21,7 @@ target_compile_options(providers-common-codec PRIVATE target_link_libraries(providers-common-codec PUBLIC contrib-libs-cxxsupp yutil - minikql-computation-llvm + yql-minikql-computation parser-pg_wrapper-interface providers-common-mkql cpp-yson-node @@ -31,6 +31,11 @@ target_link_libraries(providers-common-codec PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(providers-common-codec PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_buf.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_results.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_restricted_yson.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_type_flags.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_buf.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_codec_results.cpp diff --git a/ydb/library/yql/providers/common/codec/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/common/codec/ut/CMakeLists.darwin-arm64.txt index c7e50d81c02c..1036e29119fe 100644 --- a/ydb/library/yql/providers/common/codec/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/common/codec/ut/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-library-yql-providers-common-codec-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-common-codec-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_json_codec_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/common/codec/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/common/codec/ut/CMakeLists.darwin-x86_64.txt index 1753db1f68bd..129b42fc2a78 100644 --- a/ydb/library/yql/providers/common/codec/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/common/codec/ut/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-library-yql-providers-common-codec-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-common-codec-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_json_codec_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/common/codec/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/common/codec/ut/CMakeLists.linux-aarch64.txt index bc1dd28c05b1..524d06ad3dc1 100644 --- a/ydb/library/yql/providers/common/codec/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/common/codec/ut/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-library-yql-providers-common-codec-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-common-codec-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_json_codec_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/common/codec/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/common/codec/ut/CMakeLists.linux-x86_64.txt index 1f38c1c8d70f..25306306db37 100644 --- a/ydb/library/yql/providers/common/codec/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/common/codec/ut/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-library-yql-providers-common-codec-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-common-codec-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/codec/yql_json_codec_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/common/codec/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/common/codec/ut/CMakeLists.windows-x86_64.txt index bfe1b6a60dd5..c66773f2dc6b 100644 --- a/ydb/library/yql/providers/common/codec/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/common/codec/ut/CMakeLists.windows-x86_64.txt @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/common/comp_nodes/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/common/comp_nodes/CMakeLists.darwin-arm64.txt index f559551f3b9f..9806f1c3d7bc 100644 --- a/ydb/library/yql/providers/common/comp_nodes/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/common/comp_nodes/CMakeLists.darwin-arm64.txt @@ -16,20 +16,27 @@ target_link_libraries(providers-common-comp_nodes PUBLIC yutil library-yql-ast yql-ast-serialize - minikql-computation-llvm + yql-minikql-computation library-yql-core yql-core-type_ann providers-common-codec common-schema-expr - yql-minikql-codegen - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO ) target_sources(providers-common-comp_nodes PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_factory.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formatcode.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formattype.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formattypediff.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_makecode.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_maketype.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_parsetypehandle.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_position.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_reprcode.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_serializetypehandle.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_splittype.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_type_resource.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_typehandle.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_typekind.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formatcode.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formattype.cpp diff --git a/ydb/library/yql/providers/common/comp_nodes/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/common/comp_nodes/CMakeLists.darwin-x86_64.txt index f559551f3b9f..9806f1c3d7bc 100644 --- a/ydb/library/yql/providers/common/comp_nodes/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/common/comp_nodes/CMakeLists.darwin-x86_64.txt @@ -16,20 +16,27 @@ target_link_libraries(providers-common-comp_nodes PUBLIC yutil library-yql-ast yql-ast-serialize - minikql-computation-llvm + yql-minikql-computation library-yql-core yql-core-type_ann providers-common-codec common-schema-expr - yql-minikql-codegen - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO ) target_sources(providers-common-comp_nodes PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_factory.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formatcode.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formattype.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formattypediff.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_makecode.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_maketype.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_parsetypehandle.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_position.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_reprcode.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_serializetypehandle.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_splittype.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_type_resource.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_typehandle.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_typekind.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formatcode.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formattype.cpp diff --git a/ydb/library/yql/providers/common/comp_nodes/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/common/comp_nodes/CMakeLists.linux-aarch64.txt index e9e8316ac3b0..4a47cc76f02e 100644 --- a/ydb/library/yql/providers/common/comp_nodes/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/common/comp_nodes/CMakeLists.linux-aarch64.txt @@ -17,20 +17,27 @@ target_link_libraries(providers-common-comp_nodes PUBLIC yutil library-yql-ast yql-ast-serialize - minikql-computation-llvm + yql-minikql-computation library-yql-core yql-core-type_ann providers-common-codec common-schema-expr - yql-minikql-codegen - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO ) target_sources(providers-common-comp_nodes PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_factory.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formatcode.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formattype.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formattypediff.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_makecode.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_maketype.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_parsetypehandle.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_position.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_reprcode.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_serializetypehandle.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_splittype.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_type_resource.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_typehandle.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_typekind.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formatcode.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formattype.cpp diff --git a/ydb/library/yql/providers/common/comp_nodes/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/common/comp_nodes/CMakeLists.linux-x86_64.txt index e9e8316ac3b0..4a47cc76f02e 100644 --- a/ydb/library/yql/providers/common/comp_nodes/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/common/comp_nodes/CMakeLists.linux-x86_64.txt @@ -17,20 +17,27 @@ target_link_libraries(providers-common-comp_nodes PUBLIC yutil library-yql-ast yql-ast-serialize - minikql-computation-llvm + yql-minikql-computation library-yql-core yql-core-type_ann providers-common-codec common-schema-expr - yql-minikql-codegen - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO ) target_sources(providers-common-comp_nodes PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_factory.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formatcode.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formattype.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formattypediff.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_makecode.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_maketype.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_parsetypehandle.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_position.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_reprcode.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_serializetypehandle.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_splittype.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_type_resource.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_typehandle.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_typekind.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formatcode.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formattype.cpp diff --git a/ydb/library/yql/providers/common/comp_nodes/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/common/comp_nodes/CMakeLists.windows-x86_64.txt index f559551f3b9f..9806f1c3d7bc 100644 --- a/ydb/library/yql/providers/common/comp_nodes/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/common/comp_nodes/CMakeLists.windows-x86_64.txt @@ -16,20 +16,27 @@ target_link_libraries(providers-common-comp_nodes PUBLIC yutil library-yql-ast yql-ast-serialize - minikql-computation-llvm + yql-minikql-computation library-yql-core yql-core-type_ann providers-common-codec common-schema-expr - yql-minikql-codegen - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO ) target_sources(providers-common-comp_nodes PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_factory.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formatcode.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formattype.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formattypediff.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_makecode.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_maketype.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_parsetypehandle.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_position.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_reprcode.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_serializetypehandle.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_splittype.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_type_resource.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_typehandle.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_typekind.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formatcode.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/comp_nodes/yql_formattype.cpp diff --git a/ydb/library/yql/providers/common/config/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/common/config/CMakeLists.darwin-arm64.txt index 769b029dfdc3..effddd2532b8 100644 --- a/ydb/library/yql/providers/common/config/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/common/config/CMakeLists.darwin-arm64.txt @@ -22,6 +22,7 @@ target_link_libraries(providers-common-config PUBLIC cpp-string_utils-levenshtein_diff ) target_sources(providers-common-config PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/config/yql_setting.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/config/yql_configuration_transformer.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/config/yql_dispatch.cpp ) diff --git a/ydb/library/yql/providers/common/config/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/common/config/CMakeLists.darwin-x86_64.txt index 769b029dfdc3..effddd2532b8 100644 --- a/ydb/library/yql/providers/common/config/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/common/config/CMakeLists.darwin-x86_64.txt @@ -22,6 +22,7 @@ target_link_libraries(providers-common-config PUBLIC cpp-string_utils-levenshtein_diff ) target_sources(providers-common-config PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/config/yql_setting.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/config/yql_configuration_transformer.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/config/yql_dispatch.cpp ) diff --git a/ydb/library/yql/providers/common/config/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/common/config/CMakeLists.linux-aarch64.txt index bd721c96e9cf..62071afb287a 100644 --- a/ydb/library/yql/providers/common/config/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/common/config/CMakeLists.linux-aarch64.txt @@ -23,6 +23,7 @@ target_link_libraries(providers-common-config PUBLIC cpp-string_utils-levenshtein_diff ) target_sources(providers-common-config PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/config/yql_setting.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/config/yql_configuration_transformer.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/config/yql_dispatch.cpp ) diff --git a/ydb/library/yql/providers/common/config/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/common/config/CMakeLists.linux-x86_64.txt index bd721c96e9cf..62071afb287a 100644 --- a/ydb/library/yql/providers/common/config/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/common/config/CMakeLists.linux-x86_64.txt @@ -23,6 +23,7 @@ target_link_libraries(providers-common-config PUBLIC cpp-string_utils-levenshtein_diff ) target_sources(providers-common-config PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/config/yql_setting.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/config/yql_configuration_transformer.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/config/yql_dispatch.cpp ) diff --git a/ydb/library/yql/providers/common/config/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/common/config/CMakeLists.windows-x86_64.txt index 769b029dfdc3..effddd2532b8 100644 --- a/ydb/library/yql/providers/common/config/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/common/config/CMakeLists.windows-x86_64.txt @@ -22,6 +22,7 @@ target_link_libraries(providers-common-config PUBLIC cpp-string_utils-levenshtein_diff ) target_sources(providers-common-config PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/config/yql_setting.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/config/yql_configuration_transformer.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/config/yql_dispatch.cpp ) diff --git a/ydb/library/yql/providers/common/db_id_async_resolver/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/common/db_id_async_resolver/CMakeLists.darwin-arm64.txt index 2a1c24b27b01..474f0c904386 100644 --- a/ydb/library/yql/providers/common/db_id_async_resolver/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/common/db_id_async_resolver/CMakeLists.darwin-arm64.txt @@ -25,6 +25,10 @@ target_link_libraries(providers-common-db_id_async_resolver PUBLIC yql-public-issue tools-enum_parser-enum_serialization_runtime ) +target_sources(providers-common-db_id_async_resolver PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/db_id_async_resolver/db_async_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/db_id_async_resolver/mdb_endpoint_generator.h +) generate_enum_serilization(providers-common-db_id_async_resolver ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/db_id_async_resolver/db_async_resolver.h INCLUDE_HEADERS diff --git a/ydb/library/yql/providers/common/db_id_async_resolver/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/common/db_id_async_resolver/CMakeLists.darwin-x86_64.txt index 2a1c24b27b01..474f0c904386 100644 --- a/ydb/library/yql/providers/common/db_id_async_resolver/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/common/db_id_async_resolver/CMakeLists.darwin-x86_64.txt @@ -25,6 +25,10 @@ target_link_libraries(providers-common-db_id_async_resolver PUBLIC yql-public-issue tools-enum_parser-enum_serialization_runtime ) +target_sources(providers-common-db_id_async_resolver PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/db_id_async_resolver/db_async_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/db_id_async_resolver/mdb_endpoint_generator.h +) generate_enum_serilization(providers-common-db_id_async_resolver ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/db_id_async_resolver/db_async_resolver.h INCLUDE_HEADERS diff --git a/ydb/library/yql/providers/common/db_id_async_resolver/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/common/db_id_async_resolver/CMakeLists.linux-aarch64.txt index c1487ce767a9..8df14061ddd9 100644 --- a/ydb/library/yql/providers/common/db_id_async_resolver/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/common/db_id_async_resolver/CMakeLists.linux-aarch64.txt @@ -26,6 +26,10 @@ target_link_libraries(providers-common-db_id_async_resolver PUBLIC yql-public-issue tools-enum_parser-enum_serialization_runtime ) +target_sources(providers-common-db_id_async_resolver PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/db_id_async_resolver/db_async_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/db_id_async_resolver/mdb_endpoint_generator.h +) generate_enum_serilization(providers-common-db_id_async_resolver ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/db_id_async_resolver/db_async_resolver.h INCLUDE_HEADERS diff --git a/ydb/library/yql/providers/common/db_id_async_resolver/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/common/db_id_async_resolver/CMakeLists.linux-x86_64.txt index c1487ce767a9..8df14061ddd9 100644 --- a/ydb/library/yql/providers/common/db_id_async_resolver/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/common/db_id_async_resolver/CMakeLists.linux-x86_64.txt @@ -26,6 +26,10 @@ target_link_libraries(providers-common-db_id_async_resolver PUBLIC yql-public-issue tools-enum_parser-enum_serialization_runtime ) +target_sources(providers-common-db_id_async_resolver PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/db_id_async_resolver/db_async_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/db_id_async_resolver/mdb_endpoint_generator.h +) generate_enum_serilization(providers-common-db_id_async_resolver ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/db_id_async_resolver/db_async_resolver.h INCLUDE_HEADERS diff --git a/ydb/library/yql/providers/common/db_id_async_resolver/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/common/db_id_async_resolver/CMakeLists.windows-x86_64.txt index 2a1c24b27b01..474f0c904386 100644 --- a/ydb/library/yql/providers/common/db_id_async_resolver/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/common/db_id_async_resolver/CMakeLists.windows-x86_64.txt @@ -25,6 +25,10 @@ target_link_libraries(providers-common-db_id_async_resolver PUBLIC yql-public-issue tools-enum_parser-enum_serialization_runtime ) +target_sources(providers-common-db_id_async_resolver PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/db_id_async_resolver/db_async_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/db_id_async_resolver/mdb_endpoint_generator.h +) generate_enum_serilization(providers-common-db_id_async_resolver ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/db_id_async_resolver/db_async_resolver.h INCLUDE_HEADERS diff --git a/ydb/library/yql/providers/common/gateway/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/common/gateway/CMakeLists.darwin-arm64.txt index d3d0e1bddff3..8687b632636d 100644 --- a/ydb/library/yql/providers/common/gateway/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/common/gateway/CMakeLists.darwin-arm64.txt @@ -15,5 +15,6 @@ target_link_libraries(providers-common-gateway PUBLIC library-yql-ast ) target_sources(providers-common-gateway PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/gateway/yql_provider_gateway.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/gateway/yql_provider_gateway.cpp ) diff --git a/ydb/library/yql/providers/common/gateway/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/common/gateway/CMakeLists.darwin-x86_64.txt index d3d0e1bddff3..8687b632636d 100644 --- a/ydb/library/yql/providers/common/gateway/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/common/gateway/CMakeLists.darwin-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(providers-common-gateway PUBLIC library-yql-ast ) target_sources(providers-common-gateway PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/gateway/yql_provider_gateway.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/gateway/yql_provider_gateway.cpp ) diff --git a/ydb/library/yql/providers/common/gateway/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/common/gateway/CMakeLists.linux-aarch64.txt index e9f7a10f2540..813166fe202b 100644 --- a/ydb/library/yql/providers/common/gateway/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/common/gateway/CMakeLists.linux-aarch64.txt @@ -16,5 +16,6 @@ target_link_libraries(providers-common-gateway PUBLIC library-yql-ast ) target_sources(providers-common-gateway PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/gateway/yql_provider_gateway.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/gateway/yql_provider_gateway.cpp ) diff --git a/ydb/library/yql/providers/common/gateway/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/common/gateway/CMakeLists.linux-x86_64.txt index e9f7a10f2540..813166fe202b 100644 --- a/ydb/library/yql/providers/common/gateway/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/common/gateway/CMakeLists.linux-x86_64.txt @@ -16,5 +16,6 @@ target_link_libraries(providers-common-gateway PUBLIC library-yql-ast ) target_sources(providers-common-gateway PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/gateway/yql_provider_gateway.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/gateway/yql_provider_gateway.cpp ) diff --git a/ydb/library/yql/providers/common/gateway/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/common/gateway/CMakeLists.windows-x86_64.txt index d3d0e1bddff3..8687b632636d 100644 --- a/ydb/library/yql/providers/common/gateway/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/common/gateway/CMakeLists.windows-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(providers-common-gateway PUBLIC library-yql-ast ) target_sources(providers-common-gateway PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/gateway/yql_provider_gateway.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/gateway/yql_provider_gateway.cpp ) diff --git a/ydb/library/yql/providers/common/http_gateway/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/common/http_gateway/ut/CMakeLists.darwin-arm64.txt index 55e75becfd17..8ae005542943 100644 --- a/ydb/library/yql/providers/common/http_gateway/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/common/http_gateway/ut/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-library-yql-providers-common-http_gateway-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-common-http_gateway-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/http_gateway/yql_dns_gateway_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/common/http_gateway/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/common/http_gateway/ut/CMakeLists.darwin-x86_64.txt index fb317d341c08..eef7ecca631e 100644 --- a/ydb/library/yql/providers/common/http_gateway/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/common/http_gateway/ut/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-library-yql-providers-common-http_gateway-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-common-http_gateway-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/http_gateway/yql_dns_gateway_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/common/http_gateway/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/common/http_gateway/ut/CMakeLists.linux-aarch64.txt index 83a4e5624c34..218745cd7b93 100644 --- a/ydb/library/yql/providers/common/http_gateway/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/common/http_gateway/ut/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-library-yql-providers-common-http_gateway-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-common-http_gateway-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/http_gateway/yql_dns_gateway_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/common/http_gateway/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/common/http_gateway/ut/CMakeLists.linux-x86_64.txt index 5e73f3c7c410..a36059abcc9f 100644 --- a/ydb/library/yql/providers/common/http_gateway/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/common/http_gateway/ut/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-library-yql-providers-common-http_gateway-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-common-http_gateway-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/http_gateway/yql_dns_gateway_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/common/http_gateway/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/common/http_gateway/ut/CMakeLists.windows-x86_64.txt index 49d6e16b092d..e276747ea03f 100644 --- a/ydb/library/yql/providers/common/http_gateway/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/common/http_gateway/ut/CMakeLists.windows-x86_64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/common/metrics/protos/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/common/metrics/protos/CMakeLists.darwin-arm64.txt index e4138a2b75e2..e1b76a64f804 100644 --- a/ydb/library/yql/providers/common/metrics/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/common/metrics/protos/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(common-metrics-protos PUBLIC target_proto_messages(common-metrics-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/metrics/protos/metrics_registry.proto ) +target_sources(common-metrics-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/metrics/protos/metrics_registry.pb.h +) target_proto_addincls(common-metrics-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/common/metrics/protos/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/common/metrics/protos/CMakeLists.darwin-x86_64.txt index e4138a2b75e2..e1b76a64f804 100644 --- a/ydb/library/yql/providers/common/metrics/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/common/metrics/protos/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(common-metrics-protos PUBLIC target_proto_messages(common-metrics-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/metrics/protos/metrics_registry.proto ) +target_sources(common-metrics-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/metrics/protos/metrics_registry.pb.h +) target_proto_addincls(common-metrics-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/common/metrics/protos/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/common/metrics/protos/CMakeLists.linux-aarch64.txt index 7cf0fa8c6a5d..0195823c91e9 100644 --- a/ydb/library/yql/providers/common/metrics/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/common/metrics/protos/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(common-metrics-protos PUBLIC target_proto_messages(common-metrics-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/metrics/protos/metrics_registry.proto ) +target_sources(common-metrics-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/metrics/protos/metrics_registry.pb.h +) target_proto_addincls(common-metrics-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/common/metrics/protos/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/common/metrics/protos/CMakeLists.linux-x86_64.txt index 7cf0fa8c6a5d..0195823c91e9 100644 --- a/ydb/library/yql/providers/common/metrics/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/common/metrics/protos/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(common-metrics-protos PUBLIC target_proto_messages(common-metrics-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/metrics/protos/metrics_registry.proto ) +target_sources(common-metrics-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/metrics/protos/metrics_registry.pb.h +) target_proto_addincls(common-metrics-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/common/metrics/protos/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/common/metrics/protos/CMakeLists.windows-x86_64.txt index e4138a2b75e2..e1b76a64f804 100644 --- a/ydb/library/yql/providers/common/metrics/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/common/metrics/protos/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(common-metrics-protos PUBLIC target_proto_messages(common-metrics-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/metrics/protos/metrics_registry.proto ) +target_sources(common-metrics-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/metrics/protos/metrics_registry.pb.h +) target_proto_addincls(common-metrics-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/common/mkql/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/common/mkql/CMakeLists.darwin-arm64.txt index ee01009ed164..1ad1ce16faf3 100644 --- a/ydb/library/yql/providers/common/mkql/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/common/mkql/CMakeLists.darwin-arm64.txt @@ -27,6 +27,9 @@ target_link_libraries(providers-common-mkql PUBLIC yql-parser-pg_catalog ) target_sources(providers-common-mkql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/parser.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/yql_provider_mkql.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/yql_type_mkql.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/parser.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/yql_provider_mkql.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/yql_type_mkql.cpp diff --git a/ydb/library/yql/providers/common/mkql/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/common/mkql/CMakeLists.darwin-x86_64.txt index ee01009ed164..1ad1ce16faf3 100644 --- a/ydb/library/yql/providers/common/mkql/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/common/mkql/CMakeLists.darwin-x86_64.txt @@ -27,6 +27,9 @@ target_link_libraries(providers-common-mkql PUBLIC yql-parser-pg_catalog ) target_sources(providers-common-mkql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/parser.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/yql_provider_mkql.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/yql_type_mkql.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/parser.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/yql_provider_mkql.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/yql_type_mkql.cpp diff --git a/ydb/library/yql/providers/common/mkql/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/common/mkql/CMakeLists.linux-aarch64.txt index 94ae336cc2c5..a5f8baaa8c25 100644 --- a/ydb/library/yql/providers/common/mkql/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/common/mkql/CMakeLists.linux-aarch64.txt @@ -28,6 +28,9 @@ target_link_libraries(providers-common-mkql PUBLIC yql-parser-pg_catalog ) target_sources(providers-common-mkql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/parser.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/yql_provider_mkql.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/yql_type_mkql.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/parser.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/yql_provider_mkql.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/yql_type_mkql.cpp diff --git a/ydb/library/yql/providers/common/mkql/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/common/mkql/CMakeLists.linux-x86_64.txt index 94ae336cc2c5..a5f8baaa8c25 100644 --- a/ydb/library/yql/providers/common/mkql/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/common/mkql/CMakeLists.linux-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(providers-common-mkql PUBLIC yql-parser-pg_catalog ) target_sources(providers-common-mkql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/parser.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/yql_provider_mkql.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/yql_type_mkql.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/parser.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/yql_provider_mkql.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/yql_type_mkql.cpp diff --git a/ydb/library/yql/providers/common/mkql/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/common/mkql/CMakeLists.windows-x86_64.txt index ee01009ed164..1ad1ce16faf3 100644 --- a/ydb/library/yql/providers/common/mkql/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/common/mkql/CMakeLists.windows-x86_64.txt @@ -27,6 +27,9 @@ target_link_libraries(providers-common-mkql PUBLIC yql-parser-pg_catalog ) target_sources(providers-common-mkql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/parser.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/yql_provider_mkql.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/yql_type_mkql.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/parser.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/yql_provider_mkql.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/mkql/yql_type_mkql.cpp diff --git a/ydb/library/yql/providers/common/proto/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/common/proto/CMakeLists.darwin-arm64.txt index 962067cd496e..2895acb6466a 100644 --- a/ydb/library/yql/providers/common/proto/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/common/proto/CMakeLists.darwin-arm64.txt @@ -43,6 +43,10 @@ target_proto_messages(providers-common-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/proto/gateways_config.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/proto/udf_resolver.proto ) +target_sources(providers-common-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/proto/gateways_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/proto/udf_resolver.pb.h +) target_proto_addincls(providers-common-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/common/proto/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/common/proto/CMakeLists.darwin-x86_64.txt index 962067cd496e..2895acb6466a 100644 --- a/ydb/library/yql/providers/common/proto/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/common/proto/CMakeLists.darwin-x86_64.txt @@ -43,6 +43,10 @@ target_proto_messages(providers-common-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/proto/gateways_config.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/proto/udf_resolver.proto ) +target_sources(providers-common-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/proto/gateways_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/proto/udf_resolver.pb.h +) target_proto_addincls(providers-common-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/common/proto/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/common/proto/CMakeLists.linux-aarch64.txt index 9925b68fbfb3..fc268c974285 100644 --- a/ydb/library/yql/providers/common/proto/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/common/proto/CMakeLists.linux-aarch64.txt @@ -44,6 +44,10 @@ target_proto_messages(providers-common-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/proto/gateways_config.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/proto/udf_resolver.proto ) +target_sources(providers-common-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/proto/gateways_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/proto/udf_resolver.pb.h +) target_proto_addincls(providers-common-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/common/proto/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/common/proto/CMakeLists.linux-x86_64.txt index 9925b68fbfb3..fc268c974285 100644 --- a/ydb/library/yql/providers/common/proto/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/common/proto/CMakeLists.linux-x86_64.txt @@ -44,6 +44,10 @@ target_proto_messages(providers-common-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/proto/gateways_config.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/proto/udf_resolver.proto ) +target_sources(providers-common-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/proto/gateways_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/proto/udf_resolver.pb.h +) target_proto_addincls(providers-common-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/common/proto/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/common/proto/CMakeLists.windows-x86_64.txt index 962067cd496e..2895acb6466a 100644 --- a/ydb/library/yql/providers/common/proto/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/common/proto/CMakeLists.windows-x86_64.txt @@ -43,6 +43,10 @@ target_proto_messages(providers-common-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/proto/gateways_config.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/proto/udf_resolver.proto ) +target_sources(providers-common-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/proto/gateways_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/proto/udf_resolver.pb.h +) target_proto_addincls(providers-common-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/common/provider/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/common/provider/CMakeLists.darwin-arm64.txt index 8933bfd7116e..3d4baa25111c 100644 --- a/ydb/library/yql/providers/common/provider/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/common/provider/CMakeLists.darwin-arm64.txt @@ -20,6 +20,10 @@ target_link_libraries(providers-common-provider PUBLIC library-yql-core ) target_sources(providers-common-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_data_provider_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_provider_names.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_table_lookup.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_data_provider_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_provider.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_table_lookup.cpp diff --git a/ydb/library/yql/providers/common/provider/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/common/provider/CMakeLists.darwin-x86_64.txt index 8933bfd7116e..3d4baa25111c 100644 --- a/ydb/library/yql/providers/common/provider/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/common/provider/CMakeLists.darwin-x86_64.txt @@ -20,6 +20,10 @@ target_link_libraries(providers-common-provider PUBLIC library-yql-core ) target_sources(providers-common-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_data_provider_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_provider_names.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_table_lookup.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_data_provider_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_provider.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_table_lookup.cpp diff --git a/ydb/library/yql/providers/common/provider/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/common/provider/CMakeLists.linux-aarch64.txt index 1573d99d010d..d9ceba24a7cc 100644 --- a/ydb/library/yql/providers/common/provider/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/common/provider/CMakeLists.linux-aarch64.txt @@ -21,6 +21,10 @@ target_link_libraries(providers-common-provider PUBLIC library-yql-core ) target_sources(providers-common-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_data_provider_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_provider_names.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_table_lookup.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_data_provider_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_provider.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_table_lookup.cpp diff --git a/ydb/library/yql/providers/common/provider/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/common/provider/CMakeLists.linux-x86_64.txt index 1573d99d010d..d9ceba24a7cc 100644 --- a/ydb/library/yql/providers/common/provider/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/common/provider/CMakeLists.linux-x86_64.txt @@ -21,6 +21,10 @@ target_link_libraries(providers-common-provider PUBLIC library-yql-core ) target_sources(providers-common-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_data_provider_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_provider_names.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_table_lookup.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_data_provider_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_provider.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_table_lookup.cpp diff --git a/ydb/library/yql/providers/common/provider/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/common/provider/CMakeLists.windows-x86_64.txt index 8933bfd7116e..3d4baa25111c 100644 --- a/ydb/library/yql/providers/common/provider/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/common/provider/CMakeLists.windows-x86_64.txt @@ -20,6 +20,10 @@ target_link_libraries(providers-common-provider PUBLIC library-yql-core ) target_sources(providers-common-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_data_provider_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_provider_names.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_table_lookup.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_data_provider_impl.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_provider.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/provider/yql_table_lookup.cpp diff --git a/ydb/library/yql/providers/common/structured_token/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/common/structured_token/CMakeLists.darwin-arm64.txt index 75b84199aa6e..ac2d1d58b456 100644 --- a/ydb/library/yql/providers/common/structured_token/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/common/structured_token/CMakeLists.darwin-arm64.txt @@ -17,6 +17,8 @@ target_link_libraries(providers-common-structured_token PUBLIC library-yql-utils ) target_sources(providers-common-structured_token PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/yql_structured_token.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/yql_token_builder.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/yql_structured_token.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/yql_token_builder.cpp ) diff --git a/ydb/library/yql/providers/common/structured_token/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/common/structured_token/CMakeLists.darwin-x86_64.txt index 75b84199aa6e..ac2d1d58b456 100644 --- a/ydb/library/yql/providers/common/structured_token/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/common/structured_token/CMakeLists.darwin-x86_64.txt @@ -17,6 +17,8 @@ target_link_libraries(providers-common-structured_token PUBLIC library-yql-utils ) target_sources(providers-common-structured_token PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/yql_structured_token.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/yql_token_builder.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/yql_structured_token.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/yql_token_builder.cpp ) diff --git a/ydb/library/yql/providers/common/structured_token/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/common/structured_token/CMakeLists.linux-aarch64.txt index 6c23ea45754e..f240cbb67585 100644 --- a/ydb/library/yql/providers/common/structured_token/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/common/structured_token/CMakeLists.linux-aarch64.txt @@ -18,6 +18,8 @@ target_link_libraries(providers-common-structured_token PUBLIC library-yql-utils ) target_sources(providers-common-structured_token PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/yql_structured_token.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/yql_token_builder.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/yql_structured_token.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/yql_token_builder.cpp ) diff --git a/ydb/library/yql/providers/common/structured_token/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/common/structured_token/CMakeLists.linux-x86_64.txt index 6c23ea45754e..f240cbb67585 100644 --- a/ydb/library/yql/providers/common/structured_token/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/common/structured_token/CMakeLists.linux-x86_64.txt @@ -18,6 +18,8 @@ target_link_libraries(providers-common-structured_token PUBLIC library-yql-utils ) target_sources(providers-common-structured_token PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/yql_structured_token.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/yql_token_builder.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/yql_structured_token.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/yql_token_builder.cpp ) diff --git a/ydb/library/yql/providers/common/structured_token/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/common/structured_token/CMakeLists.windows-x86_64.txt index 75b84199aa6e..ac2d1d58b456 100644 --- a/ydb/library/yql/providers/common/structured_token/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/common/structured_token/CMakeLists.windows-x86_64.txt @@ -17,6 +17,8 @@ target_link_libraries(providers-common-structured_token PUBLIC library-yql-utils ) target_sources(providers-common-structured_token PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/yql_structured_token.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/yql_token_builder.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/yql_structured_token.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/yql_token_builder.cpp ) diff --git a/ydb/library/yql/providers/common/structured_token/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/common/structured_token/ut/CMakeLists.darwin-arm64.txt index fc141ed146ec..dfe8c491440a 100644 --- a/ydb/library/yql/providers/common/structured_token/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/common/structured_token/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(yql-providers-common-structured_token-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(yql-providers-common-structured_token-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/ut/yql_structured_token_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/common/structured_token/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/common/structured_token/ut/CMakeLists.darwin-x86_64.txt index 75fcf42ce22d..3003289d9ffa 100644 --- a/ydb/library/yql/providers/common/structured_token/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/common/structured_token/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(yql-providers-common-structured_token-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(yql-providers-common-structured_token-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/ut/yql_structured_token_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/common/structured_token/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/common/structured_token/ut/CMakeLists.linux-aarch64.txt index 55b58634b369..9cbbfd8550cd 100644 --- a/ydb/library/yql/providers/common/structured_token/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/common/structured_token/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(yql-providers-common-structured_token-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(yql-providers-common-structured_token-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/ut/yql_structured_token_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/common/structured_token/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/common/structured_token/ut/CMakeLists.linux-x86_64.txt index 7072a495309c..e532566745c6 100644 --- a/ydb/library/yql/providers/common/structured_token/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/common/structured_token/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(yql-providers-common-structured_token-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(yql-providers-common-structured_token-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/structured_token/ut/yql_structured_token_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/common/structured_token/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/common/structured_token/ut/CMakeLists.windows-x86_64.txt index 37018fc8d9a2..28ee10a8f477 100644 --- a/ydb/library/yql/providers/common/structured_token/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/common/structured_token/ut/CMakeLists.windows-x86_64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/common/token_accessor/grpc/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/common/token_accessor/grpc/CMakeLists.darwin-arm64.txt index b1ce956e1c6f..cc9d3f8571a4 100644 --- a/ydb/library/yql/providers/common/token_accessor/grpc/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/common/token_accessor/grpc/CMakeLists.darwin-arm64.txt @@ -38,6 +38,10 @@ target_link_libraries(common-token_accessor-grpc PUBLIC target_proto_messages(common-token_accessor-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/token_accessor/grpc/token_accessor_pb.proto ) +target_sources(common-token_accessor-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/token_accessor/grpc/token_accessor_pb.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/token_accessor/grpc/token_accessor_pb.grpc.pb.h +) target_proto_addincls(common-token_accessor-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/common/token_accessor/grpc/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/common/token_accessor/grpc/CMakeLists.darwin-x86_64.txt index b1ce956e1c6f..cc9d3f8571a4 100644 --- a/ydb/library/yql/providers/common/token_accessor/grpc/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/common/token_accessor/grpc/CMakeLists.darwin-x86_64.txt @@ -38,6 +38,10 @@ target_link_libraries(common-token_accessor-grpc PUBLIC target_proto_messages(common-token_accessor-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/token_accessor/grpc/token_accessor_pb.proto ) +target_sources(common-token_accessor-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/token_accessor/grpc/token_accessor_pb.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/token_accessor/grpc/token_accessor_pb.grpc.pb.h +) target_proto_addincls(common-token_accessor-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/common/token_accessor/grpc/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/common/token_accessor/grpc/CMakeLists.linux-aarch64.txt index 9b5a78a1df24..412eeaa9a2e3 100644 --- a/ydb/library/yql/providers/common/token_accessor/grpc/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/common/token_accessor/grpc/CMakeLists.linux-aarch64.txt @@ -39,6 +39,10 @@ target_link_libraries(common-token_accessor-grpc PUBLIC target_proto_messages(common-token_accessor-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/token_accessor/grpc/token_accessor_pb.proto ) +target_sources(common-token_accessor-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/token_accessor/grpc/token_accessor_pb.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/token_accessor/grpc/token_accessor_pb.grpc.pb.h +) target_proto_addincls(common-token_accessor-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/common/token_accessor/grpc/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/common/token_accessor/grpc/CMakeLists.linux-x86_64.txt index 9b5a78a1df24..412eeaa9a2e3 100644 --- a/ydb/library/yql/providers/common/token_accessor/grpc/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/common/token_accessor/grpc/CMakeLists.linux-x86_64.txt @@ -39,6 +39,10 @@ target_link_libraries(common-token_accessor-grpc PUBLIC target_proto_messages(common-token_accessor-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/token_accessor/grpc/token_accessor_pb.proto ) +target_sources(common-token_accessor-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/token_accessor/grpc/token_accessor_pb.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/token_accessor/grpc/token_accessor_pb.grpc.pb.h +) target_proto_addincls(common-token_accessor-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/common/token_accessor/grpc/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/common/token_accessor/grpc/CMakeLists.windows-x86_64.txt index b1ce956e1c6f..cc9d3f8571a4 100644 --- a/ydb/library/yql/providers/common/token_accessor/grpc/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/common/token_accessor/grpc/CMakeLists.windows-x86_64.txt @@ -38,6 +38,10 @@ target_link_libraries(common-token_accessor-grpc PUBLIC target_proto_messages(common-token_accessor-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/token_accessor/grpc/token_accessor_pb.proto ) +target_sources(common-token_accessor-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/token_accessor/grpc/token_accessor_pb.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/common/token_accessor/grpc/token_accessor_pb.grpc.pb.h +) target_proto_addincls(common-token_accessor-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/common/udf_resolve/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/common/udf_resolve/CMakeLists.darwin-arm64.txt index 77ba8d72e5fc..96668726f658 100644 --- a/ydb/library/yql/providers/common/udf_resolve/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/common/udf_resolve/CMakeLists.darwin-arm64.txt @@ -27,6 +27,10 @@ target_link_libraries(providers-common-udf_resolve PUBLIC common-schema-expr ) target_sources(providers-common-udf_resolve PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_files_box.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_outproc_udf_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_simple_udf_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_udf_resolver_with_index.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_files_box.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_outproc_udf_resolver.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_simple_udf_resolver.cpp diff --git a/ydb/library/yql/providers/common/udf_resolve/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/common/udf_resolve/CMakeLists.darwin-x86_64.txt index 77ba8d72e5fc..96668726f658 100644 --- a/ydb/library/yql/providers/common/udf_resolve/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/common/udf_resolve/CMakeLists.darwin-x86_64.txt @@ -27,6 +27,10 @@ target_link_libraries(providers-common-udf_resolve PUBLIC common-schema-expr ) target_sources(providers-common-udf_resolve PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_files_box.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_outproc_udf_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_simple_udf_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_udf_resolver_with_index.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_files_box.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_outproc_udf_resolver.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_simple_udf_resolver.cpp diff --git a/ydb/library/yql/providers/common/udf_resolve/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/common/udf_resolve/CMakeLists.linux-aarch64.txt index 557d2db701f1..35ea0c66be5c 100644 --- a/ydb/library/yql/providers/common/udf_resolve/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/common/udf_resolve/CMakeLists.linux-aarch64.txt @@ -28,6 +28,10 @@ target_link_libraries(providers-common-udf_resolve PUBLIC common-schema-expr ) target_sources(providers-common-udf_resolve PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_files_box.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_outproc_udf_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_simple_udf_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_udf_resolver_with_index.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_files_box.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_outproc_udf_resolver.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_simple_udf_resolver.cpp diff --git a/ydb/library/yql/providers/common/udf_resolve/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/common/udf_resolve/CMakeLists.linux-x86_64.txt index 557d2db701f1..35ea0c66be5c 100644 --- a/ydb/library/yql/providers/common/udf_resolve/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/common/udf_resolve/CMakeLists.linux-x86_64.txt @@ -28,6 +28,10 @@ target_link_libraries(providers-common-udf_resolve PUBLIC common-schema-expr ) target_sources(providers-common-udf_resolve PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_files_box.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_outproc_udf_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_simple_udf_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_udf_resolver_with_index.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_files_box.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_outproc_udf_resolver.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_simple_udf_resolver.cpp diff --git a/ydb/library/yql/providers/common/udf_resolve/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/common/udf_resolve/CMakeLists.windows-x86_64.txt index 77ba8d72e5fc..96668726f658 100644 --- a/ydb/library/yql/providers/common/udf_resolve/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/common/udf_resolve/CMakeLists.windows-x86_64.txt @@ -27,6 +27,10 @@ target_link_libraries(providers-common-udf_resolve PUBLIC common-schema-expr ) target_sources(providers-common-udf_resolve PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_files_box.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_outproc_udf_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_simple_udf_resolver.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_udf_resolver_with_index.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_files_box.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_outproc_udf_resolver.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/common/udf_resolve/yql_simple_udf_resolver.cpp diff --git a/ydb/library/yql/providers/common/ut_helpers/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/common/ut_helpers/CMakeLists.darwin-arm64.txt index 47d6d6a20795..485a14066704 100644 --- a/ydb/library/yql/providers/common/ut_helpers/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/common/ut_helpers/CMakeLists.darwin-arm64.txt @@ -16,7 +16,7 @@ target_link_libraries(providers-common-ut_helpers PUBLIC yutil library-cpp-retry core-testlib-basics - minikql-computation-llvm + yql-minikql-computation udf-service-exception_policy library-yql-sql providers-common-comp_nodes diff --git a/ydb/library/yql/providers/common/ut_helpers/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/common/ut_helpers/CMakeLists.darwin-x86_64.txt index 47d6d6a20795..485a14066704 100644 --- a/ydb/library/yql/providers/common/ut_helpers/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/common/ut_helpers/CMakeLists.darwin-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(providers-common-ut_helpers PUBLIC yutil library-cpp-retry core-testlib-basics - minikql-computation-llvm + yql-minikql-computation udf-service-exception_policy library-yql-sql providers-common-comp_nodes diff --git a/ydb/library/yql/providers/common/ut_helpers/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/common/ut_helpers/CMakeLists.linux-aarch64.txt index b532046c4a34..7c83c84b9d32 100644 --- a/ydb/library/yql/providers/common/ut_helpers/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/common/ut_helpers/CMakeLists.linux-aarch64.txt @@ -17,7 +17,7 @@ target_link_libraries(providers-common-ut_helpers PUBLIC yutil library-cpp-retry core-testlib-basics - minikql-computation-llvm + yql-minikql-computation udf-service-exception_policy library-yql-sql providers-common-comp_nodes diff --git a/ydb/library/yql/providers/common/ut_helpers/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/common/ut_helpers/CMakeLists.linux-x86_64.txt index b532046c4a34..7c83c84b9d32 100644 --- a/ydb/library/yql/providers/common/ut_helpers/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/common/ut_helpers/CMakeLists.linux-x86_64.txt @@ -17,7 +17,7 @@ target_link_libraries(providers-common-ut_helpers PUBLIC yutil library-cpp-retry core-testlib-basics - minikql-computation-llvm + yql-minikql-computation udf-service-exception_policy library-yql-sql providers-common-comp_nodes diff --git a/ydb/library/yql/providers/common/ut_helpers/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/common/ut_helpers/CMakeLists.windows-x86_64.txt index 47d6d6a20795..485a14066704 100644 --- a/ydb/library/yql/providers/common/ut_helpers/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/common/ut_helpers/CMakeLists.windows-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(providers-common-ut_helpers PUBLIC yutil library-cpp-retry core-testlib-basics - minikql-computation-llvm + yql-minikql-computation udf-service-exception_policy library-yql-sql providers-common-comp_nodes diff --git a/ydb/library/yql/providers/config/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/config/CMakeLists.darwin-arm64.txt index d2daa2064b6c..429e64ad1550 100644 --- a/ydb/library/yql/providers/config/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/config/CMakeLists.darwin-arm64.txt @@ -26,5 +26,6 @@ target_link_libraries(yql-providers-config PUBLIC providers-common-activation ) target_sources(yql-providers-config PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/config/yql_config_provider.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/config/yql_config_provider.cpp ) diff --git a/ydb/library/yql/providers/config/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/config/CMakeLists.darwin-x86_64.txt index d2daa2064b6c..429e64ad1550 100644 --- a/ydb/library/yql/providers/config/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/config/CMakeLists.darwin-x86_64.txt @@ -26,5 +26,6 @@ target_link_libraries(yql-providers-config PUBLIC providers-common-activation ) target_sources(yql-providers-config PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/config/yql_config_provider.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/config/yql_config_provider.cpp ) diff --git a/ydb/library/yql/providers/config/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/config/CMakeLists.linux-aarch64.txt index acfd736aac10..c8982af1de83 100644 --- a/ydb/library/yql/providers/config/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/config/CMakeLists.linux-aarch64.txt @@ -27,5 +27,6 @@ target_link_libraries(yql-providers-config PUBLIC providers-common-activation ) target_sources(yql-providers-config PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/config/yql_config_provider.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/config/yql_config_provider.cpp ) diff --git a/ydb/library/yql/providers/config/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/config/CMakeLists.linux-x86_64.txt index acfd736aac10..c8982af1de83 100644 --- a/ydb/library/yql/providers/config/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/config/CMakeLists.linux-x86_64.txt @@ -27,5 +27,6 @@ target_link_libraries(yql-providers-config PUBLIC providers-common-activation ) target_sources(yql-providers-config PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/config/yql_config_provider.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/config/yql_config_provider.cpp ) diff --git a/ydb/library/yql/providers/config/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/config/CMakeLists.windows-x86_64.txt index d2daa2064b6c..429e64ad1550 100644 --- a/ydb/library/yql/providers/config/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/config/CMakeLists.windows-x86_64.txt @@ -26,5 +26,6 @@ target_link_libraries(yql-providers-config PUBLIC providers-common-activation ) target_sources(yql-providers-config PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/config/yql_config_provider.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/config/yql_config_provider.cpp ) diff --git a/ydb/library/yql/providers/dq/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/dq/CMakeLists.darwin-arm64.txt deleted file mode 100644 index a72600c8cf3d..000000000000 --- a/ydb/library/yql/providers/dq/CMakeLists.darwin-arm64.txt +++ /dev/null @@ -1,29 +0,0 @@ - -# This file was generated by the build system used internally in the Yandex monorepo. -# Only simple modifications are allowed (adding source-files to targets, adding simple properties -# like target_include_directories). These modifications will be ported to original -# ya.make files by maintainers. Any complex modifications which can't be ported back to the -# original buildsystem will not be accepted. - - -add_subdirectory(actors) -add_subdirectory(api) -add_subdirectory(common) -add_subdirectory(config) -add_subdirectory(counters) -add_subdirectory(expr_nodes) -add_subdirectory(global_worker_manager) -add_subdirectory(interface) -add_subdirectory(local_gateway) -add_subdirectory(metrics) -add_subdirectory(mkql) -add_subdirectory(opt) -add_subdirectory(planner) -add_subdirectory(provider) -add_subdirectory(runtime) -add_subdirectory(scheduler) -add_subdirectory(service) -add_subdirectory(stats_collector) -add_subdirectory(task_runner) -add_subdirectory(task_runner_actor) -add_subdirectory(worker_manager) diff --git a/ydb/library/yql/providers/dq/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/dq/CMakeLists.darwin-x86_64.txt deleted file mode 100644 index a72600c8cf3d..000000000000 --- a/ydb/library/yql/providers/dq/CMakeLists.darwin-x86_64.txt +++ /dev/null @@ -1,29 +0,0 @@ - -# This file was generated by the build system used internally in the Yandex monorepo. -# Only simple modifications are allowed (adding source-files to targets, adding simple properties -# like target_include_directories). These modifications will be ported to original -# ya.make files by maintainers. Any complex modifications which can't be ported back to the -# original buildsystem will not be accepted. - - -add_subdirectory(actors) -add_subdirectory(api) -add_subdirectory(common) -add_subdirectory(config) -add_subdirectory(counters) -add_subdirectory(expr_nodes) -add_subdirectory(global_worker_manager) -add_subdirectory(interface) -add_subdirectory(local_gateway) -add_subdirectory(metrics) -add_subdirectory(mkql) -add_subdirectory(opt) -add_subdirectory(planner) -add_subdirectory(provider) -add_subdirectory(runtime) -add_subdirectory(scheduler) -add_subdirectory(service) -add_subdirectory(stats_collector) -add_subdirectory(task_runner) -add_subdirectory(task_runner_actor) -add_subdirectory(worker_manager) diff --git a/ydb/library/yql/providers/dq/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/dq/CMakeLists.linux-aarch64.txt deleted file mode 100644 index a72600c8cf3d..000000000000 --- a/ydb/library/yql/providers/dq/CMakeLists.linux-aarch64.txt +++ /dev/null @@ -1,29 +0,0 @@ - -# This file was generated by the build system used internally in the Yandex monorepo. -# Only simple modifications are allowed (adding source-files to targets, adding simple properties -# like target_include_directories). These modifications will be ported to original -# ya.make files by maintainers. Any complex modifications which can't be ported back to the -# original buildsystem will not be accepted. - - -add_subdirectory(actors) -add_subdirectory(api) -add_subdirectory(common) -add_subdirectory(config) -add_subdirectory(counters) -add_subdirectory(expr_nodes) -add_subdirectory(global_worker_manager) -add_subdirectory(interface) -add_subdirectory(local_gateway) -add_subdirectory(metrics) -add_subdirectory(mkql) -add_subdirectory(opt) -add_subdirectory(planner) -add_subdirectory(provider) -add_subdirectory(runtime) -add_subdirectory(scheduler) -add_subdirectory(service) -add_subdirectory(stats_collector) -add_subdirectory(task_runner) -add_subdirectory(task_runner_actor) -add_subdirectory(worker_manager) diff --git a/ydb/library/yql/providers/dq/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/dq/CMakeLists.linux-x86_64.txt deleted file mode 100644 index a72600c8cf3d..000000000000 --- a/ydb/library/yql/providers/dq/CMakeLists.linux-x86_64.txt +++ /dev/null @@ -1,29 +0,0 @@ - -# This file was generated by the build system used internally in the Yandex monorepo. -# Only simple modifications are allowed (adding source-files to targets, adding simple properties -# like target_include_directories). These modifications will be ported to original -# ya.make files by maintainers. Any complex modifications which can't be ported back to the -# original buildsystem will not be accepted. - - -add_subdirectory(actors) -add_subdirectory(api) -add_subdirectory(common) -add_subdirectory(config) -add_subdirectory(counters) -add_subdirectory(expr_nodes) -add_subdirectory(global_worker_manager) -add_subdirectory(interface) -add_subdirectory(local_gateway) -add_subdirectory(metrics) -add_subdirectory(mkql) -add_subdirectory(opt) -add_subdirectory(planner) -add_subdirectory(provider) -add_subdirectory(runtime) -add_subdirectory(scheduler) -add_subdirectory(service) -add_subdirectory(stats_collector) -add_subdirectory(task_runner) -add_subdirectory(task_runner_actor) -add_subdirectory(worker_manager) diff --git a/ydb/library/yql/providers/dq/CMakeLists.txt b/ydb/library/yql/providers/dq/CMakeLists.txt index d863ebd18067..a72600c8cf3d 100644 --- a/ydb/library/yql/providers/dq/CMakeLists.txt +++ b/ydb/library/yql/providers/dq/CMakeLists.txt @@ -6,14 +6,24 @@ # original buildsystem will not be accepted. -if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) - include(CMakeLists.linux-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) - include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) -endif() +add_subdirectory(actors) +add_subdirectory(api) +add_subdirectory(common) +add_subdirectory(config) +add_subdirectory(counters) +add_subdirectory(expr_nodes) +add_subdirectory(global_worker_manager) +add_subdirectory(interface) +add_subdirectory(local_gateway) +add_subdirectory(metrics) +add_subdirectory(mkql) +add_subdirectory(opt) +add_subdirectory(planner) +add_subdirectory(provider) +add_subdirectory(runtime) +add_subdirectory(scheduler) +add_subdirectory(service) +add_subdirectory(stats_collector) +add_subdirectory(task_runner) +add_subdirectory(task_runner_actor) +add_subdirectory(worker_manager) diff --git a/ydb/library/yql/providers/dq/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/dq/CMakeLists.windows-x86_64.txt deleted file mode 100644 index f57ff8ff790c..000000000000 --- a/ydb/library/yql/providers/dq/CMakeLists.windows-x86_64.txt +++ /dev/null @@ -1,27 +0,0 @@ - -# This file was generated by the build system used internally in the Yandex monorepo. -# Only simple modifications are allowed (adding source-files to targets, adding simple properties -# like target_include_directories). These modifications will be ported to original -# ya.make files by maintainers. Any complex modifications which can't be ported back to the -# original buildsystem will not be accepted. - - -add_subdirectory(actors) -add_subdirectory(api) -add_subdirectory(common) -add_subdirectory(config) -add_subdirectory(counters) -add_subdirectory(expr_nodes) -add_subdirectory(global_worker_manager) -add_subdirectory(interface) -add_subdirectory(metrics) -add_subdirectory(mkql) -add_subdirectory(opt) -add_subdirectory(planner) -add_subdirectory(provider) -add_subdirectory(runtime) -add_subdirectory(scheduler) -add_subdirectory(service) -add_subdirectory(task_runner) -add_subdirectory(task_runner_actor) -add_subdirectory(worker_manager) diff --git a/ydb/library/yql/providers/dq/actors/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/dq/actors/ut/CMakeLists.darwin-arm64.txt index 88122dd702be..07829a1cc5a8 100644 --- a/ydb/library/yql/providers/dq/actors/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/dq/actors/ut/CMakeLists.darwin-arm64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-library-yql-providers-dq-actors-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-dq-actors-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/grouped_issues_ut.cpp @@ -63,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/dq/actors/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/dq/actors/ut/CMakeLists.darwin-x86_64.txt index da0b2d6dab13..30fa891bd45d 100644 --- a/ydb/library/yql/providers/dq/actors/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/dq/actors/ut/CMakeLists.darwin-x86_64.txt @@ -32,8 +32,6 @@ target_link_options(ydb-library-yql-providers-dq-actors-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-dq-actors-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/grouped_issues_ut.cpp @@ -64,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/dq/actors/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/dq/actors/ut/CMakeLists.linux-aarch64.txt index a6ab2878fff5..cf7953aa6310 100644 --- a/ydb/library/yql/providers/dq/actors/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/dq/actors/ut/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-library-yql-providers-dq-actors-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-dq-actors-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/grouped_issues_ut.cpp @@ -67,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/dq/actors/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/dq/actors/ut/CMakeLists.linux-x86_64.txt index 12a0d9c27fce..a7d38e03c133 100644 --- a/ydb/library/yql/providers/dq/actors/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/dq/actors/ut/CMakeLists.linux-x86_64.txt @@ -35,9 +35,6 @@ target_link_options(ydb-library-yql-providers-dq-actors-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-dq-actors-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/grouped_issues_ut.cpp @@ -68,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/dq/actors/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/dq/actors/ut/CMakeLists.windows-x86_64.txt index 82c094b149e2..d53335368e5d 100644 --- a/ydb/library/yql/providers/dq/actors/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/dq/actors/ut/CMakeLists.windows-x86_64.txt @@ -57,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/dq/actors/yt/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/dq/actors/yt/CMakeLists.darwin-arm64.txt index 4f092792ac02..7bc9b19ac96d 100644 --- a/ydb/library/yql/providers/dq/actors/yt/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/dq/actors/yt/CMakeLists.darwin-arm64.txt @@ -28,6 +28,12 @@ target_link_libraries(dq-actors-yt PUBLIC yt-yt-client ) target_sources(dq-actors-yt PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/nodeid_assigner.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/resource_manager.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/nodeid_cleaner.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/worker_registrator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/lock.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/yt_wrapper.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/nodeid_assigner.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/resource_manager.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/nodeid_cleaner.cpp diff --git a/ydb/library/yql/providers/dq/actors/yt/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/dq/actors/yt/CMakeLists.darwin-x86_64.txt index 4f092792ac02..7bc9b19ac96d 100644 --- a/ydb/library/yql/providers/dq/actors/yt/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/dq/actors/yt/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,12 @@ target_link_libraries(dq-actors-yt PUBLIC yt-yt-client ) target_sources(dq-actors-yt PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/nodeid_assigner.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/resource_manager.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/nodeid_cleaner.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/worker_registrator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/lock.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/yt_wrapper.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/nodeid_assigner.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/resource_manager.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/nodeid_cleaner.cpp diff --git a/ydb/library/yql/providers/dq/actors/yt/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/dq/actors/yt/CMakeLists.linux-aarch64.txt index fc15f03aaa22..42e56dac4a9c 100644 --- a/ydb/library/yql/providers/dq/actors/yt/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/dq/actors/yt/CMakeLists.linux-aarch64.txt @@ -29,6 +29,12 @@ target_link_libraries(dq-actors-yt PUBLIC yt-yt-client ) target_sources(dq-actors-yt PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/nodeid_assigner.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/resource_manager.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/nodeid_cleaner.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/worker_registrator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/lock.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/yt_wrapper.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/nodeid_assigner.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/resource_manager.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/nodeid_cleaner.cpp diff --git a/ydb/library/yql/providers/dq/actors/yt/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/dq/actors/yt/CMakeLists.linux-x86_64.txt index fc15f03aaa22..42e56dac4a9c 100644 --- a/ydb/library/yql/providers/dq/actors/yt/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/dq/actors/yt/CMakeLists.linux-x86_64.txt @@ -29,6 +29,12 @@ target_link_libraries(dq-actors-yt PUBLIC yt-yt-client ) target_sources(dq-actors-yt PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/nodeid_assigner.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/resource_manager.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/nodeid_cleaner.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/worker_registrator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/lock.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/yt_wrapper.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/nodeid_assigner.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/resource_manager.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/nodeid_cleaner.cpp diff --git a/ydb/library/yql/providers/dq/actors/yt/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/dq/actors/yt/CMakeLists.windows-x86_64.txt index 1f3c7886ccc2..658ce38690f9 100644 --- a/ydb/library/yql/providers/dq/actors/yt/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/dq/actors/yt/CMakeLists.windows-x86_64.txt @@ -27,6 +27,8 @@ target_link_libraries(dq-actors-yt PUBLIC dq-actors-events ) target_sources(dq-actors-yt PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/nodeid_assigner.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/resource_manager.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/nodeid_assigner.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/actors/yt/resource_manager.cpp ) diff --git a/ydb/library/yql/providers/dq/api/grpc/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/dq/api/grpc/CMakeLists.darwin-arm64.txt index bead812e5aa8..6016de0c90ef 100644 --- a/ydb/library/yql/providers/dq/api/grpc/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/dq/api/grpc/CMakeLists.darwin-arm64.txt @@ -39,6 +39,10 @@ target_link_libraries(dq-api-grpc PUBLIC target_proto_messages(dq-api-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/api/grpc/api.proto ) +target_sources(dq-api-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/grpc/api.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/grpc/api.grpc.pb.h +) target_proto_addincls(dq-api-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/dq/api/grpc/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/dq/api/grpc/CMakeLists.darwin-x86_64.txt index bead812e5aa8..6016de0c90ef 100644 --- a/ydb/library/yql/providers/dq/api/grpc/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/dq/api/grpc/CMakeLists.darwin-x86_64.txt @@ -39,6 +39,10 @@ target_link_libraries(dq-api-grpc PUBLIC target_proto_messages(dq-api-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/api/grpc/api.proto ) +target_sources(dq-api-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/grpc/api.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/grpc/api.grpc.pb.h +) target_proto_addincls(dq-api-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/dq/api/grpc/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/dq/api/grpc/CMakeLists.linux-aarch64.txt index 85e3fb1fc1b6..942e9bb2a58a 100644 --- a/ydb/library/yql/providers/dq/api/grpc/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/dq/api/grpc/CMakeLists.linux-aarch64.txt @@ -40,6 +40,10 @@ target_link_libraries(dq-api-grpc PUBLIC target_proto_messages(dq-api-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/api/grpc/api.proto ) +target_sources(dq-api-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/grpc/api.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/grpc/api.grpc.pb.h +) target_proto_addincls(dq-api-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/dq/api/grpc/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/dq/api/grpc/CMakeLists.linux-x86_64.txt index 85e3fb1fc1b6..942e9bb2a58a 100644 --- a/ydb/library/yql/providers/dq/api/grpc/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/dq/api/grpc/CMakeLists.linux-x86_64.txt @@ -40,6 +40,10 @@ target_link_libraries(dq-api-grpc PUBLIC target_proto_messages(dq-api-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/api/grpc/api.proto ) +target_sources(dq-api-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/grpc/api.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/grpc/api.grpc.pb.h +) target_proto_addincls(dq-api-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/dq/api/grpc/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/dq/api/grpc/CMakeLists.windows-x86_64.txt index bead812e5aa8..6016de0c90ef 100644 --- a/ydb/library/yql/providers/dq/api/grpc/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/dq/api/grpc/CMakeLists.windows-x86_64.txt @@ -39,6 +39,10 @@ target_link_libraries(dq-api-grpc PUBLIC target_proto_messages(dq-api-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/api/grpc/api.proto ) +target_sources(dq-api-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/grpc/api.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/grpc/api.grpc.pb.h +) target_proto_addincls(dq-api-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/dq/api/protos/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/dq/api/protos/CMakeLists.darwin-arm64.txt index c490ba5b0957..6fbea1f29974 100644 --- a/ydb/library/yql/providers/dq/api/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/dq/api/protos/CMakeLists.darwin-arm64.txt @@ -59,6 +59,11 @@ target_proto_messages(dq-api-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/api/protos/dqs.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/api/protos/task_command_executor.proto ) +target_sources(dq-api-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/protos/service.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/protos/dqs.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/protos/task_command_executor.pb.h +) target_proto_addincls(dq-api-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/dq/api/protos/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/dq/api/protos/CMakeLists.darwin-x86_64.txt index c490ba5b0957..6fbea1f29974 100644 --- a/ydb/library/yql/providers/dq/api/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/dq/api/protos/CMakeLists.darwin-x86_64.txt @@ -59,6 +59,11 @@ target_proto_messages(dq-api-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/api/protos/dqs.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/api/protos/task_command_executor.proto ) +target_sources(dq-api-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/protos/service.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/protos/dqs.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/protos/task_command_executor.pb.h +) target_proto_addincls(dq-api-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/dq/api/protos/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/dq/api/protos/CMakeLists.linux-aarch64.txt index e318d9e377d5..7526d187a9e9 100644 --- a/ydb/library/yql/providers/dq/api/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/dq/api/protos/CMakeLists.linux-aarch64.txt @@ -60,6 +60,11 @@ target_proto_messages(dq-api-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/api/protos/dqs.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/api/protos/task_command_executor.proto ) +target_sources(dq-api-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/protos/service.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/protos/dqs.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/protos/task_command_executor.pb.h +) target_proto_addincls(dq-api-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/dq/api/protos/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/dq/api/protos/CMakeLists.linux-x86_64.txt index e318d9e377d5..7526d187a9e9 100644 --- a/ydb/library/yql/providers/dq/api/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/dq/api/protos/CMakeLists.linux-x86_64.txt @@ -60,6 +60,11 @@ target_proto_messages(dq-api-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/api/protos/dqs.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/api/protos/task_command_executor.proto ) +target_sources(dq-api-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/protos/service.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/protos/dqs.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/protos/task_command_executor.pb.h +) target_proto_addincls(dq-api-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/dq/api/protos/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/dq/api/protos/CMakeLists.windows-x86_64.txt index c490ba5b0957..6fbea1f29974 100644 --- a/ydb/library/yql/providers/dq/api/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/dq/api/protos/CMakeLists.windows-x86_64.txt @@ -59,6 +59,11 @@ target_proto_messages(dq-api-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/api/protos/dqs.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/api/protos/task_command_executor.proto ) +target_sources(dq-api-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/protos/service.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/protos/dqs.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/api/protos/task_command_executor.pb.h +) target_proto_addincls(dq-api-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/dq/config/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/dq/config/CMakeLists.darwin-arm64.txt index 67633d60000f..19f403217f1a 100644 --- a/ydb/library/yql/providers/dq/config/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/dq/config/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(providers-dq-config PUBLIC target_proto_messages(providers-dq-config PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/config/config.proto ) +target_sources(providers-dq-config PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/config/config.pb.h +) target_proto_addincls(providers-dq-config ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/dq/config/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/dq/config/CMakeLists.darwin-x86_64.txt index 67633d60000f..19f403217f1a 100644 --- a/ydb/library/yql/providers/dq/config/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/dq/config/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(providers-dq-config PUBLIC target_proto_messages(providers-dq-config PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/config/config.proto ) +target_sources(providers-dq-config PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/config/config.pb.h +) target_proto_addincls(providers-dq-config ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/dq/config/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/dq/config/CMakeLists.linux-aarch64.txt index 6081a00e96be..fcce5fccb93d 100644 --- a/ydb/library/yql/providers/dq/config/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/dq/config/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(providers-dq-config PUBLIC target_proto_messages(providers-dq-config PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/config/config.proto ) +target_sources(providers-dq-config PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/config/config.pb.h +) target_proto_addincls(providers-dq-config ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/dq/config/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/dq/config/CMakeLists.linux-x86_64.txt index 6081a00e96be..fcce5fccb93d 100644 --- a/ydb/library/yql/providers/dq/config/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/dq/config/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(providers-dq-config PUBLIC target_proto_messages(providers-dq-config PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/config/config.proto ) +target_sources(providers-dq-config PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/config/config.pb.h +) target_proto_addincls(providers-dq-config ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/dq/config/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/dq/config/CMakeLists.windows-x86_64.txt index 67633d60000f..19f403217f1a 100644 --- a/ydb/library/yql/providers/dq/config/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/dq/config/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(providers-dq-config PUBLIC target_proto_messages(providers-dq-config PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/config/config.proto ) +target_sources(providers-dq-config PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/config/config.pb.h +) target_proto_addincls(providers-dq-config ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/dq/expr_nodes/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/dq/expr_nodes/CMakeLists.darwin-arm64.txt index 7aba0afce610..9f5d0837eefe 100644 --- a/ydb/library/yql/providers/dq/expr_nodes/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/dq/expr_nodes/CMakeLists.darwin-arm64.txt @@ -21,6 +21,10 @@ target_sources(providers-dq-expr_nodes PRIVATE ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.decl.inl.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.defs.inl.h ) add_custom_command( OUTPUT diff --git a/ydb/library/yql/providers/dq/expr_nodes/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/dq/expr_nodes/CMakeLists.darwin-x86_64.txt index 7aba0afce610..9f5d0837eefe 100644 --- a/ydb/library/yql/providers/dq/expr_nodes/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/dq/expr_nodes/CMakeLists.darwin-x86_64.txt @@ -21,6 +21,10 @@ target_sources(providers-dq-expr_nodes PRIVATE ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.decl.inl.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.defs.inl.h ) add_custom_command( OUTPUT diff --git a/ydb/library/yql/providers/dq/expr_nodes/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/dq/expr_nodes/CMakeLists.linux-aarch64.txt index aa3ec454d102..dbc58bcc34a8 100644 --- a/ydb/library/yql/providers/dq/expr_nodes/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/dq/expr_nodes/CMakeLists.linux-aarch64.txt @@ -22,6 +22,10 @@ target_sources(providers-dq-expr_nodes PRIVATE ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.decl.inl.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.defs.inl.h ) add_custom_command( OUTPUT diff --git a/ydb/library/yql/providers/dq/expr_nodes/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/dq/expr_nodes/CMakeLists.linux-x86_64.txt index aa3ec454d102..dbc58bcc34a8 100644 --- a/ydb/library/yql/providers/dq/expr_nodes/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/dq/expr_nodes/CMakeLists.linux-x86_64.txt @@ -22,6 +22,10 @@ target_sources(providers-dq-expr_nodes PRIVATE ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.decl.inl.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.defs.inl.h ) add_custom_command( OUTPUT diff --git a/ydb/library/yql/providers/dq/expr_nodes/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/dq/expr_nodes/CMakeLists.windows-x86_64.txt index 7aba0afce610..9f5d0837eefe 100644 --- a/ydb/library/yql/providers/dq/expr_nodes/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/dq/expr_nodes/CMakeLists.windows-x86_64.txt @@ -21,6 +21,10 @@ target_sources(providers-dq-expr_nodes PRIVATE ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.decl.inl.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.defs.inl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/dq/expr_nodes/dqs_expr_nodes.defs.inl.h ) add_custom_command( OUTPUT diff --git a/ydb/library/yql/providers/dq/global_worker_manager/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/dq/global_worker_manager/ut/CMakeLists.darwin-arm64.txt index cd8615e7d0b1..360c420a6827 100644 --- a/ydb/library/yql/providers/dq/global_worker_manager/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/dq/global_worker_manager/ut/CMakeLists.darwin-arm64.txt @@ -25,13 +25,13 @@ target_link_libraries(yql-providers-dq-global_worker_manager-ut PUBLIC dq-actors-yt providers-dq-actors dq-actors-compute + minikql-computation-llvm14 + minikql-comp_nodes-llvm14 ) target_link_options(yql-providers-dq-global_worker_manager-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(yql-providers-dq-global_worker_manager-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/global_worker_manager/global_worker_manager_ut.cpp @@ -62,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/dq/global_worker_manager/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/dq/global_worker_manager/ut/CMakeLists.darwin-x86_64.txt index 4ad3896fc4fe..6ceb1e65c6e2 100644 --- a/ydb/library/yql/providers/dq/global_worker_manager/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/dq/global_worker_manager/ut/CMakeLists.darwin-x86_64.txt @@ -26,13 +26,13 @@ target_link_libraries(yql-providers-dq-global_worker_manager-ut PUBLIC dq-actors-yt providers-dq-actors dq-actors-compute + minikql-computation-llvm14 + minikql-comp_nodes-llvm14 ) target_link_options(yql-providers-dq-global_worker_manager-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(yql-providers-dq-global_worker_manager-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/global_worker_manager/global_worker_manager_ut.cpp @@ -63,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/dq/global_worker_manager/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/dq/global_worker_manager/ut/CMakeLists.linux-aarch64.txt index 9b75965945a0..686cc010689e 100644 --- a/ydb/library/yql/providers/dq/global_worker_manager/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/dq/global_worker_manager/ut/CMakeLists.linux-aarch64.txt @@ -26,6 +26,8 @@ target_link_libraries(yql-providers-dq-global_worker_manager-ut PUBLIC dq-actors-yt providers-dq-actors dq-actors-compute + minikql-computation-llvm14 + minikql-comp_nodes-llvm14 ) target_link_options(yql-providers-dq-global_worker_manager-ut PRIVATE -ldl @@ -33,10 +35,6 @@ target_link_options(yql-providers-dq-global_worker_manager-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(yql-providers-dq-global_worker_manager-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/global_worker_manager/global_worker_manager_ut.cpp @@ -67,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/dq/global_worker_manager/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/dq/global_worker_manager/ut/CMakeLists.linux-x86_64.txt index 885e67a072e0..d4d90b95d2bd 100644 --- a/ydb/library/yql/providers/dq/global_worker_manager/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/dq/global_worker_manager/ut/CMakeLists.linux-x86_64.txt @@ -27,6 +27,8 @@ target_link_libraries(yql-providers-dq-global_worker_manager-ut PUBLIC dq-actors-yt providers-dq-actors dq-actors-compute + minikql-computation-llvm14 + minikql-comp_nodes-llvm14 ) target_link_options(yql-providers-dq-global_worker_manager-ut PRIVATE -ldl @@ -34,10 +36,6 @@ target_link_options(yql-providers-dq-global_worker_manager-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(yql-providers-dq-global_worker_manager-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/global_worker_manager/global_worker_manager_ut.cpp @@ -68,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/dq/local_gateway/CMakeLists.txt b/ydb/library/yql/providers/dq/local_gateway/CMakeLists.txt index 380079ac7b4a..d863ebd18067 100644 --- a/ydb/library/yql/providers/dq/local_gateway/CMakeLists.txt +++ b/ydb/library/yql/providers/dq/local_gateway/CMakeLists.txt @@ -14,4 +14,6 @@ elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL include(CMakeLists.darwin-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) endif() diff --git a/ydb/library/yql/providers/dq/local_gateway/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/dq/local_gateway/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..25fa35388169 --- /dev/null +++ b/ydb/library/yql/providers/dq/local_gateway/CMakeLists.windows-x86_64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(providers-dq-local_gateway) +target_compile_options(providers-dq-local_gateway PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(providers-dq-local_gateway PUBLIC + contrib-libs-cxxsupp + yutil + library-yql-utils + dq-actors-compute + dq-actors-spilling + providers-dq-provider + dq-api-protos + providers-dq-task_runner + providers-dq-worker_manager + providers-dq-service + providers-dq-stats_collector +) +target_sources(providers-dq-local_gateway PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/local_gateway/yql_dq_gateway_local.cpp +) diff --git a/ydb/library/yql/providers/dq/opt/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/dq/opt/CMakeLists.darwin-arm64.txt index d7b365119715..4535b923b8ec 100644 --- a/ydb/library/yql/providers/dq/opt/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/dq/opt/CMakeLists.darwin-arm64.txt @@ -25,7 +25,7 @@ target_link_libraries(providers-dq-opt PUBLIC library-yql-core yql-core-peephole_opt yql-core-type_ann - minikql-computation-llvm + yql-minikql-computation cpp-yson-node ) target_sources(providers-dq-opt PRIVATE diff --git a/ydb/library/yql/providers/dq/opt/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/dq/opt/CMakeLists.darwin-x86_64.txt index d7b365119715..4535b923b8ec 100644 --- a/ydb/library/yql/providers/dq/opt/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/dq/opt/CMakeLists.darwin-x86_64.txt @@ -25,7 +25,7 @@ target_link_libraries(providers-dq-opt PUBLIC library-yql-core yql-core-peephole_opt yql-core-type_ann - minikql-computation-llvm + yql-minikql-computation cpp-yson-node ) target_sources(providers-dq-opt PRIVATE diff --git a/ydb/library/yql/providers/dq/opt/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/dq/opt/CMakeLists.linux-aarch64.txt index 7e6d60a07c1f..3ef65f628dc7 100644 --- a/ydb/library/yql/providers/dq/opt/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/dq/opt/CMakeLists.linux-aarch64.txt @@ -26,7 +26,7 @@ target_link_libraries(providers-dq-opt PUBLIC library-yql-core yql-core-peephole_opt yql-core-type_ann - minikql-computation-llvm + yql-minikql-computation cpp-yson-node ) target_sources(providers-dq-opt PRIVATE diff --git a/ydb/library/yql/providers/dq/opt/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/dq/opt/CMakeLists.linux-x86_64.txt index 7e6d60a07c1f..3ef65f628dc7 100644 --- a/ydb/library/yql/providers/dq/opt/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/dq/opt/CMakeLists.linux-x86_64.txt @@ -26,7 +26,7 @@ target_link_libraries(providers-dq-opt PUBLIC library-yql-core yql-core-peephole_opt yql-core-type_ann - minikql-computation-llvm + yql-minikql-computation cpp-yson-node ) target_sources(providers-dq-opt PRIVATE diff --git a/ydb/library/yql/providers/dq/opt/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/dq/opt/CMakeLists.windows-x86_64.txt index d7b365119715..4535b923b8ec 100644 --- a/ydb/library/yql/providers/dq/opt/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/dq/opt/CMakeLists.windows-x86_64.txt @@ -25,7 +25,7 @@ target_link_libraries(providers-dq-opt PUBLIC library-yql-core yql-core-peephole_opt yql-core-type_ann - minikql-computation-llvm + yql-minikql-computation cpp-yson-node ) target_sources(providers-dq-opt PRIVATE diff --git a/ydb/library/yql/providers/dq/planner/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/dq/planner/CMakeLists.darwin-arm64.txt index e75e5ea43015..1eb527d9caff 100644 --- a/ydb/library/yql/providers/dq/planner/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/dq/planner/CMakeLists.darwin-arm64.txt @@ -15,7 +15,7 @@ target_link_libraries(providers-dq-planner PUBLIC contrib-libs-cxxsupp yutil yql-core-services - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-dq-integration yql-dq-opt yql-dq-type_ann diff --git a/ydb/library/yql/providers/dq/planner/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/dq/planner/CMakeLists.darwin-x86_64.txt index e75e5ea43015..1eb527d9caff 100644 --- a/ydb/library/yql/providers/dq/planner/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/dq/planner/CMakeLists.darwin-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(providers-dq-planner PUBLIC contrib-libs-cxxsupp yutil yql-core-services - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-dq-integration yql-dq-opt yql-dq-type_ann diff --git a/ydb/library/yql/providers/dq/planner/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/dq/planner/CMakeLists.linux-aarch64.txt index 301b127603a0..369876931c74 100644 --- a/ydb/library/yql/providers/dq/planner/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/dq/planner/CMakeLists.linux-aarch64.txt @@ -16,7 +16,7 @@ target_link_libraries(providers-dq-planner PUBLIC contrib-libs-cxxsupp yutil yql-core-services - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-dq-integration yql-dq-opt yql-dq-type_ann diff --git a/ydb/library/yql/providers/dq/planner/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/dq/planner/CMakeLists.linux-x86_64.txt index 301b127603a0..369876931c74 100644 --- a/ydb/library/yql/providers/dq/planner/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/dq/planner/CMakeLists.linux-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(providers-dq-planner PUBLIC contrib-libs-cxxsupp yutil yql-core-services - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-dq-integration yql-dq-opt yql-dq-type_ann diff --git a/ydb/library/yql/providers/dq/planner/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/dq/planner/CMakeLists.windows-x86_64.txt index e75e5ea43015..1eb527d9caff 100644 --- a/ydb/library/yql/providers/dq/planner/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/dq/planner/CMakeLists.windows-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(providers-dq-planner PUBLIC contrib-libs-cxxsupp yutil yql-core-services - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-dq-integration yql-dq-opt yql-dq-type_ann diff --git a/ydb/library/yql/providers/dq/provider/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/dq/provider/CMakeLists.darwin-arm64.txt index 729e4a5cb794..abfbb7c506bd 100644 --- a/ydb/library/yql/providers/dq/provider/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/dq/provider/CMakeLists.darwin-arm64.txt @@ -49,6 +49,16 @@ target_link_libraries(providers-dq-provider PUBLIC library-yql-minikql ) target_sources(providers-dq-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_control.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasink_type_ann.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasource_type_ann.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_gateway.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasink.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasource.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_recapture.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_statistics.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_statistics_json.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_control.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasink_constraints.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasink_type_ann.cpp diff --git a/ydb/library/yql/providers/dq/provider/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/dq/provider/CMakeLists.darwin-x86_64.txt index 729e4a5cb794..abfbb7c506bd 100644 --- a/ydb/library/yql/providers/dq/provider/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/dq/provider/CMakeLists.darwin-x86_64.txt @@ -49,6 +49,16 @@ target_link_libraries(providers-dq-provider PUBLIC library-yql-minikql ) target_sources(providers-dq-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_control.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasink_type_ann.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasource_type_ann.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_gateway.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasink.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasource.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_recapture.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_statistics.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_statistics_json.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_control.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasink_constraints.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasink_type_ann.cpp diff --git a/ydb/library/yql/providers/dq/provider/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/dq/provider/CMakeLists.linux-aarch64.txt index 4b90bc051f7a..18d2b47f7085 100644 --- a/ydb/library/yql/providers/dq/provider/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/dq/provider/CMakeLists.linux-aarch64.txt @@ -50,6 +50,16 @@ target_link_libraries(providers-dq-provider PUBLIC library-yql-minikql ) target_sources(providers-dq-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_control.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasink_type_ann.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasource_type_ann.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_gateway.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasink.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasource.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_recapture.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_statistics.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_statistics_json.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_control.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasink_constraints.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasink_type_ann.cpp diff --git a/ydb/library/yql/providers/dq/provider/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/dq/provider/CMakeLists.linux-x86_64.txt index 4b90bc051f7a..18d2b47f7085 100644 --- a/ydb/library/yql/providers/dq/provider/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/dq/provider/CMakeLists.linux-x86_64.txt @@ -50,6 +50,16 @@ target_link_libraries(providers-dq-provider PUBLIC library-yql-minikql ) target_sources(providers-dq-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_control.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasink_type_ann.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasource_type_ann.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_gateway.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasink.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasource.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_recapture.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_statistics.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_statistics_json.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_control.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasink_constraints.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasink_type_ann.cpp diff --git a/ydb/library/yql/providers/dq/provider/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/dq/provider/CMakeLists.windows-x86_64.txt index 729e4a5cb794..abfbb7c506bd 100644 --- a/ydb/library/yql/providers/dq/provider/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/dq/provider/CMakeLists.windows-x86_64.txt @@ -49,6 +49,16 @@ target_link_libraries(providers-dq-provider PUBLIC library-yql-minikql ) target_sources(providers-dq-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_control.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasink_type_ann.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasource_type_ann.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_gateway.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasink.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasource.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_recapture.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_statistics.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_statistics_json.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_control.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasink_constraints.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_datasink_type_ann.cpp diff --git a/ydb/library/yql/providers/dq/provider/exec/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/dq/provider/exec/CMakeLists.darwin-arm64.txt index 4f1b26c851e9..5fa38f74f974 100644 --- a/ydb/library/yql/providers/dq/provider/exec/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/dq/provider/exec/CMakeLists.darwin-arm64.txt @@ -40,5 +40,6 @@ target_link_libraries(dq-provider-exec PUBLIC providers-result-expr_nodes ) target_sources(dq-provider-exec PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/exec/yql_dq_exectransformer.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/exec/yql_dq_exectransformer.cpp ) diff --git a/ydb/library/yql/providers/dq/provider/exec/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/dq/provider/exec/CMakeLists.darwin-x86_64.txt index 4f1b26c851e9..5fa38f74f974 100644 --- a/ydb/library/yql/providers/dq/provider/exec/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/dq/provider/exec/CMakeLists.darwin-x86_64.txt @@ -40,5 +40,6 @@ target_link_libraries(dq-provider-exec PUBLIC providers-result-expr_nodes ) target_sources(dq-provider-exec PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/exec/yql_dq_exectransformer.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/exec/yql_dq_exectransformer.cpp ) diff --git a/ydb/library/yql/providers/dq/provider/exec/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/dq/provider/exec/CMakeLists.linux-aarch64.txt index 5e7983f052c9..560289b2f299 100644 --- a/ydb/library/yql/providers/dq/provider/exec/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/dq/provider/exec/CMakeLists.linux-aarch64.txt @@ -41,5 +41,6 @@ target_link_libraries(dq-provider-exec PUBLIC providers-result-expr_nodes ) target_sources(dq-provider-exec PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/exec/yql_dq_exectransformer.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/exec/yql_dq_exectransformer.cpp ) diff --git a/ydb/library/yql/providers/dq/provider/exec/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/dq/provider/exec/CMakeLists.linux-x86_64.txt index 5e7983f052c9..560289b2f299 100644 --- a/ydb/library/yql/providers/dq/provider/exec/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/dq/provider/exec/CMakeLists.linux-x86_64.txt @@ -41,5 +41,6 @@ target_link_libraries(dq-provider-exec PUBLIC providers-result-expr_nodes ) target_sources(dq-provider-exec PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/exec/yql_dq_exectransformer.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/exec/yql_dq_exectransformer.cpp ) diff --git a/ydb/library/yql/providers/dq/provider/exec/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/dq/provider/exec/CMakeLists.windows-x86_64.txt index 4f1b26c851e9..5fa38f74f974 100644 --- a/ydb/library/yql/providers/dq/provider/exec/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/dq/provider/exec/CMakeLists.windows-x86_64.txt @@ -40,5 +40,6 @@ target_link_libraries(dq-provider-exec PUBLIC providers-result-expr_nodes ) target_sources(dq-provider-exec PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/exec/yql_dq_exectransformer.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/exec/yql_dq_exectransformer.cpp ) diff --git a/ydb/library/yql/providers/dq/provider/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/dq/provider/ut/CMakeLists.darwin-arm64.txt index 808c4d8432ed..2ae08984c248 100644 --- a/ydb/library/yql/providers/dq/provider/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/dq/provider/ut/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-library-yql-providers-dq-provider-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-dq-provider-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_provider_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/dq/provider/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/dq/provider/ut/CMakeLists.darwin-x86_64.txt index 5cf15dc14a59..c03ba76b37a3 100644 --- a/ydb/library/yql/providers/dq/provider/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/dq/provider/ut/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-library-yql-providers-dq-provider-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-dq-provider-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_provider_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/dq/provider/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/dq/provider/ut/CMakeLists.linux-aarch64.txt index 520fcbbec5ae..30e373447ad8 100644 --- a/ydb/library/yql/providers/dq/provider/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/dq/provider/ut/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-library-yql-providers-dq-provider-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-dq-provider-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_provider_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/dq/provider/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/dq/provider/ut/CMakeLists.linux-x86_64.txt index 67361572c7a2..4236624accce 100644 --- a/ydb/library/yql/providers/dq/provider/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/dq/provider/ut/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-library-yql-providers-dq-provider-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-dq-provider-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/provider/yql_dq_provider_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/dq/provider/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/dq/provider/ut/CMakeLists.windows-x86_64.txt index e5f846b20259..b4f8749f0de9 100644 --- a/ydb/library/yql/providers/dq/provider/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/dq/provider/ut/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/dq/runtime/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/dq/runtime/CMakeLists.darwin-arm64.txt index 1c490e52773d..66d221aa03f1 100644 --- a/ydb/library/yql/providers/dq/runtime/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/dq/runtime/CMakeLists.darwin-arm64.txt @@ -14,7 +14,7 @@ target_compile_options(providers-dq-runtime PRIVATE target_link_libraries(providers-dq-runtime PUBLIC contrib-libs-cxxsupp yutil - minikql-invoke_builtins-llvm + yql-minikql-invoke_builtins library-yql-utils yql-utils-log yql-utils-backtrace diff --git a/ydb/library/yql/providers/dq/runtime/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/dq/runtime/CMakeLists.darwin-x86_64.txt index 1c490e52773d..66d221aa03f1 100644 --- a/ydb/library/yql/providers/dq/runtime/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/dq/runtime/CMakeLists.darwin-x86_64.txt @@ -14,7 +14,7 @@ target_compile_options(providers-dq-runtime PRIVATE target_link_libraries(providers-dq-runtime PUBLIC contrib-libs-cxxsupp yutil - minikql-invoke_builtins-llvm + yql-minikql-invoke_builtins library-yql-utils yql-utils-log yql-utils-backtrace diff --git a/ydb/library/yql/providers/dq/runtime/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/dq/runtime/CMakeLists.linux-aarch64.txt index d63919158623..53f65eb6db9a 100644 --- a/ydb/library/yql/providers/dq/runtime/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/dq/runtime/CMakeLists.linux-aarch64.txt @@ -15,7 +15,7 @@ target_link_libraries(providers-dq-runtime PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - minikql-invoke_builtins-llvm + yql-minikql-invoke_builtins library-yql-utils yql-utils-log yql-utils-backtrace diff --git a/ydb/library/yql/providers/dq/runtime/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/dq/runtime/CMakeLists.linux-x86_64.txt index d63919158623..53f65eb6db9a 100644 --- a/ydb/library/yql/providers/dq/runtime/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/dq/runtime/CMakeLists.linux-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(providers-dq-runtime PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - minikql-invoke_builtins-llvm + yql-minikql-invoke_builtins library-yql-utils yql-utils-log yql-utils-backtrace diff --git a/ydb/library/yql/providers/dq/runtime/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/dq/runtime/CMakeLists.windows-x86_64.txt index 1c490e52773d..66d221aa03f1 100644 --- a/ydb/library/yql/providers/dq/runtime/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/dq/runtime/CMakeLists.windows-x86_64.txt @@ -14,7 +14,7 @@ target_compile_options(providers-dq-runtime PRIVATE target_link_libraries(providers-dq-runtime PUBLIC contrib-libs-cxxsupp yutil - minikql-invoke_builtins-llvm + yql-minikql-invoke_builtins library-yql-utils yql-utils-log yql-utils-backtrace diff --git a/ydb/library/yql/providers/dq/scheduler/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/dq/scheduler/ut/CMakeLists.darwin-arm64.txt index 84654a8a2382..accd2abdb8ed 100644 --- a/ydb/library/yql/providers/dq/scheduler/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/dq/scheduler/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-library-yql-providers-dq-scheduler-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-dq-scheduler-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/scheduler/ut/dq_scheduler_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/dq/scheduler/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/dq/scheduler/ut/CMakeLists.darwin-x86_64.txt index aa754d167c2b..f2d122ac9275 100644 --- a/ydb/library/yql/providers/dq/scheduler/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/dq/scheduler/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-library-yql-providers-dq-scheduler-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-dq-scheduler-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/scheduler/ut/dq_scheduler_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/dq/scheduler/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/dq/scheduler/ut/CMakeLists.linux-aarch64.txt index cdeda2cc9181..e09e64afee29 100644 --- a/ydb/library/yql/providers/dq/scheduler/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/dq/scheduler/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-library-yql-providers-dq-scheduler-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-dq-scheduler-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/scheduler/ut/dq_scheduler_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/dq/scheduler/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/dq/scheduler/ut/CMakeLists.linux-x86_64.txt index 3ee08ce18863..a47b700235a5 100644 --- a/ydb/library/yql/providers/dq/scheduler/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/dq/scheduler/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-library-yql-providers-dq-scheduler-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-dq-scheduler-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/scheduler/ut/dq_scheduler_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/dq/scheduler/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/dq/scheduler/ut/CMakeLists.windows-x86_64.txt index e5ba4657a5c1..4e06b6304529 100644 --- a/ydb/library/yql/providers/dq/scheduler/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/dq/scheduler/ut/CMakeLists.windows-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/dq/stats_collector/CMakeLists.txt b/ydb/library/yql/providers/dq/stats_collector/CMakeLists.txt index 380079ac7b4a..d863ebd18067 100644 --- a/ydb/library/yql/providers/dq/stats_collector/CMakeLists.txt +++ b/ydb/library/yql/providers/dq/stats_collector/CMakeLists.txt @@ -14,4 +14,6 @@ elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL include(CMakeLists.darwin-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) endif() diff --git a/ydb/library/yql/providers/dq/stats_collector/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/dq/stats_collector/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..78e0de74fc2c --- /dev/null +++ b/ydb/library/yql/providers/dq/stats_collector/CMakeLists.windows-x86_64.txt @@ -0,0 +1,23 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(providers-dq-stats_collector) +target_compile_options(providers-dq-stats_collector PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(providers-dq-stats_collector PUBLIC + contrib-libs-cxxsupp + yutil + library-actors-core + library-actors-helpers + cpp-monlib-dynamic_counters +) +target_sources(providers-dq-stats_collector PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/dq/stats_collector/pool_stats_collector.cpp +) diff --git a/ydb/library/yql/providers/dq/task_runner/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/dq/task_runner/CMakeLists.darwin-arm64.txt index 1b27cb756f59..b41435e0cbc0 100644 --- a/ydb/library/yql/providers/dq/task_runner/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/dq/task_runner/CMakeLists.darwin-arm64.txt @@ -18,7 +18,7 @@ target_link_libraries(providers-dq-task_runner PUBLIC cpp-threading-task_scheduler cpp-yson-node dq-integration-transform - minikql-invoke_builtins-llvm + yql-minikql-invoke_builtins library-yql-protos library-yql-utils yql-utils-backtrace diff --git a/ydb/library/yql/providers/dq/task_runner/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/dq/task_runner/CMakeLists.darwin-x86_64.txt index 1b27cb756f59..b41435e0cbc0 100644 --- a/ydb/library/yql/providers/dq/task_runner/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/dq/task_runner/CMakeLists.darwin-x86_64.txt @@ -18,7 +18,7 @@ target_link_libraries(providers-dq-task_runner PUBLIC cpp-threading-task_scheduler cpp-yson-node dq-integration-transform - minikql-invoke_builtins-llvm + yql-minikql-invoke_builtins library-yql-protos library-yql-utils yql-utils-backtrace diff --git a/ydb/library/yql/providers/dq/task_runner/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/dq/task_runner/CMakeLists.linux-aarch64.txt index c83911f55132..beb4b7c26087 100644 --- a/ydb/library/yql/providers/dq/task_runner/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/dq/task_runner/CMakeLists.linux-aarch64.txt @@ -19,7 +19,7 @@ target_link_libraries(providers-dq-task_runner PUBLIC cpp-threading-task_scheduler cpp-yson-node dq-integration-transform - minikql-invoke_builtins-llvm + yql-minikql-invoke_builtins library-yql-protos library-yql-utils yql-utils-backtrace diff --git a/ydb/library/yql/providers/dq/task_runner/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/dq/task_runner/CMakeLists.linux-x86_64.txt index c83911f55132..beb4b7c26087 100644 --- a/ydb/library/yql/providers/dq/task_runner/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/dq/task_runner/CMakeLists.linux-x86_64.txt @@ -19,7 +19,7 @@ target_link_libraries(providers-dq-task_runner PUBLIC cpp-threading-task_scheduler cpp-yson-node dq-integration-transform - minikql-invoke_builtins-llvm + yql-minikql-invoke_builtins library-yql-protos library-yql-utils yql-utils-backtrace diff --git a/ydb/library/yql/providers/dq/task_runner/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/dq/task_runner/CMakeLists.windows-x86_64.txt index 1b27cb756f59..b41435e0cbc0 100644 --- a/ydb/library/yql/providers/dq/task_runner/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/dq/task_runner/CMakeLists.windows-x86_64.txt @@ -18,7 +18,7 @@ target_link_libraries(providers-dq-task_runner PUBLIC cpp-threading-task_scheduler cpp-yson-node dq-integration-transform - minikql-invoke_builtins-llvm + yql-minikql-invoke_builtins library-yql-protos library-yql-utils yql-utils-backtrace diff --git a/ydb/library/yql/providers/function/expr_nodes/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/function/expr_nodes/CMakeLists.darwin-arm64.txt index 7dd678e97adf..12102a84f2f7 100644 --- a/ydb/library/yql/providers/function/expr_nodes/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/function/expr_nodes/CMakeLists.darwin-arm64.txt @@ -15,6 +15,9 @@ target_link_libraries(providers-function-expr_nodes PUBLIC yql-core-expr_nodes ) target_sources(providers-function-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/function/expr_nodes/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/function/expr_nodes/CMakeLists.darwin-x86_64.txt index 7dd678e97adf..12102a84f2f7 100644 --- a/ydb/library/yql/providers/function/expr_nodes/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/function/expr_nodes/CMakeLists.darwin-x86_64.txt @@ -15,6 +15,9 @@ target_link_libraries(providers-function-expr_nodes PUBLIC yql-core-expr_nodes ) target_sources(providers-function-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/function/expr_nodes/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/function/expr_nodes/CMakeLists.linux-aarch64.txt index c8d502305a11..603d50e99982 100644 --- a/ydb/library/yql/providers/function/expr_nodes/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/function/expr_nodes/CMakeLists.linux-aarch64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-function-expr_nodes PUBLIC yql-core-expr_nodes ) target_sources(providers-function-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/function/expr_nodes/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/function/expr_nodes/CMakeLists.linux-x86_64.txt index c8d502305a11..603d50e99982 100644 --- a/ydb/library/yql/providers/function/expr_nodes/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/function/expr_nodes/CMakeLists.linux-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-function-expr_nodes PUBLIC yql-core-expr_nodes ) target_sources(providers-function-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/function/expr_nodes/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/function/expr_nodes/CMakeLists.windows-x86_64.txt index 7dd678e97adf..12102a84f2f7 100644 --- a/ydb/library/yql/providers/function/expr_nodes/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/function/expr_nodes/CMakeLists.windows-x86_64.txt @@ -15,6 +15,9 @@ target_link_libraries(providers-function-expr_nodes PUBLIC yql-core-expr_nodes ) target_sources(providers-function-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/expr_nodes/dq_function_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/function/proto/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/function/proto/CMakeLists.darwin-arm64.txt index 4e85a89b0d07..bb26671a5171 100644 --- a/ydb/library/yql/providers/function/proto/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/function/proto/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(providers-function-proto PUBLIC target_proto_messages(providers-function-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/function/proto/dq_function.proto ) +target_sources(providers-function-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/proto/dq_function.pb.h +) target_proto_addincls(providers-function-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/function/proto/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/function/proto/CMakeLists.darwin-x86_64.txt index 4e85a89b0d07..bb26671a5171 100644 --- a/ydb/library/yql/providers/function/proto/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/function/proto/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(providers-function-proto PUBLIC target_proto_messages(providers-function-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/function/proto/dq_function.proto ) +target_sources(providers-function-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/proto/dq_function.pb.h +) target_proto_addincls(providers-function-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/function/proto/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/function/proto/CMakeLists.linux-aarch64.txt index 76e1dd4a9684..9ba69fef81ae 100644 --- a/ydb/library/yql/providers/function/proto/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/function/proto/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(providers-function-proto PUBLIC target_proto_messages(providers-function-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/function/proto/dq_function.proto ) +target_sources(providers-function-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/proto/dq_function.pb.h +) target_proto_addincls(providers-function-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/function/proto/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/function/proto/CMakeLists.linux-x86_64.txt index 76e1dd4a9684..9ba69fef81ae 100644 --- a/ydb/library/yql/providers/function/proto/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/function/proto/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(providers-function-proto PUBLIC target_proto_messages(providers-function-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/function/proto/dq_function.proto ) +target_sources(providers-function-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/proto/dq_function.pb.h +) target_proto_addincls(providers-function-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/function/proto/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/function/proto/CMakeLists.windows-x86_64.txt index 4e85a89b0d07..bb26671a5171 100644 --- a/ydb/library/yql/providers/function/proto/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/function/proto/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(providers-function-proto PUBLIC target_proto_messages(providers-function-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/function/proto/dq_function.proto ) +target_sources(providers-function-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/function/proto/dq_function.pb.h +) target_proto_addincls(providers-function-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/generic/actors/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/generic/actors/CMakeLists.darwin-arm64.txt index bd1cd8293b82..eb51490f4d2a 100644 --- a/ydb/library/yql/providers/generic/actors/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/generic/actors/CMakeLists.darwin-arm64.txt @@ -15,7 +15,7 @@ target_link_libraries(providers-generic-actors PUBLIC contrib-libs-cxxsupp yutil dq-actors-compute - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client providers-generic-proto yql-public-types diff --git a/ydb/library/yql/providers/generic/actors/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/generic/actors/CMakeLists.darwin-x86_64.txt index bd1cd8293b82..eb51490f4d2a 100644 --- a/ydb/library/yql/providers/generic/actors/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/generic/actors/CMakeLists.darwin-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(providers-generic-actors PUBLIC contrib-libs-cxxsupp yutil dq-actors-compute - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client providers-generic-proto yql-public-types diff --git a/ydb/library/yql/providers/generic/actors/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/generic/actors/CMakeLists.linux-aarch64.txt index b037d621fbe4..da5ca5d7a8c0 100644 --- a/ydb/library/yql/providers/generic/actors/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/generic/actors/CMakeLists.linux-aarch64.txt @@ -16,7 +16,7 @@ target_link_libraries(providers-generic-actors PUBLIC contrib-libs-cxxsupp yutil dq-actors-compute - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client providers-generic-proto yql-public-types diff --git a/ydb/library/yql/providers/generic/actors/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/generic/actors/CMakeLists.linux-x86_64.txt index b037d621fbe4..da5ca5d7a8c0 100644 --- a/ydb/library/yql/providers/generic/actors/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/generic/actors/CMakeLists.linux-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(providers-generic-actors PUBLIC contrib-libs-cxxsupp yutil dq-actors-compute - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client providers-generic-proto yql-public-types diff --git a/ydb/library/yql/providers/generic/actors/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/generic/actors/CMakeLists.windows-x86_64.txt index bd1cd8293b82..eb51490f4d2a 100644 --- a/ydb/library/yql/providers/generic/actors/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/generic/actors/CMakeLists.windows-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(providers-generic-actors PUBLIC contrib-libs-cxxsupp yutil dq-actors-compute - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client providers-generic-proto yql-public-types diff --git a/ydb/library/yql/providers/generic/connector/api/common/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/generic/connector/api/common/CMakeLists.darwin-arm64.txt index 1af4185e0700..69315c7230a9 100644 --- a/ydb/library/yql/providers/generic/connector/api/common/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/generic/connector/api/common/CMakeLists.darwin-arm64.txt @@ -41,6 +41,10 @@ target_proto_messages(connector-api-common PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/connector/api/common/data_source.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/connector/api/common/endpoint.proto ) +target_sources(connector-api-common PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/common/data_source.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/common/endpoint.pb.h +) target_proto_addincls(connector-api-common ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/generic/connector/api/common/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/generic/connector/api/common/CMakeLists.darwin-x86_64.txt index 1af4185e0700..69315c7230a9 100644 --- a/ydb/library/yql/providers/generic/connector/api/common/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/generic/connector/api/common/CMakeLists.darwin-x86_64.txt @@ -41,6 +41,10 @@ target_proto_messages(connector-api-common PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/connector/api/common/data_source.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/connector/api/common/endpoint.proto ) +target_sources(connector-api-common PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/common/data_source.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/common/endpoint.pb.h +) target_proto_addincls(connector-api-common ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/generic/connector/api/common/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/generic/connector/api/common/CMakeLists.linux-aarch64.txt index ca49587737b8..3c48b23c2029 100644 --- a/ydb/library/yql/providers/generic/connector/api/common/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/generic/connector/api/common/CMakeLists.linux-aarch64.txt @@ -42,6 +42,10 @@ target_proto_messages(connector-api-common PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/connector/api/common/data_source.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/connector/api/common/endpoint.proto ) +target_sources(connector-api-common PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/common/data_source.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/common/endpoint.pb.h +) target_proto_addincls(connector-api-common ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/generic/connector/api/common/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/generic/connector/api/common/CMakeLists.linux-x86_64.txt index ca49587737b8..3c48b23c2029 100644 --- a/ydb/library/yql/providers/generic/connector/api/common/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/generic/connector/api/common/CMakeLists.linux-x86_64.txt @@ -42,6 +42,10 @@ target_proto_messages(connector-api-common PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/connector/api/common/data_source.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/connector/api/common/endpoint.proto ) +target_sources(connector-api-common PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/common/data_source.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/common/endpoint.pb.h +) target_proto_addincls(connector-api-common ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/generic/connector/api/common/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/generic/connector/api/common/CMakeLists.windows-x86_64.txt index 1af4185e0700..69315c7230a9 100644 --- a/ydb/library/yql/providers/generic/connector/api/common/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/generic/connector/api/common/CMakeLists.windows-x86_64.txt @@ -41,6 +41,10 @@ target_proto_messages(connector-api-common PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/connector/api/common/data_source.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/connector/api/common/endpoint.proto ) +target_sources(connector-api-common PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/common/data_source.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/common/endpoint.pb.h +) target_proto_addincls(connector-api-common ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/generic/connector/api/service/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/generic/connector/api/service/CMakeLists.darwin-arm64.txt index 75d63720a62e..3c2ca4b4d75f 100644 --- a/ydb/library/yql/providers/generic/connector/api/service/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/generic/connector/api/service/CMakeLists.darwin-arm64.txt @@ -40,6 +40,10 @@ target_link_libraries(connector-api-service PUBLIC target_proto_messages(connector-api-service PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/connector/api/service/connector.proto ) +target_sources(connector-api-service PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/service/connector.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/service/connector.grpc.pb.h +) target_proto_addincls(connector-api-service ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/generic/connector/api/service/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/generic/connector/api/service/CMakeLists.darwin-x86_64.txt index 75d63720a62e..3c2ca4b4d75f 100644 --- a/ydb/library/yql/providers/generic/connector/api/service/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/generic/connector/api/service/CMakeLists.darwin-x86_64.txt @@ -40,6 +40,10 @@ target_link_libraries(connector-api-service PUBLIC target_proto_messages(connector-api-service PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/connector/api/service/connector.proto ) +target_sources(connector-api-service PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/service/connector.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/service/connector.grpc.pb.h +) target_proto_addincls(connector-api-service ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/generic/connector/api/service/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/generic/connector/api/service/CMakeLists.linux-aarch64.txt index b41c8ae0980c..026d93e90810 100644 --- a/ydb/library/yql/providers/generic/connector/api/service/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/generic/connector/api/service/CMakeLists.linux-aarch64.txt @@ -41,6 +41,10 @@ target_link_libraries(connector-api-service PUBLIC target_proto_messages(connector-api-service PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/connector/api/service/connector.proto ) +target_sources(connector-api-service PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/service/connector.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/service/connector.grpc.pb.h +) target_proto_addincls(connector-api-service ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/generic/connector/api/service/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/generic/connector/api/service/CMakeLists.linux-x86_64.txt index b41c8ae0980c..026d93e90810 100644 --- a/ydb/library/yql/providers/generic/connector/api/service/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/generic/connector/api/service/CMakeLists.linux-x86_64.txt @@ -41,6 +41,10 @@ target_link_libraries(connector-api-service PUBLIC target_proto_messages(connector-api-service PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/connector/api/service/connector.proto ) +target_sources(connector-api-service PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/service/connector.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/service/connector.grpc.pb.h +) target_proto_addincls(connector-api-service ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/generic/connector/api/service/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/generic/connector/api/service/CMakeLists.windows-x86_64.txt index 75d63720a62e..3c2ca4b4d75f 100644 --- a/ydb/library/yql/providers/generic/connector/api/service/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/generic/connector/api/service/CMakeLists.windows-x86_64.txt @@ -40,6 +40,10 @@ target_link_libraries(connector-api-service PUBLIC target_proto_messages(connector-api-service PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/connector/api/service/connector.proto ) +target_sources(connector-api-service PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/service/connector.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/service/connector.grpc.pb.h +) target_proto_addincls(connector-api-service ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/generic/connector/api/service/protos/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/generic/connector/api/service/protos/CMakeLists.darwin-arm64.txt index f37533ca6f22..fffd64db5ee6 100644 --- a/ydb/library/yql/providers/generic/connector/api/service/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/generic/connector/api/service/protos/CMakeLists.darwin-arm64.txt @@ -30,6 +30,9 @@ target_link_libraries(api-service-protos PUBLIC target_proto_messages(api-service-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/connector/api/service/protos/connector.proto ) +target_sources(api-service-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/service/protos/connector.pb.h +) target_proto_addincls(api-service-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/generic/connector/api/service/protos/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/generic/connector/api/service/protos/CMakeLists.darwin-x86_64.txt index f37533ca6f22..fffd64db5ee6 100644 --- a/ydb/library/yql/providers/generic/connector/api/service/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/generic/connector/api/service/protos/CMakeLists.darwin-x86_64.txt @@ -30,6 +30,9 @@ target_link_libraries(api-service-protos PUBLIC target_proto_messages(api-service-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/connector/api/service/protos/connector.proto ) +target_sources(api-service-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/service/protos/connector.pb.h +) target_proto_addincls(api-service-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/generic/connector/api/service/protos/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/generic/connector/api/service/protos/CMakeLists.linux-aarch64.txt index f6fb469b6cc4..063c93eb075e 100644 --- a/ydb/library/yql/providers/generic/connector/api/service/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/generic/connector/api/service/protos/CMakeLists.linux-aarch64.txt @@ -31,6 +31,9 @@ target_link_libraries(api-service-protos PUBLIC target_proto_messages(api-service-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/connector/api/service/protos/connector.proto ) +target_sources(api-service-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/service/protos/connector.pb.h +) target_proto_addincls(api-service-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/generic/connector/api/service/protos/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/generic/connector/api/service/protos/CMakeLists.linux-x86_64.txt index f6fb469b6cc4..063c93eb075e 100644 --- a/ydb/library/yql/providers/generic/connector/api/service/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/generic/connector/api/service/protos/CMakeLists.linux-x86_64.txt @@ -31,6 +31,9 @@ target_link_libraries(api-service-protos PUBLIC target_proto_messages(api-service-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/connector/api/service/protos/connector.proto ) +target_sources(api-service-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/service/protos/connector.pb.h +) target_proto_addincls(api-service-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/generic/connector/api/service/protos/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/generic/connector/api/service/protos/CMakeLists.windows-x86_64.txt index f37533ca6f22..fffd64db5ee6 100644 --- a/ydb/library/yql/providers/generic/connector/api/service/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/generic/connector/api/service/protos/CMakeLists.windows-x86_64.txt @@ -30,6 +30,9 @@ target_link_libraries(api-service-protos PUBLIC target_proto_messages(api-service-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/connector/api/service/protos/connector.proto ) +target_sources(api-service-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/connector/api/service/protos/connector.pb.h +) target_proto_addincls(api-service-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/generic/expr_nodes/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/generic/expr_nodes/CMakeLists.darwin-arm64.txt index ef7d722030b6..7a7b33de9893 100644 --- a/ydb/library/yql/providers/generic/expr_nodes/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/generic/expr_nodes/CMakeLists.darwin-arm64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-generic-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-generic-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/generic/expr_nodes/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/generic/expr_nodes/CMakeLists.darwin-x86_64.txt index ef7d722030b6..7a7b33de9893 100644 --- a/ydb/library/yql/providers/generic/expr_nodes/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/generic/expr_nodes/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-generic-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-generic-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/generic/expr_nodes/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/generic/expr_nodes/CMakeLists.linux-aarch64.txt index e07208f2e1e7..f68b910de3dc 100644 --- a/ydb/library/yql/providers/generic/expr_nodes/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/generic/expr_nodes/CMakeLists.linux-aarch64.txt @@ -17,6 +17,9 @@ target_link_libraries(providers-generic-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-generic-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/generic/expr_nodes/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/generic/expr_nodes/CMakeLists.linux-x86_64.txt index e07208f2e1e7..f68b910de3dc 100644 --- a/ydb/library/yql/providers/generic/expr_nodes/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/generic/expr_nodes/CMakeLists.linux-x86_64.txt @@ -17,6 +17,9 @@ target_link_libraries(providers-generic-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-generic-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/generic/expr_nodes/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/generic/expr_nodes/CMakeLists.windows-x86_64.txt index ef7d722030b6..7a7b33de9893 100644 --- a/ydb/library/yql/providers/generic/expr_nodes/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/generic/expr_nodes/CMakeLists.windows-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-generic-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-generic-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/expr_nodes/yql_generic_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/generic/proto/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/generic/proto/CMakeLists.darwin-arm64.txt index 9d2318ef89af..886fdde14af2 100644 --- a/ydb/library/yql/providers/generic/proto/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/generic/proto/CMakeLists.darwin-arm64.txt @@ -43,6 +43,10 @@ target_proto_messages(providers-generic-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/proto/range.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/proto/source.proto ) +target_sources(providers-generic-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/proto/range.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/proto/source.pb.h +) target_proto_addincls(providers-generic-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/generic/proto/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/generic/proto/CMakeLists.darwin-x86_64.txt index 9d2318ef89af..886fdde14af2 100644 --- a/ydb/library/yql/providers/generic/proto/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/generic/proto/CMakeLists.darwin-x86_64.txt @@ -43,6 +43,10 @@ target_proto_messages(providers-generic-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/proto/range.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/proto/source.proto ) +target_sources(providers-generic-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/proto/range.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/proto/source.pb.h +) target_proto_addincls(providers-generic-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/generic/proto/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/generic/proto/CMakeLists.linux-aarch64.txt index 4e41576ab28d..91ffb74f3cda 100644 --- a/ydb/library/yql/providers/generic/proto/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/generic/proto/CMakeLists.linux-aarch64.txt @@ -44,6 +44,10 @@ target_proto_messages(providers-generic-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/proto/range.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/proto/source.proto ) +target_sources(providers-generic-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/proto/range.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/proto/source.pb.h +) target_proto_addincls(providers-generic-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/generic/proto/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/generic/proto/CMakeLists.linux-x86_64.txt index 4e41576ab28d..91ffb74f3cda 100644 --- a/ydb/library/yql/providers/generic/proto/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/generic/proto/CMakeLists.linux-x86_64.txt @@ -44,6 +44,10 @@ target_proto_messages(providers-generic-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/proto/range.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/proto/source.proto ) +target_sources(providers-generic-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/proto/range.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/proto/source.pb.h +) target_proto_addincls(providers-generic-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/generic/proto/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/generic/proto/CMakeLists.windows-x86_64.txt index 9d2318ef89af..886fdde14af2 100644 --- a/ydb/library/yql/providers/generic/proto/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/generic/proto/CMakeLists.windows-x86_64.txt @@ -43,6 +43,10 @@ target_proto_messages(providers-generic-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/proto/range.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/proto/source.proto ) +target_sources(providers-generic-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/proto/range.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/generic/proto/source.pb.h +) target_proto_addincls(providers-generic-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/generic/provider/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/generic/provider/CMakeLists.darwin-arm64.txt index 99acc2f8d302..60e46937cee3 100644 --- a/ydb/library/yql/providers/generic/provider/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/generic/provider/CMakeLists.darwin-arm64.txt @@ -25,7 +25,7 @@ target_link_libraries(providers-generic-provider PUBLIC yql-core-type_ann yql-dq-expr_nodes yql-dq-integration - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-config providers-common-db_id_async_resolver providers-common-dq @@ -43,6 +43,10 @@ target_link_libraries(providers-generic-provider PUBLIC yql-utils-plan ) target_sources(providers-generic-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_provider_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_settings.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_state.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_cluster_config.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_datasink.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_datasink_execution.cpp diff --git a/ydb/library/yql/providers/generic/provider/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/generic/provider/CMakeLists.darwin-x86_64.txt index 99acc2f8d302..60e46937cee3 100644 --- a/ydb/library/yql/providers/generic/provider/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/generic/provider/CMakeLists.darwin-x86_64.txt @@ -25,7 +25,7 @@ target_link_libraries(providers-generic-provider PUBLIC yql-core-type_ann yql-dq-expr_nodes yql-dq-integration - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-config providers-common-db_id_async_resolver providers-common-dq @@ -43,6 +43,10 @@ target_link_libraries(providers-generic-provider PUBLIC yql-utils-plan ) target_sources(providers-generic-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_provider_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_settings.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_state.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_cluster_config.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_datasink.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_datasink_execution.cpp diff --git a/ydb/library/yql/providers/generic/provider/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/generic/provider/CMakeLists.linux-aarch64.txt index ab92daf0406b..d60ea957096b 100644 --- a/ydb/library/yql/providers/generic/provider/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/generic/provider/CMakeLists.linux-aarch64.txt @@ -26,7 +26,7 @@ target_link_libraries(providers-generic-provider PUBLIC yql-core-type_ann yql-dq-expr_nodes yql-dq-integration - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-config providers-common-db_id_async_resolver providers-common-dq @@ -44,6 +44,10 @@ target_link_libraries(providers-generic-provider PUBLIC yql-utils-plan ) target_sources(providers-generic-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_provider_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_settings.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_state.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_cluster_config.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_datasink.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_datasink_execution.cpp diff --git a/ydb/library/yql/providers/generic/provider/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/generic/provider/CMakeLists.linux-x86_64.txt index ab92daf0406b..d60ea957096b 100644 --- a/ydb/library/yql/providers/generic/provider/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/generic/provider/CMakeLists.linux-x86_64.txt @@ -26,7 +26,7 @@ target_link_libraries(providers-generic-provider PUBLIC yql-core-type_ann yql-dq-expr_nodes yql-dq-integration - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-config providers-common-db_id_async_resolver providers-common-dq @@ -44,6 +44,10 @@ target_link_libraries(providers-generic-provider PUBLIC yql-utils-plan ) target_sources(providers-generic-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_provider_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_settings.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_state.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_cluster_config.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_datasink.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_datasink_execution.cpp diff --git a/ydb/library/yql/providers/generic/provider/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/generic/provider/CMakeLists.windows-x86_64.txt index 99acc2f8d302..60e46937cee3 100644 --- a/ydb/library/yql/providers/generic/provider/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/generic/provider/CMakeLists.windows-x86_64.txt @@ -25,7 +25,7 @@ target_link_libraries(providers-generic-provider PUBLIC yql-core-type_ann yql-dq-expr_nodes yql-dq-integration - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-config providers-common-db_id_async_resolver providers-common-dq @@ -43,6 +43,10 @@ target_link_libraries(providers-generic-provider PUBLIC yql-utils-plan ) target_sources(providers-generic-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_provider_impl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_settings.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_state.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_cluster_config.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_datasink.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/yql_generic_datasink_execution.cpp diff --git a/ydb/library/yql/providers/generic/provider/ut/pushdown/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/generic/provider/ut/pushdown/CMakeLists.darwin-arm64.txt index 9f9f1f4e0687..3017d2559e31 100644 --- a/ydb/library/yql/providers/generic/provider/ut/pushdown/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/generic/provider/ut/pushdown/CMakeLists.darwin-arm64.txt @@ -31,14 +31,13 @@ target_link_libraries(yql-providers-generic-provider-ut-pushdown PUBLIC providers-result-provider udf-service-stub library-yql-sql + minikql-invoke_builtins-llvm14 yql-sql-pg_dummy ) target_link_options(yql-providers-generic-provider-ut-pushdown PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(yql-providers-generic-provider-ut-pushdown PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/ut/pushdown/pushdown_ut.cpp @@ -68,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/generic/provider/ut/pushdown/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/generic/provider/ut/pushdown/CMakeLists.darwin-x86_64.txt index e686f091c338..a89dae2c13f9 100644 --- a/ydb/library/yql/providers/generic/provider/ut/pushdown/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/generic/provider/ut/pushdown/CMakeLists.darwin-x86_64.txt @@ -32,14 +32,13 @@ target_link_libraries(yql-providers-generic-provider-ut-pushdown PUBLIC providers-result-provider udf-service-stub library-yql-sql + minikql-invoke_builtins-llvm14 yql-sql-pg_dummy ) target_link_options(yql-providers-generic-provider-ut-pushdown PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(yql-providers-generic-provider-ut-pushdown PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/ut/pushdown/pushdown_ut.cpp @@ -69,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/generic/provider/ut/pushdown/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/generic/provider/ut/pushdown/CMakeLists.linux-aarch64.txt index bc949cb41d53..988453319799 100644 --- a/ydb/library/yql/providers/generic/provider/ut/pushdown/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/generic/provider/ut/pushdown/CMakeLists.linux-aarch64.txt @@ -32,6 +32,7 @@ target_link_libraries(yql-providers-generic-provider-ut-pushdown PUBLIC providers-result-provider udf-service-stub library-yql-sql + minikql-invoke_builtins-llvm14 yql-sql-pg_dummy ) target_link_options(yql-providers-generic-provider-ut-pushdown PRIVATE @@ -40,9 +41,6 @@ target_link_options(yql-providers-generic-provider-ut-pushdown PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(yql-providers-generic-provider-ut-pushdown PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/ut/pushdown/pushdown_ut.cpp @@ -72,6 +70,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/generic/provider/ut/pushdown/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/generic/provider/ut/pushdown/CMakeLists.linux-x86_64.txt index 77fc10386fc4..04a91aba9292 100644 --- a/ydb/library/yql/providers/generic/provider/ut/pushdown/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/generic/provider/ut/pushdown/CMakeLists.linux-x86_64.txt @@ -33,6 +33,7 @@ target_link_libraries(yql-providers-generic-provider-ut-pushdown PUBLIC providers-result-provider udf-service-stub library-yql-sql + minikql-invoke_builtins-llvm14 yql-sql-pg_dummy ) target_link_options(yql-providers-generic-provider-ut-pushdown PRIVATE @@ -41,9 +42,6 @@ target_link_options(yql-providers-generic-provider-ut-pushdown PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(yql-providers-generic-provider-ut-pushdown PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/generic/provider/ut/pushdown/pushdown_ut.cpp @@ -73,6 +71,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/generic/provider/ut/pushdown/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/generic/provider/ut/pushdown/CMakeLists.windows-x86_64.txt index 4b418322c7cd..b9e55f786e42 100644 --- a/ydb/library/yql/providers/generic/provider/ut/pushdown/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/generic/provider/ut/pushdown/CMakeLists.windows-x86_64.txt @@ -32,6 +32,7 @@ target_link_libraries(yql-providers-generic-provider-ut-pushdown PUBLIC providers-result-provider udf-service-stub library-yql-sql + minikql-invoke_builtins-llvm14 yql-sql-pg_dummy ) target_sources(yql-providers-generic-provider-ut-pushdown PRIVATE @@ -62,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/pg/expr_nodes/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/pg/expr_nodes/CMakeLists.darwin-arm64.txt index 0683401494c4..ab7feea705f6 100644 --- a/ydb/library/yql/providers/pg/expr_nodes/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/pg/expr_nodes/CMakeLists.darwin-arm64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-pg-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-pg-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/pg/expr_nodes/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/pg/expr_nodes/CMakeLists.darwin-x86_64.txt index 0683401494c4..ab7feea705f6 100644 --- a/ydb/library/yql/providers/pg/expr_nodes/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/pg/expr_nodes/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-pg-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-pg-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/pg/expr_nodes/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/pg/expr_nodes/CMakeLists.linux-aarch64.txt index c693d31507e9..ae34dee0760d 100644 --- a/ydb/library/yql/providers/pg/expr_nodes/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/pg/expr_nodes/CMakeLists.linux-aarch64.txt @@ -17,6 +17,9 @@ target_link_libraries(providers-pg-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-pg-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/pg/expr_nodes/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/pg/expr_nodes/CMakeLists.linux-x86_64.txt index c693d31507e9..ae34dee0760d 100644 --- a/ydb/library/yql/providers/pg/expr_nodes/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/pg/expr_nodes/CMakeLists.linux-x86_64.txt @@ -17,6 +17,9 @@ target_link_libraries(providers-pg-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-pg-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/pg/expr_nodes/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/pg/expr_nodes/CMakeLists.windows-x86_64.txt index 0683401494c4..ab7feea705f6 100644 --- a/ydb/library/yql/providers/pg/expr_nodes/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/pg/expr_nodes/CMakeLists.windows-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-pg-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-pg-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pg/expr_nodes/yql_pg_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/pg/provider/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/pg/provider/CMakeLists.darwin-arm64.txt index 25f820f2f2c5..1ebf54e642b3 100644 --- a/ydb/library/yql/providers/pg/provider/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/pg/provider/CMakeLists.darwin-arm64.txt @@ -25,6 +25,8 @@ target_link_libraries(providers-pg-provider PUBLIC yql-utils-log ) target_sources(providers-pg-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_provider_impl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_datasink.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_datasink_execution.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_datasink_type_ann.cpp diff --git a/ydb/library/yql/providers/pg/provider/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/pg/provider/CMakeLists.darwin-x86_64.txt index 25f820f2f2c5..1ebf54e642b3 100644 --- a/ydb/library/yql/providers/pg/provider/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/pg/provider/CMakeLists.darwin-x86_64.txt @@ -25,6 +25,8 @@ target_link_libraries(providers-pg-provider PUBLIC yql-utils-log ) target_sources(providers-pg-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_provider_impl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_datasink.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_datasink_execution.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_datasink_type_ann.cpp diff --git a/ydb/library/yql/providers/pg/provider/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/pg/provider/CMakeLists.linux-aarch64.txt index 5aa8a755b9c7..6c0144dba8c8 100644 --- a/ydb/library/yql/providers/pg/provider/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/pg/provider/CMakeLists.linux-aarch64.txt @@ -26,6 +26,8 @@ target_link_libraries(providers-pg-provider PUBLIC yql-utils-log ) target_sources(providers-pg-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_provider_impl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_datasink.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_datasink_execution.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_datasink_type_ann.cpp diff --git a/ydb/library/yql/providers/pg/provider/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/pg/provider/CMakeLists.linux-x86_64.txt index 5aa8a755b9c7..6c0144dba8c8 100644 --- a/ydb/library/yql/providers/pg/provider/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/pg/provider/CMakeLists.linux-x86_64.txt @@ -26,6 +26,8 @@ target_link_libraries(providers-pg-provider PUBLIC yql-utils-log ) target_sources(providers-pg-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_provider_impl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_datasink.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_datasink_execution.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_datasink_type_ann.cpp diff --git a/ydb/library/yql/providers/pg/provider/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/pg/provider/CMakeLists.windows-x86_64.txt index 25f820f2f2c5..1ebf54e642b3 100644 --- a/ydb/library/yql/providers/pg/provider/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/pg/provider/CMakeLists.windows-x86_64.txt @@ -25,6 +25,8 @@ target_link_libraries(providers-pg-provider PUBLIC yql-utils-log ) target_sources(providers-pg-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_provider_impl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_datasink.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_datasink_execution.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pg/provider/yql_pg_datasink_type_ann.cpp diff --git a/ydb/library/yql/providers/pq/async_io/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/pq/async_io/CMakeLists.darwin-arm64.txt index 7d61f0f8b52c..537674ec231f 100644 --- a/ydb/library/yql/providers/pq/async_io/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/pq/async_io/CMakeLists.darwin-arm64.txt @@ -14,7 +14,7 @@ target_compile_options(providers-pq-async_io PRIVATE target_link_libraries(providers-pq-async_io PUBLIC contrib-libs-cxxsupp yutil - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client yql-public-types yql-utils-log diff --git a/ydb/library/yql/providers/pq/async_io/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/pq/async_io/CMakeLists.darwin-x86_64.txt index 7d61f0f8b52c..537674ec231f 100644 --- a/ydb/library/yql/providers/pq/async_io/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/pq/async_io/CMakeLists.darwin-x86_64.txt @@ -14,7 +14,7 @@ target_compile_options(providers-pq-async_io PRIVATE target_link_libraries(providers-pq-async_io PUBLIC contrib-libs-cxxsupp yutil - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client yql-public-types yql-utils-log diff --git a/ydb/library/yql/providers/pq/async_io/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/pq/async_io/CMakeLists.linux-aarch64.txt index e8c53efab853..535086092d00 100644 --- a/ydb/library/yql/providers/pq/async_io/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/pq/async_io/CMakeLists.linux-aarch64.txt @@ -15,7 +15,7 @@ target_link_libraries(providers-pq-async_io PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client yql-public-types yql-utils-log diff --git a/ydb/library/yql/providers/pq/async_io/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/pq/async_io/CMakeLists.linux-x86_64.txt index e8c53efab853..535086092d00 100644 --- a/ydb/library/yql/providers/pq/async_io/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/pq/async_io/CMakeLists.linux-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(providers-pq-async_io PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client yql-public-types yql-utils-log diff --git a/ydb/library/yql/providers/pq/async_io/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/pq/async_io/CMakeLists.windows-x86_64.txt index 7d61f0f8b52c..537674ec231f 100644 --- a/ydb/library/yql/providers/pq/async_io/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/pq/async_io/CMakeLists.windows-x86_64.txt @@ -14,7 +14,7 @@ target_compile_options(providers-pq-async_io PRIVATE target_link_libraries(providers-pq-async_io PUBLIC contrib-libs-cxxsupp yutil - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client yql-public-types yql-utils-log diff --git a/ydb/library/yql/providers/pq/expr_nodes/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/pq/expr_nodes/CMakeLists.darwin-arm64.txt index 7be05df4a359..94d00772a8fb 100644 --- a/ydb/library/yql/providers/pq/expr_nodes/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/pq/expr_nodes/CMakeLists.darwin-arm64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-pq-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-pq-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/pq/expr_nodes/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/pq/expr_nodes/CMakeLists.darwin-x86_64.txt index 7be05df4a359..94d00772a8fb 100644 --- a/ydb/library/yql/providers/pq/expr_nodes/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/pq/expr_nodes/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-pq-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-pq-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/pq/expr_nodes/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/pq/expr_nodes/CMakeLists.linux-aarch64.txt index 3c61e41263a7..680d709ed191 100644 --- a/ydb/library/yql/providers/pq/expr_nodes/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/pq/expr_nodes/CMakeLists.linux-aarch64.txt @@ -17,6 +17,9 @@ target_link_libraries(providers-pq-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-pq-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/pq/expr_nodes/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/pq/expr_nodes/CMakeLists.linux-x86_64.txt index 3c61e41263a7..680d709ed191 100644 --- a/ydb/library/yql/providers/pq/expr_nodes/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/pq/expr_nodes/CMakeLists.linux-x86_64.txt @@ -17,6 +17,9 @@ target_link_libraries(providers-pq-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-pq-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/pq/expr_nodes/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/pq/expr_nodes/CMakeLists.windows-x86_64.txt index 7be05df4a359..94d00772a8fb 100644 --- a/ydb/library/yql/providers/pq/expr_nodes/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/pq/expr_nodes/CMakeLists.windows-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-pq-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-pq-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/expr_nodes/yql_pq_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/pq/proto/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/pq/proto/CMakeLists.darwin-arm64.txt index 0ecfcba40b3f..b5ce922d961b 100644 --- a/ydb/library/yql/providers/pq/proto/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/pq/proto/CMakeLists.darwin-arm64.txt @@ -54,6 +54,11 @@ target_proto_messages(providers-pq-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pq/proto/dq_io_state.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pq/proto/dq_task_params.proto ) +target_sources(providers-pq-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/proto/dq_io.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/proto/dq_io_state.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/proto/dq_task_params.pb.h +) target_proto_addincls(providers-pq-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/pq/proto/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/pq/proto/CMakeLists.darwin-x86_64.txt index 0ecfcba40b3f..b5ce922d961b 100644 --- a/ydb/library/yql/providers/pq/proto/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/pq/proto/CMakeLists.darwin-x86_64.txt @@ -54,6 +54,11 @@ target_proto_messages(providers-pq-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pq/proto/dq_io_state.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pq/proto/dq_task_params.proto ) +target_sources(providers-pq-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/proto/dq_io.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/proto/dq_io_state.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/proto/dq_task_params.pb.h +) target_proto_addincls(providers-pq-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/pq/proto/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/pq/proto/CMakeLists.linux-aarch64.txt index 146b3d1aa814..42ad63a76ab8 100644 --- a/ydb/library/yql/providers/pq/proto/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/pq/proto/CMakeLists.linux-aarch64.txt @@ -55,6 +55,11 @@ target_proto_messages(providers-pq-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pq/proto/dq_io_state.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pq/proto/dq_task_params.proto ) +target_sources(providers-pq-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/proto/dq_io.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/proto/dq_io_state.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/proto/dq_task_params.pb.h +) target_proto_addincls(providers-pq-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/pq/proto/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/pq/proto/CMakeLists.linux-x86_64.txt index 146b3d1aa814..42ad63a76ab8 100644 --- a/ydb/library/yql/providers/pq/proto/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/pq/proto/CMakeLists.linux-x86_64.txt @@ -55,6 +55,11 @@ target_proto_messages(providers-pq-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pq/proto/dq_io_state.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pq/proto/dq_task_params.proto ) +target_sources(providers-pq-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/proto/dq_io.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/proto/dq_io_state.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/proto/dq_task_params.pb.h +) target_proto_addincls(providers-pq-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/pq/proto/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/pq/proto/CMakeLists.windows-x86_64.txt index 0ecfcba40b3f..b5ce922d961b 100644 --- a/ydb/library/yql/providers/pq/proto/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/pq/proto/CMakeLists.windows-x86_64.txt @@ -54,6 +54,11 @@ target_proto_messages(providers-pq-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pq/proto/dq_io_state.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/pq/proto/dq_task_params.proto ) +target_sources(providers-pq-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/proto/dq_io.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/proto/dq_io_state.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/pq/proto/dq_task_params.pb.h +) target_proto_addincls(providers-pq-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/pq/provider/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/pq/provider/CMakeLists.darwin-arm64.txt index ac95caed16f9..50750bfbc39e 100644 --- a/ydb/library/yql/providers/pq/provider/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/pq/provider/CMakeLists.darwin-arm64.txt @@ -17,7 +17,7 @@ target_link_libraries(providers-pq-provider PUBLIC library-cpp-random_provider library-cpp-time_provider library-yql-ast - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-db_id_async_resolver providers-common-structured_token yql-public-udf diff --git a/ydb/library/yql/providers/pq/provider/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/pq/provider/CMakeLists.darwin-x86_64.txt index ac95caed16f9..50750bfbc39e 100644 --- a/ydb/library/yql/providers/pq/provider/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/pq/provider/CMakeLists.darwin-x86_64.txt @@ -17,7 +17,7 @@ target_link_libraries(providers-pq-provider PUBLIC library-cpp-random_provider library-cpp-time_provider library-yql-ast - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-db_id_async_resolver providers-common-structured_token yql-public-udf diff --git a/ydb/library/yql/providers/pq/provider/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/pq/provider/CMakeLists.linux-aarch64.txt index c968919088dc..8415b2d0838e 100644 --- a/ydb/library/yql/providers/pq/provider/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/pq/provider/CMakeLists.linux-aarch64.txt @@ -18,7 +18,7 @@ target_link_libraries(providers-pq-provider PUBLIC library-cpp-random_provider library-cpp-time_provider library-yql-ast - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-db_id_async_resolver providers-common-structured_token yql-public-udf diff --git a/ydb/library/yql/providers/pq/provider/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/pq/provider/CMakeLists.linux-x86_64.txt index c968919088dc..8415b2d0838e 100644 --- a/ydb/library/yql/providers/pq/provider/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/pq/provider/CMakeLists.linux-x86_64.txt @@ -18,7 +18,7 @@ target_link_libraries(providers-pq-provider PUBLIC library-cpp-random_provider library-cpp-time_provider library-yql-ast - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-db_id_async_resolver providers-common-structured_token yql-public-udf diff --git a/ydb/library/yql/providers/pq/provider/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/pq/provider/CMakeLists.windows-x86_64.txt index ac95caed16f9..50750bfbc39e 100644 --- a/ydb/library/yql/providers/pq/provider/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/pq/provider/CMakeLists.windows-x86_64.txt @@ -17,7 +17,7 @@ target_link_libraries(providers-pq-provider PUBLIC library-cpp-random_provider library-cpp-time_provider library-yql-ast - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-db_id_async_resolver providers-common-structured_token yql-public-udf diff --git a/ydb/library/yql/providers/result/expr_nodes/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/result/expr_nodes/CMakeLists.darwin-arm64.txt index ea7eea1b5c81..cd8e2bc5b4ae 100644 --- a/ydb/library/yql/providers/result/expr_nodes/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/result/expr_nodes/CMakeLists.darwin-arm64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-result-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-result-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/result/expr_nodes/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/result/expr_nodes/CMakeLists.darwin-x86_64.txt index ea7eea1b5c81..cd8e2bc5b4ae 100644 --- a/ydb/library/yql/providers/result/expr_nodes/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/result/expr_nodes/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-result-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-result-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/result/expr_nodes/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/result/expr_nodes/CMakeLists.linux-aarch64.txt index 9f87a9aa6237..1145be584a96 100644 --- a/ydb/library/yql/providers/result/expr_nodes/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/result/expr_nodes/CMakeLists.linux-aarch64.txt @@ -17,6 +17,9 @@ target_link_libraries(providers-result-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-result-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/result/expr_nodes/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/result/expr_nodes/CMakeLists.linux-x86_64.txt index 9f87a9aa6237..1145be584a96 100644 --- a/ydb/library/yql/providers/result/expr_nodes/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/result/expr_nodes/CMakeLists.linux-x86_64.txt @@ -17,6 +17,9 @@ target_link_libraries(providers-result-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-result-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/result/expr_nodes/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/result/expr_nodes/CMakeLists.windows-x86_64.txt index ea7eea1b5c81..cd8e2bc5b4ae 100644 --- a/ydb/library/yql/providers/result/expr_nodes/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/result/expr_nodes/CMakeLists.windows-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-result-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-result-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/result/expr_nodes/yql_res_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/result/provider/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/result/provider/CMakeLists.darwin-arm64.txt index 4fd2b545afcd..9e33a42c9091 100644 --- a/ydb/library/yql/providers/result/provider/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/result/provider/CMakeLists.darwin-arm64.txt @@ -25,5 +25,6 @@ target_link_libraries(providers-result-provider PUBLIC providers-result-expr_nodes ) target_sources(providers-result-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/result/provider/yql_result_provider.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/result/provider/yql_result_provider.cpp ) diff --git a/ydb/library/yql/providers/result/provider/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/result/provider/CMakeLists.darwin-x86_64.txt index 4fd2b545afcd..9e33a42c9091 100644 --- a/ydb/library/yql/providers/result/provider/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/result/provider/CMakeLists.darwin-x86_64.txt @@ -25,5 +25,6 @@ target_link_libraries(providers-result-provider PUBLIC providers-result-expr_nodes ) target_sources(providers-result-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/result/provider/yql_result_provider.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/result/provider/yql_result_provider.cpp ) diff --git a/ydb/library/yql/providers/result/provider/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/result/provider/CMakeLists.linux-aarch64.txt index 03a6a5058bf5..c246064a8ad4 100644 --- a/ydb/library/yql/providers/result/provider/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/result/provider/CMakeLists.linux-aarch64.txt @@ -26,5 +26,6 @@ target_link_libraries(providers-result-provider PUBLIC providers-result-expr_nodes ) target_sources(providers-result-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/result/provider/yql_result_provider.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/result/provider/yql_result_provider.cpp ) diff --git a/ydb/library/yql/providers/result/provider/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/result/provider/CMakeLists.linux-x86_64.txt index 03a6a5058bf5..c246064a8ad4 100644 --- a/ydb/library/yql/providers/result/provider/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/result/provider/CMakeLists.linux-x86_64.txt @@ -26,5 +26,6 @@ target_link_libraries(providers-result-provider PUBLIC providers-result-expr_nodes ) target_sources(providers-result-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/result/provider/yql_result_provider.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/result/provider/yql_result_provider.cpp ) diff --git a/ydb/library/yql/providers/result/provider/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/result/provider/CMakeLists.windows-x86_64.txt index 4fd2b545afcd..9e33a42c9091 100644 --- a/ydb/library/yql/providers/result/provider/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/result/provider/CMakeLists.windows-x86_64.txt @@ -25,5 +25,6 @@ target_link_libraries(providers-result-provider PUBLIC providers-result-expr_nodes ) target_sources(providers-result-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/result/provider/yql_result_provider.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/result/provider/yql_result_provider.cpp ) diff --git a/ydb/library/yql/providers/s3/actors/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/s3/actors/CMakeLists.darwin-arm64.txt index 11a03525ea31..47fc2f842bb2 100644 --- a/ydb/library/yql/providers/s3/actors/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/s3/actors/CMakeLists.darwin-arm64.txt @@ -29,7 +29,7 @@ target_link_libraries(providers-s3-actors PUBLIC cpp-xml-document fq-libs-events dq-actors-compute - minikql-computation-llvm + yql-minikql-computation providers-common-arrow common-arrow-interface providers-common-http_gateway @@ -51,5 +51,6 @@ target_sources(providers-s3-actors PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/actors/yql_s3_sink_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/actors/yql_s3_source_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/actors/yql_s3_write_actor.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/actors/yql_arrow_column_converters.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/actors/yql_s3_read_actor.cpp ) diff --git a/ydb/library/yql/providers/s3/actors/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/s3/actors/CMakeLists.darwin-x86_64.txt index 11a03525ea31..47fc2f842bb2 100644 --- a/ydb/library/yql/providers/s3/actors/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/s3/actors/CMakeLists.darwin-x86_64.txt @@ -29,7 +29,7 @@ target_link_libraries(providers-s3-actors PUBLIC cpp-xml-document fq-libs-events dq-actors-compute - minikql-computation-llvm + yql-minikql-computation providers-common-arrow common-arrow-interface providers-common-http_gateway @@ -51,5 +51,6 @@ target_sources(providers-s3-actors PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/actors/yql_s3_sink_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/actors/yql_s3_source_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/actors/yql_s3_write_actor.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/actors/yql_arrow_column_converters.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/actors/yql_s3_read_actor.cpp ) diff --git a/ydb/library/yql/providers/s3/actors/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/s3/actors/CMakeLists.linux-aarch64.txt index 68caf1f56d3f..b418b065ff72 100644 --- a/ydb/library/yql/providers/s3/actors/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/s3/actors/CMakeLists.linux-aarch64.txt @@ -30,7 +30,7 @@ target_link_libraries(providers-s3-actors PUBLIC cpp-xml-document fq-libs-events dq-actors-compute - minikql-computation-llvm + yql-minikql-computation providers-common-arrow common-arrow-interface providers-common-http_gateway @@ -52,5 +52,6 @@ target_sources(providers-s3-actors PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/actors/yql_s3_sink_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/actors/yql_s3_source_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/actors/yql_s3_write_actor.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/actors/yql_arrow_column_converters.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/actors/yql_s3_read_actor.cpp ) diff --git a/ydb/library/yql/providers/s3/actors/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/s3/actors/CMakeLists.linux-x86_64.txt index 68caf1f56d3f..b418b065ff72 100644 --- a/ydb/library/yql/providers/s3/actors/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/s3/actors/CMakeLists.linux-x86_64.txt @@ -30,7 +30,7 @@ target_link_libraries(providers-s3-actors PUBLIC cpp-xml-document fq-libs-events dq-actors-compute - minikql-computation-llvm + yql-minikql-computation providers-common-arrow common-arrow-interface providers-common-http_gateway @@ -52,5 +52,6 @@ target_sources(providers-s3-actors PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/actors/yql_s3_sink_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/actors/yql_s3_source_factory.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/actors/yql_s3_write_actor.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/actors/yql_arrow_column_converters.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/actors/yql_s3_read_actor.cpp ) diff --git a/ydb/library/yql/providers/s3/actors/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/s3/actors/CMakeLists.windows-x86_64.txt index 4937183580db..fd4150dc0e84 100644 --- a/ydb/library/yql/providers/s3/actors/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/s3/actors/CMakeLists.windows-x86_64.txt @@ -27,7 +27,7 @@ target_link_libraries(providers-s3-actors PUBLIC cpp-xml-document fq-libs-events dq-actors-compute - minikql-computation-llvm + yql-minikql-computation providers-common-arrow common-arrow-interface providers-common-http_gateway diff --git a/ydb/library/yql/providers/s3/credentials/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/s3/credentials/ut/CMakeLists.darwin-arm64.txt index 5b22c6092159..6c2aff507ff5 100644 --- a/ydb/library/yql/providers/s3/credentials/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/s3/credentials/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-library-yql-providers-s3-credentials-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-s3-credentials-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/credentials/credentials_ut.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/credentials/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/s3/credentials/ut/CMakeLists.darwin-x86_64.txt index 2191586958af..16fa3804c315 100644 --- a/ydb/library/yql/providers/s3/credentials/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/s3/credentials/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-library-yql-providers-s3-credentials-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-s3-credentials-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/credentials/credentials_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/credentials/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/s3/credentials/ut/CMakeLists.linux-aarch64.txt index 33b5e239449a..8d88c922f463 100644 --- a/ydb/library/yql/providers/s3/credentials/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/s3/credentials/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-yql-providers-s3-credentials-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-s3-credentials-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/credentials/credentials_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/credentials/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/s3/credentials/ut/CMakeLists.linux-x86_64.txt index 4502d9a24a10..aa2ec90e8415 100644 --- a/ydb/library/yql/providers/s3/credentials/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/s3/credentials/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-yql-providers-s3-credentials-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-s3-credentials-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/credentials/credentials_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/credentials/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/s3/credentials/ut/CMakeLists.windows-x86_64.txt index 8aa38546d61e..06384fd52c32 100644 --- a/ydb/library/yql/providers/s3/credentials/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/s3/credentials/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/expr_nodes/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/s3/expr_nodes/CMakeLists.darwin-arm64.txt index b710ed0a9f2d..6914cfb40f65 100644 --- a/ydb/library/yql/providers/s3/expr_nodes/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/s3/expr_nodes/CMakeLists.darwin-arm64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-s3-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-s3-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/s3/expr_nodes/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/s3/expr_nodes/CMakeLists.darwin-x86_64.txt index b710ed0a9f2d..6914cfb40f65 100644 --- a/ydb/library/yql/providers/s3/expr_nodes/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/s3/expr_nodes/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-s3-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-s3-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/s3/expr_nodes/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/s3/expr_nodes/CMakeLists.linux-aarch64.txt index 57cfefbe9d85..8d5a32372bbb 100644 --- a/ydb/library/yql/providers/s3/expr_nodes/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/s3/expr_nodes/CMakeLists.linux-aarch64.txt @@ -17,6 +17,9 @@ target_link_libraries(providers-s3-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-s3-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/s3/expr_nodes/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/s3/expr_nodes/CMakeLists.linux-x86_64.txt index 57cfefbe9d85..8d5a32372bbb 100644 --- a/ydb/library/yql/providers/s3/expr_nodes/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/s3/expr_nodes/CMakeLists.linux-x86_64.txt @@ -17,6 +17,9 @@ target_link_libraries(providers-s3-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-s3-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/s3/expr_nodes/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/s3/expr_nodes/CMakeLists.windows-x86_64.txt index b710ed0a9f2d..6914cfb40f65 100644 --- a/ydb/library/yql/providers/s3/expr_nodes/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/s3/expr_nodes/CMakeLists.windows-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-s3-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-s3-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/expr_nodes/yql_s3_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/s3/object_listers/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/s3/object_listers/ut/CMakeLists.darwin-arm64.txt index 05da0564a316..1aea52a5954a 100644 --- a/ydb/library/yql/providers/s3/object_listers/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/s3/object_listers/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-library-yql-providers-s3-object_listers-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-s3-object_listers-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/object_listers/yql_s3_path_ut.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/object_listers/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/s3/object_listers/ut/CMakeLists.darwin-x86_64.txt index 8cb595c1e1c7..edae5d1e30e6 100644 --- a/ydb/library/yql/providers/s3/object_listers/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/s3/object_listers/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-library-yql-providers-s3-object_listers-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-s3-object_listers-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/object_listers/yql_s3_path_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/object_listers/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/s3/object_listers/ut/CMakeLists.linux-aarch64.txt index 401b4507243d..edc7c5e8ddb6 100644 --- a/ydb/library/yql/providers/s3/object_listers/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/s3/object_listers/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-yql-providers-s3-object_listers-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-s3-object_listers-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/object_listers/yql_s3_path_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/object_listers/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/s3/object_listers/ut/CMakeLists.linux-x86_64.txt index cbb021028bac..216d64efb45a 100644 --- a/ydb/library/yql/providers/s3/object_listers/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/s3/object_listers/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-yql-providers-s3-object_listers-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-s3-object_listers-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/object_listers/yql_s3_path_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/object_listers/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/s3/object_listers/ut/CMakeLists.windows-x86_64.txt index eeeb92a6ea2d..7710cb947660 100644 --- a/ydb/library/yql/providers/s3/object_listers/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/s3/object_listers/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/path_generator/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/s3/path_generator/ut/CMakeLists.darwin-arm64.txt index 2a0d5457a042..008c9618811d 100644 --- a/ydb/library/yql/providers/s3/path_generator/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/s3/path_generator/ut/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-library-yql-providers-s3-path_generator-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-s3-path_generator-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/path_generator/ut/yql_generate_partitioning_rules_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/path_generator/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/s3/path_generator/ut/CMakeLists.darwin-x86_64.txt index 682675fc60ec..55c747367552 100644 --- a/ydb/library/yql/providers/s3/path_generator/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/s3/path_generator/ut/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-library-yql-providers-s3-path_generator-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-s3-path_generator-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/path_generator/ut/yql_generate_partitioning_rules_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/path_generator/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/s3/path_generator/ut/CMakeLists.linux-aarch64.txt index b483edc6a9ae..6cf40a74b8f7 100644 --- a/ydb/library/yql/providers/s3/path_generator/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/s3/path_generator/ut/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-library-yql-providers-s3-path_generator-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-s3-path_generator-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/path_generator/ut/yql_generate_partitioning_rules_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/path_generator/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/s3/path_generator/ut/CMakeLists.linux-x86_64.txt index 91608acb7e20..74053756b3a5 100644 --- a/ydb/library/yql/providers/s3/path_generator/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/s3/path_generator/ut/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-library-yql-providers-s3-path_generator-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-s3-path_generator-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/path_generator/ut/yql_generate_partitioning_rules_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/proto/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/s3/proto/CMakeLists.darwin-arm64.txt index 4fbbfdc929b2..fb98e52c7bbd 100644 --- a/ydb/library/yql/providers/s3/proto/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/s3/proto/CMakeLists.darwin-arm64.txt @@ -80,6 +80,13 @@ target_proto_messages(providers-s3-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/proto/sink.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/proto/source.proto ) +target_sources(providers-s3-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/credentials.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/range.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/retry_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/sink.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/source.pb.h +) target_proto_addincls(providers-s3-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/s3/proto/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/s3/proto/CMakeLists.darwin-x86_64.txt index 4fbbfdc929b2..fb98e52c7bbd 100644 --- a/ydb/library/yql/providers/s3/proto/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/s3/proto/CMakeLists.darwin-x86_64.txt @@ -80,6 +80,13 @@ target_proto_messages(providers-s3-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/proto/sink.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/proto/source.proto ) +target_sources(providers-s3-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/credentials.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/range.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/retry_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/sink.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/source.pb.h +) target_proto_addincls(providers-s3-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/s3/proto/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/s3/proto/CMakeLists.linux-aarch64.txt index 40ffa2724b35..8dd03e2acdfb 100644 --- a/ydb/library/yql/providers/s3/proto/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/s3/proto/CMakeLists.linux-aarch64.txt @@ -81,6 +81,13 @@ target_proto_messages(providers-s3-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/proto/sink.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/proto/source.proto ) +target_sources(providers-s3-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/credentials.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/range.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/retry_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/sink.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/source.pb.h +) target_proto_addincls(providers-s3-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/s3/proto/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/s3/proto/CMakeLists.linux-x86_64.txt index 40ffa2724b35..8dd03e2acdfb 100644 --- a/ydb/library/yql/providers/s3/proto/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/s3/proto/CMakeLists.linux-x86_64.txt @@ -81,6 +81,13 @@ target_proto_messages(providers-s3-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/proto/sink.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/proto/source.proto ) +target_sources(providers-s3-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/credentials.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/range.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/retry_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/sink.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/source.pb.h +) target_proto_addincls(providers-s3-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/s3/proto/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/s3/proto/CMakeLists.windows-x86_64.txt index 4fbbfdc929b2..fb98e52c7bbd 100644 --- a/ydb/library/yql/providers/s3/proto/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/s3/proto/CMakeLists.windows-x86_64.txt @@ -80,6 +80,13 @@ target_proto_messages(providers-s3-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/proto/sink.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/proto/source.proto ) +target_sources(providers-s3-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/credentials.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/range.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/retry_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/sink.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/s3/proto/source.pb.h +) target_proto_addincls(providers-s3-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/s3/provider/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/s3/provider/CMakeLists.darwin-arm64.txt index 4888c34be029..84f7615afeb6 100644 --- a/ydb/library/yql/providers/s3/provider/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/s3/provider/CMakeLists.darwin-arm64.txt @@ -27,7 +27,7 @@ target_link_libraries(providers-s3-provider PUBLIC yql-core-type_ann yql-dq-expr_nodes yql-dq-integration - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-config providers-common-dq providers-common-http_gateway diff --git a/ydb/library/yql/providers/s3/provider/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/s3/provider/CMakeLists.darwin-x86_64.txt index 4888c34be029..84f7615afeb6 100644 --- a/ydb/library/yql/providers/s3/provider/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/s3/provider/CMakeLists.darwin-x86_64.txt @@ -27,7 +27,7 @@ target_link_libraries(providers-s3-provider PUBLIC yql-core-type_ann yql-dq-expr_nodes yql-dq-integration - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-config providers-common-dq providers-common-http_gateway diff --git a/ydb/library/yql/providers/s3/provider/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/s3/provider/CMakeLists.linux-aarch64.txt index b28d320cdbe9..b42e7ef963cc 100644 --- a/ydb/library/yql/providers/s3/provider/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/s3/provider/CMakeLists.linux-aarch64.txt @@ -28,7 +28,7 @@ target_link_libraries(providers-s3-provider PUBLIC yql-core-type_ann yql-dq-expr_nodes yql-dq-integration - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-config providers-common-dq providers-common-http_gateway diff --git a/ydb/library/yql/providers/s3/provider/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/s3/provider/CMakeLists.linux-x86_64.txt index b28d320cdbe9..b42e7ef963cc 100644 --- a/ydb/library/yql/providers/s3/provider/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/s3/provider/CMakeLists.linux-x86_64.txt @@ -28,7 +28,7 @@ target_link_libraries(providers-s3-provider PUBLIC yql-core-type_ann yql-dq-expr_nodes yql-dq-integration - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-config providers-common-dq providers-common-http_gateway diff --git a/ydb/library/yql/providers/s3/provider/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/s3/provider/CMakeLists.windows-x86_64.txt index 4888c34be029..84f7615afeb6 100644 --- a/ydb/library/yql/providers/s3/provider/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/s3/provider/CMakeLists.windows-x86_64.txt @@ -27,7 +27,7 @@ target_link_libraries(providers-s3-provider PUBLIC yql-core-type_ann yql-dq-expr_nodes yql-dq-integration - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-config providers-common-dq providers-common-http_gateway diff --git a/ydb/library/yql/providers/s3/provider/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/s3/provider/ut/CMakeLists.darwin-arm64.txt index a9ace22c0182..1b2a56dbfbd3 100644 --- a/ydb/library/yql/providers/s3/provider/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/s3/provider/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-library-yql-providers-s3-provider-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-s3-provider-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/provider/yql_s3_listing_strategy_ut.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/provider/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/s3/provider/ut/CMakeLists.darwin-x86_64.txt index f6dfc6f3cddc..06812b9aca41 100644 --- a/ydb/library/yql/providers/s3/provider/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/s3/provider/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-library-yql-providers-s3-provider-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-s3-provider-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/provider/yql_s3_listing_strategy_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/provider/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/s3/provider/ut/CMakeLists.linux-aarch64.txt index 9e66dbc5458f..5fcf0554c8b2 100644 --- a/ydb/library/yql/providers/s3/provider/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/s3/provider/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-yql-providers-s3-provider-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-s3-provider-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/provider/yql_s3_listing_strategy_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/provider/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/s3/provider/ut/CMakeLists.linux-x86_64.txt index f9e9c70c2a74..38cf5db8cfb8 100644 --- a/ydb/library/yql/providers/s3/provider/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/s3/provider/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-yql-providers-s3-provider-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-s3-provider-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/provider/yql_s3_listing_strategy_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/provider/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/s3/provider/ut/CMakeLists.windows-x86_64.txt index 47804df20123..c54f14a50340 100644 --- a/ydb/library/yql/providers/s3/provider/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/s3/provider/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/range_helpers/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/s3/range_helpers/ut/CMakeLists.darwin-arm64.txt index a9182d67a9b3..7519f9bc848b 100644 --- a/ydb/library/yql/providers/s3/range_helpers/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/s3/range_helpers/ut/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-library-yql-providers-s3-range_helpers-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-s3-range_helpers-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/range_helpers/file_tree_builder_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/range_helpers/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/s3/range_helpers/ut/CMakeLists.darwin-x86_64.txt index 99f029dfd863..a7f0be2dfdb0 100644 --- a/ydb/library/yql/providers/s3/range_helpers/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/s3/range_helpers/ut/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-library-yql-providers-s3-range_helpers-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-s3-range_helpers-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/range_helpers/file_tree_builder_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/range_helpers/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/s3/range_helpers/ut/CMakeLists.linux-aarch64.txt index 9fdc25968df0..d3ae9c3300f4 100644 --- a/ydb/library/yql/providers/s3/range_helpers/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/s3/range_helpers/ut/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-library-yql-providers-s3-range_helpers-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-s3-range_helpers-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/range_helpers/file_tree_builder_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/range_helpers/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/s3/range_helpers/ut/CMakeLists.linux-x86_64.txt index 7c0b217f6655..6a972bf7ba8d 100644 --- a/ydb/library/yql/providers/s3/range_helpers/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/s3/range_helpers/ut/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-library-yql-providers-s3-range_helpers-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-s3-range_helpers-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/s3/range_helpers/file_tree_builder_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/s3/range_helpers/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/s3/range_helpers/ut/CMakeLists.windows-x86_64.txt index 826e5390f235..b99cb7d82308 100644 --- a/ydb/library/yql/providers/s3/range_helpers/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/s3/range_helpers/ut/CMakeLists.windows-x86_64.txt @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/solomon/async_io/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/solomon/async_io/CMakeLists.darwin-arm64.txt index 3150d2b9f0cc..57efac1991ed 100644 --- a/ydb/library/yql/providers/solomon/async_io/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/solomon/async_io/CMakeLists.darwin-arm64.txt @@ -16,7 +16,7 @@ target_link_libraries(providers-solomon-async_io PUBLIC yutil cpp-json-easy_parse monlib-encode-json - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client yql-public-types yql-public-udf diff --git a/ydb/library/yql/providers/solomon/async_io/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/solomon/async_io/CMakeLists.darwin-x86_64.txt index 3150d2b9f0cc..57efac1991ed 100644 --- a/ydb/library/yql/providers/solomon/async_io/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/solomon/async_io/CMakeLists.darwin-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(providers-solomon-async_io PUBLIC yutil cpp-json-easy_parse monlib-encode-json - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client yql-public-types yql-public-udf diff --git a/ydb/library/yql/providers/solomon/async_io/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/solomon/async_io/CMakeLists.linux-aarch64.txt index 46d7ce34d585..1b57f1fce307 100644 --- a/ydb/library/yql/providers/solomon/async_io/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/solomon/async_io/CMakeLists.linux-aarch64.txt @@ -17,7 +17,7 @@ target_link_libraries(providers-solomon-async_io PUBLIC yutil cpp-json-easy_parse monlib-encode-json - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client yql-public-types yql-public-udf diff --git a/ydb/library/yql/providers/solomon/async_io/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/solomon/async_io/CMakeLists.linux-x86_64.txt index 46d7ce34d585..1b57f1fce307 100644 --- a/ydb/library/yql/providers/solomon/async_io/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/solomon/async_io/CMakeLists.linux-x86_64.txt @@ -17,7 +17,7 @@ target_link_libraries(providers-solomon-async_io PUBLIC yutil cpp-json-easy_parse monlib-encode-json - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client yql-public-types yql-public-udf diff --git a/ydb/library/yql/providers/solomon/async_io/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/solomon/async_io/CMakeLists.windows-x86_64.txt index 3150d2b9f0cc..57efac1991ed 100644 --- a/ydb/library/yql/providers/solomon/async_io/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/solomon/async_io/CMakeLists.windows-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(providers-solomon-async_io PUBLIC yutil cpp-json-easy_parse monlib-encode-json - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client yql-public-types yql-public-udf diff --git a/ydb/library/yql/providers/solomon/expr_nodes/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/solomon/expr_nodes/CMakeLists.darwin-arm64.txt index 540c22ed8f82..843d97ccac90 100644 --- a/ydb/library/yql/providers/solomon/expr_nodes/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/solomon/expr_nodes/CMakeLists.darwin-arm64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-solomon-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-solomon-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/solomon/expr_nodes/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/solomon/expr_nodes/CMakeLists.darwin-x86_64.txt index 540c22ed8f82..843d97ccac90 100644 --- a/ydb/library/yql/providers/solomon/expr_nodes/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/solomon/expr_nodes/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-solomon-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-solomon-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/solomon/expr_nodes/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/solomon/expr_nodes/CMakeLists.linux-aarch64.txt index a3797cbf522c..8bec357bd607 100644 --- a/ydb/library/yql/providers/solomon/expr_nodes/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/solomon/expr_nodes/CMakeLists.linux-aarch64.txt @@ -17,6 +17,9 @@ target_link_libraries(providers-solomon-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-solomon-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/solomon/expr_nodes/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/solomon/expr_nodes/CMakeLists.linux-x86_64.txt index a3797cbf522c..8bec357bd607 100644 --- a/ydb/library/yql/providers/solomon/expr_nodes/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/solomon/expr_nodes/CMakeLists.linux-x86_64.txt @@ -17,6 +17,9 @@ target_link_libraries(providers-solomon-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-solomon-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/solomon/expr_nodes/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/solomon/expr_nodes/CMakeLists.windows-x86_64.txt index 540c22ed8f82..843d97ccac90 100644 --- a/ydb/library/yql/providers/solomon/expr_nodes/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/solomon/expr_nodes/CMakeLists.windows-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-solomon-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-solomon-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/expr_nodes/yql_solomon_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/solomon/proto/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/solomon/proto/CMakeLists.darwin-arm64.txt index b5ca6a669d3a..47a8767abc75 100644 --- a/ydb/library/yql/providers/solomon/proto/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/solomon/proto/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(providers-solomon-proto PUBLIC target_proto_messages(providers-solomon-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/solomon/proto/dq_solomon_shard.proto ) +target_sources(providers-solomon-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/proto/dq_solomon_shard.pb.h +) target_proto_addincls(providers-solomon-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/solomon/proto/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/solomon/proto/CMakeLists.darwin-x86_64.txt index b5ca6a669d3a..47a8767abc75 100644 --- a/ydb/library/yql/providers/solomon/proto/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/solomon/proto/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(providers-solomon-proto PUBLIC target_proto_messages(providers-solomon-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/solomon/proto/dq_solomon_shard.proto ) +target_sources(providers-solomon-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/proto/dq_solomon_shard.pb.h +) target_proto_addincls(providers-solomon-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/solomon/proto/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/solomon/proto/CMakeLists.linux-aarch64.txt index 3b4b86fc9b8b..ffd61fd69910 100644 --- a/ydb/library/yql/providers/solomon/proto/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/solomon/proto/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(providers-solomon-proto PUBLIC target_proto_messages(providers-solomon-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/solomon/proto/dq_solomon_shard.proto ) +target_sources(providers-solomon-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/proto/dq_solomon_shard.pb.h +) target_proto_addincls(providers-solomon-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/solomon/proto/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/solomon/proto/CMakeLists.linux-x86_64.txt index 3b4b86fc9b8b..ffd61fd69910 100644 --- a/ydb/library/yql/providers/solomon/proto/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/solomon/proto/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(providers-solomon-proto PUBLIC target_proto_messages(providers-solomon-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/solomon/proto/dq_solomon_shard.proto ) +target_sources(providers-solomon-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/proto/dq_solomon_shard.pb.h +) target_proto_addincls(providers-solomon-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/solomon/proto/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/solomon/proto/CMakeLists.windows-x86_64.txt index b5ca6a669d3a..47a8767abc75 100644 --- a/ydb/library/yql/providers/solomon/proto/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/solomon/proto/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(providers-solomon-proto PUBLIC target_proto_messages(providers-solomon-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/solomon/proto/dq_solomon_shard.proto ) +target_sources(providers-solomon-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/solomon/proto/dq_solomon_shard.pb.h +) target_proto_addincls(providers-solomon-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/stat/expr_nodes/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/stat/expr_nodes/CMakeLists.darwin-arm64.txt index ecd82e499caf..da1b55044d26 100644 --- a/ydb/library/yql/providers/stat/expr_nodes/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/stat/expr_nodes/CMakeLists.darwin-arm64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-stat-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-stat-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/stat/expr_nodes/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/stat/expr_nodes/CMakeLists.darwin-x86_64.txt index ecd82e499caf..da1b55044d26 100644 --- a/ydb/library/yql/providers/stat/expr_nodes/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/stat/expr_nodes/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-stat-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-stat-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/stat/expr_nodes/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/stat/expr_nodes/CMakeLists.linux-aarch64.txt index 062f55f7cc2d..868e39639272 100644 --- a/ydb/library/yql/providers/stat/expr_nodes/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/stat/expr_nodes/CMakeLists.linux-aarch64.txt @@ -17,6 +17,9 @@ target_link_libraries(providers-stat-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-stat-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/stat/expr_nodes/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/stat/expr_nodes/CMakeLists.linux-x86_64.txt index 062f55f7cc2d..868e39639272 100644 --- a/ydb/library/yql/providers/stat/expr_nodes/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/stat/expr_nodes/CMakeLists.linux-x86_64.txt @@ -17,6 +17,9 @@ target_link_libraries(providers-stat-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-stat-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/stat/expr_nodes/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/stat/expr_nodes/CMakeLists.windows-x86_64.txt index ecd82e499caf..da1b55044d26 100644 --- a/ydb/library/yql/providers/stat/expr_nodes/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/stat/expr_nodes/CMakeLists.windows-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-stat-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-stat-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/stat/expr_nodes/yql_stat_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/ydb/actors/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/ydb/actors/CMakeLists.darwin-arm64.txt index 765fdd735e22..99a5cab4b5ce 100644 --- a/ydb/library/yql/providers/ydb/actors/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/ydb/actors/CMakeLists.darwin-arm64.txt @@ -15,7 +15,7 @@ target_link_libraries(providers-ydb-actors PUBLIC contrib-libs-cxxsupp yutil ydb-core-scheme - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client yql-public-types yql-utils-log diff --git a/ydb/library/yql/providers/ydb/actors/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/ydb/actors/CMakeLists.darwin-x86_64.txt index 765fdd735e22..99a5cab4b5ce 100644 --- a/ydb/library/yql/providers/ydb/actors/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/ydb/actors/CMakeLists.darwin-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(providers-ydb-actors PUBLIC contrib-libs-cxxsupp yutil ydb-core-scheme - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client yql-public-types yql-utils-log diff --git a/ydb/library/yql/providers/ydb/actors/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/ydb/actors/CMakeLists.linux-aarch64.txt index 83d1b45399e3..3f650874fa1f 100644 --- a/ydb/library/yql/providers/ydb/actors/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/ydb/actors/CMakeLists.linux-aarch64.txt @@ -16,7 +16,7 @@ target_link_libraries(providers-ydb-actors PUBLIC contrib-libs-cxxsupp yutil ydb-core-scheme - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client yql-public-types yql-utils-log diff --git a/ydb/library/yql/providers/ydb/actors/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/ydb/actors/CMakeLists.linux-x86_64.txt index 83d1b45399e3..3f650874fa1f 100644 --- a/ydb/library/yql/providers/ydb/actors/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/ydb/actors/CMakeLists.linux-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(providers-ydb-actors PUBLIC contrib-libs-cxxsupp yutil ydb-core-scheme - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client yql-public-types yql-utils-log diff --git a/ydb/library/yql/providers/ydb/actors/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/ydb/actors/CMakeLists.windows-x86_64.txt index 765fdd735e22..99a5cab4b5ce 100644 --- a/ydb/library/yql/providers/ydb/actors/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/ydb/actors/CMakeLists.windows-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(providers-ydb-actors PUBLIC contrib-libs-cxxsupp yutil ydb-core-scheme - minikql-computation-llvm + yql-minikql-computation common-token_accessor-client yql-public-types yql-utils-log diff --git a/ydb/library/yql/providers/ydb/comp_nodes/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/ydb/comp_nodes/CMakeLists.darwin-arm64.txt index e867dae5a9d3..7d73d516d8d4 100644 --- a/ydb/library/yql/providers/ydb/comp_nodes/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/ydb/comp_nodes/CMakeLists.darwin-arm64.txt @@ -17,7 +17,7 @@ target_link_libraries(providers-ydb-comp_nodes PUBLIC ydb-core-scheme library-mkql_proto-protos dq-actors-protos - minikql-computation-llvm + yql-minikql-computation providers-common-structured_token providers-ydb-proto public-lib-experimental diff --git a/ydb/library/yql/providers/ydb/comp_nodes/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/ydb/comp_nodes/CMakeLists.darwin-x86_64.txt index e867dae5a9d3..7d73d516d8d4 100644 --- a/ydb/library/yql/providers/ydb/comp_nodes/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/ydb/comp_nodes/CMakeLists.darwin-x86_64.txt @@ -17,7 +17,7 @@ target_link_libraries(providers-ydb-comp_nodes PUBLIC ydb-core-scheme library-mkql_proto-protos dq-actors-protos - minikql-computation-llvm + yql-minikql-computation providers-common-structured_token providers-ydb-proto public-lib-experimental diff --git a/ydb/library/yql/providers/ydb/comp_nodes/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/ydb/comp_nodes/CMakeLists.linux-aarch64.txt index 88f19f4552f4..f6c3fce042dd 100644 --- a/ydb/library/yql/providers/ydb/comp_nodes/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/ydb/comp_nodes/CMakeLists.linux-aarch64.txt @@ -18,7 +18,7 @@ target_link_libraries(providers-ydb-comp_nodes PUBLIC ydb-core-scheme library-mkql_proto-protos dq-actors-protos - minikql-computation-llvm + yql-minikql-computation providers-common-structured_token providers-ydb-proto public-lib-experimental diff --git a/ydb/library/yql/providers/ydb/comp_nodes/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/ydb/comp_nodes/CMakeLists.linux-x86_64.txt index 88f19f4552f4..f6c3fce042dd 100644 --- a/ydb/library/yql/providers/ydb/comp_nodes/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/ydb/comp_nodes/CMakeLists.linux-x86_64.txt @@ -18,7 +18,7 @@ target_link_libraries(providers-ydb-comp_nodes PUBLIC ydb-core-scheme library-mkql_proto-protos dq-actors-protos - minikql-computation-llvm + yql-minikql-computation providers-common-structured_token providers-ydb-proto public-lib-experimental diff --git a/ydb/library/yql/providers/ydb/comp_nodes/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/ydb/comp_nodes/CMakeLists.windows-x86_64.txt index e867dae5a9d3..7d73d516d8d4 100644 --- a/ydb/library/yql/providers/ydb/comp_nodes/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/ydb/comp_nodes/CMakeLists.windows-x86_64.txt @@ -17,7 +17,7 @@ target_link_libraries(providers-ydb-comp_nodes PUBLIC ydb-core-scheme library-mkql_proto-protos dq-actors-protos - minikql-computation-llvm + yql-minikql-computation providers-common-structured_token providers-ydb-proto public-lib-experimental diff --git a/ydb/library/yql/providers/ydb/expr_nodes/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/ydb/expr_nodes/CMakeLists.darwin-arm64.txt index 99d4c2103a91..425e123439a4 100644 --- a/ydb/library/yql/providers/ydb/expr_nodes/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/ydb/expr_nodes/CMakeLists.darwin-arm64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-ydb-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-ydb-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/ydb/expr_nodes/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/ydb/expr_nodes/CMakeLists.darwin-x86_64.txt index 99d4c2103a91..425e123439a4 100644 --- a/ydb/library/yql/providers/ydb/expr_nodes/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/ydb/expr_nodes/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-ydb-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-ydb-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/ydb/expr_nodes/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/ydb/expr_nodes/CMakeLists.linux-aarch64.txt index 48a5c5cc29a4..09c9dc7332e9 100644 --- a/ydb/library/yql/providers/ydb/expr_nodes/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/ydb/expr_nodes/CMakeLists.linux-aarch64.txt @@ -17,6 +17,9 @@ target_link_libraries(providers-ydb-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-ydb-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/ydb/expr_nodes/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/ydb/expr_nodes/CMakeLists.linux-x86_64.txt index 48a5c5cc29a4..09c9dc7332e9 100644 --- a/ydb/library/yql/providers/ydb/expr_nodes/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/ydb/expr_nodes/CMakeLists.linux-x86_64.txt @@ -17,6 +17,9 @@ target_link_libraries(providers-ydb-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-ydb-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/ydb/expr_nodes/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/ydb/expr_nodes/CMakeLists.windows-x86_64.txt index 99d4c2103a91..425e123439a4 100644 --- a/ydb/library/yql/providers/ydb/expr_nodes/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/ydb/expr_nodes/CMakeLists.windows-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-ydb-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-ydb-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/expr_nodes/yql_ydb_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/ydb/proto/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/ydb/proto/CMakeLists.darwin-arm64.txt index 43eb51761dba..650598c8b34b 100644 --- a/ydb/library/yql/providers/ydb/proto/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/ydb/proto/CMakeLists.darwin-arm64.txt @@ -41,6 +41,10 @@ target_proto_messages(providers-ydb-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/ydb/proto/range.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/ydb/proto/source.proto ) +target_sources(providers-ydb-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/proto/range.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/proto/source.pb.h +) target_proto_addincls(providers-ydb-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/ydb/proto/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/ydb/proto/CMakeLists.darwin-x86_64.txt index 43eb51761dba..650598c8b34b 100644 --- a/ydb/library/yql/providers/ydb/proto/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/ydb/proto/CMakeLists.darwin-x86_64.txt @@ -41,6 +41,10 @@ target_proto_messages(providers-ydb-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/ydb/proto/range.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/ydb/proto/source.proto ) +target_sources(providers-ydb-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/proto/range.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/proto/source.pb.h +) target_proto_addincls(providers-ydb-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/ydb/proto/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/ydb/proto/CMakeLists.linux-aarch64.txt index 071884921680..5f77db85434a 100644 --- a/ydb/library/yql/providers/ydb/proto/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/ydb/proto/CMakeLists.linux-aarch64.txt @@ -42,6 +42,10 @@ target_proto_messages(providers-ydb-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/ydb/proto/range.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/ydb/proto/source.proto ) +target_sources(providers-ydb-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/proto/range.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/proto/source.pb.h +) target_proto_addincls(providers-ydb-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/ydb/proto/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/ydb/proto/CMakeLists.linux-x86_64.txt index 071884921680..5f77db85434a 100644 --- a/ydb/library/yql/providers/ydb/proto/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/ydb/proto/CMakeLists.linux-x86_64.txt @@ -42,6 +42,10 @@ target_proto_messages(providers-ydb-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/ydb/proto/range.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/ydb/proto/source.proto ) +target_sources(providers-ydb-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/proto/range.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/proto/source.pb.h +) target_proto_addincls(providers-ydb-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/ydb/proto/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/ydb/proto/CMakeLists.windows-x86_64.txt index 43eb51761dba..650598c8b34b 100644 --- a/ydb/library/yql/providers/ydb/proto/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/ydb/proto/CMakeLists.windows-x86_64.txt @@ -41,6 +41,10 @@ target_proto_messages(providers-ydb-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/ydb/proto/range.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/ydb/proto/source.proto ) +target_sources(providers-ydb-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/proto/range.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/ydb/proto/source.pb.h +) target_proto_addincls(providers-ydb-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/providers/ydb/provider/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/ydb/provider/CMakeLists.darwin-arm64.txt index fee49f06acc9..1b481280c7b7 100644 --- a/ydb/library/yql/providers/ydb/provider/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/ydb/provider/CMakeLists.darwin-arm64.txt @@ -19,7 +19,7 @@ target_link_libraries(providers-ydb-provider PUBLIC cpp-yson-node fq-libs-common library-yql-ast - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-structured_token common-token_accessor-client library-yql-core diff --git a/ydb/library/yql/providers/ydb/provider/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/ydb/provider/CMakeLists.darwin-x86_64.txt index fee49f06acc9..1b481280c7b7 100644 --- a/ydb/library/yql/providers/ydb/provider/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/ydb/provider/CMakeLists.darwin-x86_64.txt @@ -19,7 +19,7 @@ target_link_libraries(providers-ydb-provider PUBLIC cpp-yson-node fq-libs-common library-yql-ast - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-structured_token common-token_accessor-client library-yql-core diff --git a/ydb/library/yql/providers/ydb/provider/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/ydb/provider/CMakeLists.linux-aarch64.txt index d37494217eb4..374700a56721 100644 --- a/ydb/library/yql/providers/ydb/provider/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/ydb/provider/CMakeLists.linux-aarch64.txt @@ -20,7 +20,7 @@ target_link_libraries(providers-ydb-provider PUBLIC cpp-yson-node fq-libs-common library-yql-ast - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-structured_token common-token_accessor-client library-yql-core diff --git a/ydb/library/yql/providers/ydb/provider/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/ydb/provider/CMakeLists.linux-x86_64.txt index d37494217eb4..374700a56721 100644 --- a/ydb/library/yql/providers/ydb/provider/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/ydb/provider/CMakeLists.linux-x86_64.txt @@ -20,7 +20,7 @@ target_link_libraries(providers-ydb-provider PUBLIC cpp-yson-node fq-libs-common library-yql-ast - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-structured_token common-token_accessor-client library-yql-core diff --git a/ydb/library/yql/providers/ydb/provider/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/ydb/provider/CMakeLists.windows-x86_64.txt index fee49f06acc9..1b481280c7b7 100644 --- a/ydb/library/yql/providers/ydb/provider/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/ydb/provider/CMakeLists.windows-x86_64.txt @@ -19,7 +19,7 @@ target_link_libraries(providers-ydb-provider PUBLIC cpp-yson-node fq-libs-common library-yql-ast - minikql-comp_nodes-llvm + yql-minikql-comp_nodes providers-common-structured_token common-token_accessor-client library-yql-core diff --git a/ydb/library/yql/providers/yt/CMakeLists.txt b/ydb/library/yql/providers/yt/CMakeLists.txt index d863ebd18067..c762ef5d46c5 100644 --- a/ydb/library/yql/providers/yt/CMakeLists.txt +++ b/ydb/library/yql/providers/yt/CMakeLists.txt @@ -6,14 +6,14 @@ # original buildsystem will not be accepted. -if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) - include(CMakeLists.linux-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) - include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) -endif() +add_subdirectory(codec) +add_subdirectory(common) +add_subdirectory(comp_nodes) +add_subdirectory(dq_task_preprocessor) +add_subdirectory(expr_nodes) +add_subdirectory(gateway) +add_subdirectory(job) +add_subdirectory(lib) +add_subdirectory(mkql_dq) +add_subdirectory(opt) +add_subdirectory(provider) diff --git a/ydb/library/yql/providers/yt/codec/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/codec/CMakeLists.darwin-arm64.txt index eae0a3b160f3..d93a3c7cf22b 100644 --- a/ydb/library/yql/providers/yt/codec/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/yt/codec/CMakeLists.darwin-arm64.txt @@ -30,9 +30,11 @@ target_link_libraries(providers-yt-codec PUBLIC providers-yt-common yt-lib-mkql_helpers yt-lib-skiff - yt-codec-codegen ) target_sources(providers-yt-codec PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_io.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_job.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_io.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_job.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec.cpp diff --git a/ydb/library/yql/providers/yt/codec/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/codec/CMakeLists.darwin-x86_64.txt index eae0a3b160f3..d93a3c7cf22b 100644 --- a/ydb/library/yql/providers/yt/codec/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/yt/codec/CMakeLists.darwin-x86_64.txt @@ -30,9 +30,11 @@ target_link_libraries(providers-yt-codec PUBLIC providers-yt-common yt-lib-mkql_helpers yt-lib-skiff - yt-codec-codegen ) target_sources(providers-yt-codec PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_io.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_job.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_io.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_job.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec.cpp diff --git a/ydb/library/yql/providers/yt/codec/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/codec/CMakeLists.linux-aarch64.txt index e9793a476ef9..a3bb411c1c87 100644 --- a/ydb/library/yql/providers/yt/codec/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/yt/codec/CMakeLists.linux-aarch64.txt @@ -31,9 +31,11 @@ target_link_libraries(providers-yt-codec PUBLIC providers-yt-common yt-lib-mkql_helpers yt-lib-skiff - yt-codec-codegen ) target_sources(providers-yt-codec PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_io.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_job.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_io.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_job.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec.cpp diff --git a/ydb/library/yql/providers/yt/codec/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/codec/CMakeLists.linux-x86_64.txt index e9793a476ef9..a3bb411c1c87 100644 --- a/ydb/library/yql/providers/yt/codec/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/yt/codec/CMakeLists.linux-x86_64.txt @@ -31,9 +31,11 @@ target_link_libraries(providers-yt-codec PUBLIC providers-yt-common yt-lib-mkql_helpers yt-lib-skiff - yt-codec-codegen ) target_sources(providers-yt-codec PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_io.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_job.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_io.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_job.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec.cpp diff --git a/ydb/library/yql/providers/yt/codec/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/codec/CMakeLists.windows-x86_64.txt index eae0a3b160f3..d93a3c7cf22b 100644 --- a/ydb/library/yql/providers/yt/codec/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/yt/codec/CMakeLists.windows-x86_64.txt @@ -30,9 +30,11 @@ target_link_libraries(providers-yt-codec PUBLIC providers-yt-common yt-lib-mkql_helpers yt-lib-skiff - yt-codec-codegen ) target_sources(providers-yt-codec PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_io.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_job.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_io.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_job.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec.cpp diff --git a/ydb/library/yql/providers/yt/codec/codegen/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/codec/codegen/CMakeLists.darwin-arm64.txt index 31b931eb7c5d..f29c871d9db2 100644 --- a/ydb/library/yql/providers/yt/codec/codegen/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/yt/codec/codegen/CMakeLists.darwin-arm64.txt @@ -6,13 +6,8 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) add_subdirectory(ut) -get_built_tool_path( - TOOL_rescompiler_bin - TOOL_rescompiler_dependency - tools/rescompiler/bin - rescompiler -) add_library(yt-codec-codegen) target_compile_options(yt-codec-codegen PRIVATE @@ -23,81 +18,12 @@ target_link_libraries(yt-codec-codegen PUBLIC yutil library-cpp-resource ydb-library-binary_json - minikql-computation-llvm + minikql-computation-llvm14 parser-pg_wrapper-interface library-yql-utils - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - llvm12-lib-Support - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO - yql-minikql-codegen + minikql-codegen-llvm14 ) target_sources(yt-codec-codegen PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_cg.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_cg.cpp ) - -add_global_library_for(yt-codec-codegen.global yt-codec-codegen) -target_compile_options(yt-codec-codegen.global PRIVATE - -DUSE_CURRENT_UDF_ABI_VERSION -) -target_link_libraries(yt-codec-codegen.global PUBLIC - contrib-libs-cxxsupp - yutil - library-cpp-resource - ydb-library-binary_json - minikql-computation-llvm - parser-pg_wrapper-interface - library-yql-utils - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - llvm12-lib-Support - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO - yql-minikql-codegen -) -target_sources(yt-codec-codegen.global PRIVATE - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/12ec3101983db48f6ee4095b4f5fb784.cpp -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_optimized.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_merged.bc - COMMAND - ${LLVMOPT} - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_merged.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_optimized.bc - -internalize-public-api-list=WriteJust#WriteNothing#WriteBool#Write8#Write16#Write32#Write64#Write120#WriteDecimal32#WriteDecimal64#WriteDecimal128#WriteFloat#WriteDouble#WriteString#ReadBool#ReadInt8#ReadUint8#ReadInt16#ReadUint16#ReadInt32#ReadUint32#ReadInt64#ReadUint64#ReadInt120#ReadDecimal32#ReadDecimal64#ReadDecimal128#ReadFloat#ReadDouble#ReadOptional#ReadVariantData#SkipFixedData#SkipVarData#ReadTzDate#ReadTzDatetime#ReadTzTimestamp#WriteTzDate#WriteTzDatetime#WriteTzTimestamp#GetWrittenBytes#FillZero - -passes="default,globalopt,globaldce,internalize" -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_merged.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_bc.cpp.bc - COMMAND - ${LLVMLINK} - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_bc.cpp.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_merged.bc -) -llvm_compile_cxx(yt-codec-codegen.global - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_bc.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_bc.cpp.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -resources(yt-codec-codegen.global - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/12ec3101983db48f6ee4095b4f5fb784.cpp - INPUTS - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_optimized.bc - KEYS - /llvm_bc/YtCodecFuncs -) diff --git a/ydb/library/yql/providers/yt/codec/codegen/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/codec/codegen/CMakeLists.darwin-x86_64.txt index 31b931eb7c5d..f29c871d9db2 100644 --- a/ydb/library/yql/providers/yt/codec/codegen/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/yt/codec/codegen/CMakeLists.darwin-x86_64.txt @@ -6,13 +6,8 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) add_subdirectory(ut) -get_built_tool_path( - TOOL_rescompiler_bin - TOOL_rescompiler_dependency - tools/rescompiler/bin - rescompiler -) add_library(yt-codec-codegen) target_compile_options(yt-codec-codegen PRIVATE @@ -23,81 +18,12 @@ target_link_libraries(yt-codec-codegen PUBLIC yutil library-cpp-resource ydb-library-binary_json - minikql-computation-llvm + minikql-computation-llvm14 parser-pg_wrapper-interface library-yql-utils - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - llvm12-lib-Support - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO - yql-minikql-codegen + minikql-codegen-llvm14 ) target_sources(yt-codec-codegen PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_cg.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_cg.cpp ) - -add_global_library_for(yt-codec-codegen.global yt-codec-codegen) -target_compile_options(yt-codec-codegen.global PRIVATE - -DUSE_CURRENT_UDF_ABI_VERSION -) -target_link_libraries(yt-codec-codegen.global PUBLIC - contrib-libs-cxxsupp - yutil - library-cpp-resource - ydb-library-binary_json - minikql-computation-llvm - parser-pg_wrapper-interface - library-yql-utils - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - llvm12-lib-Support - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO - yql-minikql-codegen -) -target_sources(yt-codec-codegen.global PRIVATE - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/12ec3101983db48f6ee4095b4f5fb784.cpp -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_optimized.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_merged.bc - COMMAND - ${LLVMOPT} - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_merged.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_optimized.bc - -internalize-public-api-list=WriteJust#WriteNothing#WriteBool#Write8#Write16#Write32#Write64#Write120#WriteDecimal32#WriteDecimal64#WriteDecimal128#WriteFloat#WriteDouble#WriteString#ReadBool#ReadInt8#ReadUint8#ReadInt16#ReadUint16#ReadInt32#ReadUint32#ReadInt64#ReadUint64#ReadInt120#ReadDecimal32#ReadDecimal64#ReadDecimal128#ReadFloat#ReadDouble#ReadOptional#ReadVariantData#SkipFixedData#SkipVarData#ReadTzDate#ReadTzDatetime#ReadTzTimestamp#WriteTzDate#WriteTzDatetime#WriteTzTimestamp#GetWrittenBytes#FillZero - -passes="default,globalopt,globaldce,internalize" -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_merged.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_bc.cpp.bc - COMMAND - ${LLVMLINK} - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_bc.cpp.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_merged.bc -) -llvm_compile_cxx(yt-codec-codegen.global - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_bc.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_bc.cpp.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -resources(yt-codec-codegen.global - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/12ec3101983db48f6ee4095b4f5fb784.cpp - INPUTS - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_optimized.bc - KEYS - /llvm_bc/YtCodecFuncs -) diff --git a/ydb/library/yql/providers/yt/codec/codegen/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/codec/codegen/CMakeLists.linux-aarch64.txt index 66f13add1cce..7365376ac07e 100644 --- a/ydb/library/yql/providers/yt/codec/codegen/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/yt/codec/codegen/CMakeLists.linux-aarch64.txt @@ -6,13 +6,8 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) add_subdirectory(ut) -get_built_tool_path( - TOOL_rescompiler_bin - TOOL_rescompiler_dependency - tools/rescompiler/bin - rescompiler -) add_library(yt-codec-codegen) target_compile_options(yt-codec-codegen PRIVATE @@ -24,82 +19,12 @@ target_link_libraries(yt-codec-codegen PUBLIC yutil library-cpp-resource ydb-library-binary_json - minikql-computation-llvm + minikql-computation-llvm14 parser-pg_wrapper-interface library-yql-utils - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - llvm12-lib-Support - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO - yql-minikql-codegen + minikql-codegen-llvm14 ) target_sources(yt-codec-codegen PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_cg.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_cg.cpp ) - -add_global_library_for(yt-codec-codegen.global yt-codec-codegen) -target_compile_options(yt-codec-codegen.global PRIVATE - -DUSE_CURRENT_UDF_ABI_VERSION -) -target_link_libraries(yt-codec-codegen.global PUBLIC - contrib-libs-linux-headers - contrib-libs-cxxsupp - yutil - library-cpp-resource - ydb-library-binary_json - minikql-computation-llvm - parser-pg_wrapper-interface - library-yql-utils - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - llvm12-lib-Support - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO - yql-minikql-codegen -) -target_sources(yt-codec-codegen.global PRIVATE - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/12ec3101983db48f6ee4095b4f5fb784.cpp -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_optimized.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_merged.bc - COMMAND - ${LLVMOPT} - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_merged.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_optimized.bc - -internalize-public-api-list=WriteJust#WriteNothing#WriteBool#Write8#Write16#Write32#Write64#Write120#WriteDecimal32#WriteDecimal64#WriteDecimal128#WriteFloat#WriteDouble#WriteString#ReadBool#ReadInt8#ReadUint8#ReadInt16#ReadUint16#ReadInt32#ReadUint32#ReadInt64#ReadUint64#ReadInt120#ReadDecimal32#ReadDecimal64#ReadDecimal128#ReadFloat#ReadDouble#ReadOptional#ReadVariantData#SkipFixedData#SkipVarData#ReadTzDate#ReadTzDatetime#ReadTzTimestamp#WriteTzDate#WriteTzDatetime#WriteTzTimestamp#GetWrittenBytes#FillZero - -passes="default,globalopt,globaldce,internalize" -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_merged.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_bc.cpp.bc - COMMAND - ${LLVMLINK} - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_bc.cpp.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_merged.bc -) -llvm_compile_cxx(yt-codec-codegen.global - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_bc.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_bc.cpp.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -resources(yt-codec-codegen.global - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/12ec3101983db48f6ee4095b4f5fb784.cpp - INPUTS - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_optimized.bc - KEYS - /llvm_bc/YtCodecFuncs -) diff --git a/ydb/library/yql/providers/yt/codec/codegen/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/codec/codegen/CMakeLists.linux-x86_64.txt index 66f13add1cce..7365376ac07e 100644 --- a/ydb/library/yql/providers/yt/codec/codegen/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/yt/codec/codegen/CMakeLists.linux-x86_64.txt @@ -6,13 +6,8 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) add_subdirectory(ut) -get_built_tool_path( - TOOL_rescompiler_bin - TOOL_rescompiler_dependency - tools/rescompiler/bin - rescompiler -) add_library(yt-codec-codegen) target_compile_options(yt-codec-codegen PRIVATE @@ -24,82 +19,12 @@ target_link_libraries(yt-codec-codegen PUBLIC yutil library-cpp-resource ydb-library-binary_json - minikql-computation-llvm + minikql-computation-llvm14 parser-pg_wrapper-interface library-yql-utils - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - llvm12-lib-Support - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO - yql-minikql-codegen + minikql-codegen-llvm14 ) target_sources(yt-codec-codegen PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_cg.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_cg.cpp ) - -add_global_library_for(yt-codec-codegen.global yt-codec-codegen) -target_compile_options(yt-codec-codegen.global PRIVATE - -DUSE_CURRENT_UDF_ABI_VERSION -) -target_link_libraries(yt-codec-codegen.global PUBLIC - contrib-libs-linux-headers - contrib-libs-cxxsupp - yutil - library-cpp-resource - ydb-library-binary_json - minikql-computation-llvm - parser-pg_wrapper-interface - library-yql-utils - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - llvm12-lib-Support - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO - yql-minikql-codegen -) -target_sources(yt-codec-codegen.global PRIVATE - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/12ec3101983db48f6ee4095b4f5fb784.cpp -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_optimized.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_merged.bc - COMMAND - ${LLVMOPT} - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_merged.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_optimized.bc - -internalize-public-api-list=WriteJust#WriteNothing#WriteBool#Write8#Write16#Write32#Write64#Write120#WriteDecimal32#WriteDecimal64#WriteDecimal128#WriteFloat#WriteDouble#WriteString#ReadBool#ReadInt8#ReadUint8#ReadInt16#ReadUint16#ReadInt32#ReadUint32#ReadInt64#ReadUint64#ReadInt120#ReadDecimal32#ReadDecimal64#ReadDecimal128#ReadFloat#ReadDouble#ReadOptional#ReadVariantData#SkipFixedData#SkipVarData#ReadTzDate#ReadTzDatetime#ReadTzTimestamp#WriteTzDate#WriteTzDatetime#WriteTzTimestamp#GetWrittenBytes#FillZero - -passes="default,globalopt,globaldce,internalize" -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_merged.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_bc.cpp.bc - COMMAND - ${LLVMLINK} - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_bc.cpp.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_merged.bc -) -llvm_compile_cxx(yt-codec-codegen.global - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_bc.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_bc.cpp.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -resources(yt-codec-codegen.global - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/12ec3101983db48f6ee4095b4f5fb784.cpp - INPUTS - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_optimized.bc - KEYS - /llvm_bc/YtCodecFuncs -) diff --git a/ydb/library/yql/providers/yt/codec/codegen/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/codec/codegen/CMakeLists.windows-x86_64.txt index 31b931eb7c5d..f29c871d9db2 100644 --- a/ydb/library/yql/providers/yt/codec/codegen/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/yt/codec/codegen/CMakeLists.windows-x86_64.txt @@ -6,13 +6,8 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) add_subdirectory(ut) -get_built_tool_path( - TOOL_rescompiler_bin - TOOL_rescompiler_dependency - tools/rescompiler/bin - rescompiler -) add_library(yt-codec-codegen) target_compile_options(yt-codec-codegen PRIVATE @@ -23,81 +18,12 @@ target_link_libraries(yt-codec-codegen PUBLIC yutil library-cpp-resource ydb-library-binary_json - minikql-computation-llvm + minikql-computation-llvm14 parser-pg_wrapper-interface library-yql-utils - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - llvm12-lib-Support - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO - yql-minikql-codegen + minikql-codegen-llvm14 ) target_sources(yt-codec-codegen PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_cg.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_cg.cpp ) - -add_global_library_for(yt-codec-codegen.global yt-codec-codegen) -target_compile_options(yt-codec-codegen.global PRIVATE - -DUSE_CURRENT_UDF_ABI_VERSION -) -target_link_libraries(yt-codec-codegen.global PUBLIC - contrib-libs-cxxsupp - yutil - library-cpp-resource - ydb-library-binary_json - minikql-computation-llvm - parser-pg_wrapper-interface - library-yql-utils - llvm12-lib-IR - lib-ExecutionEngine-MCJIT - llvm12-lib-Linker - llvm12-lib-Support - lib-Target-X86 - Target-X86-AsmParser - lib-Transforms-IPO - yql-minikql-codegen -) -target_sources(yt-codec-codegen.global PRIVATE - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/12ec3101983db48f6ee4095b4f5fb784.cpp -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_optimized.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_merged.bc - COMMAND - ${LLVMOPT} - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_merged.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_optimized.bc - -internalize-public-api-list=WriteJust#WriteNothing#WriteBool#Write8#Write16#Write32#Write64#Write120#WriteDecimal32#WriteDecimal64#WriteDecimal128#WriteFloat#WriteDouble#WriteString#ReadBool#ReadInt8#ReadUint8#ReadInt16#ReadUint16#ReadInt32#ReadUint32#ReadInt64#ReadUint64#ReadInt120#ReadDecimal32#ReadDecimal64#ReadDecimal128#ReadFloat#ReadDouble#ReadOptional#ReadVariantData#SkipFixedData#SkipVarData#ReadTzDate#ReadTzDatetime#ReadTzTimestamp#WriteTzDate#WriteTzDatetime#WriteTzTimestamp#GetWrittenBytes#FillZero - -passes="default,globalopt,globaldce,internalize" -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_merged.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_bc.cpp.bc - COMMAND - ${LLVMLINK} - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_bc.cpp.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_merged.bc -) -llvm_compile_cxx(yt-codec-codegen.global - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_bc.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_bc.cpp.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -resources(yt-codec-codegen.global - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/12ec3101983db48f6ee4095b4f5fb784.cpp - INPUTS - ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/codec/codegen/YtCodecFuncs_optimized.bc - KEYS - /llvm_bc/YtCodecFuncs -) diff --git a/ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..da1077860e31 --- /dev/null +++ b/ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.darwin-arm64.txt @@ -0,0 +1,23 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(codec-codegen-no_llvm) +target_compile_options(codec-codegen-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(codec-codegen-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen +) +target_link_libraries(codec-codegen-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil +) +target_sources(codec-codegen-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_cg_dummy.cpp +) diff --git a/ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..da1077860e31 --- /dev/null +++ b/ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,23 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(codec-codegen-no_llvm) +target_compile_options(codec-codegen-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(codec-codegen-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen +) +target_link_libraries(codec-codegen-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil +) +target_sources(codec-codegen-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_cg_dummy.cpp +) diff --git a/ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..ec96f665b5ce --- /dev/null +++ b/ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.linux-aarch64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(codec-codegen-no_llvm) +target_compile_options(codec-codegen-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(codec-codegen-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen +) +target_link_libraries(codec-codegen-no_llvm PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil +) +target_sources(codec-codegen-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_cg_dummy.cpp +) diff --git a/ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..ec96f665b5ce --- /dev/null +++ b/ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.linux-x86_64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(codec-codegen-no_llvm) +target_compile_options(codec-codegen-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(codec-codegen-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen +) +target_link_libraries(codec-codegen-no_llvm PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil +) +target_sources(codec-codegen-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_cg_dummy.cpp +) diff --git a/ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.txt b/ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..da1077860e31 --- /dev/null +++ b/ydb/library/yql/providers/yt/codec/codegen/no_llvm/CMakeLists.windows-x86_64.txt @@ -0,0 +1,23 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(codec-codegen-no_llvm) +target_compile_options(codec-codegen-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(codec-codegen-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen +) +target_link_libraries(codec-codegen-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil +) +target_sources(codec-codegen-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/yt_codec_cg_dummy.cpp +) diff --git a/ydb/library/yql/providers/yt/codec/codegen/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/codec/codegen/ut/CMakeLists.darwin-arm64.txt index 613308b30c56..5343bd29f2cf 100644 --- a/ydb/library/yql/providers/yt/codec/codegen/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/yt/codec/codegen/ut/CMakeLists.darwin-arm64.txt @@ -19,7 +19,7 @@ target_link_libraries(ydb-library-yql-providers-yt-codec-codegen-ut PUBLIC yutil cpp-testing-unittest_main yt-codec-codegen - minikql-computation-llvm + minikql-computation-llvm14 udf-service-exception_policy library-yql-sql yql-sql-pg_dummy @@ -29,8 +29,6 @@ target_link_options(ydb-library-yql-providers-yt-codec-codegen-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-yt-codec-codegen-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/ut/yt_codec_cg_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/yt/codec/codegen/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/codec/codegen/ut/CMakeLists.darwin-x86_64.txt index e9fafaccff9c..f5919cd3c2b4 100644 --- a/ydb/library/yql/providers/yt/codec/codegen/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/yt/codec/codegen/ut/CMakeLists.darwin-x86_64.txt @@ -20,7 +20,7 @@ target_link_libraries(ydb-library-yql-providers-yt-codec-codegen-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main yt-codec-codegen - minikql-computation-llvm + minikql-computation-llvm14 udf-service-exception_policy library-yql-sql yql-sql-pg_dummy @@ -30,8 +30,6 @@ target_link_options(ydb-library-yql-providers-yt-codec-codegen-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-yt-codec-codegen-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/ut/yt_codec_cg_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/yt/codec/codegen/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/codec/codegen/ut/CMakeLists.linux-aarch64.txt index 940a32c07bdc..771c46d65755 100644 --- a/ydb/library/yql/providers/yt/codec/codegen/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/yt/codec/codegen/ut/CMakeLists.linux-aarch64.txt @@ -20,7 +20,7 @@ target_link_libraries(ydb-library-yql-providers-yt-codec-codegen-ut PUBLIC yutil cpp-testing-unittest_main yt-codec-codegen - minikql-computation-llvm + minikql-computation-llvm14 udf-service-exception_policy library-yql-sql yql-sql-pg_dummy @@ -32,9 +32,6 @@ target_link_options(ydb-library-yql-providers-yt-codec-codegen-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-yt-codec-codegen-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/ut/yt_codec_cg_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/yt/codec/codegen/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/codec/codegen/ut/CMakeLists.linux-x86_64.txt index 4455b224355a..676bf3104432 100644 --- a/ydb/library/yql/providers/yt/codec/codegen/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/yt/codec/codegen/ut/CMakeLists.linux-x86_64.txt @@ -21,7 +21,7 @@ target_link_libraries(ydb-library-yql-providers-yt-codec-codegen-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main yt-codec-codegen - minikql-computation-llvm + minikql-computation-llvm14 udf-service-exception_policy library-yql-sql yql-sql-pg_dummy @@ -33,9 +33,6 @@ target_link_options(ydb-library-yql-providers-yt-codec-codegen-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-yt-codec-codegen-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/codegen/ut/yt_codec_cg_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/yt/codec/codegen/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/codec/codegen/ut/CMakeLists.windows-x86_64.txt index 0189d49889c9..28ce4b567d4a 100644 --- a/ydb/library/yql/providers/yt/codec/codegen/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/yt/codec/codegen/ut/CMakeLists.windows-x86_64.txt @@ -20,7 +20,7 @@ target_link_libraries(ydb-library-yql-providers-yt-codec-codegen-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main yt-codec-codegen - minikql-computation-llvm + minikql-computation-llvm14 udf-service-exception_policy library-yql-sql yql-sql-pg_dummy @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/yt/codec/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/codec/ut/CMakeLists.darwin-arm64.txt index 97d7a200e627..db1535689ed8 100644 --- a/ydb/library/yql/providers/yt/codec/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/yt/codec/ut/CMakeLists.darwin-arm64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) add_executable(ydb-library-yql-providers-yt-codec-ut) target_compile_options(ydb-library-yql-providers-yt-codec-ut PRIVATE @@ -20,20 +21,19 @@ target_link_libraries(ydb-library-yql-providers-yt-codec-ut PUBLIC cpp-testing-unittest_main providers-yt-codec cpp-yson-node - minikql-computation-llvm + minikql-computation-llvm14 udf-service-exception_policy library-yql-sql yql-sql-pg_dummy providers-common-codec providers-common-mkql yt-lib-yson_helpers + yt-codec-codegen ) target_link_options(ydb-library-yql-providers-yt-codec-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-yt-codec-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_io_ut.cpp @@ -63,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/yt/codec/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/codec/ut/CMakeLists.darwin-x86_64.txt index d60b5ec3fb50..475a13284a20 100644 --- a/ydb/library/yql/providers/yt/codec/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/yt/codec/ut/CMakeLists.darwin-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) add_executable(ydb-library-yql-providers-yt-codec-ut) target_compile_options(ydb-library-yql-providers-yt-codec-ut PRIVATE @@ -21,20 +22,19 @@ target_link_libraries(ydb-library-yql-providers-yt-codec-ut PUBLIC cpp-testing-unittest_main providers-yt-codec cpp-yson-node - minikql-computation-llvm + minikql-computation-llvm14 udf-service-exception_policy library-yql-sql yql-sql-pg_dummy providers-common-codec providers-common-mkql yt-lib-yson_helpers + yt-codec-codegen ) target_link_options(ydb-library-yql-providers-yt-codec-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-yt-codec-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_io_ut.cpp @@ -64,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/yt/codec/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/codec/ut/CMakeLists.linux-aarch64.txt index d00ff286f945..5f71d1286168 100644 --- a/ydb/library/yql/providers/yt/codec/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/yt/codec/ut/CMakeLists.linux-aarch64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) add_executable(ydb-library-yql-providers-yt-codec-ut) target_compile_options(ydb-library-yql-providers-yt-codec-ut PRIVATE @@ -21,13 +22,14 @@ target_link_libraries(ydb-library-yql-providers-yt-codec-ut PUBLIC cpp-testing-unittest_main providers-yt-codec cpp-yson-node - minikql-computation-llvm + minikql-computation-llvm14 udf-service-exception_policy library-yql-sql yql-sql-pg_dummy providers-common-codec providers-common-mkql yt-lib-yson_helpers + yt-codec-codegen ) target_link_options(ydb-library-yql-providers-yt-codec-ut PRIVATE -ldl @@ -35,9 +37,6 @@ target_link_options(ydb-library-yql-providers-yt-codec-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-yt-codec-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_io_ut.cpp @@ -67,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/yt/codec/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/codec/ut/CMakeLists.linux-x86_64.txt index 1004710d7ffb..50747a696240 100644 --- a/ydb/library/yql/providers/yt/codec/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/yt/codec/ut/CMakeLists.linux-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) add_executable(ydb-library-yql-providers-yt-codec-ut) target_compile_options(ydb-library-yql-providers-yt-codec-ut PRIVATE @@ -22,13 +23,14 @@ target_link_libraries(ydb-library-yql-providers-yt-codec-ut PUBLIC cpp-testing-unittest_main providers-yt-codec cpp-yson-node - minikql-computation-llvm + minikql-computation-llvm14 udf-service-exception_policy library-yql-sql yql-sql-pg_dummy providers-common-codec providers-common-mkql yt-lib-yson_helpers + yt-codec-codegen ) target_link_options(ydb-library-yql-providers-yt-codec-ut PRIVATE -ldl @@ -36,9 +38,6 @@ target_link_options(ydb-library-yql-providers-yt-codec-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-providers-yt-codec-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_io_ut.cpp @@ -68,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/yt/codec/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/codec/ut/CMakeLists.windows-x86_64.txt index f5ea5a23c573..2d0fcf95a02a 100644 --- a/ydb/library/yql/providers/yt/codec/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/yt/codec/ut/CMakeLists.windows-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) add_executable(ydb-library-yql-providers-yt-codec-ut) target_compile_options(ydb-library-yql-providers-yt-codec-ut PRIVATE @@ -21,13 +22,14 @@ target_link_libraries(ydb-library-yql-providers-yt-codec-ut PUBLIC cpp-testing-unittest_main providers-yt-codec cpp-yson-node - minikql-computation-llvm + minikql-computation-llvm14 udf-service-exception_policy library-yql-sql yql-sql-pg_dummy providers-common-codec providers-common-mkql yt-lib-yson_helpers + yt-codec-codegen ) target_sources(ydb-library-yql-providers-yt-codec-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_io_ut.cpp @@ -57,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..23c00ba1d280 --- /dev/null +++ b/ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.darwin-arm64.txt @@ -0,0 +1,78 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-providers-yt-codec-ut-no_llvm) +target_compile_options(ydb-library-yql-providers-yt-codec-ut-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-providers-yt-codec-ut-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec +) +target_link_libraries(ydb-library-yql-providers-yt-codec-ut-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + providers-yt-codec + cpp-yson-node + minikql-codegen-no_llvm + minikql-computation-no_llvm + udf-service-exception_policy + library-yql-sql + yql-sql-pg_dummy + providers-common-codec + providers-common-mkql + yt-lib-yson_helpers + codec-codegen-no_llvm +) +target_link_options(ydb-library-yql-providers-yt-codec-ut-no_llvm PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-library-yql-providers-yt-codec-ut-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_io_ut.cpp +) +set_property( + TARGET + ydb-library-yql-providers-yt-codec-ut-no_llvm + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-providers-yt-codec-ut-no_llvm + TEST_TARGET + ydb-library-yql-providers-yt-codec-ut-no_llvm + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-providers-yt-codec-ut-no_llvm + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-providers-yt-codec-ut-no_llvm + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-library-yql-providers-yt-codec-ut-no_llvm + system_allocator +) +vcs_info(ydb-library-yql-providers-yt-codec-ut-no_llvm) diff --git a/ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..587fe23ad0eb --- /dev/null +++ b/ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,79 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-providers-yt-codec-ut-no_llvm) +target_compile_options(ydb-library-yql-providers-yt-codec-ut-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-providers-yt-codec-ut-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec +) +target_link_libraries(ydb-library-yql-providers-yt-codec-ut-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + providers-yt-codec + cpp-yson-node + minikql-codegen-no_llvm + minikql-computation-no_llvm + udf-service-exception_policy + library-yql-sql + yql-sql-pg_dummy + providers-common-codec + providers-common-mkql + yt-lib-yson_helpers + codec-codegen-no_llvm +) +target_link_options(ydb-library-yql-providers-yt-codec-ut-no_llvm PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-library-yql-providers-yt-codec-ut-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_io_ut.cpp +) +set_property( + TARGET + ydb-library-yql-providers-yt-codec-ut-no_llvm + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-providers-yt-codec-ut-no_llvm + TEST_TARGET + ydb-library-yql-providers-yt-codec-ut-no_llvm + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-providers-yt-codec-ut-no_llvm + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-providers-yt-codec-ut-no_llvm + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-library-yql-providers-yt-codec-ut-no_llvm + system_allocator +) +vcs_info(ydb-library-yql-providers-yt-codec-ut-no_llvm) diff --git a/ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..c4c50add3cf4 --- /dev/null +++ b/ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.linux-aarch64.txt @@ -0,0 +1,81 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-providers-yt-codec-ut-no_llvm) +target_compile_options(ydb-library-yql-providers-yt-codec-ut-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-providers-yt-codec-ut-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec +) +target_link_libraries(ydb-library-yql-providers-yt-codec-ut-no_llvm PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + providers-yt-codec + cpp-yson-node + minikql-codegen-no_llvm + minikql-computation-no_llvm + udf-service-exception_policy + library-yql-sql + yql-sql-pg_dummy + providers-common-codec + providers-common-mkql + yt-lib-yson_helpers + codec-codegen-no_llvm +) +target_link_options(ydb-library-yql-providers-yt-codec-ut-no_llvm PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-library-yql-providers-yt-codec-ut-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_io_ut.cpp +) +set_property( + TARGET + ydb-library-yql-providers-yt-codec-ut-no_llvm + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-providers-yt-codec-ut-no_llvm + TEST_TARGET + ydb-library-yql-providers-yt-codec-ut-no_llvm + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-providers-yt-codec-ut-no_llvm + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-providers-yt-codec-ut-no_llvm + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-library-yql-providers-yt-codec-ut-no_llvm + cpp-malloc-jemalloc +) +vcs_info(ydb-library-yql-providers-yt-codec-ut-no_llvm) diff --git a/ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..d7d1a525c02b --- /dev/null +++ b/ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.linux-x86_64.txt @@ -0,0 +1,83 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-providers-yt-codec-ut-no_llvm) +target_compile_options(ydb-library-yql-providers-yt-codec-ut-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-providers-yt-codec-ut-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec +) +target_link_libraries(ydb-library-yql-providers-yt-codec-ut-no_llvm PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + providers-yt-codec + cpp-yson-node + minikql-codegen-no_llvm + minikql-computation-no_llvm + udf-service-exception_policy + library-yql-sql + yql-sql-pg_dummy + providers-common-codec + providers-common-mkql + yt-lib-yson_helpers + codec-codegen-no_llvm +) +target_link_options(ydb-library-yql-providers-yt-codec-ut-no_llvm PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-library-yql-providers-yt-codec-ut-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_io_ut.cpp +) +set_property( + TARGET + ydb-library-yql-providers-yt-codec-ut-no_llvm + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-providers-yt-codec-ut-no_llvm + TEST_TARGET + ydb-library-yql-providers-yt-codec-ut-no_llvm + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-providers-yt-codec-ut-no_llvm + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-providers-yt-codec-ut-no_llvm + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-library-yql-providers-yt-codec-ut-no_llvm + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(ydb-library-yql-providers-yt-codec-ut-no_llvm) diff --git a/ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.txt b/ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..d1bf960b2b3f --- /dev/null +++ b/ydb/library/yql/providers/yt/codec/ut/no_llvm/CMakeLists.windows-x86_64.txt @@ -0,0 +1,74 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-providers-yt-codec-ut-no_llvm) +target_compile_options(ydb-library-yql-providers-yt-codec-ut-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(ydb-library-yql-providers-yt-codec-ut-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec +) +target_link_libraries(ydb-library-yql-providers-yt-codec-ut-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + providers-yt-codec + cpp-yson-node + minikql-codegen-no_llvm + minikql-computation-no_llvm + udf-service-exception_policy + library-yql-sql + yql-sql-pg_dummy + providers-common-codec + providers-common-mkql + yt-lib-yson_helpers + codec-codegen-no_llvm +) +target_sources(ydb-library-yql-providers-yt-codec-ut-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/codec/yt_codec_io_ut.cpp +) +set_property( + TARGET + ydb-library-yql-providers-yt-codec-ut-no_llvm + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-providers-yt-codec-ut-no_llvm + TEST_TARGET + ydb-library-yql-providers-yt-codec-ut-no_llvm + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-providers-yt-codec-ut-no_llvm + PROPERTY + LABELS + SMALL + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-providers-yt-codec-ut-no_llvm + PROPERTY + PROCESSORS + 1 +) +target_allocator(ydb-library-yql-providers-yt-codec-ut-no_llvm + system_allocator +) +vcs_info(ydb-library-yql-providers-yt-codec-ut-no_llvm) diff --git a/ydb/library/yql/providers/yt/comp_nodes/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/comp_nodes/CMakeLists.darwin-arm64.txt index e724b2788838..254f2ac72774 100644 --- a/ydb/library/yql/providers/yt/comp_nodes/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/yt/comp_nodes/CMakeLists.darwin-arm64.txt @@ -7,31 +7,12 @@ add_subdirectory(dq) -add_subdirectory(ut) +add_subdirectory(llvm) +add_subdirectory(llvm14) +add_subdirectory(no_llvm) -add_library(providers-yt-comp_nodes) -target_compile_options(providers-yt-comp_nodes PRIVATE - -DUSE_CURRENT_UDF_ABI_VERSION -) -target_link_libraries(providers-yt-comp_nodes PUBLIC +add_library(providers-yt-comp_nodes INTERFACE) +target_link_libraries(providers-yt-comp_nodes INTERFACE contrib-libs-cxxsupp yutil - cpp-streams-brotli - library-yql-minikql - yql-public-udf - library-yql-utils - providers-common-codec - providers-common-mkql - providers-yt-codec - providers-yt-expr_nodes -) -target_sources(providers-yt-comp_nodes PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_file_input_state.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_file_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_input_stream.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_input.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_output.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_table_content.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_table.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_ungrouping_list.cpp ) diff --git a/ydb/library/yql/providers/yt/comp_nodes/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/comp_nodes/CMakeLists.darwin-x86_64.txt index e724b2788838..254f2ac72774 100644 --- a/ydb/library/yql/providers/yt/comp_nodes/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/yt/comp_nodes/CMakeLists.darwin-x86_64.txt @@ -7,31 +7,12 @@ add_subdirectory(dq) -add_subdirectory(ut) +add_subdirectory(llvm) +add_subdirectory(llvm14) +add_subdirectory(no_llvm) -add_library(providers-yt-comp_nodes) -target_compile_options(providers-yt-comp_nodes PRIVATE - -DUSE_CURRENT_UDF_ABI_VERSION -) -target_link_libraries(providers-yt-comp_nodes PUBLIC +add_library(providers-yt-comp_nodes INTERFACE) +target_link_libraries(providers-yt-comp_nodes INTERFACE contrib-libs-cxxsupp yutil - cpp-streams-brotli - library-yql-minikql - yql-public-udf - library-yql-utils - providers-common-codec - providers-common-mkql - providers-yt-codec - providers-yt-expr_nodes -) -target_sources(providers-yt-comp_nodes PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_file_input_state.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_file_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_input_stream.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_input.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_output.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_table_content.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_table.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_ungrouping_list.cpp ) diff --git a/ydb/library/yql/providers/yt/comp_nodes/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/comp_nodes/CMakeLists.linux-aarch64.txt index 70f9622a1894..8f33d2fc6018 100644 --- a/ydb/library/yql/providers/yt/comp_nodes/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/yt/comp_nodes/CMakeLists.linux-aarch64.txt @@ -7,32 +7,13 @@ add_subdirectory(dq) -add_subdirectory(ut) +add_subdirectory(llvm) +add_subdirectory(llvm14) +add_subdirectory(no_llvm) -add_library(providers-yt-comp_nodes) -target_compile_options(providers-yt-comp_nodes PRIVATE - -DUSE_CURRENT_UDF_ABI_VERSION -) -target_link_libraries(providers-yt-comp_nodes PUBLIC +add_library(providers-yt-comp_nodes INTERFACE) +target_link_libraries(providers-yt-comp_nodes INTERFACE contrib-libs-linux-headers contrib-libs-cxxsupp yutil - cpp-streams-brotli - library-yql-minikql - yql-public-udf - library-yql-utils - providers-common-codec - providers-common-mkql - providers-yt-codec - providers-yt-expr_nodes -) -target_sources(providers-yt-comp_nodes PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_file_input_state.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_file_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_input_stream.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_input.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_output.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_table_content.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_table.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_ungrouping_list.cpp ) diff --git a/ydb/library/yql/providers/yt/comp_nodes/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/comp_nodes/CMakeLists.linux-x86_64.txt index 70f9622a1894..8f33d2fc6018 100644 --- a/ydb/library/yql/providers/yt/comp_nodes/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/yt/comp_nodes/CMakeLists.linux-x86_64.txt @@ -7,32 +7,13 @@ add_subdirectory(dq) -add_subdirectory(ut) +add_subdirectory(llvm) +add_subdirectory(llvm14) +add_subdirectory(no_llvm) -add_library(providers-yt-comp_nodes) -target_compile_options(providers-yt-comp_nodes PRIVATE - -DUSE_CURRENT_UDF_ABI_VERSION -) -target_link_libraries(providers-yt-comp_nodes PUBLIC +add_library(providers-yt-comp_nodes INTERFACE) +target_link_libraries(providers-yt-comp_nodes INTERFACE contrib-libs-linux-headers contrib-libs-cxxsupp yutil - cpp-streams-brotli - library-yql-minikql - yql-public-udf - library-yql-utils - providers-common-codec - providers-common-mkql - providers-yt-codec - providers-yt-expr_nodes -) -target_sources(providers-yt-comp_nodes PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_file_input_state.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_file_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_input_stream.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_input.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_output.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_table_content.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_table.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_ungrouping_list.cpp ) diff --git a/ydb/library/yql/providers/yt/comp_nodes/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/comp_nodes/CMakeLists.windows-x86_64.txt index e724b2788838..254f2ac72774 100644 --- a/ydb/library/yql/providers/yt/comp_nodes/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/yt/comp_nodes/CMakeLists.windows-x86_64.txt @@ -7,31 +7,12 @@ add_subdirectory(dq) -add_subdirectory(ut) +add_subdirectory(llvm) +add_subdirectory(llvm14) +add_subdirectory(no_llvm) -add_library(providers-yt-comp_nodes) -target_compile_options(providers-yt-comp_nodes PRIVATE - -DUSE_CURRENT_UDF_ABI_VERSION -) -target_link_libraries(providers-yt-comp_nodes PUBLIC +add_library(providers-yt-comp_nodes INTERFACE) +target_link_libraries(providers-yt-comp_nodes INTERFACE contrib-libs-cxxsupp yutil - cpp-streams-brotli - library-yql-minikql - yql-public-udf - library-yql-utils - providers-common-codec - providers-common-mkql - providers-yt-codec - providers-yt-expr_nodes -) -target_sources(providers-yt-comp_nodes PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_file_input_state.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_file_list.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_input_stream.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_input.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_output.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_table_content.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_table.cpp - ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/yql_mkql_ungrouping_list.cpp ) diff --git a/ydb/library/yql/providers/yt/comp_nodes/dq/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/comp_nodes/dq/CMakeLists.darwin-arm64.txt index 9082a770b58d..02de73b47a2c 100644 --- a/ydb/library/yql/providers/yt/comp_nodes/dq/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/yt/comp_nodes/dq/CMakeLists.darwin-arm64.txt @@ -17,11 +17,12 @@ target_include_directories(yt-comp_nodes-dq PRIVATE target_link_libraries(yt-comp_nodes-dq PUBLIC contrib-libs-cxxsupp yutil - minikql-computation-llvm + library-yql-minikql + minikql-computation-llvm14 providers-yt-comp_nodes providers-yt-codec providers-common-codec - core-formats-arrow + yql-utils-failure_injector cpp-mapreduce-interface cpp-mapreduce-common cpp-yson-node diff --git a/ydb/library/yql/providers/yt/comp_nodes/dq/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/comp_nodes/dq/CMakeLists.darwin-x86_64.txt index 9082a770b58d..02de73b47a2c 100644 --- a/ydb/library/yql/providers/yt/comp_nodes/dq/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/yt/comp_nodes/dq/CMakeLists.darwin-x86_64.txt @@ -17,11 +17,12 @@ target_include_directories(yt-comp_nodes-dq PRIVATE target_link_libraries(yt-comp_nodes-dq PUBLIC contrib-libs-cxxsupp yutil - minikql-computation-llvm + library-yql-minikql + minikql-computation-llvm14 providers-yt-comp_nodes providers-yt-codec providers-common-codec - core-formats-arrow + yql-utils-failure_injector cpp-mapreduce-interface cpp-mapreduce-common cpp-yson-node diff --git a/ydb/library/yql/providers/yt/comp_nodes/dq/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/comp_nodes/dq/CMakeLists.linux-aarch64.txt index 06ae4cb2da3f..28a4c1a75173 100644 --- a/ydb/library/yql/providers/yt/comp_nodes/dq/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/yt/comp_nodes/dq/CMakeLists.linux-aarch64.txt @@ -19,11 +19,12 @@ target_link_libraries(yt-comp_nodes-dq PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - minikql-computation-llvm + library-yql-minikql + minikql-computation-llvm14 providers-yt-comp_nodes providers-yt-codec providers-common-codec - core-formats-arrow + yql-utils-failure_injector cpp-mapreduce-interface cpp-mapreduce-common cpp-yson-node @@ -36,6 +37,7 @@ target_link_libraries(yt-comp_nodes-dq PUBLIC yt-lib-yt_rpc_helpers ) target_sources(yt-comp_nodes-dq PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/dq/arrow_converter.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/dq/stream_decoder.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/dq/dq_yt_rpc_reader.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/dq/dq_yt_rpc_helpers.cpp diff --git a/ydb/library/yql/providers/yt/comp_nodes/dq/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/comp_nodes/dq/CMakeLists.linux-x86_64.txt index 06ae4cb2da3f..28a4c1a75173 100644 --- a/ydb/library/yql/providers/yt/comp_nodes/dq/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/yt/comp_nodes/dq/CMakeLists.linux-x86_64.txt @@ -19,11 +19,12 @@ target_link_libraries(yt-comp_nodes-dq PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - minikql-computation-llvm + library-yql-minikql + minikql-computation-llvm14 providers-yt-comp_nodes providers-yt-codec providers-common-codec - core-formats-arrow + yql-utils-failure_injector cpp-mapreduce-interface cpp-mapreduce-common cpp-yson-node @@ -36,6 +37,7 @@ target_link_libraries(yt-comp_nodes-dq PUBLIC yt-lib-yt_rpc_helpers ) target_sources(yt-comp_nodes-dq PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/dq/arrow_converter.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/dq/stream_decoder.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/dq/dq_yt_rpc_reader.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes/dq/dq_yt_rpc_helpers.cpp diff --git a/ydb/library/yql/providers/yt/comp_nodes/dq/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/comp_nodes/dq/CMakeLists.windows-x86_64.txt index 9082a770b58d..02de73b47a2c 100644 --- a/ydb/library/yql/providers/yt/comp_nodes/dq/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/yt/comp_nodes/dq/CMakeLists.windows-x86_64.txt @@ -17,11 +17,12 @@ target_include_directories(yt-comp_nodes-dq PRIVATE target_link_libraries(yt-comp_nodes-dq PUBLIC contrib-libs-cxxsupp yutil - minikql-computation-llvm + library-yql-minikql + minikql-computation-llvm14 providers-yt-comp_nodes providers-yt-codec providers-common-codec - core-formats-arrow + yql-utils-failure_injector cpp-mapreduce-interface cpp-mapreduce-common cpp-yson-node diff --git a/ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..84fb6d2aab15 --- /dev/null +++ b/ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.darwin-arm64.txt @@ -0,0 +1,73 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yt-comp_nodes-llvm STATIC) +set_property(TARGET yt-comp_nodes-llvm PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(yt-comp_nodes-llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION + $,,-Wno-everything> +) +target_include_directories(yt-comp_nodes-llvm PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/computation +) +target_include_directories(yt-comp_nodes-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes +) +target_link_libraries(yt-comp_nodes-llvm PUBLIC + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm + minikql-invoke_builtins-llvm14 + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + cpp-streams-brotli + library-yql-minikql + yql-public-udf + library-yql-utils + providers-common-codec + providers-common-mkql + providers-yt-codec + providers-yt-expr_nodes +) +target_sources(yt-comp_nodes-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..84fb6d2aab15 --- /dev/null +++ b/ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,73 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yt-comp_nodes-llvm STATIC) +set_property(TARGET yt-comp_nodes-llvm PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(yt-comp_nodes-llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION + $,,-Wno-everything> +) +target_include_directories(yt-comp_nodes-llvm PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/computation +) +target_include_directories(yt-comp_nodes-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes +) +target_link_libraries(yt-comp_nodes-llvm PUBLIC + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm + minikql-invoke_builtins-llvm14 + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + cpp-streams-brotli + library-yql-minikql + yql-public-udf + library-yql-utils + providers-common-codec + providers-common-mkql + providers-yt-codec + providers-yt-expr_nodes +) +target_sources(yt-comp_nodes-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..0c4498c1d38f --- /dev/null +++ b/ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.linux-aarch64.txt @@ -0,0 +1,74 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yt-comp_nodes-llvm STATIC) +set_property(TARGET yt-comp_nodes-llvm PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(yt-comp_nodes-llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION + $,,-Wno-everything> +) +target_include_directories(yt-comp_nodes-llvm PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/computation +) +target_include_directories(yt-comp_nodes-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes +) +target_link_libraries(yt-comp_nodes-llvm PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm + minikql-invoke_builtins-llvm14 + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + cpp-streams-brotli + library-yql-minikql + yql-public-udf + library-yql-utils + providers-common-codec + providers-common-mkql + providers-yt-codec + providers-yt-expr_nodes +) +target_sources(yt-comp_nodes-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..0c4498c1d38f --- /dev/null +++ b/ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.linux-x86_64.txt @@ -0,0 +1,74 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yt-comp_nodes-llvm STATIC) +set_property(TARGET yt-comp_nodes-llvm PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(yt-comp_nodes-llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION + $,,-Wno-everything> +) +target_include_directories(yt-comp_nodes-llvm PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/computation +) +target_include_directories(yt-comp_nodes-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes +) +target_link_libraries(yt-comp_nodes-llvm PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm + minikql-invoke_builtins-llvm14 + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + cpp-streams-brotli + library-yql-minikql + yql-public-udf + library-yql-utils + providers-common-codec + providers-common-mkql + providers-yt-codec + providers-yt-expr_nodes +) +target_sources(yt-comp_nodes-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.txt b/ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..84fb6d2aab15 --- /dev/null +++ b/ydb/library/yql/providers/yt/comp_nodes/llvm/CMakeLists.windows-x86_64.txt @@ -0,0 +1,73 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yt-comp_nodes-llvm STATIC) +set_property(TARGET yt-comp_nodes-llvm PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(yt-comp_nodes-llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION + $,,-Wno-everything> +) +target_include_directories(yt-comp_nodes-llvm PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/computation +) +target_include_directories(yt-comp_nodes-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes +) +target_link_libraries(yt-comp_nodes-llvm PUBLIC + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm + minikql-invoke_builtins-llvm14 + llvm12-lib-IR + lib-ExecutionEngine-MCJIT + llvm12-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + cpp-streams-brotli + library-yql-minikql + yql-public-udf + library-yql-utils + providers-common-codec + providers-common-mkql + providers-yt-codec + providers-yt-expr_nodes +) +target_sources(yt-comp_nodes-llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..20f3cf9c5705 --- /dev/null +++ b/ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.darwin-arm64.txt @@ -0,0 +1,73 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yt-comp_nodes-llvm14 STATIC) +set_property(TARGET yt-comp_nodes-llvm14 PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(yt-comp_nodes-llvm14 PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION + $,,-Wno-everything> +) +target_include_directories(yt-comp_nodes-llvm14 PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14 + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/computation +) +target_include_directories(yt-comp_nodes-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes +) +target_link_libraries(yt-comp_nodes-llvm14 PUBLIC + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm14 + minikql-invoke_builtins-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + cpp-streams-brotli + library-yql-minikql + yql-public-udf + library-yql-utils + providers-common-codec + providers-common-mkql + providers-yt-codec + providers-yt-expr_nodes +) +target_sources(yt-comp_nodes-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..20f3cf9c5705 --- /dev/null +++ b/ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,73 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yt-comp_nodes-llvm14 STATIC) +set_property(TARGET yt-comp_nodes-llvm14 PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(yt-comp_nodes-llvm14 PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION + $,,-Wno-everything> +) +target_include_directories(yt-comp_nodes-llvm14 PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14 + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/computation +) +target_include_directories(yt-comp_nodes-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes +) +target_link_libraries(yt-comp_nodes-llvm14 PUBLIC + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm14 + minikql-invoke_builtins-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + cpp-streams-brotli + library-yql-minikql + yql-public-udf + library-yql-utils + providers-common-codec + providers-common-mkql + providers-yt-codec + providers-yt-expr_nodes +) +target_sources(yt-comp_nodes-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..a0f4e895d353 --- /dev/null +++ b/ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.linux-aarch64.txt @@ -0,0 +1,74 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yt-comp_nodes-llvm14 STATIC) +set_property(TARGET yt-comp_nodes-llvm14 PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(yt-comp_nodes-llvm14 PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION + $,,-Wno-everything> +) +target_include_directories(yt-comp_nodes-llvm14 PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14 + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/computation +) +target_include_directories(yt-comp_nodes-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes +) +target_link_libraries(yt-comp_nodes-llvm14 PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm14 + minikql-invoke_builtins-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + cpp-streams-brotli + library-yql-minikql + yql-public-udf + library-yql-utils + providers-common-codec + providers-common-mkql + providers-yt-codec + providers-yt-expr_nodes +) +target_sources(yt-comp_nodes-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..a0f4e895d353 --- /dev/null +++ b/ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.linux-x86_64.txt @@ -0,0 +1,74 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yt-comp_nodes-llvm14 STATIC) +set_property(TARGET yt-comp_nodes-llvm14 PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(yt-comp_nodes-llvm14 PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION + $,,-Wno-everything> +) +target_include_directories(yt-comp_nodes-llvm14 PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14 + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/computation +) +target_include_directories(yt-comp_nodes-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes +) +target_link_libraries(yt-comp_nodes-llvm14 PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm14 + minikql-invoke_builtins-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + cpp-streams-brotli + library-yql-minikql + yql-public-udf + library-yql-utils + providers-common-codec + providers-common-mkql + providers-yt-codec + providers-yt-expr_nodes +) +target_sources(yt-comp_nodes-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.txt b/ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..20f3cf9c5705 --- /dev/null +++ b/ydb/library/yql/providers/yt/comp_nodes/llvm14/CMakeLists.windows-x86_64.txt @@ -0,0 +1,73 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yt-comp_nodes-llvm14 STATIC) +set_property(TARGET yt-comp_nodes-llvm14 PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(yt-comp_nodes-llvm14 PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION + $,,-Wno-everything> +) +target_include_directories(yt-comp_nodes-llvm14 PUBLIC + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14 + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/computation +) +target_include_directories(yt-comp_nodes-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes +) +target_link_libraries(yt-comp_nodes-llvm14 PUBLIC + contrib-libs-cxxsupp + yutil + minikql-codegen-llvm14 + minikql-invoke_builtins-llvm14 + llvm14-lib-IR + lib-ExecutionEngine-MCJIT + llvm14-lib-Linker + lib-Target-X86 + Target-X86-AsmParser + lib-Transforms-IPO + cpp-streams-brotli + library-yql-minikql + yql-public-udf + library-yql-utils + providers-common-codec + providers-common-mkql + providers-yt-codec + providers-yt-expr_nodes +) +target_sources(yt-comp_nodes-llvm14 PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/llvm14/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..cb5b81707316 --- /dev/null +++ b/ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.darwin-arm64.txt @@ -0,0 +1,67 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yt-comp_nodes-no_llvm STATIC) +set_property(TARGET yt-comp_nodes-no_llvm PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(yt-comp_nodes-no_llvm PRIVATE + -DMKQL_DISABLE_CODEGEN + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(yt-comp_nodes-no_llvm PUBLIC + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/llvm_stub + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/computation +) +target_include_directories(yt-comp_nodes-no_llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes +) +target_link_libraries(yt-comp_nodes-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + cpp-streams-brotli + library-yql-minikql + yql-public-udf + library-yql-utils + providers-common-codec + providers-common-mkql + providers-yt-codec + providers-yt-expr_nodes + minikql-invoke_builtins-no_llvm +) +target_sources(yt-comp_nodes-no_llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..cb5b81707316 --- /dev/null +++ b/ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,67 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yt-comp_nodes-no_llvm STATIC) +set_property(TARGET yt-comp_nodes-no_llvm PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(yt-comp_nodes-no_llvm PRIVATE + -DMKQL_DISABLE_CODEGEN + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(yt-comp_nodes-no_llvm PUBLIC + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/llvm_stub + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/computation +) +target_include_directories(yt-comp_nodes-no_llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes +) +target_link_libraries(yt-comp_nodes-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + cpp-streams-brotli + library-yql-minikql + yql-public-udf + library-yql-utils + providers-common-codec + providers-common-mkql + providers-yt-codec + providers-yt-expr_nodes + minikql-invoke_builtins-no_llvm +) +target_sources(yt-comp_nodes-no_llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..9072a823dbd3 --- /dev/null +++ b/ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.linux-aarch64.txt @@ -0,0 +1,68 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yt-comp_nodes-no_llvm STATIC) +set_property(TARGET yt-comp_nodes-no_llvm PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(yt-comp_nodes-no_llvm PRIVATE + -DMKQL_DISABLE_CODEGEN + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(yt-comp_nodes-no_llvm PUBLIC + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/llvm_stub + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/computation +) +target_include_directories(yt-comp_nodes-no_llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes +) +target_link_libraries(yt-comp_nodes-no_llvm PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-streams-brotli + library-yql-minikql + yql-public-udf + library-yql-utils + providers-common-codec + providers-common-mkql + providers-yt-codec + providers-yt-expr_nodes + minikql-invoke_builtins-no_llvm +) +target_sources(yt-comp_nodes-no_llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..9072a823dbd3 --- /dev/null +++ b/ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.linux-x86_64.txt @@ -0,0 +1,68 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yt-comp_nodes-no_llvm STATIC) +set_property(TARGET yt-comp_nodes-no_llvm PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(yt-comp_nodes-no_llvm PRIVATE + -DMKQL_DISABLE_CODEGEN + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(yt-comp_nodes-no_llvm PUBLIC + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/llvm_stub + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/computation +) +target_include_directories(yt-comp_nodes-no_llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes +) +target_link_libraries(yt-comp_nodes-no_llvm PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-streams-brotli + library-yql-minikql + yql-public-udf + library-yql-utils + providers-common-codec + providers-common-mkql + providers-yt-codec + providers-yt-expr_nodes + minikql-invoke_builtins-no_llvm +) +target_sources(yt-comp_nodes-no_llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.txt b/ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..cb5b81707316 --- /dev/null +++ b/ydb/library/yql/providers/yt/comp_nodes/no_llvm/CMakeLists.windows-x86_64.txt @@ -0,0 +1,67 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yt-comp_nodes-no_llvm STATIC) +set_property(TARGET yt-comp_nodes-no_llvm PROPERTY + LINKER_LANGUAGE CXX +) +target_compile_options(yt-comp_nodes-no_llvm PRIVATE + -DMKQL_DISABLE_CODEGEN + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(yt-comp_nodes-no_llvm PUBLIC + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/codegen/llvm_stub + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/computation +) +target_include_directories(yt-comp_nodes-no_llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/comp_nodes +) +target_link_libraries(yt-comp_nodes-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + cpp-streams-brotli + library-yql-minikql + yql-public-udf + library-yql-utils + providers-common-codec + providers-common-mkql + providers-yt-codec + providers-yt-expr_nodes + minikql-invoke_builtins-no_llvm +) +target_sources(yt-comp_nodes-no_llvm PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/computation/mkql_computation_node_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_codegen_llvm.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_impl.h +) +copy_file( + ${CMAKE_SOURCE_DIR}/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h.txt + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/comp_nodes/no_llvm/ydb/library/yql/minikql/invoke_builtins/mkql_builtins_decimal.h +) diff --git a/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.darwin-arm64.txt index 7d03fe3302f5..e62f2859e678 100644 --- a/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.darwin-arm64.txt @@ -22,7 +22,7 @@ target_link_libraries(providers-yt-dq_task_preprocessor PUBLIC yql-utils-log yql-utils-failure_injector library-yql-minikql - minikql-computation-llvm + yql-minikql-computation providers-common-codec providers-dq-interface providers-yt-codec diff --git a/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.darwin-x86_64.txt index 7d03fe3302f5..e62f2859e678 100644 --- a/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.darwin-x86_64.txt @@ -22,7 +22,7 @@ target_link_libraries(providers-yt-dq_task_preprocessor PUBLIC yql-utils-log yql-utils-failure_injector library-yql-minikql - minikql-computation-llvm + yql-minikql-computation providers-common-codec providers-dq-interface providers-yt-codec diff --git a/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.linux-aarch64.txt index b03d0481c588..88925398a5cb 100644 --- a/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.linux-aarch64.txt @@ -23,7 +23,7 @@ target_link_libraries(providers-yt-dq_task_preprocessor PUBLIC yql-utils-log yql-utils-failure_injector library-yql-minikql - minikql-computation-llvm + yql-minikql-computation providers-common-codec providers-dq-interface providers-yt-codec diff --git a/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.linux-x86_64.txt index b03d0481c588..88925398a5cb 100644 --- a/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.linux-x86_64.txt @@ -23,7 +23,7 @@ target_link_libraries(providers-yt-dq_task_preprocessor PUBLIC yql-utils-log yql-utils-failure_injector library-yql-minikql - minikql-computation-llvm + yql-minikql-computation providers-common-codec providers-dq-interface providers-yt-codec diff --git a/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.txt b/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.txt index 380079ac7b4a..d863ebd18067 100644 --- a/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.txt +++ b/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.txt @@ -14,4 +14,6 @@ elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL include(CMakeLists.darwin-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) endif() diff --git a/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..e62f2859e678 --- /dev/null +++ b/ydb/library/yql/providers/yt/dq_task_preprocessor/CMakeLists.windows-x86_64.txt @@ -0,0 +1,34 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(providers-yt-dq_task_preprocessor) +target_compile_options(providers-yt-dq_task_preprocessor PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(providers-yt-dq_task_preprocessor PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-yson + cpp-yson-node + cpp-mapreduce-common + cpp-mapreduce-interface + library-yql-utils + yql-utils-log + yql-utils-failure_injector + library-yql-minikql + yql-minikql-computation + providers-common-codec + providers-dq-interface + providers-yt-codec + yt-gateway-lib + yt-lib-yson_helpers +) +target_sources(providers-yt-dq_task_preprocessor PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/dq_task_preprocessor/yql_yt_dq_task_preprocessor.cpp +) diff --git a/ydb/library/yql/providers/yt/expr_nodes/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/expr_nodes/CMakeLists.darwin-arm64.txt index ed0dc39cb7dd..f93289639b10 100644 --- a/ydb/library/yql/providers/yt/expr_nodes/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/yt/expr_nodes/CMakeLists.darwin-arm64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-yt-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-yt-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/yt/expr_nodes/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/expr_nodes/CMakeLists.darwin-x86_64.txt index ed0dc39cb7dd..f93289639b10 100644 --- a/ydb/library/yql/providers/yt/expr_nodes/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/yt/expr_nodes/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-yt-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-yt-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/yt/expr_nodes/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/expr_nodes/CMakeLists.linux-aarch64.txt index b1b99d65f9d4..fcc572b061b0 100644 --- a/ydb/library/yql/providers/yt/expr_nodes/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/yt/expr_nodes/CMakeLists.linux-aarch64.txt @@ -17,6 +17,9 @@ target_link_libraries(providers-yt-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-yt-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/yt/expr_nodes/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/expr_nodes/CMakeLists.linux-x86_64.txt index b1b99d65f9d4..fcc572b061b0 100644 --- a/ydb/library/yql/providers/yt/expr_nodes/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/yt/expr_nodes/CMakeLists.linux-x86_64.txt @@ -17,6 +17,9 @@ target_link_libraries(providers-yt-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-yt-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/yt/expr_nodes/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/expr_nodes/CMakeLists.windows-x86_64.txt index ed0dc39cb7dd..f93289639b10 100644 --- a/ydb/library/yql/providers/yt/expr_nodes/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/yt/expr_nodes/CMakeLists.windows-x86_64.txt @@ -16,6 +16,9 @@ target_link_libraries(providers-yt-expr_nodes PUBLIC providers-common-provider ) target_sources(providers-yt-expr_nodes PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.gen.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.decl.inl.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.defs.inl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.cpp ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.gen.h ${CMAKE_BINARY_DIR}/ydb/library/yql/providers/yt/expr_nodes/yql_yt_expr_nodes.decl.inl.h diff --git a/ydb/library/yql/providers/yt/gateway/file/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/gateway/file/CMakeLists.darwin-arm64.txt index 323acc09e87d..429e5b4e1e5b 100644 --- a/ydb/library/yql/providers/yt/gateway/file/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/yt/gateway/file/CMakeLists.darwin-arm64.txt @@ -21,7 +21,7 @@ target_link_libraries(yt-gateway-file PUBLIC yql-core-file_storage core-file_storage-proto core-file_storage-http_download - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-public-udf library-yql-utils yql-utils-threading diff --git a/ydb/library/yql/providers/yt/gateway/file/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/gateway/file/CMakeLists.darwin-x86_64.txt index 323acc09e87d..429e5b4e1e5b 100644 --- a/ydb/library/yql/providers/yt/gateway/file/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/yt/gateway/file/CMakeLists.darwin-x86_64.txt @@ -21,7 +21,7 @@ target_link_libraries(yt-gateway-file PUBLIC yql-core-file_storage core-file_storage-proto core-file_storage-http_download - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-public-udf library-yql-utils yql-utils-threading diff --git a/ydb/library/yql/providers/yt/gateway/file/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/gateway/file/CMakeLists.linux-aarch64.txt index 33f1a8c2fcc2..e6945c9bd465 100644 --- a/ydb/library/yql/providers/yt/gateway/file/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/yt/gateway/file/CMakeLists.linux-aarch64.txt @@ -22,7 +22,7 @@ target_link_libraries(yt-gateway-file PUBLIC yql-core-file_storage core-file_storage-proto core-file_storage-http_download - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-public-udf library-yql-utils yql-utils-threading diff --git a/ydb/library/yql/providers/yt/gateway/file/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/gateway/file/CMakeLists.linux-x86_64.txt index 33f1a8c2fcc2..e6945c9bd465 100644 --- a/ydb/library/yql/providers/yt/gateway/file/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/yt/gateway/file/CMakeLists.linux-x86_64.txt @@ -22,7 +22,7 @@ target_link_libraries(yt-gateway-file PUBLIC yql-core-file_storage core-file_storage-proto core-file_storage-http_download - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-public-udf library-yql-utils yql-utils-threading diff --git a/ydb/library/yql/providers/yt/gateway/file/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/gateway/file/CMakeLists.windows-x86_64.txt index 323acc09e87d..429e5b4e1e5b 100644 --- a/ydb/library/yql/providers/yt/gateway/file/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/yt/gateway/file/CMakeLists.windows-x86_64.txt @@ -21,7 +21,7 @@ target_link_libraries(yt-gateway-file PUBLIC yql-core-file_storage core-file_storage-proto core-file_storage-http_download - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-public-udf library-yql-utils yql-utils-threading diff --git a/ydb/library/yql/providers/yt/gateway/lib/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/gateway/lib/CMakeLists.darwin-arm64.txt index 6721e4c5ba97..ea4e3c1ab9ec 100644 --- a/ydb/library/yql/providers/yt/gateway/lib/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/yt/gateway/lib/CMakeLists.darwin-arm64.txt @@ -36,6 +36,11 @@ target_link_libraries(yt-gateway-lib PUBLIC yt-lib-yson_helpers ) target_sources(yt-gateway-lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/query_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/temp_files.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/transaction_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/user_files.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/yt_helpers.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/query_cache.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/temp_files.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/transaction_cache.cpp diff --git a/ydb/library/yql/providers/yt/gateway/lib/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/gateway/lib/CMakeLists.darwin-x86_64.txt index 6721e4c5ba97..ea4e3c1ab9ec 100644 --- a/ydb/library/yql/providers/yt/gateway/lib/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/yt/gateway/lib/CMakeLists.darwin-x86_64.txt @@ -36,6 +36,11 @@ target_link_libraries(yt-gateway-lib PUBLIC yt-lib-yson_helpers ) target_sources(yt-gateway-lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/query_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/temp_files.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/transaction_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/user_files.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/yt_helpers.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/query_cache.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/temp_files.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/transaction_cache.cpp diff --git a/ydb/library/yql/providers/yt/gateway/lib/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/gateway/lib/CMakeLists.linux-aarch64.txt index fee6ac163b66..9203828499f4 100644 --- a/ydb/library/yql/providers/yt/gateway/lib/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/yt/gateway/lib/CMakeLists.linux-aarch64.txt @@ -37,6 +37,11 @@ target_link_libraries(yt-gateway-lib PUBLIC yt-lib-yson_helpers ) target_sources(yt-gateway-lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/query_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/temp_files.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/transaction_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/user_files.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/yt_helpers.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/query_cache.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/temp_files.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/transaction_cache.cpp diff --git a/ydb/library/yql/providers/yt/gateway/lib/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/gateway/lib/CMakeLists.linux-x86_64.txt index fee6ac163b66..9203828499f4 100644 --- a/ydb/library/yql/providers/yt/gateway/lib/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/yt/gateway/lib/CMakeLists.linux-x86_64.txt @@ -37,6 +37,11 @@ target_link_libraries(yt-gateway-lib PUBLIC yt-lib-yson_helpers ) target_sources(yt-gateway-lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/query_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/temp_files.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/transaction_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/user_files.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/yt_helpers.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/query_cache.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/temp_files.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/transaction_cache.cpp diff --git a/ydb/library/yql/providers/yt/gateway/lib/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/gateway/lib/CMakeLists.windows-x86_64.txt index 6721e4c5ba97..ea4e3c1ab9ec 100644 --- a/ydb/library/yql/providers/yt/gateway/lib/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/yt/gateway/lib/CMakeLists.windows-x86_64.txt @@ -36,6 +36,11 @@ target_link_libraries(yt-gateway-lib PUBLIC yt-lib-yson_helpers ) target_sources(yt-gateway-lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/query_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/temp_files.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/transaction_cache.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/user_files.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/yt_helpers.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/query_cache.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/temp_files.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/lib/transaction_cache.cpp diff --git a/ydb/library/yql/providers/yt/gateway/native/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/gateway/native/CMakeLists.darwin-arm64.txt index f8b5242d5612..a6b920fbc757 100644 --- a/ydb/library/yql/providers/yt/gateway/native/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/yt/gateway/native/CMakeLists.darwin-arm64.txt @@ -27,7 +27,7 @@ target_link_libraries(yt-gateway-native PUBLIC cpp-mapreduce-interface library-yql-ast yql-core-file_storage - minikql-comp_nodes-llvm + yql-minikql-comp_nodes library-yql-utils yql-utils-log yql-utils-threading diff --git a/ydb/library/yql/providers/yt/gateway/native/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/gateway/native/CMakeLists.darwin-x86_64.txt index f8b5242d5612..a6b920fbc757 100644 --- a/ydb/library/yql/providers/yt/gateway/native/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/yt/gateway/native/CMakeLists.darwin-x86_64.txt @@ -27,7 +27,7 @@ target_link_libraries(yt-gateway-native PUBLIC cpp-mapreduce-interface library-yql-ast yql-core-file_storage - minikql-comp_nodes-llvm + yql-minikql-comp_nodes library-yql-utils yql-utils-log yql-utils-threading diff --git a/ydb/library/yql/providers/yt/gateway/native/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/gateway/native/CMakeLists.linux-aarch64.txt index 06abdf6b882f..8aa735476506 100644 --- a/ydb/library/yql/providers/yt/gateway/native/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/yt/gateway/native/CMakeLists.linux-aarch64.txt @@ -28,7 +28,7 @@ target_link_libraries(yt-gateway-native PUBLIC cpp-mapreduce-interface library-yql-ast yql-core-file_storage - minikql-comp_nodes-llvm + yql-minikql-comp_nodes library-yql-utils yql-utils-log yql-utils-threading diff --git a/ydb/library/yql/providers/yt/gateway/native/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/gateway/native/CMakeLists.linux-x86_64.txt index 06abdf6b882f..8aa735476506 100644 --- a/ydb/library/yql/providers/yt/gateway/native/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/yt/gateway/native/CMakeLists.linux-x86_64.txt @@ -28,7 +28,7 @@ target_link_libraries(yt-gateway-native PUBLIC cpp-mapreduce-interface library-yql-ast yql-core-file_storage - minikql-comp_nodes-llvm + yql-minikql-comp_nodes library-yql-utils yql-utils-log yql-utils-threading diff --git a/ydb/library/yql/providers/yt/gateway/native/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/gateway/native/CMakeLists.windows-x86_64.txt index f8b5242d5612..a6b920fbc757 100644 --- a/ydb/library/yql/providers/yt/gateway/native/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/yt/gateway/native/CMakeLists.windows-x86_64.txt @@ -27,7 +27,7 @@ target_link_libraries(yt-gateway-native PUBLIC cpp-mapreduce-interface library-yql-ast yql-core-file_storage - minikql-comp_nodes-llvm + yql-minikql-comp_nodes library-yql-utils yql-utils-log yql-utils-threading diff --git a/ydb/library/yql/providers/yt/gateway/native/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/gateway/native/ut/CMakeLists.darwin-arm64.txt index 3212f5b67fd8..e3cc8565b489 100644 --- a/ydb/library/yql/providers/yt/gateway/native/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/yt/gateway/native/ut/CMakeLists.darwin-arm64.txt @@ -17,18 +17,20 @@ target_link_libraries(ydb-library-yql-providers-yt-gateway-native-ut PUBLIC cpp-testing-unittest_main yt-gateway-native yt-gateway-file + yt-codec-codegen + yt-comp_nodes-llvm14 yql-core-ut_common cpp-testing-mock_server cpp-testing-common udf-service-terminate_policy yql-sql-pg + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 ) target_link_options(ydb-library-yql-providers-yt-gateway-native-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-yt-gateway-native-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/native/ut/yql_yt_native_folders_ut.cpp @@ -58,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/yt/gateway/native/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/gateway/native/ut/CMakeLists.darwin-x86_64.txt index f82906144be5..de6ef5bd3caa 100644 --- a/ydb/library/yql/providers/yt/gateway/native/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/yt/gateway/native/ut/CMakeLists.darwin-x86_64.txt @@ -18,18 +18,20 @@ target_link_libraries(ydb-library-yql-providers-yt-gateway-native-ut PUBLIC cpp-testing-unittest_main yt-gateway-native yt-gateway-file + yt-codec-codegen + yt-comp_nodes-llvm14 yql-core-ut_common cpp-testing-mock_server cpp-testing-common udf-service-terminate_policy yql-sql-pg + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 ) target_link_options(ydb-library-yql-providers-yt-gateway-native-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-yt-gateway-native-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/native/ut/yql_yt_native_folders_ut.cpp @@ -59,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/yt/gateway/native/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/gateway/native/ut/CMakeLists.linux-aarch64.txt index db240f6fe494..ebb2fa774530 100644 --- a/ydb/library/yql/providers/yt/gateway/native/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/yt/gateway/native/ut/CMakeLists.linux-aarch64.txt @@ -18,11 +18,15 @@ target_link_libraries(ydb-library-yql-providers-yt-gateway-native-ut PUBLIC cpp-testing-unittest_main yt-gateway-native yt-gateway-file + yt-codec-codegen + yt-comp_nodes-llvm14 yql-core-ut_common cpp-testing-mock_server cpp-testing-common udf-service-terminate_policy yql-sql-pg + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 ) target_link_options(ydb-library-yql-providers-yt-gateway-native-ut PRIVATE -ldl @@ -30,10 +34,6 @@ target_link_options(ydb-library-yql-providers-yt-gateway-native-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(ydb-library-yql-providers-yt-gateway-native-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/native/ut/yql_yt_native_folders_ut.cpp @@ -63,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/yt/gateway/native/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/gateway/native/ut/CMakeLists.linux-x86_64.txt index 706267e53940..625ff5300e11 100644 --- a/ydb/library/yql/providers/yt/gateway/native/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/yt/gateway/native/ut/CMakeLists.linux-x86_64.txt @@ -19,11 +19,15 @@ target_link_libraries(ydb-library-yql-providers-yt-gateway-native-ut PUBLIC cpp-testing-unittest_main yt-gateway-native yt-gateway-file + yt-codec-codegen + yt-comp_nodes-llvm14 yql-core-ut_common cpp-testing-mock_server cpp-testing-common udf-service-terminate_policy yql-sql-pg + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 ) target_link_options(ydb-library-yql-providers-yt-gateway-native-ut PRIVATE -ldl @@ -31,10 +35,6 @@ target_link_options(ydb-library-yql-providers-yt-gateway-native-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(ydb-library-yql-providers-yt-gateway-native-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/native/ut/yql_yt_native_folders_ut.cpp @@ -64,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/yt/gateway/native/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/gateway/native/ut/CMakeLists.windows-x86_64.txt index ca24288198f4..c6f91f0b23ea 100644 --- a/ydb/library/yql/providers/yt/gateway/native/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/yt/gateway/native/ut/CMakeLists.windows-x86_64.txt @@ -18,11 +18,15 @@ target_link_libraries(ydb-library-yql-providers-yt-gateway-native-ut PUBLIC cpp-testing-unittest_main yt-gateway-native yt-gateway-file + yt-codec-codegen + yt-comp_nodes-llvm14 yql-core-ut_common cpp-testing-mock_server cpp-testing-common udf-service-terminate_policy yql-sql-pg + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 ) target_sources(ydb-library-yql-providers-yt-gateway-native-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/gateway/native/ut/yql_yt_native_folders_ut.cpp @@ -52,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/yt/job/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/job/CMakeLists.darwin-arm64.txt index d8fe463cb8a4..6ecc1f2c62d0 100644 --- a/ydb/library/yql/providers/yt/job/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/yt/job/CMakeLists.darwin-arm64.txt @@ -20,7 +20,7 @@ target_link_libraries(providers-yt-job PUBLIC cpp-yson-node cpp-mapreduce-interface mapreduce-library-user_job_statistics - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-public-udf library-yql-utils yql-utils-backtrace @@ -37,6 +37,7 @@ target_link_libraries(providers-yt-job PUBLIC yt-lib-mkql_helpers ) target_sources(providers-yt-job PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/job/yql_job_registry.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/job/yql_job_base.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/job/yql_job_calc.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/job/yql_job_factory.cpp diff --git a/ydb/library/yql/providers/yt/job/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/job/CMakeLists.darwin-x86_64.txt index d8fe463cb8a4..6ecc1f2c62d0 100644 --- a/ydb/library/yql/providers/yt/job/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/yt/job/CMakeLists.darwin-x86_64.txt @@ -20,7 +20,7 @@ target_link_libraries(providers-yt-job PUBLIC cpp-yson-node cpp-mapreduce-interface mapreduce-library-user_job_statistics - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-public-udf library-yql-utils yql-utils-backtrace @@ -37,6 +37,7 @@ target_link_libraries(providers-yt-job PUBLIC yt-lib-mkql_helpers ) target_sources(providers-yt-job PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/job/yql_job_registry.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/job/yql_job_base.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/job/yql_job_calc.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/job/yql_job_factory.cpp diff --git a/ydb/library/yql/providers/yt/job/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/job/CMakeLists.linux-aarch64.txt index 2b08e8872b6e..9a4d4d86fb1e 100644 --- a/ydb/library/yql/providers/yt/job/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/yt/job/CMakeLists.linux-aarch64.txt @@ -21,7 +21,7 @@ target_link_libraries(providers-yt-job PUBLIC cpp-yson-node cpp-mapreduce-interface mapreduce-library-user_job_statistics - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-public-udf library-yql-utils yql-utils-backtrace @@ -38,6 +38,7 @@ target_link_libraries(providers-yt-job PUBLIC yt-lib-mkql_helpers ) target_sources(providers-yt-job PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/job/yql_job_registry.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/job/yql_job_base.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/job/yql_job_calc.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/job/yql_job_factory.cpp diff --git a/ydb/library/yql/providers/yt/job/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/job/CMakeLists.linux-x86_64.txt index 2b08e8872b6e..9a4d4d86fb1e 100644 --- a/ydb/library/yql/providers/yt/job/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/yt/job/CMakeLists.linux-x86_64.txt @@ -21,7 +21,7 @@ target_link_libraries(providers-yt-job PUBLIC cpp-yson-node cpp-mapreduce-interface mapreduce-library-user_job_statistics - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-public-udf library-yql-utils yql-utils-backtrace @@ -38,6 +38,7 @@ target_link_libraries(providers-yt-job PUBLIC yt-lib-mkql_helpers ) target_sources(providers-yt-job PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/job/yql_job_registry.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/job/yql_job_base.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/job/yql_job_calc.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/job/yql_job_factory.cpp diff --git a/ydb/library/yql/providers/yt/job/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/job/CMakeLists.windows-x86_64.txt index d8fe463cb8a4..6ecc1f2c62d0 100644 --- a/ydb/library/yql/providers/yt/job/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/yt/job/CMakeLists.windows-x86_64.txt @@ -20,7 +20,7 @@ target_link_libraries(providers-yt-job PUBLIC cpp-yson-node cpp-mapreduce-interface mapreduce-library-user_job_statistics - minikql-comp_nodes-llvm + yql-minikql-comp_nodes yql-public-udf library-yql-utils yql-utils-backtrace @@ -37,6 +37,7 @@ target_link_libraries(providers-yt-job PUBLIC yt-lib-mkql_helpers ) target_sources(providers-yt-job PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/job/yql_job_registry.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/job/yql_job_base.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/job/yql_job_calc.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/job/yql_job_factory.cpp diff --git a/ydb/library/yql/providers/yt/lib/config_clusters/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/lib/config_clusters/CMakeLists.darwin-arm64.txt index 65bef0287b89..9255c145df54 100644 --- a/ydb/library/yql/providers/yt/lib/config_clusters/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/yt/lib/config_clusters/CMakeLists.darwin-arm64.txt @@ -14,5 +14,6 @@ target_link_libraries(yt-lib-config_clusters PUBLIC providers-common-proto ) target_sources(yt-lib-config_clusters PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/config_clusters/config_clusters.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/config_clusters/config_clusters.cpp ) diff --git a/ydb/library/yql/providers/yt/lib/config_clusters/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/lib/config_clusters/CMakeLists.darwin-x86_64.txt index 65bef0287b89..9255c145df54 100644 --- a/ydb/library/yql/providers/yt/lib/config_clusters/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/yt/lib/config_clusters/CMakeLists.darwin-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(yt-lib-config_clusters PUBLIC providers-common-proto ) target_sources(yt-lib-config_clusters PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/config_clusters/config_clusters.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/config_clusters/config_clusters.cpp ) diff --git a/ydb/library/yql/providers/yt/lib/config_clusters/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/lib/config_clusters/CMakeLists.linux-aarch64.txt index 5ea0218edbe0..3705fb96a3d5 100644 --- a/ydb/library/yql/providers/yt/lib/config_clusters/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/yt/lib/config_clusters/CMakeLists.linux-aarch64.txt @@ -15,5 +15,6 @@ target_link_libraries(yt-lib-config_clusters PUBLIC providers-common-proto ) target_sources(yt-lib-config_clusters PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/config_clusters/config_clusters.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/config_clusters/config_clusters.cpp ) diff --git a/ydb/library/yql/providers/yt/lib/config_clusters/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/lib/config_clusters/CMakeLists.linux-x86_64.txt index 5ea0218edbe0..3705fb96a3d5 100644 --- a/ydb/library/yql/providers/yt/lib/config_clusters/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/yt/lib/config_clusters/CMakeLists.linux-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(yt-lib-config_clusters PUBLIC providers-common-proto ) target_sources(yt-lib-config_clusters PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/config_clusters/config_clusters.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/config_clusters/config_clusters.cpp ) diff --git a/ydb/library/yql/providers/yt/lib/config_clusters/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/lib/config_clusters/CMakeLists.windows-x86_64.txt index 65bef0287b89..9255c145df54 100644 --- a/ydb/library/yql/providers/yt/lib/config_clusters/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/yt/lib/config_clusters/CMakeLists.windows-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(yt-lib-config_clusters PUBLIC providers-common-proto ) target_sources(yt-lib-config_clusters PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/config_clusters/config_clusters.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/config_clusters/config_clusters.cpp ) diff --git a/ydb/library/yql/providers/yt/lib/expr_traits/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/lib/expr_traits/CMakeLists.darwin-arm64.txt index 043abfbe19ae..3eb100b1d142 100644 --- a/ydb/library/yql/providers/yt/lib/expr_traits/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/yt/lib/expr_traits/CMakeLists.darwin-arm64.txt @@ -15,7 +15,7 @@ target_link_libraries(yt-lib-expr_traits PUBLIC contrib-libs-cxxsupp yutil library-yql-ast - minikql-computation-llvm + yql-minikql-computation yql-utils-log library-yql-core yql-core-expr_nodes diff --git a/ydb/library/yql/providers/yt/lib/expr_traits/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/lib/expr_traits/CMakeLists.darwin-x86_64.txt index 043abfbe19ae..3eb100b1d142 100644 --- a/ydb/library/yql/providers/yt/lib/expr_traits/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/yt/lib/expr_traits/CMakeLists.darwin-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(yt-lib-expr_traits PUBLIC contrib-libs-cxxsupp yutil library-yql-ast - minikql-computation-llvm + yql-minikql-computation yql-utils-log library-yql-core yql-core-expr_nodes diff --git a/ydb/library/yql/providers/yt/lib/expr_traits/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/lib/expr_traits/CMakeLists.linux-aarch64.txt index 2f1f86b50efb..37eaaa620071 100644 --- a/ydb/library/yql/providers/yt/lib/expr_traits/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/yt/lib/expr_traits/CMakeLists.linux-aarch64.txt @@ -16,7 +16,7 @@ target_link_libraries(yt-lib-expr_traits PUBLIC contrib-libs-cxxsupp yutil library-yql-ast - minikql-computation-llvm + yql-minikql-computation yql-utils-log library-yql-core yql-core-expr_nodes diff --git a/ydb/library/yql/providers/yt/lib/expr_traits/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/lib/expr_traits/CMakeLists.linux-x86_64.txt index 2f1f86b50efb..37eaaa620071 100644 --- a/ydb/library/yql/providers/yt/lib/expr_traits/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/yt/lib/expr_traits/CMakeLists.linux-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(yt-lib-expr_traits PUBLIC contrib-libs-cxxsupp yutil library-yql-ast - minikql-computation-llvm + yql-minikql-computation yql-utils-log library-yql-core yql-core-expr_nodes diff --git a/ydb/library/yql/providers/yt/lib/expr_traits/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/lib/expr_traits/CMakeLists.windows-x86_64.txt index 043abfbe19ae..3eb100b1d142 100644 --- a/ydb/library/yql/providers/yt/lib/expr_traits/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/yt/lib/expr_traits/CMakeLists.windows-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(yt-lib-expr_traits PUBLIC contrib-libs-cxxsupp yutil library-yql-ast - minikql-computation-llvm + yql-minikql-computation yql-utils-log library-yql-core yql-core-expr_nodes diff --git a/ydb/library/yql/providers/yt/lib/hash/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/lib/hash/CMakeLists.darwin-arm64.txt index 83599316ec7a..6f86785c374c 100644 --- a/ydb/library/yql/providers/yt/lib/hash/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/yt/lib/hash/CMakeLists.darwin-arm64.txt @@ -16,6 +16,7 @@ target_link_libraries(yt-lib-hash PUBLIC library-yql-utils yql-utils-log library-yql-core + yql-core-expr_nodes ) target_sources(yt-lib-hash PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/hash/yql_hash_builder.cpp diff --git a/ydb/library/yql/providers/yt/lib/hash/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/lib/hash/CMakeLists.darwin-x86_64.txt index 83599316ec7a..6f86785c374c 100644 --- a/ydb/library/yql/providers/yt/lib/hash/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/yt/lib/hash/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,7 @@ target_link_libraries(yt-lib-hash PUBLIC library-yql-utils yql-utils-log library-yql-core + yql-core-expr_nodes ) target_sources(yt-lib-hash PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/hash/yql_hash_builder.cpp diff --git a/ydb/library/yql/providers/yt/lib/hash/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/lib/hash/CMakeLists.linux-aarch64.txt index 99d1aa98ac18..2c8e7fe1afbe 100644 --- a/ydb/library/yql/providers/yt/lib/hash/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/yt/lib/hash/CMakeLists.linux-aarch64.txt @@ -17,6 +17,7 @@ target_link_libraries(yt-lib-hash PUBLIC library-yql-utils yql-utils-log library-yql-core + yql-core-expr_nodes ) target_sources(yt-lib-hash PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/hash/yql_hash_builder.cpp diff --git a/ydb/library/yql/providers/yt/lib/hash/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/lib/hash/CMakeLists.linux-x86_64.txt index 99d1aa98ac18..2c8e7fe1afbe 100644 --- a/ydb/library/yql/providers/yt/lib/hash/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/yt/lib/hash/CMakeLists.linux-x86_64.txt @@ -17,6 +17,7 @@ target_link_libraries(yt-lib-hash PUBLIC library-yql-utils yql-utils-log library-yql-core + yql-core-expr_nodes ) target_sources(yt-lib-hash PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/hash/yql_hash_builder.cpp diff --git a/ydb/library/yql/providers/yt/lib/hash/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/lib/hash/CMakeLists.windows-x86_64.txt index 83599316ec7a..6f86785c374c 100644 --- a/ydb/library/yql/providers/yt/lib/hash/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/yt/lib/hash/CMakeLists.windows-x86_64.txt @@ -16,6 +16,7 @@ target_link_libraries(yt-lib-hash PUBLIC library-yql-utils yql-utils-log library-yql-core + yql-core-expr_nodes ) target_sources(yt-lib-hash PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/hash/yql_hash_builder.cpp diff --git a/ydb/library/yql/providers/yt/lib/lambda_builder/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/lib/lambda_builder/CMakeLists.darwin-arm64.txt index aaf3957c88ac..978eba334842 100644 --- a/ydb/library/yql/providers/yt/lib/lambda_builder/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/yt/lib/lambda_builder/CMakeLists.darwin-arm64.txt @@ -17,7 +17,7 @@ target_link_libraries(yt-lib-lambda_builder PUBLIC library-cpp-random_provider library-cpp-time_provider library-yql-ast - minikql-computation-llvm + yql-minikql-computation yql-public-udf library-yql-utils providers-common-mkql diff --git a/ydb/library/yql/providers/yt/lib/lambda_builder/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/lib/lambda_builder/CMakeLists.darwin-x86_64.txt index aaf3957c88ac..978eba334842 100644 --- a/ydb/library/yql/providers/yt/lib/lambda_builder/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/yt/lib/lambda_builder/CMakeLists.darwin-x86_64.txt @@ -17,7 +17,7 @@ target_link_libraries(yt-lib-lambda_builder PUBLIC library-cpp-random_provider library-cpp-time_provider library-yql-ast - minikql-computation-llvm + yql-minikql-computation yql-public-udf library-yql-utils providers-common-mkql diff --git a/ydb/library/yql/providers/yt/lib/lambda_builder/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/lib/lambda_builder/CMakeLists.linux-aarch64.txt index d4bdc5f092b5..2214fcb2349d 100644 --- a/ydb/library/yql/providers/yt/lib/lambda_builder/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/yt/lib/lambda_builder/CMakeLists.linux-aarch64.txt @@ -18,7 +18,7 @@ target_link_libraries(yt-lib-lambda_builder PUBLIC library-cpp-random_provider library-cpp-time_provider library-yql-ast - minikql-computation-llvm + yql-minikql-computation yql-public-udf library-yql-utils providers-common-mkql diff --git a/ydb/library/yql/providers/yt/lib/lambda_builder/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/lib/lambda_builder/CMakeLists.linux-x86_64.txt index d4bdc5f092b5..2214fcb2349d 100644 --- a/ydb/library/yql/providers/yt/lib/lambda_builder/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/yt/lib/lambda_builder/CMakeLists.linux-x86_64.txt @@ -18,7 +18,7 @@ target_link_libraries(yt-lib-lambda_builder PUBLIC library-cpp-random_provider library-cpp-time_provider library-yql-ast - minikql-computation-llvm + yql-minikql-computation yql-public-udf library-yql-utils providers-common-mkql diff --git a/ydb/library/yql/providers/yt/lib/lambda_builder/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/lib/lambda_builder/CMakeLists.windows-x86_64.txt index aaf3957c88ac..978eba334842 100644 --- a/ydb/library/yql/providers/yt/lib/lambda_builder/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/yt/lib/lambda_builder/CMakeLists.windows-x86_64.txt @@ -17,7 +17,7 @@ target_link_libraries(yt-lib-lambda_builder PUBLIC library-cpp-random_provider library-cpp-time_provider library-yql-ast - minikql-computation-llvm + yql-minikql-computation yql-public-udf library-yql-utils providers-common-mkql diff --git a/ydb/library/yql/providers/yt/lib/log/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/lib/log/CMakeLists.darwin-arm64.txt index a9eff09932fc..c61a342045dc 100644 --- a/ydb/library/yql/providers/yt/lib/log/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/yt/lib/log/CMakeLists.darwin-arm64.txt @@ -16,5 +16,6 @@ target_link_libraries(yt-lib-log PUBLIC yql-utils-log ) target_sources(yt-lib-log PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/log/yt_logger.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/log/yt_logger.cpp ) diff --git a/ydb/library/yql/providers/yt/lib/log/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/lib/log/CMakeLists.darwin-x86_64.txt index a9eff09932fc..c61a342045dc 100644 --- a/ydb/library/yql/providers/yt/lib/log/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/yt/lib/log/CMakeLists.darwin-x86_64.txt @@ -16,5 +16,6 @@ target_link_libraries(yt-lib-log PUBLIC yql-utils-log ) target_sources(yt-lib-log PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/log/yt_logger.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/log/yt_logger.cpp ) diff --git a/ydb/library/yql/providers/yt/lib/log/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/lib/log/CMakeLists.linux-aarch64.txt index 1e2645d272ed..3264f6fd429c 100644 --- a/ydb/library/yql/providers/yt/lib/log/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/yt/lib/log/CMakeLists.linux-aarch64.txt @@ -17,5 +17,6 @@ target_link_libraries(yt-lib-log PUBLIC yql-utils-log ) target_sources(yt-lib-log PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/log/yt_logger.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/log/yt_logger.cpp ) diff --git a/ydb/library/yql/providers/yt/lib/log/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/lib/log/CMakeLists.linux-x86_64.txt index 1e2645d272ed..3264f6fd429c 100644 --- a/ydb/library/yql/providers/yt/lib/log/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/yt/lib/log/CMakeLists.linux-x86_64.txt @@ -17,5 +17,6 @@ target_link_libraries(yt-lib-log PUBLIC yql-utils-log ) target_sources(yt-lib-log PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/log/yt_logger.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/log/yt_logger.cpp ) diff --git a/ydb/library/yql/providers/yt/lib/log/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/lib/log/CMakeLists.windows-x86_64.txt index a9eff09932fc..c61a342045dc 100644 --- a/ydb/library/yql/providers/yt/lib/log/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/yt/lib/log/CMakeLists.windows-x86_64.txt @@ -16,5 +16,6 @@ target_link_libraries(yt-lib-log PUBLIC yql-utils-log ) target_sources(yt-lib-log PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/log/yt_logger.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/lib/log/yt_logger.cpp ) diff --git a/ydb/library/yql/providers/yt/provider/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/provider/CMakeLists.darwin-arm64.txt index 0ccf8f945474..769d7bdc605e 100644 --- a/ydb/library/yql/providers/yt/provider/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/yt/provider/CMakeLists.darwin-arm64.txt @@ -73,6 +73,8 @@ target_link_libraries(providers-yt-provider PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(providers-yt-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_provider_impl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_datasink_constraints.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_datasink_exec.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_datasink_finalize.cpp diff --git a/ydb/library/yql/providers/yt/provider/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/provider/CMakeLists.darwin-x86_64.txt index 0ccf8f945474..769d7bdc605e 100644 --- a/ydb/library/yql/providers/yt/provider/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/yt/provider/CMakeLists.darwin-x86_64.txt @@ -73,6 +73,8 @@ target_link_libraries(providers-yt-provider PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(providers-yt-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_provider_impl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_datasink_constraints.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_datasink_exec.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_datasink_finalize.cpp diff --git a/ydb/library/yql/providers/yt/provider/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/provider/CMakeLists.linux-aarch64.txt index 1ddc770b112e..f8a494c5c7d5 100644 --- a/ydb/library/yql/providers/yt/provider/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/yt/provider/CMakeLists.linux-aarch64.txt @@ -74,6 +74,8 @@ target_link_libraries(providers-yt-provider PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(providers-yt-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_provider_impl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_datasink_constraints.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_datasink_exec.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_datasink_finalize.cpp diff --git a/ydb/library/yql/providers/yt/provider/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/provider/CMakeLists.linux-x86_64.txt index 1ddc770b112e..f8a494c5c7d5 100644 --- a/ydb/library/yql/providers/yt/provider/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/yt/provider/CMakeLists.linux-x86_64.txt @@ -74,6 +74,8 @@ target_link_libraries(providers-yt-provider PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(providers-yt-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_provider_impl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_datasink_constraints.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_datasink_exec.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_datasink_finalize.cpp diff --git a/ydb/library/yql/providers/yt/provider/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/provider/CMakeLists.windows-x86_64.txt index 0ccf8f945474..769d7bdc605e 100644 --- a/ydb/library/yql/providers/yt/provider/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/yt/provider/CMakeLists.windows-x86_64.txt @@ -73,6 +73,8 @@ target_link_libraries(providers-yt-provider PUBLIC tools-enum_parser-enum_serialization_runtime ) target_sources(providers-yt-provider PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_provider.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_provider_impl.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_datasink_constraints.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_datasink_exec.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/yql_yt_datasink_finalize.cpp diff --git a/ydb/library/yql/providers/yt/provider/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/providers/yt/provider/ut/CMakeLists.darwin-arm64.txt index efcc86d4c365..11de8467a5e0 100644 --- a/ydb/library/yql/providers/yt/provider/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/providers/yt/provider/ut/CMakeLists.darwin-arm64.txt @@ -21,6 +21,8 @@ target_link_libraries(ydb-library-yql-providers-yt-provider-ut PUBLIC providers-yt-provider yt-lib-schema yt-gateway-file + yt-codec-codegen + yt-comp_nodes-llvm14 yql-core-ut_common library-yql-ast udf-service-terminate_policy @@ -34,15 +36,14 @@ target_link_libraries(ydb-library-yql-providers-yt-provider-ut PUBLIC providers-dq-provider providers-result-provider yql-sql-v1 - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 + minikql-comp_nodes-llvm14 yql-sql-pg ) target_link_options(ydb-library-yql-providers-yt-provider-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-yt-provider-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/ut/yql_yt_dq_integration_ut.cpp @@ -74,6 +75,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/yt/provider/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/providers/yt/provider/ut/CMakeLists.darwin-x86_64.txt index dfa077e6df60..d79caca22122 100644 --- a/ydb/library/yql/providers/yt/provider/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/providers/yt/provider/ut/CMakeLists.darwin-x86_64.txt @@ -22,6 +22,8 @@ target_link_libraries(ydb-library-yql-providers-yt-provider-ut PUBLIC providers-yt-provider yt-lib-schema yt-gateway-file + yt-codec-codegen + yt-comp_nodes-llvm14 yql-core-ut_common library-yql-ast udf-service-terminate_policy @@ -35,15 +37,14 @@ target_link_libraries(ydb-library-yql-providers-yt-provider-ut PUBLIC providers-dq-provider providers-result-provider yql-sql-v1 - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 + minikql-comp_nodes-llvm14 yql-sql-pg ) target_link_options(ydb-library-yql-providers-yt-provider-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-providers-yt-provider-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/ut/yql_yt_dq_integration_ut.cpp @@ -75,6 +76,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/yt/provider/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/providers/yt/provider/ut/CMakeLists.linux-aarch64.txt index 1389d843ed45..6f8dccf160e7 100644 --- a/ydb/library/yql/providers/yt/provider/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/providers/yt/provider/ut/CMakeLists.linux-aarch64.txt @@ -22,6 +22,8 @@ target_link_libraries(ydb-library-yql-providers-yt-provider-ut PUBLIC providers-yt-provider yt-lib-schema yt-gateway-file + yt-codec-codegen + yt-comp_nodes-llvm14 yql-core-ut_common library-yql-ast udf-service-terminate_policy @@ -35,7 +37,8 @@ target_link_libraries(ydb-library-yql-providers-yt-provider-ut PUBLIC providers-dq-provider providers-result-provider yql-sql-v1 - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 + minikql-comp_nodes-llvm14 yql-sql-pg ) target_link_options(ydb-library-yql-providers-yt-provider-ut PRIVATE @@ -44,10 +47,6 @@ target_link_options(ydb-library-yql-providers-yt-provider-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(ydb-library-yql-providers-yt-provider-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/ut/yql_yt_dq_integration_ut.cpp @@ -79,6 +78,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/yt/provider/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/providers/yt/provider/ut/CMakeLists.linux-x86_64.txt index 4f29f9c95769..f2c066cd6754 100644 --- a/ydb/library/yql/providers/yt/provider/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/providers/yt/provider/ut/CMakeLists.linux-x86_64.txt @@ -23,6 +23,8 @@ target_link_libraries(ydb-library-yql-providers-yt-provider-ut PUBLIC providers-yt-provider yt-lib-schema yt-gateway-file + yt-codec-codegen + yt-comp_nodes-llvm14 yql-core-ut_common library-yql-ast udf-service-terminate_policy @@ -36,7 +38,8 @@ target_link_libraries(ydb-library-yql-providers-yt-provider-ut PUBLIC providers-dq-provider providers-result-provider yql-sql-v1 - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 + minikql-comp_nodes-llvm14 yql-sql-pg ) target_link_options(ydb-library-yql-providers-yt-provider-ut PRIVATE @@ -45,10 +48,6 @@ target_link_options(ydb-library-yql-providers-yt-provider-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(ydb-library-yql-providers-yt-provider-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/providers/yt/provider/ut/yql_yt_dq_integration_ut.cpp @@ -80,6 +79,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/providers/yt/provider/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/providers/yt/provider/ut/CMakeLists.windows-x86_64.txt index 8bc613ff3e79..9efaed8aabe3 100644 --- a/ydb/library/yql/providers/yt/provider/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/providers/yt/provider/ut/CMakeLists.windows-x86_64.txt @@ -22,6 +22,8 @@ target_link_libraries(ydb-library-yql-providers-yt-provider-ut PUBLIC providers-yt-provider yt-lib-schema yt-gateway-file + yt-codec-codegen + yt-comp_nodes-llvm14 yql-core-ut_common library-yql-ast udf-service-terminate_policy @@ -35,7 +37,8 @@ target_link_libraries(ydb-library-yql-providers-yt-provider-ut PUBLIC providers-dq-provider providers-result-provider yql-sql-v1 - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 + minikql-comp_nodes-llvm14 yql-sql-pg ) target_sources(ydb-library-yql-providers-yt-provider-ut PRIVATE @@ -68,6 +71,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/decimal/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/decimal/CMakeLists.darwin-arm64.txt index f63cbd1d01df..ff8057cfdf7a 100644 --- a/ydb/library/yql/public/decimal/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/decimal/CMakeLists.darwin-arm64.txt @@ -14,6 +14,8 @@ target_link_libraries(yql-public-decimal PUBLIC yutil ) target_sources(yql-public-decimal PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/decimal/yql_decimal.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/decimal/yql_decimal_serialize.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/decimal/yql_decimal.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/decimal/yql_decimal_serialize.cpp ) diff --git a/ydb/library/yql/public/decimal/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/decimal/CMakeLists.darwin-x86_64.txt index f63cbd1d01df..ff8057cfdf7a 100644 --- a/ydb/library/yql/public/decimal/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/decimal/CMakeLists.darwin-x86_64.txt @@ -14,6 +14,8 @@ target_link_libraries(yql-public-decimal PUBLIC yutil ) target_sources(yql-public-decimal PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/decimal/yql_decimal.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/decimal/yql_decimal_serialize.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/decimal/yql_decimal.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/decimal/yql_decimal_serialize.cpp ) diff --git a/ydb/library/yql/public/decimal/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/decimal/CMakeLists.linux-aarch64.txt index 1d7ff6d8fb38..b5531667245f 100644 --- a/ydb/library/yql/public/decimal/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/decimal/CMakeLists.linux-aarch64.txt @@ -15,6 +15,8 @@ target_link_libraries(yql-public-decimal PUBLIC yutil ) target_sources(yql-public-decimal PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/decimal/yql_decimal.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/decimal/yql_decimal_serialize.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/decimal/yql_decimal.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/decimal/yql_decimal_serialize.cpp ) diff --git a/ydb/library/yql/public/decimal/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/decimal/CMakeLists.linux-x86_64.txt index 1d7ff6d8fb38..b5531667245f 100644 --- a/ydb/library/yql/public/decimal/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/decimal/CMakeLists.linux-x86_64.txt @@ -15,6 +15,8 @@ target_link_libraries(yql-public-decimal PUBLIC yutil ) target_sources(yql-public-decimal PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/decimal/yql_decimal.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/decimal/yql_decimal_serialize.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/decimal/yql_decimal.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/decimal/yql_decimal_serialize.cpp ) diff --git a/ydb/library/yql/public/decimal/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/decimal/CMakeLists.windows-x86_64.txt index f63cbd1d01df..ff8057cfdf7a 100644 --- a/ydb/library/yql/public/decimal/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/decimal/CMakeLists.windows-x86_64.txt @@ -14,6 +14,8 @@ target_link_libraries(yql-public-decimal PUBLIC yutil ) target_sources(yql-public-decimal PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/decimal/yql_decimal.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/decimal/yql_decimal_serialize.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/decimal/yql_decimal.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/decimal/yql_decimal_serialize.cpp ) diff --git a/ydb/library/yql/public/decimal/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/decimal/ut/CMakeLists.darwin-arm64.txt index 2a49ed970565..acb75b4a6073 100644 --- a/ydb/library/yql/public/decimal/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/decimal/ut/CMakeLists.darwin-arm64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/decimal/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/decimal/ut/CMakeLists.darwin-x86_64.txt index 4f60b7bba223..2cae57418ba8 100644 --- a/ydb/library/yql/public/decimal/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/decimal/ut/CMakeLists.darwin-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/decimal/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/decimal/ut/CMakeLists.linux-aarch64.txt index 2af52bbe6fed..facaba00504b 100644 --- a/ydb/library/yql/public/decimal/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/decimal/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-yql-public-decimal-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-public-decimal-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/decimal/ut/yql_decimal_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/decimal/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/decimal/ut/CMakeLists.linux-x86_64.txt index 6d09d433fb74..b66eca4f27ce 100644 --- a/ydb/library/yql/public/decimal/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/decimal/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-yql-public-decimal-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-public-decimal-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/decimal/ut/yql_decimal_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/decimal/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/decimal/ut/CMakeLists.windows-x86_64.txt index 81a8aab8c60b..d7bbc6d8d490 100644 --- a/ydb/library/yql/public/decimal/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/decimal/ut/CMakeLists.windows-x86_64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/embedded/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/embedded/CMakeLists.darwin-arm64.txt index 25dad8fc57b6..73faef2c98b1 100644 --- a/ydb/library/yql/public/embedded/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/embedded/CMakeLists.darwin-arm64.txt @@ -6,6 +6,8 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) +add_subdirectory(ut) add_library(yql-public-embedded) target_compile_options(yql-public-embedded PRIVATE @@ -30,6 +32,9 @@ target_link_libraries(yql-public-embedded PUBLIC core-services-mounts yql-core-user_data library-yql-minikql + minikql-invoke_builtins-llvm14 + minikql-comp_nodes-llvm14 + minikql-computation-llvm14 library-yql-protos udf-service-exception_policy yql-utils-backtrace @@ -44,7 +49,10 @@ target_link_libraries(yql-public-embedded PUBLIC yt-lib-yt_download yt-lib-yt_url_lister providers-yt-provider + yt-codec-codegen + yt-comp_nodes-llvm14 ) target_sources(yql-public-embedded PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/yql_embedded.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/yql_embedded.cpp ) diff --git a/ydb/library/yql/public/embedded/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/embedded/CMakeLists.darwin-x86_64.txt index 25dad8fc57b6..73faef2c98b1 100644 --- a/ydb/library/yql/public/embedded/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/embedded/CMakeLists.darwin-x86_64.txt @@ -6,6 +6,8 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) +add_subdirectory(ut) add_library(yql-public-embedded) target_compile_options(yql-public-embedded PRIVATE @@ -30,6 +32,9 @@ target_link_libraries(yql-public-embedded PUBLIC core-services-mounts yql-core-user_data library-yql-minikql + minikql-invoke_builtins-llvm14 + minikql-comp_nodes-llvm14 + minikql-computation-llvm14 library-yql-protos udf-service-exception_policy yql-utils-backtrace @@ -44,7 +49,10 @@ target_link_libraries(yql-public-embedded PUBLIC yt-lib-yt_download yt-lib-yt_url_lister providers-yt-provider + yt-codec-codegen + yt-comp_nodes-llvm14 ) target_sources(yql-public-embedded PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/yql_embedded.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/yql_embedded.cpp ) diff --git a/ydb/library/yql/public/embedded/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/embedded/CMakeLists.linux-aarch64.txt index 747f38d1a5c4..2b40db71629a 100644 --- a/ydb/library/yql/public/embedded/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/embedded/CMakeLists.linux-aarch64.txt @@ -6,6 +6,8 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) +add_subdirectory(ut) add_library(yql-public-embedded) target_compile_options(yql-public-embedded PRIVATE @@ -31,6 +33,9 @@ target_link_libraries(yql-public-embedded PUBLIC core-services-mounts yql-core-user_data library-yql-minikql + minikql-invoke_builtins-llvm14 + minikql-comp_nodes-llvm14 + minikql-computation-llvm14 library-yql-protos udf-service-exception_policy yql-utils-backtrace @@ -45,7 +50,10 @@ target_link_libraries(yql-public-embedded PUBLIC yt-lib-yt_download yt-lib-yt_url_lister providers-yt-provider + yt-codec-codegen + yt-comp_nodes-llvm14 ) target_sources(yql-public-embedded PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/yql_embedded.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/yql_embedded.cpp ) diff --git a/ydb/library/yql/public/embedded/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/embedded/CMakeLists.linux-x86_64.txt index 747f38d1a5c4..2b40db71629a 100644 --- a/ydb/library/yql/public/embedded/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/embedded/CMakeLists.linux-x86_64.txt @@ -6,6 +6,8 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) +add_subdirectory(ut) add_library(yql-public-embedded) target_compile_options(yql-public-embedded PRIVATE @@ -31,6 +33,9 @@ target_link_libraries(yql-public-embedded PUBLIC core-services-mounts yql-core-user_data library-yql-minikql + minikql-invoke_builtins-llvm14 + minikql-comp_nodes-llvm14 + minikql-computation-llvm14 library-yql-protos udf-service-exception_policy yql-utils-backtrace @@ -45,7 +50,10 @@ target_link_libraries(yql-public-embedded PUBLIC yt-lib-yt_download yt-lib-yt_url_lister providers-yt-provider + yt-codec-codegen + yt-comp_nodes-llvm14 ) target_sources(yql-public-embedded PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/yql_embedded.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/yql_embedded.cpp ) diff --git a/ydb/library/yql/public/embedded/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/embedded/CMakeLists.windows-x86_64.txt index 25dad8fc57b6..73faef2c98b1 100644 --- a/ydb/library/yql/public/embedded/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/embedded/CMakeLists.windows-x86_64.txt @@ -6,6 +6,8 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) +add_subdirectory(ut) add_library(yql-public-embedded) target_compile_options(yql-public-embedded PRIVATE @@ -30,6 +32,9 @@ target_link_libraries(yql-public-embedded PUBLIC core-services-mounts yql-core-user_data library-yql-minikql + minikql-invoke_builtins-llvm14 + minikql-comp_nodes-llvm14 + minikql-computation-llvm14 library-yql-protos udf-service-exception_policy yql-utils-backtrace @@ -44,7 +49,10 @@ target_link_libraries(yql-public-embedded PUBLIC yt-lib-yt_download yt-lib-yt_url_lister providers-yt-provider + yt-codec-codegen + yt-comp_nodes-llvm14 ) target_sources(yql-public-embedded PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/yql_embedded.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/yql_embedded.cpp ) diff --git a/ydb/library/yql/public/embedded/no_llvm/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/embedded/no_llvm/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..a588e014802a --- /dev/null +++ b/ydb/library/yql/public/embedded/no_llvm/CMakeLists.darwin-arm64.txt @@ -0,0 +1,59 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(public-embedded-no_llvm) +target_compile_options(public-embedded-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(public-embedded-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded +) +target_link_libraries(public-embedded-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf + library-cpp-resource + library-cpp-yson + cpp-yson-node + cpp-mapreduce-client + cpp-mapreduce-common + library-yql-ast + yql-sql-pg + yql-core-facade + yql-core-file_storage + core-file_storage-defs + core-file_storage-proto + core-file_storage-http_download + core-services-mounts + yql-core-user_data + library-yql-minikql + minikql-invoke_builtins-no_llvm + minikql-comp_nodes-no_llvm + minikql-computation-no_llvm + minikql-codegen-no_llvm + library-yql-protos + udf-service-exception_policy + yql-utils-backtrace + yql-utils-log + yql-parser-pg_wrapper + providers-common-proto + providers-common-udf_resolve + yql-core-url_preprocessing + yql-core-url_lister + yt-gateway-native + yt-lib-log + yt-lib-yt_download + yt-lib-yt_url_lister + providers-yt-provider + codec-codegen-no_llvm + yt-comp_nodes-no_llvm +) +target_sources(public-embedded-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/yql_embedded.cpp +) diff --git a/ydb/library/yql/public/embedded/no_llvm/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/embedded/no_llvm/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..a588e014802a --- /dev/null +++ b/ydb/library/yql/public/embedded/no_llvm/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,59 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(public-embedded-no_llvm) +target_compile_options(public-embedded-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(public-embedded-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded +) +target_link_libraries(public-embedded-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf + library-cpp-resource + library-cpp-yson + cpp-yson-node + cpp-mapreduce-client + cpp-mapreduce-common + library-yql-ast + yql-sql-pg + yql-core-facade + yql-core-file_storage + core-file_storage-defs + core-file_storage-proto + core-file_storage-http_download + core-services-mounts + yql-core-user_data + library-yql-minikql + minikql-invoke_builtins-no_llvm + minikql-comp_nodes-no_llvm + minikql-computation-no_llvm + minikql-codegen-no_llvm + library-yql-protos + udf-service-exception_policy + yql-utils-backtrace + yql-utils-log + yql-parser-pg_wrapper + providers-common-proto + providers-common-udf_resolve + yql-core-url_preprocessing + yql-core-url_lister + yt-gateway-native + yt-lib-log + yt-lib-yt_download + yt-lib-yt_url_lister + providers-yt-provider + codec-codegen-no_llvm + yt-comp_nodes-no_llvm +) +target_sources(public-embedded-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/yql_embedded.cpp +) diff --git a/ydb/library/yql/public/embedded/no_llvm/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/embedded/no_llvm/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..61572a6a4f76 --- /dev/null +++ b/ydb/library/yql/public/embedded/no_llvm/CMakeLists.linux-aarch64.txt @@ -0,0 +1,60 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(public-embedded-no_llvm) +target_compile_options(public-embedded-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(public-embedded-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded +) +target_link_libraries(public-embedded-no_llvm PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf + library-cpp-resource + library-cpp-yson + cpp-yson-node + cpp-mapreduce-client + cpp-mapreduce-common + library-yql-ast + yql-sql-pg + yql-core-facade + yql-core-file_storage + core-file_storage-defs + core-file_storage-proto + core-file_storage-http_download + core-services-mounts + yql-core-user_data + library-yql-minikql + minikql-invoke_builtins-no_llvm + minikql-comp_nodes-no_llvm + minikql-computation-no_llvm + minikql-codegen-no_llvm + library-yql-protos + udf-service-exception_policy + yql-utils-backtrace + yql-utils-log + yql-parser-pg_wrapper + providers-common-proto + providers-common-udf_resolve + yql-core-url_preprocessing + yql-core-url_lister + yt-gateway-native + yt-lib-log + yt-lib-yt_download + yt-lib-yt_url_lister + providers-yt-provider + codec-codegen-no_llvm + yt-comp_nodes-no_llvm +) +target_sources(public-embedded-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/yql_embedded.cpp +) diff --git a/ydb/library/yql/public/embedded/no_llvm/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/embedded/no_llvm/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..61572a6a4f76 --- /dev/null +++ b/ydb/library/yql/public/embedded/no_llvm/CMakeLists.linux-x86_64.txt @@ -0,0 +1,60 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(public-embedded-no_llvm) +target_compile_options(public-embedded-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(public-embedded-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded +) +target_link_libraries(public-embedded-no_llvm PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf + library-cpp-resource + library-cpp-yson + cpp-yson-node + cpp-mapreduce-client + cpp-mapreduce-common + library-yql-ast + yql-sql-pg + yql-core-facade + yql-core-file_storage + core-file_storage-defs + core-file_storage-proto + core-file_storage-http_download + core-services-mounts + yql-core-user_data + library-yql-minikql + minikql-invoke_builtins-no_llvm + minikql-comp_nodes-no_llvm + minikql-computation-no_llvm + minikql-codegen-no_llvm + library-yql-protos + udf-service-exception_policy + yql-utils-backtrace + yql-utils-log + yql-parser-pg_wrapper + providers-common-proto + providers-common-udf_resolve + yql-core-url_preprocessing + yql-core-url_lister + yt-gateway-native + yt-lib-log + yt-lib-yt_download + yt-lib-yt_url_lister + providers-yt-provider + codec-codegen-no_llvm + yt-comp_nodes-no_llvm +) +target_sources(public-embedded-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/yql_embedded.cpp +) diff --git a/ydb/library/yql/public/embedded/no_llvm/CMakeLists.txt b/ydb/library/yql/public/embedded/no_llvm/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/public/embedded/no_llvm/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/public/embedded/no_llvm/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/embedded/no_llvm/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..a588e014802a --- /dev/null +++ b/ydb/library/yql/public/embedded/no_llvm/CMakeLists.windows-x86_64.txt @@ -0,0 +1,59 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(public-embedded-no_llvm) +target_compile_options(public-embedded-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(public-embedded-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded +) +target_link_libraries(public-embedded-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf + library-cpp-resource + library-cpp-yson + cpp-yson-node + cpp-mapreduce-client + cpp-mapreduce-common + library-yql-ast + yql-sql-pg + yql-core-facade + yql-core-file_storage + core-file_storage-defs + core-file_storage-proto + core-file_storage-http_download + core-services-mounts + yql-core-user_data + library-yql-minikql + minikql-invoke_builtins-no_llvm + minikql-comp_nodes-no_llvm + minikql-computation-no_llvm + minikql-codegen-no_llvm + library-yql-protos + udf-service-exception_policy + yql-utils-backtrace + yql-utils-log + yql-parser-pg_wrapper + providers-common-proto + providers-common-udf_resolve + yql-core-url_preprocessing + yql-core-url_lister + yt-gateway-native + yt-lib-log + yt-lib-yt_download + yt-lib-yt_url_lister + providers-yt-provider + codec-codegen-no_llvm + yt-comp_nodes-no_llvm +) +target_sources(public-embedded-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/yql_embedded.cpp +) diff --git a/ydb/library/yql/public/embedded/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/embedded/ut/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..962369957337 --- /dev/null +++ b/ydb/library/yql/public/embedded/ut/CMakeLists.darwin-arm64.txt @@ -0,0 +1,74 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(no_llvm) + +add_executable(ydb-library-yql-public-embedded-ut) +target_compile_options(ydb-library-yql-public-embedded-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-library-yql-public-embedded-ut PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + udf-service-exception_policy + yql-public-embedded +) +target_link_options(ydb-library-yql-public-embedded-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-library-yql-public-embedded-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/ut/yql_embedded_ut.cpp +) +set_property( + TARGET + ydb-library-yql-public-embedded-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-public-embedded-ut + TEST_TARGET + ydb-library-yql-public-embedded-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut + PROPERTY + TIMEOUT + 300 +) +target_allocator(ydb-library-yql-public-embedded-ut + system_allocator +) +vcs_info(ydb-library-yql-public-embedded-ut) diff --git a/ydb/library/yql/public/embedded/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/embedded/ut/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..bd9e8d9b9bc0 --- /dev/null +++ b/ydb/library/yql/public/embedded/ut/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,75 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(no_llvm) + +add_executable(ydb-library-yql-public-embedded-ut) +target_compile_options(ydb-library-yql-public-embedded-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-library-yql-public-embedded-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + udf-service-exception_policy + yql-public-embedded +) +target_link_options(ydb-library-yql-public-embedded-ut PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-library-yql-public-embedded-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/ut/yql_embedded_ut.cpp +) +set_property( + TARGET + ydb-library-yql-public-embedded-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-public-embedded-ut + TEST_TARGET + ydb-library-yql-public-embedded-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut + PROPERTY + TIMEOUT + 300 +) +target_allocator(ydb-library-yql-public-embedded-ut + system_allocator +) +vcs_info(ydb-library-yql-public-embedded-ut) diff --git a/ydb/library/yql/public/embedded/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/embedded/ut/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..043641458439 --- /dev/null +++ b/ydb/library/yql/public/embedded/ut/CMakeLists.linux-aarch64.txt @@ -0,0 +1,77 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(no_llvm) + +add_executable(ydb-library-yql-public-embedded-ut) +target_compile_options(ydb-library-yql-public-embedded-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-library-yql-public-embedded-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + udf-service-exception_policy + yql-public-embedded +) +target_link_options(ydb-library-yql-public-embedded-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-library-yql-public-embedded-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/ut/yql_embedded_ut.cpp +) +set_property( + TARGET + ydb-library-yql-public-embedded-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-public-embedded-ut + TEST_TARGET + ydb-library-yql-public-embedded-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut + PROPERTY + TIMEOUT + 300 +) +target_allocator(ydb-library-yql-public-embedded-ut + cpp-malloc-jemalloc +) +vcs_info(ydb-library-yql-public-embedded-ut) diff --git a/ydb/library/yql/public/embedded/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/embedded/ut/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..4bb97b8abbd7 --- /dev/null +++ b/ydb/library/yql/public/embedded/ut/CMakeLists.linux-x86_64.txt @@ -0,0 +1,79 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(no_llvm) + +add_executable(ydb-library-yql-public-embedded-ut) +target_compile_options(ydb-library-yql-public-embedded-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-library-yql-public-embedded-ut PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + udf-service-exception_policy + yql-public-embedded +) +target_link_options(ydb-library-yql-public-embedded-ut PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-library-yql-public-embedded-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/ut/yql_embedded_ut.cpp +) +set_property( + TARGET + ydb-library-yql-public-embedded-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-public-embedded-ut + TEST_TARGET + ydb-library-yql-public-embedded-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut + PROPERTY + TIMEOUT + 300 +) +target_allocator(ydb-library-yql-public-embedded-ut + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(ydb-library-yql-public-embedded-ut) diff --git a/ydb/library/yql/public/embedded/ut/CMakeLists.txt b/ydb/library/yql/public/embedded/ut/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/public/embedded/ut/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/public/embedded/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/embedded/ut/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..2314c4832941 --- /dev/null +++ b/ydb/library/yql/public/embedded/ut/CMakeLists.windows-x86_64.txt @@ -0,0 +1,70 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(no_llvm) + +add_executable(ydb-library-yql-public-embedded-ut) +target_compile_options(ydb-library-yql-public-embedded-ut PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-library-yql-public-embedded-ut PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + udf-service-exception_policy + yql-public-embedded +) +target_sources(ydb-library-yql-public-embedded-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/ut/yql_embedded_ut.cpp +) +set_property( + TARGET + ydb-library-yql-public-embedded-ut + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-public-embedded-ut + TEST_TARGET + ydb-library-yql-public-embedded-ut + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut + PROPERTY + TIMEOUT + 300 +) +target_allocator(ydb-library-yql-public-embedded-ut + system_allocator +) +vcs_info(ydb-library-yql-public-embedded-ut) diff --git a/ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..294f5a602027 --- /dev/null +++ b/ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.darwin-arm64.txt @@ -0,0 +1,73 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-public-embedded-ut-no_llvm) +target_compile_options(ydb-library-yql-public-embedded-ut-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-library-yql-public-embedded-ut-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + udf-service-exception_policy + public-embedded-no_llvm +) +target_link_options(ydb-library-yql-public-embedded-ut-no_llvm PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-library-yql-public-embedded-ut-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/ut/yql_embedded_ut.cpp +) +set_property( + TARGET + ydb-library-yql-public-embedded-ut-no_llvm + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-public-embedded-ut-no_llvm + TEST_TARGET + ydb-library-yql-public-embedded-ut-no_llvm + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut-no_llvm + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut-no_llvm + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut-no_llvm + PROPERTY + TIMEOUT + 300 +) +target_allocator(ydb-library-yql-public-embedded-ut-no_llvm + system_allocator +) +vcs_info(ydb-library-yql-public-embedded-ut-no_llvm) diff --git a/ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..f319e29ed64e --- /dev/null +++ b/ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,74 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-public-embedded-ut-no_llvm) +target_compile_options(ydb-library-yql-public-embedded-ut-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-library-yql-public-embedded-ut-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + udf-service-exception_policy + public-embedded-no_llvm +) +target_link_options(ydb-library-yql-public-embedded-ut-no_llvm PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(ydb-library-yql-public-embedded-ut-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/ut/yql_embedded_ut.cpp +) +set_property( + TARGET + ydb-library-yql-public-embedded-ut-no_llvm + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-public-embedded-ut-no_llvm + TEST_TARGET + ydb-library-yql-public-embedded-ut-no_llvm + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut-no_llvm + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut-no_llvm + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut-no_llvm + PROPERTY + TIMEOUT + 300 +) +target_allocator(ydb-library-yql-public-embedded-ut-no_llvm + system_allocator +) +vcs_info(ydb-library-yql-public-embedded-ut-no_llvm) diff --git a/ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..cf51eb733de2 --- /dev/null +++ b/ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.linux-aarch64.txt @@ -0,0 +1,76 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-public-embedded-ut-no_llvm) +target_compile_options(ydb-library-yql-public-embedded-ut-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-library-yql-public-embedded-ut-no_llvm PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + udf-service-exception_policy + public-embedded-no_llvm +) +target_link_options(ydb-library-yql-public-embedded-ut-no_llvm PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-library-yql-public-embedded-ut-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/ut/yql_embedded_ut.cpp +) +set_property( + TARGET + ydb-library-yql-public-embedded-ut-no_llvm + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-public-embedded-ut-no_llvm + TEST_TARGET + ydb-library-yql-public-embedded-ut-no_llvm + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut-no_llvm + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut-no_llvm + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut-no_llvm + PROPERTY + TIMEOUT + 300 +) +target_allocator(ydb-library-yql-public-embedded-ut-no_llvm + cpp-malloc-jemalloc +) +vcs_info(ydb-library-yql-public-embedded-ut-no_llvm) diff --git a/ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..7bd72af87f69 --- /dev/null +++ b/ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.linux-x86_64.txt @@ -0,0 +1,78 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-public-embedded-ut-no_llvm) +target_compile_options(ydb-library-yql-public-embedded-ut-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-library-yql-public-embedded-ut-no_llvm PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + udf-service-exception_policy + public-embedded-no_llvm +) +target_link_options(ydb-library-yql-public-embedded-ut-no_llvm PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(ydb-library-yql-public-embedded-ut-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/ut/yql_embedded_ut.cpp +) +set_property( + TARGET + ydb-library-yql-public-embedded-ut-no_llvm + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-public-embedded-ut-no_llvm + TEST_TARGET + ydb-library-yql-public-embedded-ut-no_llvm + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut-no_llvm + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut-no_llvm + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut-no_llvm + PROPERTY + TIMEOUT + 300 +) +target_allocator(ydb-library-yql-public-embedded-ut-no_llvm + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(ydb-library-yql-public-embedded-ut-no_llvm) diff --git a/ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.txt b/ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..a180a94fb705 --- /dev/null +++ b/ydb/library/yql/public/embedded/ut/no_llvm/CMakeLists.windows-x86_64.txt @@ -0,0 +1,69 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(ydb-library-yql-public-embedded-ut-no_llvm) +target_compile_options(ydb-library-yql-public-embedded-ut-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(ydb-library-yql-public-embedded-ut-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + udf-service-exception_policy + public-embedded-no_llvm +) +target_sources(ydb-library-yql-public-embedded-ut-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/embedded/ut/yql_embedded_ut.cpp +) +set_property( + TARGET + ydb-library-yql-public-embedded-ut-no_llvm + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + ydb-library-yql-public-embedded-ut-no_llvm + TEST_TARGET + ydb-library-yql-public-embedded-ut-no_llvm + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut-no_llvm + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut-no_llvm + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + ydb-library-yql-public-embedded-ut-no_llvm + PROPERTY + TIMEOUT + 300 +) +target_allocator(ydb-library-yql-public-embedded-ut-no_llvm + system_allocator +) +vcs_info(ydb-library-yql-public-embedded-ut-no_llvm) diff --git a/ydb/library/yql/public/fastcheck/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/fastcheck/ut/CMakeLists.darwin-arm64.txt index 54d5d97733a8..3c218247b21d 100644 --- a/ydb/library/yql/public/fastcheck/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/fastcheck/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-library-yql-public-fastcheck-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-public-fastcheck-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/fastcheck/fastcheck_ut.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/fastcheck/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/fastcheck/ut/CMakeLists.darwin-x86_64.txt index ff1721ab9b7b..7787887ca07e 100644 --- a/ydb/library/yql/public/fastcheck/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/fastcheck/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-library-yql-public-fastcheck-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-public-fastcheck-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/fastcheck/fastcheck_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/fastcheck/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/fastcheck/ut/CMakeLists.linux-aarch64.txt index 9b4ba9f94da3..dee5a36eb666 100644 --- a/ydb/library/yql/public/fastcheck/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/fastcheck/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-yql-public-fastcheck-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-public-fastcheck-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/fastcheck/fastcheck_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/fastcheck/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/fastcheck/ut/CMakeLists.linux-x86_64.txt index 6f6db82494f1..4ca26479e986 100644 --- a/ydb/library/yql/public/fastcheck/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/fastcheck/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-yql-public-fastcheck-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-public-fastcheck-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/fastcheck/fastcheck_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/fastcheck/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/fastcheck/ut/CMakeLists.windows-x86_64.txt index 57cad616bcd1..a2042a05af7f 100644 --- a/ydb/library/yql/public/fastcheck/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/fastcheck/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/issue/protos/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/issue/protos/CMakeLists.darwin-arm64.txt index bacc602d9892..9cb748edaf46 100644 --- a/ydb/library/yql/public/issue/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/issue/protos/CMakeLists.darwin-arm64.txt @@ -41,6 +41,10 @@ target_proto_messages(public-issue-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/issue/protos/issue_message.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/issue/protos/issue_severity.proto ) +target_sources(public-issue-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/issue/protos/issue_message.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/issue/protos/issue_severity.pb.h +) target_proto_addincls(public-issue-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/public/issue/protos/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/issue/protos/CMakeLists.darwin-x86_64.txt index bacc602d9892..9cb748edaf46 100644 --- a/ydb/library/yql/public/issue/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/issue/protos/CMakeLists.darwin-x86_64.txt @@ -41,6 +41,10 @@ target_proto_messages(public-issue-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/issue/protos/issue_message.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/issue/protos/issue_severity.proto ) +target_sources(public-issue-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/issue/protos/issue_message.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/issue/protos/issue_severity.pb.h +) target_proto_addincls(public-issue-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/public/issue/protos/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/issue/protos/CMakeLists.linux-aarch64.txt index d56790b5b095..1e643b139b79 100644 --- a/ydb/library/yql/public/issue/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/issue/protos/CMakeLists.linux-aarch64.txt @@ -42,6 +42,10 @@ target_proto_messages(public-issue-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/issue/protos/issue_message.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/issue/protos/issue_severity.proto ) +target_sources(public-issue-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/issue/protos/issue_message.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/issue/protos/issue_severity.pb.h +) target_proto_addincls(public-issue-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/public/issue/protos/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/issue/protos/CMakeLists.linux-x86_64.txt index d56790b5b095..1e643b139b79 100644 --- a/ydb/library/yql/public/issue/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/issue/protos/CMakeLists.linux-x86_64.txt @@ -42,6 +42,10 @@ target_proto_messages(public-issue-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/issue/protos/issue_message.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/issue/protos/issue_severity.proto ) +target_sources(public-issue-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/issue/protos/issue_message.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/issue/protos/issue_severity.pb.h +) target_proto_addincls(public-issue-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/public/issue/protos/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/issue/protos/CMakeLists.windows-x86_64.txt index bacc602d9892..9cb748edaf46 100644 --- a/ydb/library/yql/public/issue/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/issue/protos/CMakeLists.windows-x86_64.txt @@ -41,6 +41,10 @@ target_proto_messages(public-issue-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/issue/protos/issue_message.proto ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/issue/protos/issue_severity.proto ) +target_sources(public-issue-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/issue/protos/issue_message.pb.h + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/issue/protos/issue_severity.pb.h +) target_proto_addincls(public-issue-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/public/issue/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/issue/ut/CMakeLists.darwin-arm64.txt index 2553a2e1ba3c..2f537906dd05 100644 --- a/ydb/library/yql/public/issue/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/issue/ut/CMakeLists.darwin-arm64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-library-yql-public-issue-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-public-issue-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/issue/yql_issue_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/issue/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/issue/ut/CMakeLists.darwin-x86_64.txt index f06b86e548a1..18d77c7b85e0 100644 --- a/ydb/library/yql/public/issue/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/issue/ut/CMakeLists.darwin-x86_64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-library-yql-public-issue-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-public-issue-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/issue/yql_issue_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/issue/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/issue/ut/CMakeLists.linux-aarch64.txt index 2b4f7d747b3c..54dcb933522b 100644 --- a/ydb/library/yql/public/issue/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/issue/ut/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-yql-public-issue-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-public-issue-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/issue/yql_issue_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/issue/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/issue/ut/CMakeLists.linux-x86_64.txt index 55e9451c4d58..ee317eae7b9d 100644 --- a/ydb/library/yql/public/issue/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/issue/ut/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-library-yql-public-issue-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-public-issue-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/issue/yql_issue_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/issue/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/issue/ut/CMakeLists.windows-x86_64.txt index 1b8f13a0c28c..66676e387559 100644 --- a/ydb/library/yql/public/issue/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/issue/ut/CMakeLists.windows-x86_64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/purecalc/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/purecalc/CMakeLists.darwin-arm64.txt index a417180394bc..007142b25213 100644 --- a/ydb/library/yql/public/purecalc/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/purecalc/CMakeLists.darwin-arm64.txt @@ -10,6 +10,7 @@ add_subdirectory(common) add_subdirectory(examples) add_subdirectory(helpers) add_subdirectory(io_specs) +add_subdirectory(no_llvm) add_subdirectory(ut) add_library(yql-public-purecalc) diff --git a/ydb/library/yql/public/purecalc/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/purecalc/CMakeLists.darwin-x86_64.txt index a417180394bc..007142b25213 100644 --- a/ydb/library/yql/public/purecalc/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/purecalc/CMakeLists.darwin-x86_64.txt @@ -10,6 +10,7 @@ add_subdirectory(common) add_subdirectory(examples) add_subdirectory(helpers) add_subdirectory(io_specs) +add_subdirectory(no_llvm) add_subdirectory(ut) add_library(yql-public-purecalc) diff --git a/ydb/library/yql/public/purecalc/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/purecalc/CMakeLists.linux-aarch64.txt index 7d72508c1ff3..11cc4f503497 100644 --- a/ydb/library/yql/public/purecalc/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/purecalc/CMakeLists.linux-aarch64.txt @@ -10,6 +10,7 @@ add_subdirectory(common) add_subdirectory(examples) add_subdirectory(helpers) add_subdirectory(io_specs) +add_subdirectory(no_llvm) add_subdirectory(ut) add_library(yql-public-purecalc) diff --git a/ydb/library/yql/public/purecalc/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/purecalc/CMakeLists.linux-x86_64.txt index 7d72508c1ff3..11cc4f503497 100644 --- a/ydb/library/yql/public/purecalc/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/purecalc/CMakeLists.linux-x86_64.txt @@ -10,6 +10,7 @@ add_subdirectory(common) add_subdirectory(examples) add_subdirectory(helpers) add_subdirectory(io_specs) +add_subdirectory(no_llvm) add_subdirectory(ut) add_library(yql-public-purecalc) diff --git a/ydb/library/yql/public/purecalc/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/purecalc/CMakeLists.windows-x86_64.txt index a417180394bc..007142b25213 100644 --- a/ydb/library/yql/public/purecalc/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/purecalc/CMakeLists.windows-x86_64.txt @@ -10,6 +10,7 @@ add_subdirectory(common) add_subdirectory(examples) add_subdirectory(helpers) add_subdirectory(io_specs) +add_subdirectory(no_llvm) add_subdirectory(ut) add_library(yql-public-purecalc) diff --git a/ydb/library/yql/public/purecalc/common/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/purecalc/common/CMakeLists.darwin-arm64.txt index 301054c4de73..245865857353 100644 --- a/ydb/library/yql/public/purecalc/common/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/purecalc/common/CMakeLists.darwin-arm64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) get_built_tool_path( TOOL_enum_parser_bin TOOL_enum_parser_dependency @@ -17,6 +18,9 @@ add_library(public-purecalc-common) target_compile_options(public-purecalc-common PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) +target_include_directories(public-purecalc-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common +) target_link_libraries(public-purecalc-common PUBLIC contrib-libs-cxxsupp yutil @@ -25,7 +29,6 @@ target_link_libraries(public-purecalc-common PUBLIC yql-core-services core-services-mounts yql-core-user_data - minikql-comp_nodes-llvm yql-utils-backtrace yql-utils-log library-yql-core @@ -38,6 +41,10 @@ target_link_libraries(public-purecalc-common PUBLIC common-schema-expr providers-common-udf_resolve tools-enum_parser-enum_serialization_runtime + yt-codec-codegen + minikql-computation-llvm14 + minikql-invoke_builtins-llvm14 + minikql-comp_nodes-llvm14 ) target_sources(public-purecalc-common PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/compile_mkql.cpp diff --git a/ydb/library/yql/public/purecalc/common/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/purecalc/common/CMakeLists.darwin-x86_64.txt index 301054c4de73..245865857353 100644 --- a/ydb/library/yql/public/purecalc/common/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/purecalc/common/CMakeLists.darwin-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) get_built_tool_path( TOOL_enum_parser_bin TOOL_enum_parser_dependency @@ -17,6 +18,9 @@ add_library(public-purecalc-common) target_compile_options(public-purecalc-common PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) +target_include_directories(public-purecalc-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common +) target_link_libraries(public-purecalc-common PUBLIC contrib-libs-cxxsupp yutil @@ -25,7 +29,6 @@ target_link_libraries(public-purecalc-common PUBLIC yql-core-services core-services-mounts yql-core-user_data - minikql-comp_nodes-llvm yql-utils-backtrace yql-utils-log library-yql-core @@ -38,6 +41,10 @@ target_link_libraries(public-purecalc-common PUBLIC common-schema-expr providers-common-udf_resolve tools-enum_parser-enum_serialization_runtime + yt-codec-codegen + minikql-computation-llvm14 + minikql-invoke_builtins-llvm14 + minikql-comp_nodes-llvm14 ) target_sources(public-purecalc-common PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/compile_mkql.cpp diff --git a/ydb/library/yql/public/purecalc/common/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/purecalc/common/CMakeLists.linux-aarch64.txt index b6d800550b56..5266f760475d 100644 --- a/ydb/library/yql/public/purecalc/common/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/purecalc/common/CMakeLists.linux-aarch64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) get_built_tool_path( TOOL_enum_parser_bin TOOL_enum_parser_dependency @@ -17,6 +18,9 @@ add_library(public-purecalc-common) target_compile_options(public-purecalc-common PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) +target_include_directories(public-purecalc-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common +) target_link_libraries(public-purecalc-common PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp @@ -26,7 +30,6 @@ target_link_libraries(public-purecalc-common PUBLIC yql-core-services core-services-mounts yql-core-user_data - minikql-comp_nodes-llvm yql-utils-backtrace yql-utils-log library-yql-core @@ -39,6 +42,10 @@ target_link_libraries(public-purecalc-common PUBLIC common-schema-expr providers-common-udf_resolve tools-enum_parser-enum_serialization_runtime + yt-codec-codegen + minikql-computation-llvm14 + minikql-invoke_builtins-llvm14 + minikql-comp_nodes-llvm14 ) target_sources(public-purecalc-common PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/compile_mkql.cpp diff --git a/ydb/library/yql/public/purecalc/common/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/purecalc/common/CMakeLists.linux-x86_64.txt index b6d800550b56..5266f760475d 100644 --- a/ydb/library/yql/public/purecalc/common/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/purecalc/common/CMakeLists.linux-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) get_built_tool_path( TOOL_enum_parser_bin TOOL_enum_parser_dependency @@ -17,6 +18,9 @@ add_library(public-purecalc-common) target_compile_options(public-purecalc-common PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) +target_include_directories(public-purecalc-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common +) target_link_libraries(public-purecalc-common PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp @@ -26,7 +30,6 @@ target_link_libraries(public-purecalc-common PUBLIC yql-core-services core-services-mounts yql-core-user_data - minikql-comp_nodes-llvm yql-utils-backtrace yql-utils-log library-yql-core @@ -39,6 +42,10 @@ target_link_libraries(public-purecalc-common PUBLIC common-schema-expr providers-common-udf_resolve tools-enum_parser-enum_serialization_runtime + yt-codec-codegen + minikql-computation-llvm14 + minikql-invoke_builtins-llvm14 + minikql-comp_nodes-llvm14 ) target_sources(public-purecalc-common PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/compile_mkql.cpp diff --git a/ydb/library/yql/public/purecalc/common/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/purecalc/common/CMakeLists.windows-x86_64.txt index 301054c4de73..245865857353 100644 --- a/ydb/library/yql/public/purecalc/common/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/purecalc/common/CMakeLists.windows-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) get_built_tool_path( TOOL_enum_parser_bin TOOL_enum_parser_dependency @@ -17,6 +18,9 @@ add_library(public-purecalc-common) target_compile_options(public-purecalc-common PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) +target_include_directories(public-purecalc-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common +) target_link_libraries(public-purecalc-common PUBLIC contrib-libs-cxxsupp yutil @@ -25,7 +29,6 @@ target_link_libraries(public-purecalc-common PUBLIC yql-core-services core-services-mounts yql-core-user_data - minikql-comp_nodes-llvm yql-utils-backtrace yql-utils-log library-yql-core @@ -38,6 +41,10 @@ target_link_libraries(public-purecalc-common PUBLIC common-schema-expr providers-common-udf_resolve tools-enum_parser-enum_serialization_runtime + yt-codec-codegen + minikql-computation-llvm14 + minikql-invoke_builtins-llvm14 + minikql-comp_nodes-llvm14 ) target_sources(public-purecalc-common PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/compile_mkql.cpp diff --git a/ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..f7379bc8ff3d --- /dev/null +++ b/ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.darwin-arm64.txt @@ -0,0 +1,72 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) + +add_library(purecalc-common-no_llvm) +target_compile_options(purecalc-common-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(purecalc-common-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common +) +target_link_libraries(purecalc-common-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + yql-sql-pg + library-yql-ast + yql-core-services + core-services-mounts + yql-core-user_data + yql-utils-backtrace + yql-utils-log + library-yql-core + yql-core-type_ann + yql-parser-pg_wrapper + providers-common-codec + providers-common-comp_nodes + providers-common-mkql + providers-common-provider + common-schema-expr + providers-common-udf_resolve + tools-enum_parser-enum_serialization_runtime + codec-codegen-no_llvm + minikql-computation-no_llvm + minikql-invoke_builtins-no_llvm + minikql-comp_nodes-no_llvm + minikql-codegen-no_llvm +) +target_sources(purecalc-common-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/compile_mkql.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/fwd.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/inspect_input.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/interface.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/logger_init.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/names.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/processor_mode.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/program_factory.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/align_output_schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/extract_used_columns.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/output_columns_filter.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/replace_table_reads.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/type_annotation.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/type_from_schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/worker.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/worker_factory.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/wrappers.cpp +) +generate_enum_serilization(purecalc-common-no_llvm + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/interface.h + INCLUDE_HEADERS + ydb/library/yql/public/purecalc/common/interface.h +) diff --git a/ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..f7379bc8ff3d --- /dev/null +++ b/ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,72 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) + +add_library(purecalc-common-no_llvm) +target_compile_options(purecalc-common-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(purecalc-common-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common +) +target_link_libraries(purecalc-common-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + yql-sql-pg + library-yql-ast + yql-core-services + core-services-mounts + yql-core-user_data + yql-utils-backtrace + yql-utils-log + library-yql-core + yql-core-type_ann + yql-parser-pg_wrapper + providers-common-codec + providers-common-comp_nodes + providers-common-mkql + providers-common-provider + common-schema-expr + providers-common-udf_resolve + tools-enum_parser-enum_serialization_runtime + codec-codegen-no_llvm + minikql-computation-no_llvm + minikql-invoke_builtins-no_llvm + minikql-comp_nodes-no_llvm + minikql-codegen-no_llvm +) +target_sources(purecalc-common-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/compile_mkql.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/fwd.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/inspect_input.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/interface.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/logger_init.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/names.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/processor_mode.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/program_factory.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/align_output_schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/extract_used_columns.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/output_columns_filter.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/replace_table_reads.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/type_annotation.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/type_from_schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/worker.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/worker_factory.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/wrappers.cpp +) +generate_enum_serilization(purecalc-common-no_llvm + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/interface.h + INCLUDE_HEADERS + ydb/library/yql/public/purecalc/common/interface.h +) diff --git a/ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..1d865126987a --- /dev/null +++ b/ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.linux-aarch64.txt @@ -0,0 +1,73 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) + +add_library(purecalc-common-no_llvm) +target_compile_options(purecalc-common-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(purecalc-common-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common +) +target_link_libraries(purecalc-common-no_llvm PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + yql-sql-pg + library-yql-ast + yql-core-services + core-services-mounts + yql-core-user_data + yql-utils-backtrace + yql-utils-log + library-yql-core + yql-core-type_ann + yql-parser-pg_wrapper + providers-common-codec + providers-common-comp_nodes + providers-common-mkql + providers-common-provider + common-schema-expr + providers-common-udf_resolve + tools-enum_parser-enum_serialization_runtime + codec-codegen-no_llvm + minikql-computation-no_llvm + minikql-invoke_builtins-no_llvm + minikql-comp_nodes-no_llvm + minikql-codegen-no_llvm +) +target_sources(purecalc-common-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/compile_mkql.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/fwd.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/inspect_input.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/interface.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/logger_init.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/names.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/processor_mode.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/program_factory.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/align_output_schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/extract_used_columns.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/output_columns_filter.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/replace_table_reads.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/type_annotation.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/type_from_schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/worker.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/worker_factory.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/wrappers.cpp +) +generate_enum_serilization(purecalc-common-no_llvm + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/interface.h + INCLUDE_HEADERS + ydb/library/yql/public/purecalc/common/interface.h +) diff --git a/ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..1d865126987a --- /dev/null +++ b/ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.linux-x86_64.txt @@ -0,0 +1,73 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) + +add_library(purecalc-common-no_llvm) +target_compile_options(purecalc-common-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(purecalc-common-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common +) +target_link_libraries(purecalc-common-no_llvm PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + yql-sql-pg + library-yql-ast + yql-core-services + core-services-mounts + yql-core-user_data + yql-utils-backtrace + yql-utils-log + library-yql-core + yql-core-type_ann + yql-parser-pg_wrapper + providers-common-codec + providers-common-comp_nodes + providers-common-mkql + providers-common-provider + common-schema-expr + providers-common-udf_resolve + tools-enum_parser-enum_serialization_runtime + codec-codegen-no_llvm + minikql-computation-no_llvm + minikql-invoke_builtins-no_llvm + minikql-comp_nodes-no_llvm + minikql-codegen-no_llvm +) +target_sources(purecalc-common-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/compile_mkql.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/fwd.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/inspect_input.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/interface.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/logger_init.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/names.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/processor_mode.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/program_factory.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/align_output_schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/extract_used_columns.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/output_columns_filter.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/replace_table_reads.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/type_annotation.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/type_from_schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/worker.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/worker_factory.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/wrappers.cpp +) +generate_enum_serilization(purecalc-common-no_llvm + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/interface.h + INCLUDE_HEADERS + ydb/library/yql/public/purecalc/common/interface.h +) diff --git a/ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.txt b/ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..f7379bc8ff3d --- /dev/null +++ b/ydb/library/yql/public/purecalc/common/no_llvm/CMakeLists.windows-x86_64.txt @@ -0,0 +1,72 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) + +add_library(purecalc-common-no_llvm) +target_compile_options(purecalc-common-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(purecalc-common-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common +) +target_link_libraries(purecalc-common-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + yql-sql-pg + library-yql-ast + yql-core-services + core-services-mounts + yql-core-user_data + yql-utils-backtrace + yql-utils-log + library-yql-core + yql-core-type_ann + yql-parser-pg_wrapper + providers-common-codec + providers-common-comp_nodes + providers-common-mkql + providers-common-provider + common-schema-expr + providers-common-udf_resolve + tools-enum_parser-enum_serialization_runtime + codec-codegen-no_llvm + minikql-computation-no_llvm + minikql-invoke_builtins-no_llvm + minikql-comp_nodes-no_llvm + minikql-codegen-no_llvm +) +target_sources(purecalc-common-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/compile_mkql.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/fwd.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/inspect_input.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/interface.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/logger_init.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/names.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/processor_mode.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/program_factory.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/align_output_schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/extract_used_columns.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/output_columns_filter.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/replace_table_reads.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/transformations/type_annotation.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/type_from_schema.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/worker.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/worker_factory.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/wrappers.cpp +) +generate_enum_serilization(purecalc-common-no_llvm + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/common/interface.h + INCLUDE_HEADERS + ydb/library/yql/public/purecalc/common/interface.h +) diff --git a/ydb/library/yql/public/purecalc/examples/protobuf/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/purecalc/examples/protobuf/CMakeLists.darwin-arm64.txt index b2253069523d..b1bc77dd93e0 100644 --- a/ydb/library/yql/public/purecalc/examples/protobuf/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/purecalc/examples/protobuf/CMakeLists.darwin-arm64.txt @@ -35,13 +35,12 @@ target_link_options(protobuf PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_proto_messages(protobuf PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/protobuf/main.proto ) target_sources(protobuf PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/purecalc/examples/protobuf/main.pb.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/protobuf/main.cpp ) target_allocator(protobuf diff --git a/ydb/library/yql/public/purecalc/examples/protobuf/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/purecalc/examples/protobuf/CMakeLists.darwin-x86_64.txt index 711c14629991..31c30138fe33 100644 --- a/ydb/library/yql/public/purecalc/examples/protobuf/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/purecalc/examples/protobuf/CMakeLists.darwin-x86_64.txt @@ -36,13 +36,12 @@ target_link_options(protobuf PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_proto_messages(protobuf PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/protobuf/main.proto ) target_sources(protobuf PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/purecalc/examples/protobuf/main.pb.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/protobuf/main.cpp ) target_allocator(protobuf diff --git a/ydb/library/yql/public/purecalc/examples/protobuf/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/purecalc/examples/protobuf/CMakeLists.linux-aarch64.txt index 6bc0ca6ea039..eddc6fef814f 100644 --- a/ydb/library/yql/public/purecalc/examples/protobuf/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/purecalc/examples/protobuf/CMakeLists.linux-aarch64.txt @@ -38,14 +38,12 @@ target_link_options(protobuf PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_proto_messages(protobuf PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/protobuf/main.proto ) target_sources(protobuf PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/purecalc/examples/protobuf/main.pb.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/protobuf/main.cpp ) target_allocator(protobuf diff --git a/ydb/library/yql/public/purecalc/examples/protobuf/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/purecalc/examples/protobuf/CMakeLists.linux-x86_64.txt index 9a176f6229ba..553e50f7c197 100644 --- a/ydb/library/yql/public/purecalc/examples/protobuf/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/purecalc/examples/protobuf/CMakeLists.linux-x86_64.txt @@ -39,14 +39,12 @@ target_link_options(protobuf PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_proto_messages(protobuf PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/protobuf/main.proto ) target_sources(protobuf PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/purecalc/examples/protobuf/main.pb.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/protobuf/main.cpp ) target_allocator(protobuf diff --git a/ydb/library/yql/public/purecalc/examples/protobuf/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/purecalc/examples/protobuf/CMakeLists.windows-x86_64.txt index d6221c45d206..9125b3877d81 100644 --- a/ydb/library/yql/public/purecalc/examples/protobuf/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/purecalc/examples/protobuf/CMakeLists.windows-x86_64.txt @@ -36,6 +36,7 @@ target_proto_messages(protobuf PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/protobuf/main.proto ) target_sources(protobuf PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/purecalc/examples/protobuf/main.pb.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/protobuf/main.cpp ) target_allocator(protobuf diff --git a/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/CMakeLists.darwin-arm64.txt index 1c92824ec539..910cc5f868cf 100644 --- a/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/CMakeLists.darwin-arm64.txt @@ -35,13 +35,12 @@ target_link_options(protobuf_pull_list PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_proto_messages(protobuf_pull_list PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/main.proto ) target_sources(protobuf_pull_list PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/main.pb.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/main.cpp ) target_allocator(protobuf_pull_list diff --git a/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/CMakeLists.darwin-x86_64.txt index d33d5a41fa56..9c59ef8ace64 100644 --- a/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/CMakeLists.darwin-x86_64.txt @@ -36,13 +36,12 @@ target_link_options(protobuf_pull_list PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_proto_messages(protobuf_pull_list PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/main.proto ) target_sources(protobuf_pull_list PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/main.pb.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/main.cpp ) target_allocator(protobuf_pull_list diff --git a/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/CMakeLists.linux-aarch64.txt index efb081bc44f2..38a2d1a8ccb5 100644 --- a/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/CMakeLists.linux-aarch64.txt @@ -38,14 +38,12 @@ target_link_options(protobuf_pull_list PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_proto_messages(protobuf_pull_list PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/main.proto ) target_sources(protobuf_pull_list PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/main.pb.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/main.cpp ) target_allocator(protobuf_pull_list diff --git a/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/CMakeLists.linux-x86_64.txt index f27cca0d51f5..2046bbf60c2e 100644 --- a/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/CMakeLists.linux-x86_64.txt @@ -39,14 +39,12 @@ target_link_options(protobuf_pull_list PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_proto_messages(protobuf_pull_list PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/main.proto ) target_sources(protobuf_pull_list PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/main.pb.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/main.cpp ) target_allocator(protobuf_pull_list diff --git a/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/CMakeLists.windows-x86_64.txt index e74c8255b652..c2006eb138b4 100644 --- a/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/CMakeLists.windows-x86_64.txt @@ -36,6 +36,7 @@ target_proto_messages(protobuf_pull_list PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/main.proto ) target_sources(protobuf_pull_list PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/main.pb.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/protobuf_pull_list/main.cpp ) target_allocator(protobuf_pull_list diff --git a/ydb/library/yql/public/purecalc/examples/skiff_pull_list/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/purecalc/examples/skiff_pull_list/CMakeLists.darwin-arm64.txt index 5bf94873614a..27d7e05ffe1b 100644 --- a/ydb/library/yql/public/purecalc/examples/skiff_pull_list/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/purecalc/examples/skiff_pull_list/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(skiff_pull_list PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(skiff_pull_list PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/skiff_pull_list/main.cpp diff --git a/ydb/library/yql/public/purecalc/examples/skiff_pull_list/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/purecalc/examples/skiff_pull_list/CMakeLists.darwin-x86_64.txt index d2cf21e85566..acf68cd387f8 100644 --- a/ydb/library/yql/public/purecalc/examples/skiff_pull_list/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/purecalc/examples/skiff_pull_list/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(skiff_pull_list PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(skiff_pull_list PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/skiff_pull_list/main.cpp diff --git a/ydb/library/yql/public/purecalc/examples/skiff_pull_list/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/purecalc/examples/skiff_pull_list/CMakeLists.linux-aarch64.txt index 596b226847b6..2f965220bd2b 100644 --- a/ydb/library/yql/public/purecalc/examples/skiff_pull_list/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/purecalc/examples/skiff_pull_list/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(skiff_pull_list PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(skiff_pull_list PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/skiff_pull_list/main.cpp diff --git a/ydb/library/yql/public/purecalc/examples/skiff_pull_list/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/purecalc/examples/skiff_pull_list/CMakeLists.linux-x86_64.txt index ebcdf0080716..fe4ab63d9c4c 100644 --- a/ydb/library/yql/public/purecalc/examples/skiff_pull_list/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/purecalc/examples/skiff_pull_list/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(skiff_pull_list PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(skiff_pull_list PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/examples/skiff_pull_list/main.cpp diff --git a/ydb/library/yql/public/purecalc/io_specs/mkql/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/purecalc/io_specs/mkql/CMakeLists.darwin-arm64.txt index a94716ee3e5d..bfecbc7ebde9 100644 --- a/ydb/library/yql/public/purecalc/io_specs/mkql/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/purecalc/io_specs/mkql/CMakeLists.darwin-arm64.txt @@ -6,22 +6,27 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) add_subdirectory(ut) add_library(purecalc-io_specs-mkql) target_compile_options(purecalc-io_specs-mkql PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) +target_include_directories(purecalc-io_specs-mkql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql +) target_link_libraries(purecalc-io_specs-mkql PUBLIC contrib-libs-cxxsupp yutil - public-purecalc-common providers-yt-codec providers-yt-common yt-lib-mkql_helpers providers-common-codec common-schema-mkql + public-purecalc-common ) target_sources(purecalc-io_specs-mkql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/spec.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/spec.cpp ) diff --git a/ydb/library/yql/public/purecalc/io_specs/mkql/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/purecalc/io_specs/mkql/CMakeLists.darwin-x86_64.txt index a94716ee3e5d..bfecbc7ebde9 100644 --- a/ydb/library/yql/public/purecalc/io_specs/mkql/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/purecalc/io_specs/mkql/CMakeLists.darwin-x86_64.txt @@ -6,22 +6,27 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) add_subdirectory(ut) add_library(purecalc-io_specs-mkql) target_compile_options(purecalc-io_specs-mkql PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) +target_include_directories(purecalc-io_specs-mkql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql +) target_link_libraries(purecalc-io_specs-mkql PUBLIC contrib-libs-cxxsupp yutil - public-purecalc-common providers-yt-codec providers-yt-common yt-lib-mkql_helpers providers-common-codec common-schema-mkql + public-purecalc-common ) target_sources(purecalc-io_specs-mkql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/spec.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/spec.cpp ) diff --git a/ydb/library/yql/public/purecalc/io_specs/mkql/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/purecalc/io_specs/mkql/CMakeLists.linux-aarch64.txt index 2c6e3a6bee29..41709254914f 100644 --- a/ydb/library/yql/public/purecalc/io_specs/mkql/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/purecalc/io_specs/mkql/CMakeLists.linux-aarch64.txt @@ -6,23 +6,28 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) add_subdirectory(ut) add_library(purecalc-io_specs-mkql) target_compile_options(purecalc-io_specs-mkql PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) +target_include_directories(purecalc-io_specs-mkql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql +) target_link_libraries(purecalc-io_specs-mkql PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - public-purecalc-common providers-yt-codec providers-yt-common yt-lib-mkql_helpers providers-common-codec common-schema-mkql + public-purecalc-common ) target_sources(purecalc-io_specs-mkql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/spec.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/spec.cpp ) diff --git a/ydb/library/yql/public/purecalc/io_specs/mkql/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/purecalc/io_specs/mkql/CMakeLists.linux-x86_64.txt index 2c6e3a6bee29..41709254914f 100644 --- a/ydb/library/yql/public/purecalc/io_specs/mkql/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/purecalc/io_specs/mkql/CMakeLists.linux-x86_64.txt @@ -6,23 +6,28 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) add_subdirectory(ut) add_library(purecalc-io_specs-mkql) target_compile_options(purecalc-io_specs-mkql PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) +target_include_directories(purecalc-io_specs-mkql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql +) target_link_libraries(purecalc-io_specs-mkql PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - public-purecalc-common providers-yt-codec providers-yt-common yt-lib-mkql_helpers providers-common-codec common-schema-mkql + public-purecalc-common ) target_sources(purecalc-io_specs-mkql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/spec.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/spec.cpp ) diff --git a/ydb/library/yql/public/purecalc/io_specs/mkql/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/purecalc/io_specs/mkql/CMakeLists.windows-x86_64.txt index a94716ee3e5d..bfecbc7ebde9 100644 --- a/ydb/library/yql/public/purecalc/io_specs/mkql/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/purecalc/io_specs/mkql/CMakeLists.windows-x86_64.txt @@ -6,22 +6,27 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) add_subdirectory(ut) add_library(purecalc-io_specs-mkql) target_compile_options(purecalc-io_specs-mkql PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) +target_include_directories(purecalc-io_specs-mkql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql +) target_link_libraries(purecalc-io_specs-mkql PUBLIC contrib-libs-cxxsupp yutil - public-purecalc-common providers-yt-codec providers-yt-common yt-lib-mkql_helpers providers-common-codec common-schema-mkql + public-purecalc-common ) target_sources(purecalc-io_specs-mkql PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/spec.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/spec.cpp ) diff --git a/ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..c309e2dabd6b --- /dev/null +++ b/ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.darwin-arm64.txt @@ -0,0 +1,30 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(io_specs-mkql-no_llvm) +target_compile_options(io_specs-mkql-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(io_specs-mkql-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql +) +target_link_libraries(io_specs-mkql-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + providers-yt-codec + providers-yt-common + yt-lib-mkql_helpers + providers-common-codec + common-schema-mkql + purecalc-common-no_llvm +) +target_sources(io_specs-mkql-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/spec.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/spec.cpp +) diff --git a/ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..c309e2dabd6b --- /dev/null +++ b/ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,30 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(io_specs-mkql-no_llvm) +target_compile_options(io_specs-mkql-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(io_specs-mkql-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql +) +target_link_libraries(io_specs-mkql-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + providers-yt-codec + providers-yt-common + yt-lib-mkql_helpers + providers-common-codec + common-schema-mkql + purecalc-common-no_llvm +) +target_sources(io_specs-mkql-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/spec.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/spec.cpp +) diff --git a/ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..93903ca5324d --- /dev/null +++ b/ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.linux-aarch64.txt @@ -0,0 +1,31 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(io_specs-mkql-no_llvm) +target_compile_options(io_specs-mkql-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(io_specs-mkql-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql +) +target_link_libraries(io_specs-mkql-no_llvm PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + providers-yt-codec + providers-yt-common + yt-lib-mkql_helpers + providers-common-codec + common-schema-mkql + purecalc-common-no_llvm +) +target_sources(io_specs-mkql-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/spec.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/spec.cpp +) diff --git a/ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..93903ca5324d --- /dev/null +++ b/ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.linux-x86_64.txt @@ -0,0 +1,31 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(io_specs-mkql-no_llvm) +target_compile_options(io_specs-mkql-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(io_specs-mkql-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql +) +target_link_libraries(io_specs-mkql-no_llvm PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + providers-yt-codec + providers-yt-common + yt-lib-mkql_helpers + providers-common-codec + common-schema-mkql + purecalc-common-no_llvm +) +target_sources(io_specs-mkql-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/spec.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/spec.cpp +) diff --git a/ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.txt b/ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..c309e2dabd6b --- /dev/null +++ b/ydb/library/yql/public/purecalc/io_specs/mkql/no_llvm/CMakeLists.windows-x86_64.txt @@ -0,0 +1,30 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(io_specs-mkql-no_llvm) +target_compile_options(io_specs-mkql-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(io_specs-mkql-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql +) +target_link_libraries(io_specs-mkql-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + providers-yt-codec + providers-yt-common + yt-lib-mkql_helpers + providers-common-codec + common-schema-mkql + purecalc-common-no_llvm +) +target_sources(io_specs-mkql-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/spec.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/spec.cpp +) diff --git a/ydb/library/yql/public/purecalc/io_specs/mkql/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/purecalc/io_specs/mkql/ut/CMakeLists.darwin-arm64.txt index de063c0433ce..e2e19ce9c1a9 100644 --- a/ydb/library/yql/public/purecalc/io_specs/mkql/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/purecalc/io_specs/mkql/ut/CMakeLists.darwin-arm64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) add_executable(ydb-library-yql-public-purecalc-io_specs-mkql-ut) target_compile_options(ydb-library-yql-public-purecalc-io_specs-mkql-ut PRIVATE @@ -16,7 +17,7 @@ target_link_libraries(ydb-library-yql-public-purecalc-io_specs-mkql-ut PUBLIC yutil cpp-testing-unittest_main udf-service-exception_policy - public-purecalc-common + yql-public-purecalc purecalc-io_specs-mkql purecalc-ut-lib ) @@ -24,8 +25,6 @@ target_link_options(ydb-library-yql-public-purecalc-io_specs-mkql-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-public-purecalc-io_specs-mkql-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/ut/test_spec.cpp @@ -55,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/purecalc/io_specs/mkql/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/purecalc/io_specs/mkql/ut/CMakeLists.darwin-x86_64.txt index 08edd65bf81c..e8dcda8e266d 100644 --- a/ydb/library/yql/public/purecalc/io_specs/mkql/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/purecalc/io_specs/mkql/ut/CMakeLists.darwin-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) add_executable(ydb-library-yql-public-purecalc-io_specs-mkql-ut) target_compile_options(ydb-library-yql-public-purecalc-io_specs-mkql-ut PRIVATE @@ -17,7 +18,7 @@ target_link_libraries(ydb-library-yql-public-purecalc-io_specs-mkql-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main udf-service-exception_policy - public-purecalc-common + yql-public-purecalc purecalc-io_specs-mkql purecalc-ut-lib ) @@ -25,8 +26,6 @@ target_link_options(ydb-library-yql-public-purecalc-io_specs-mkql-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-public-purecalc-io_specs-mkql-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/ut/test_spec.cpp @@ -56,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/purecalc/io_specs/mkql/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/purecalc/io_specs/mkql/ut/CMakeLists.linux-aarch64.txt index 50277026691c..2f7d00a809ac 100644 --- a/ydb/library/yql/public/purecalc/io_specs/mkql/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/purecalc/io_specs/mkql/ut/CMakeLists.linux-aarch64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) add_executable(ydb-library-yql-public-purecalc-io_specs-mkql-ut) target_compile_options(ydb-library-yql-public-purecalc-io_specs-mkql-ut PRIVATE @@ -17,7 +18,7 @@ target_link_libraries(ydb-library-yql-public-purecalc-io_specs-mkql-ut PUBLIC yutil cpp-testing-unittest_main udf-service-exception_policy - public-purecalc-common + yql-public-purecalc purecalc-io_specs-mkql purecalc-ut-lib ) @@ -27,9 +28,6 @@ target_link_options(ydb-library-yql-public-purecalc-io_specs-mkql-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-public-purecalc-io_specs-mkql-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/ut/test_spec.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/purecalc/io_specs/mkql/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/purecalc/io_specs/mkql/ut/CMakeLists.linux-x86_64.txt index 36c85aeacb30..631e126fbcc6 100644 --- a/ydb/library/yql/public/purecalc/io_specs/mkql/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/purecalc/io_specs/mkql/ut/CMakeLists.linux-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) add_executable(ydb-library-yql-public-purecalc-io_specs-mkql-ut) target_compile_options(ydb-library-yql-public-purecalc-io_specs-mkql-ut PRIVATE @@ -18,7 +19,7 @@ target_link_libraries(ydb-library-yql-public-purecalc-io_specs-mkql-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main udf-service-exception_policy - public-purecalc-common + yql-public-purecalc purecalc-io_specs-mkql purecalc-ut-lib ) @@ -28,9 +29,6 @@ target_link_options(ydb-library-yql-public-purecalc-io_specs-mkql-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-public-purecalc-io_specs-mkql-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/ut/test_spec.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/purecalc/io_specs/mkql/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/purecalc/io_specs/mkql/ut/CMakeLists.windows-x86_64.txt index be8ef1154c36..b4d65b084d81 100644 --- a/ydb/library/yql/public/purecalc/io_specs/mkql/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/purecalc/io_specs/mkql/ut/CMakeLists.windows-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(no_llvm) add_executable(ydb-library-yql-public-purecalc-io_specs-mkql-ut) target_compile_options(ydb-library-yql-public-purecalc-io_specs-mkql-ut PRIVATE @@ -17,7 +18,7 @@ target_link_libraries(ydb-library-yql-public-purecalc-io_specs-mkql-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main udf-service-exception_policy - public-purecalc-common + yql-public-purecalc purecalc-io_specs-mkql purecalc-ut-lib ) @@ -49,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..10e981b4d943 --- /dev/null +++ b/ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.darwin-arm64.txt @@ -0,0 +1,75 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(public-purecalc-io_specs-mkql-ut-no_llvm) +target_compile_options(public-purecalc-io_specs-mkql-ut-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(public-purecalc-io_specs-mkql-ut-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + udf-service-exception_policy + public-purecalc-no_llvm + io_specs-mkql-no_llvm + purecalc-ut-lib +) +target_link_options(public-purecalc-io_specs-mkql-ut-no_llvm PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(public-purecalc-io_specs-mkql-ut-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/ut/test_spec.cpp +) +set_property( + TARGET + public-purecalc-io_specs-mkql-ut-no_llvm + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + public-purecalc-io_specs-mkql-ut-no_llvm + TEST_TARGET + public-purecalc-io_specs-mkql-ut-no_llvm + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + public-purecalc-io_specs-mkql-ut-no_llvm + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + public-purecalc-io_specs-mkql-ut-no_llvm + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + public-purecalc-io_specs-mkql-ut-no_llvm + PROPERTY + TIMEOUT + 300 +) +target_allocator(public-purecalc-io_specs-mkql-ut-no_llvm + system_allocator +) +vcs_info(public-purecalc-io_specs-mkql-ut-no_llvm) diff --git a/ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..112bcbdba15d --- /dev/null +++ b/ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,76 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(public-purecalc-io_specs-mkql-ut-no_llvm) +target_compile_options(public-purecalc-io_specs-mkql-ut-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(public-purecalc-io_specs-mkql-ut-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + udf-service-exception_policy + public-purecalc-no_llvm + io_specs-mkql-no_llvm + purecalc-ut-lib +) +target_link_options(public-purecalc-io_specs-mkql-ut-no_llvm PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(public-purecalc-io_specs-mkql-ut-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/ut/test_spec.cpp +) +set_property( + TARGET + public-purecalc-io_specs-mkql-ut-no_llvm + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + public-purecalc-io_specs-mkql-ut-no_llvm + TEST_TARGET + public-purecalc-io_specs-mkql-ut-no_llvm + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + public-purecalc-io_specs-mkql-ut-no_llvm + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + public-purecalc-io_specs-mkql-ut-no_llvm + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + public-purecalc-io_specs-mkql-ut-no_llvm + PROPERTY + TIMEOUT + 300 +) +target_allocator(public-purecalc-io_specs-mkql-ut-no_llvm + system_allocator +) +vcs_info(public-purecalc-io_specs-mkql-ut-no_llvm) diff --git a/ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..6e24deaed82c --- /dev/null +++ b/ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.linux-aarch64.txt @@ -0,0 +1,78 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(public-purecalc-io_specs-mkql-ut-no_llvm) +target_compile_options(public-purecalc-io_specs-mkql-ut-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(public-purecalc-io_specs-mkql-ut-no_llvm PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + cpp-testing-unittest_main + udf-service-exception_policy + public-purecalc-no_llvm + io_specs-mkql-no_llvm + purecalc-ut-lib +) +target_link_options(public-purecalc-io_specs-mkql-ut-no_llvm PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(public-purecalc-io_specs-mkql-ut-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/ut/test_spec.cpp +) +set_property( + TARGET + public-purecalc-io_specs-mkql-ut-no_llvm + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + public-purecalc-io_specs-mkql-ut-no_llvm + TEST_TARGET + public-purecalc-io_specs-mkql-ut-no_llvm + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + public-purecalc-io_specs-mkql-ut-no_llvm + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + public-purecalc-io_specs-mkql-ut-no_llvm + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + public-purecalc-io_specs-mkql-ut-no_llvm + PROPERTY + TIMEOUT + 300 +) +target_allocator(public-purecalc-io_specs-mkql-ut-no_llvm + cpp-malloc-jemalloc +) +vcs_info(public-purecalc-io_specs-mkql-ut-no_llvm) diff --git a/ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..3448543edfaf --- /dev/null +++ b/ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.linux-x86_64.txt @@ -0,0 +1,80 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(public-purecalc-io_specs-mkql-ut-no_llvm) +target_compile_options(public-purecalc-io_specs-mkql-ut-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(public-purecalc-io_specs-mkql-ut-no_llvm PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + udf-service-exception_policy + public-purecalc-no_llvm + io_specs-mkql-no_llvm + purecalc-ut-lib +) +target_link_options(public-purecalc-io_specs-mkql-ut-no_llvm PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(public-purecalc-io_specs-mkql-ut-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/ut/test_spec.cpp +) +set_property( + TARGET + public-purecalc-io_specs-mkql-ut-no_llvm + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + public-purecalc-io_specs-mkql-ut-no_llvm + TEST_TARGET + public-purecalc-io_specs-mkql-ut-no_llvm + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + public-purecalc-io_specs-mkql-ut-no_llvm + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + public-purecalc-io_specs-mkql-ut-no_llvm + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + public-purecalc-io_specs-mkql-ut-no_llvm + PROPERTY + TIMEOUT + 300 +) +target_allocator(public-purecalc-io_specs-mkql-ut-no_llvm + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(public-purecalc-io_specs-mkql-ut-no_llvm) diff --git a/ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.txt b/ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..decde8f2f2f2 --- /dev/null +++ b/ydb/library/yql/public/purecalc/io_specs/mkql/ut/no_llvm/CMakeLists.windows-x86_64.txt @@ -0,0 +1,71 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(public-purecalc-io_specs-mkql-ut-no_llvm) +target_compile_options(public-purecalc-io_specs-mkql-ut-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(public-purecalc-io_specs-mkql-ut-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + cpp-testing-unittest_main + udf-service-exception_policy + public-purecalc-no_llvm + io_specs-mkql-no_llvm + purecalc-ut-lib +) +target_sources(public-purecalc-io_specs-mkql-ut-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/mkql/ut/test_spec.cpp +) +set_property( + TARGET + public-purecalc-io_specs-mkql-ut-no_llvm + PROPERTY + SPLIT_FACTOR + 1 +) +add_yunittest( + NAME + public-purecalc-io_specs-mkql-ut-no_llvm + TEST_TARGET + public-purecalc-io_specs-mkql-ut-no_llvm + TEST_ARG + --print-before-suite + --print-before-test + --fork-tests + --print-times + --show-fails +) +set_yunittest_property( + TEST + public-purecalc-io_specs-mkql-ut-no_llvm + PROPERTY + LABELS + MEDIUM + $FILTER_ONLY_TEST_TAGS +) +set_yunittest_property( + TEST + public-purecalc-io_specs-mkql-ut-no_llvm + PROPERTY + PROCESSORS + 1 +) +set_yunittest_property( + TEST + public-purecalc-io_specs-mkql-ut-no_llvm + PROPERTY + TIMEOUT + 300 +) +target_allocator(public-purecalc-io_specs-mkql-ut-no_llvm + system_allocator +) +vcs_info(public-purecalc-io_specs-mkql-ut-no_llvm) diff --git a/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/CMakeLists.darwin-arm64.txt index 21f5abdd56b8..d6d8dcdd5e78 100644 --- a/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/CMakeLists.darwin-arm64.txt @@ -17,7 +17,7 @@ target_link_libraries(yql-public-purecalc-io_specs-protobuf-ut PUBLIC cpp-testing-unittest_main cpp-protobuf-util udf-service-exception_policy - public-purecalc-common + yql-public-purecalc purecalc-io_specs-protobuf purecalc-ut-protos ) @@ -25,8 +25,6 @@ target_link_options(yql-public-purecalc-io_specs-protobuf-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(yql-public-purecalc-io_specs-protobuf-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/test_spec.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/CMakeLists.darwin-x86_64.txt index b5599ef49618..16e70037b516 100644 --- a/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/CMakeLists.darwin-x86_64.txt @@ -18,7 +18,7 @@ target_link_libraries(yql-public-purecalc-io_specs-protobuf-ut PUBLIC cpp-testing-unittest_main cpp-protobuf-util udf-service-exception_policy - public-purecalc-common + yql-public-purecalc purecalc-io_specs-protobuf purecalc-ut-protos ) @@ -26,8 +26,6 @@ target_link_options(yql-public-purecalc-io_specs-protobuf-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(yql-public-purecalc-io_specs-protobuf-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/test_spec.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/CMakeLists.linux-aarch64.txt index 2ff8d5a7fc07..7f4fb0ab0e69 100644 --- a/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/CMakeLists.linux-aarch64.txt @@ -18,7 +18,7 @@ target_link_libraries(yql-public-purecalc-io_specs-protobuf-ut PUBLIC cpp-testing-unittest_main cpp-protobuf-util udf-service-exception_policy - public-purecalc-common + yql-public-purecalc purecalc-io_specs-protobuf purecalc-ut-protos ) @@ -28,9 +28,6 @@ target_link_options(yql-public-purecalc-io_specs-protobuf-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(yql-public-purecalc-io_specs-protobuf-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/test_spec.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/CMakeLists.linux-x86_64.txt index 2defc0237f49..a2f68aa84bde 100644 --- a/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/CMakeLists.linux-x86_64.txt @@ -19,7 +19,7 @@ target_link_libraries(yql-public-purecalc-io_specs-protobuf-ut PUBLIC cpp-testing-unittest_main cpp-protobuf-util udf-service-exception_policy - public-purecalc-common + yql-public-purecalc purecalc-io_specs-protobuf purecalc-ut-protos ) @@ -29,9 +29,6 @@ target_link_options(yql-public-purecalc-io_specs-protobuf-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(yql-public-purecalc-io_specs-protobuf-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/test_spec.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/CMakeLists.windows-x86_64.txt index 4e2687f66062..f91ce9529cb8 100644 --- a/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/purecalc/io_specs/protobuf/ut/CMakeLists.windows-x86_64.txt @@ -18,7 +18,7 @@ target_link_libraries(yql-public-purecalc-io_specs-protobuf-ut PUBLIC cpp-testing-unittest_main cpp-protobuf-util udf-service-exception_policy - public-purecalc-common + yql-public-purecalc purecalc-io_specs-protobuf purecalc-ut-protos ) @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/CMakeLists.darwin-arm64.txt index e482710c074d..9d656e2799a2 100644 --- a/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/CMakeLists.darwin-arm64.txt @@ -18,6 +18,7 @@ target_link_libraries(purecalc-io_specs-protobuf_raw PUBLIC purecalc-helpers-protobuf ) target_sources(purecalc-io_specs-protobuf_raw PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/spec.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/proto_holder.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/spec.cpp ) diff --git a/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/CMakeLists.darwin-x86_64.txt index e482710c074d..9d656e2799a2 100644 --- a/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/CMakeLists.darwin-x86_64.txt @@ -18,6 +18,7 @@ target_link_libraries(purecalc-io_specs-protobuf_raw PUBLIC purecalc-helpers-protobuf ) target_sources(purecalc-io_specs-protobuf_raw PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/spec.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/proto_holder.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/spec.cpp ) diff --git a/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/CMakeLists.linux-aarch64.txt index eb794e6f378b..242ab97bac22 100644 --- a/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/CMakeLists.linux-aarch64.txt @@ -19,6 +19,7 @@ target_link_libraries(purecalc-io_specs-protobuf_raw PUBLIC purecalc-helpers-protobuf ) target_sources(purecalc-io_specs-protobuf_raw PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/spec.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/proto_holder.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/spec.cpp ) diff --git a/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/CMakeLists.linux-x86_64.txt index eb794e6f378b..242ab97bac22 100644 --- a/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/CMakeLists.linux-x86_64.txt @@ -19,6 +19,7 @@ target_link_libraries(purecalc-io_specs-protobuf_raw PUBLIC purecalc-helpers-protobuf ) target_sources(purecalc-io_specs-protobuf_raw PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/spec.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/proto_holder.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/spec.cpp ) diff --git a/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/CMakeLists.windows-x86_64.txt index e482710c074d..9d656e2799a2 100644 --- a/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/CMakeLists.windows-x86_64.txt @@ -18,6 +18,7 @@ target_link_libraries(purecalc-io_specs-protobuf_raw PUBLIC purecalc-helpers-protobuf ) target_sources(purecalc-io_specs-protobuf_raw PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/spec.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/proto_holder.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/io_specs/protobuf_raw/spec.cpp ) diff --git a/ydb/library/yql/public/purecalc/no_llvm/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/purecalc/no_llvm/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..2361ef39c61a --- /dev/null +++ b/ydb/library/yql/public/purecalc/no_llvm/CMakeLists.darwin-arm64.txt @@ -0,0 +1,30 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(public-purecalc-no_llvm) +target_compile_options(public-purecalc-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(public-purecalc-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc +) +target_link_libraries(public-purecalc-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + udf-service-exception_policy + purecalc-common-no_llvm + codec-codegen-no_llvm + minikql-codegen-no_llvm + minikql-computation-no_llvm + minikql-invoke_builtins-no_llvm + minikql-comp_nodes-no_llvm +) +target_sources(public-purecalc-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/purecalc.cpp +) diff --git a/ydb/library/yql/public/purecalc/no_llvm/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/purecalc/no_llvm/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..2361ef39c61a --- /dev/null +++ b/ydb/library/yql/public/purecalc/no_llvm/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,30 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(public-purecalc-no_llvm) +target_compile_options(public-purecalc-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(public-purecalc-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc +) +target_link_libraries(public-purecalc-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + udf-service-exception_policy + purecalc-common-no_llvm + codec-codegen-no_llvm + minikql-codegen-no_llvm + minikql-computation-no_llvm + minikql-invoke_builtins-no_llvm + minikql-comp_nodes-no_llvm +) +target_sources(public-purecalc-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/purecalc.cpp +) diff --git a/ydb/library/yql/public/purecalc/no_llvm/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/purecalc/no_llvm/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..22308601d256 --- /dev/null +++ b/ydb/library/yql/public/purecalc/no_llvm/CMakeLists.linux-aarch64.txt @@ -0,0 +1,31 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(public-purecalc-no_llvm) +target_compile_options(public-purecalc-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(public-purecalc-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc +) +target_link_libraries(public-purecalc-no_llvm PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + udf-service-exception_policy + purecalc-common-no_llvm + codec-codegen-no_llvm + minikql-codegen-no_llvm + minikql-computation-no_llvm + minikql-invoke_builtins-no_llvm + minikql-comp_nodes-no_llvm +) +target_sources(public-purecalc-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/purecalc.cpp +) diff --git a/ydb/library/yql/public/purecalc/no_llvm/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/purecalc/no_llvm/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..22308601d256 --- /dev/null +++ b/ydb/library/yql/public/purecalc/no_llvm/CMakeLists.linux-x86_64.txt @@ -0,0 +1,31 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(public-purecalc-no_llvm) +target_compile_options(public-purecalc-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(public-purecalc-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc +) +target_link_libraries(public-purecalc-no_llvm PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + udf-service-exception_policy + purecalc-common-no_llvm + codec-codegen-no_llvm + minikql-codegen-no_llvm + minikql-computation-no_llvm + minikql-invoke_builtins-no_llvm + minikql-comp_nodes-no_llvm +) +target_sources(public-purecalc-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/purecalc.cpp +) diff --git a/ydb/library/yql/public/purecalc/no_llvm/CMakeLists.txt b/ydb/library/yql/public/purecalc/no_llvm/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/public/purecalc/no_llvm/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/public/purecalc/no_llvm/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/purecalc/no_llvm/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..2361ef39c61a --- /dev/null +++ b/ydb/library/yql/public/purecalc/no_llvm/CMakeLists.windows-x86_64.txt @@ -0,0 +1,30 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(public-purecalc-no_llvm) +target_compile_options(public-purecalc-no_llvm PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_include_directories(public-purecalc-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc +) +target_link_libraries(public-purecalc-no_llvm PUBLIC + contrib-libs-cxxsupp + yutil + udf-service-exception_policy + purecalc-common-no_llvm + codec-codegen-no_llvm + minikql-codegen-no_llvm + minikql-computation-no_llvm + minikql-invoke_builtins-no_llvm + minikql-comp_nodes-no_llvm +) +target_sources(public-purecalc-no_llvm PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/purecalc.cpp +) diff --git a/ydb/library/yql/public/purecalc/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/purecalc/ut/CMakeLists.darwin-arm64.txt index db6a308f3a60..42ec79d4e87e 100644 --- a/ydb/library/yql/public/purecalc/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/purecalc/ut/CMakeLists.darwin-arm64.txt @@ -25,10 +25,10 @@ target_link_options(ydb-library-yql-public-purecalc-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-public-purecalc-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/empty_stream.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/fake_spec.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/fake_spec.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/test_schema.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/test_sexpr.cpp @@ -63,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/purecalc/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/purecalc/ut/CMakeLists.darwin-x86_64.txt index 4a4c7b68a29f..7b6cf87f54cc 100644 --- a/ydb/library/yql/public/purecalc/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/purecalc/ut/CMakeLists.darwin-x86_64.txt @@ -26,10 +26,10 @@ target_link_options(ydb-library-yql-public-purecalc-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-public-purecalc-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/empty_stream.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/fake_spec.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/fake_spec.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/test_schema.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/test_sexpr.cpp @@ -64,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/purecalc/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/purecalc/ut/CMakeLists.linux-aarch64.txt index 01d22ca88f7a..3e546cdc51cb 100644 --- a/ydb/library/yql/public/purecalc/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/purecalc/ut/CMakeLists.linux-aarch64.txt @@ -28,11 +28,10 @@ target_link_options(ydb-library-yql-public-purecalc-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-public-purecalc-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/empty_stream.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/fake_spec.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/fake_spec.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/test_schema.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/test_sexpr.cpp @@ -67,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/purecalc/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/purecalc/ut/CMakeLists.linux-x86_64.txt index 5c64f772cb05..fd869c2acabb 100644 --- a/ydb/library/yql/public/purecalc/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/purecalc/ut/CMakeLists.linux-x86_64.txt @@ -29,11 +29,10 @@ target_link_options(ydb-library-yql-public-purecalc-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-public-purecalc-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/empty_stream.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/fake_spec.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/fake_spec.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/test_schema.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/test_sexpr.cpp @@ -68,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/purecalc/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/purecalc/ut/CMakeLists.windows-x86_64.txt index eb1ce4c4c3fa..510603f3b453 100644 --- a/ydb/library/yql/public/purecalc/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/purecalc/ut/CMakeLists.windows-x86_64.txt @@ -23,6 +23,8 @@ target_link_libraries(ydb-library-yql-public-purecalc-ut PUBLIC purecalc-ut-protos ) target_sources(ydb-library-yql-public-purecalc-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/empty_stream.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/fake_spec.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/fake_spec.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/test_schema.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/test_sexpr.cpp @@ -57,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/purecalc/ut/lib/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/purecalc/ut/lib/CMakeLists.darwin-arm64.txt index 36bfa6b4d555..fea668350439 100644 --- a/ydb/library/yql/public/purecalc/ut/lib/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/purecalc/ut/lib/CMakeLists.darwin-arm64.txt @@ -15,5 +15,6 @@ target_link_libraries(purecalc-ut-lib PUBLIC cpp-yson-node ) target_sources(purecalc-ut-lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/lib/helpers.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/lib/helpers.cpp ) diff --git a/ydb/library/yql/public/purecalc/ut/lib/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/purecalc/ut/lib/CMakeLists.darwin-x86_64.txt index 36bfa6b4d555..fea668350439 100644 --- a/ydb/library/yql/public/purecalc/ut/lib/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/purecalc/ut/lib/CMakeLists.darwin-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(purecalc-ut-lib PUBLIC cpp-yson-node ) target_sources(purecalc-ut-lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/lib/helpers.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/lib/helpers.cpp ) diff --git a/ydb/library/yql/public/purecalc/ut/lib/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/purecalc/ut/lib/CMakeLists.linux-aarch64.txt index b32b5970c1f4..048fd6d9170e 100644 --- a/ydb/library/yql/public/purecalc/ut/lib/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/purecalc/ut/lib/CMakeLists.linux-aarch64.txt @@ -16,5 +16,6 @@ target_link_libraries(purecalc-ut-lib PUBLIC cpp-yson-node ) target_sources(purecalc-ut-lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/lib/helpers.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/lib/helpers.cpp ) diff --git a/ydb/library/yql/public/purecalc/ut/lib/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/purecalc/ut/lib/CMakeLists.linux-x86_64.txt index b32b5970c1f4..048fd6d9170e 100644 --- a/ydb/library/yql/public/purecalc/ut/lib/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/purecalc/ut/lib/CMakeLists.linux-x86_64.txt @@ -16,5 +16,6 @@ target_link_libraries(purecalc-ut-lib PUBLIC cpp-yson-node ) target_sources(purecalc-ut-lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/lib/helpers.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/lib/helpers.cpp ) diff --git a/ydb/library/yql/public/purecalc/ut/lib/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/purecalc/ut/lib/CMakeLists.windows-x86_64.txt index 36bfa6b4d555..fea668350439 100644 --- a/ydb/library/yql/public/purecalc/ut/lib/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/purecalc/ut/lib/CMakeLists.windows-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(purecalc-ut-lib PUBLIC cpp-yson-node ) target_sources(purecalc-ut-lib PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/lib/helpers.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/lib/helpers.cpp ) diff --git a/ydb/library/yql/public/purecalc/ut/protos/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/purecalc/ut/protos/CMakeLists.darwin-arm64.txt index 12f10544f8b7..112ce14740b6 100644 --- a/ydb/library/yql/public/purecalc/ut/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/purecalc/ut/protos/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(purecalc-ut-protos PUBLIC target_proto_messages(purecalc-ut-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/protos/test_structs.proto ) +target_sources(purecalc-ut-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/purecalc/ut/protos/test_structs.pb.h +) target_proto_addincls(purecalc-ut-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/public/purecalc/ut/protos/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/purecalc/ut/protos/CMakeLists.darwin-x86_64.txt index 12f10544f8b7..112ce14740b6 100644 --- a/ydb/library/yql/public/purecalc/ut/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/purecalc/ut/protos/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(purecalc-ut-protos PUBLIC target_proto_messages(purecalc-ut-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/protos/test_structs.proto ) +target_sources(purecalc-ut-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/purecalc/ut/protos/test_structs.pb.h +) target_proto_addincls(purecalc-ut-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/public/purecalc/ut/protos/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/purecalc/ut/protos/CMakeLists.linux-aarch64.txt index 806ee8016556..9447e5e67472 100644 --- a/ydb/library/yql/public/purecalc/ut/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/purecalc/ut/protos/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(purecalc-ut-protos PUBLIC target_proto_messages(purecalc-ut-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/protos/test_structs.proto ) +target_sources(purecalc-ut-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/purecalc/ut/protos/test_structs.pb.h +) target_proto_addincls(purecalc-ut-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/public/purecalc/ut/protos/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/purecalc/ut/protos/CMakeLists.linux-x86_64.txt index 806ee8016556..9447e5e67472 100644 --- a/ydb/library/yql/public/purecalc/ut/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/purecalc/ut/protos/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(purecalc-ut-protos PUBLIC target_proto_messages(purecalc-ut-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/protos/test_structs.proto ) +target_sources(purecalc-ut-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/purecalc/ut/protos/test_structs.pb.h +) target_proto_addincls(purecalc-ut-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/public/purecalc/ut/protos/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/purecalc/ut/protos/CMakeLists.windows-x86_64.txt index 12f10544f8b7..112ce14740b6 100644 --- a/ydb/library/yql/public/purecalc/ut/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/purecalc/ut/protos/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(purecalc-ut-protos PUBLIC target_proto_messages(purecalc-ut-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/purecalc/ut/protos/test_structs.proto ) +target_sources(purecalc-ut-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/purecalc/ut/protos/test_structs.pb.h +) target_proto_addincls(purecalc-ut-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/public/types/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/types/CMakeLists.darwin-arm64.txt index 6af082dd5750..c78ead6383bf 100644 --- a/ydb/library/yql/public/types/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/types/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(yql-public-types PUBLIC target_proto_messages(yql-public-types PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/types/yql_types.proto ) +target_sources(yql-public-types PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/types/yql_types.pb.h +) target_proto_addincls(yql-public-types ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/public/types/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/types/CMakeLists.darwin-x86_64.txt index 6af082dd5750..c78ead6383bf 100644 --- a/ydb/library/yql/public/types/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/types/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(yql-public-types PUBLIC target_proto_messages(yql-public-types PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/types/yql_types.proto ) +target_sources(yql-public-types PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/types/yql_types.pb.h +) target_proto_addincls(yql-public-types ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/public/types/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/types/CMakeLists.linux-aarch64.txt index 9f51523b7dad..7ccf949ffd62 100644 --- a/ydb/library/yql/public/types/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/types/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(yql-public-types PUBLIC target_proto_messages(yql-public-types PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/types/yql_types.proto ) +target_sources(yql-public-types PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/types/yql_types.pb.h +) target_proto_addincls(yql-public-types ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/public/types/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/types/CMakeLists.linux-x86_64.txt index 9f51523b7dad..7ccf949ffd62 100644 --- a/ydb/library/yql/public/types/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/types/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(yql-public-types PUBLIC target_proto_messages(yql-public-types PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/types/yql_types.proto ) +target_sources(yql-public-types PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/types/yql_types.pb.h +) target_proto_addincls(yql-public-types ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/public/types/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/types/CMakeLists.windows-x86_64.txt index 6af082dd5750..c78ead6383bf 100644 --- a/ydb/library/yql/public/types/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/types/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(yql-public-types PUBLIC target_proto_messages(yql-public-types PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/types/yql_types.proto ) +target_sources(yql-public-types PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/public/types/yql_types.pb.h +) target_proto_addincls(yql-public-types ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/public/udf/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/udf/CMakeLists.darwin-arm64.txt index b23af34525d8..5163d05676eb 100644 --- a/ydb/library/yql/public/udf/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/udf/CMakeLists.darwin-arm64.txt @@ -26,6 +26,27 @@ target_link_libraries(yql-public-udf PUBLIC cpp-deprecated-atomic ) target_sources(yql-public-udf PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_allocator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_counter.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_data_type.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_pg_type_description.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_ptr.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_registrator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_static_registry.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_string.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_inspection.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_ops.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_printer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_size_check.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_types.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_ut_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_validate.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_value.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_value_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_value_inl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_version.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_allocator.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_counter.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_data_type.cpp diff --git a/ydb/library/yql/public/udf/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/udf/CMakeLists.darwin-x86_64.txt index b23af34525d8..5163d05676eb 100644 --- a/ydb/library/yql/public/udf/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/udf/CMakeLists.darwin-x86_64.txt @@ -26,6 +26,27 @@ target_link_libraries(yql-public-udf PUBLIC cpp-deprecated-atomic ) target_sources(yql-public-udf PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_allocator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_counter.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_data_type.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_pg_type_description.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_ptr.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_registrator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_static_registry.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_string.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_inspection.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_ops.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_printer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_size_check.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_types.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_ut_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_validate.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_value.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_value_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_value_inl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_version.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_allocator.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_counter.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_data_type.cpp diff --git a/ydb/library/yql/public/udf/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/udf/CMakeLists.linux-aarch64.txt index 4903599672f9..98791bb489ae 100644 --- a/ydb/library/yql/public/udf/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/udf/CMakeLists.linux-aarch64.txt @@ -27,6 +27,27 @@ target_link_libraries(yql-public-udf PUBLIC cpp-deprecated-atomic ) target_sources(yql-public-udf PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_allocator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_counter.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_data_type.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_pg_type_description.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_ptr.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_registrator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_static_registry.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_string.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_inspection.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_ops.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_printer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_size_check.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_types.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_ut_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_validate.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_value.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_value_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_value_inl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_version.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_allocator.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_counter.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_data_type.cpp diff --git a/ydb/library/yql/public/udf/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/udf/CMakeLists.linux-x86_64.txt index 4903599672f9..98791bb489ae 100644 --- a/ydb/library/yql/public/udf/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/udf/CMakeLists.linux-x86_64.txt @@ -27,6 +27,27 @@ target_link_libraries(yql-public-udf PUBLIC cpp-deprecated-atomic ) target_sources(yql-public-udf PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_allocator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_counter.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_data_type.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_pg_type_description.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_ptr.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_registrator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_static_registry.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_string.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_inspection.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_ops.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_printer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_size_check.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_types.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_ut_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_validate.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_value.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_value_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_value_inl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_version.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_allocator.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_counter.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_data_type.cpp diff --git a/ydb/library/yql/public/udf/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/udf/CMakeLists.windows-x86_64.txt index b23af34525d8..5163d05676eb 100644 --- a/ydb/library/yql/public/udf/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/udf/CMakeLists.windows-x86_64.txt @@ -26,6 +26,27 @@ target_link_libraries(yql-public-udf PUBLIC cpp-deprecated-atomic ) target_sources(yql-public-udf PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_allocator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_counter.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_data_type.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_pg_type_description.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_ptr.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_registrator.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_static_registry.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_string.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_inspection.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_ops.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_printer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_type_size_check.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_types.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_ut_helpers.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_validate.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_value.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_value_builder.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_value_inl.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_version.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_allocator.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_counter.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_data_type.cpp diff --git a/ydb/library/yql/public/udf/service/exception_policy/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/udf/service/exception_policy/CMakeLists.darwin-arm64.txt index c0011de5e5fa..2b10475457ff 100644 --- a/ydb/library/yql/public/udf/service/exception_policy/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/udf/service/exception_policy/CMakeLists.darwin-arm64.txt @@ -7,16 +7,24 @@ -add_library(udf-service-exception_policy) -target_compile_options(udf-service-exception_policy PRIVATE +add_library(udf-service-exception_policy INTERFACE) +target_link_libraries(udf-service-exception_policy INTERFACE + contrib-libs-cxxsupp + yutil + library-yql-minikql + yql-public-udf +) + +add_global_library_for(udf-service-exception_policy.global udf-service-exception_policy) +target_compile_options(udf-service-exception_policy.global PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(udf-service-exception_policy PUBLIC +target_link_libraries(udf-service-exception_policy.global PUBLIC contrib-libs-cxxsupp yutil library-yql-minikql yql-public-udf ) -target_sources(udf-service-exception_policy PRIVATE +target_sources(udf-service-exception_policy.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/service/exception_policy/udf_service.cpp ) diff --git a/ydb/library/yql/public/udf/service/exception_policy/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/udf/service/exception_policy/CMakeLists.darwin-x86_64.txt index c0011de5e5fa..2b10475457ff 100644 --- a/ydb/library/yql/public/udf/service/exception_policy/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/udf/service/exception_policy/CMakeLists.darwin-x86_64.txt @@ -7,16 +7,24 @@ -add_library(udf-service-exception_policy) -target_compile_options(udf-service-exception_policy PRIVATE +add_library(udf-service-exception_policy INTERFACE) +target_link_libraries(udf-service-exception_policy INTERFACE + contrib-libs-cxxsupp + yutil + library-yql-minikql + yql-public-udf +) + +add_global_library_for(udf-service-exception_policy.global udf-service-exception_policy) +target_compile_options(udf-service-exception_policy.global PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(udf-service-exception_policy PUBLIC +target_link_libraries(udf-service-exception_policy.global PUBLIC contrib-libs-cxxsupp yutil library-yql-minikql yql-public-udf ) -target_sources(udf-service-exception_policy PRIVATE +target_sources(udf-service-exception_policy.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/service/exception_policy/udf_service.cpp ) diff --git a/ydb/library/yql/public/udf/service/exception_policy/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/udf/service/exception_policy/CMakeLists.linux-aarch64.txt index 6481ad202204..f7fb7e3707ae 100644 --- a/ydb/library/yql/public/udf/service/exception_policy/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/udf/service/exception_policy/CMakeLists.linux-aarch64.txt @@ -7,17 +7,26 @@ -add_library(udf-service-exception_policy) -target_compile_options(udf-service-exception_policy PRIVATE +add_library(udf-service-exception_policy INTERFACE) +target_link_libraries(udf-service-exception_policy INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-yql-minikql + yql-public-udf +) + +add_global_library_for(udf-service-exception_policy.global udf-service-exception_policy) +target_compile_options(udf-service-exception_policy.global PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(udf-service-exception_policy PUBLIC +target_link_libraries(udf-service-exception_policy.global PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil library-yql-minikql yql-public-udf ) -target_sources(udf-service-exception_policy PRIVATE +target_sources(udf-service-exception_policy.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/service/exception_policy/udf_service.cpp ) diff --git a/ydb/library/yql/public/udf/service/exception_policy/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/udf/service/exception_policy/CMakeLists.linux-x86_64.txt index 6481ad202204..f7fb7e3707ae 100644 --- a/ydb/library/yql/public/udf/service/exception_policy/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/udf/service/exception_policy/CMakeLists.linux-x86_64.txt @@ -7,17 +7,26 @@ -add_library(udf-service-exception_policy) -target_compile_options(udf-service-exception_policy PRIVATE +add_library(udf-service-exception_policy INTERFACE) +target_link_libraries(udf-service-exception_policy INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-yql-minikql + yql-public-udf +) + +add_global_library_for(udf-service-exception_policy.global udf-service-exception_policy) +target_compile_options(udf-service-exception_policy.global PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(udf-service-exception_policy PUBLIC +target_link_libraries(udf-service-exception_policy.global PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil library-yql-minikql yql-public-udf ) -target_sources(udf-service-exception_policy PRIVATE +target_sources(udf-service-exception_policy.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/service/exception_policy/udf_service.cpp ) diff --git a/ydb/library/yql/public/udf/service/exception_policy/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/udf/service/exception_policy/CMakeLists.windows-x86_64.txt index c0011de5e5fa..2b10475457ff 100644 --- a/ydb/library/yql/public/udf/service/exception_policy/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/udf/service/exception_policy/CMakeLists.windows-x86_64.txt @@ -7,16 +7,24 @@ -add_library(udf-service-exception_policy) -target_compile_options(udf-service-exception_policy PRIVATE +add_library(udf-service-exception_policy INTERFACE) +target_link_libraries(udf-service-exception_policy INTERFACE + contrib-libs-cxxsupp + yutil + library-yql-minikql + yql-public-udf +) + +add_global_library_for(udf-service-exception_policy.global udf-service-exception_policy) +target_compile_options(udf-service-exception_policy.global PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(udf-service-exception_policy PUBLIC +target_link_libraries(udf-service-exception_policy.global PUBLIC contrib-libs-cxxsupp yutil library-yql-minikql yql-public-udf ) -target_sources(udf-service-exception_policy PRIVATE +target_sources(udf-service-exception_policy.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/service/exception_policy/udf_service.cpp ) diff --git a/ydb/library/yql/public/udf/service/stub/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/udf/service/stub/CMakeLists.darwin-arm64.txt index dca6cc3d42b5..68cbe171d8a4 100644 --- a/ydb/library/yql/public/udf/service/stub/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/udf/service/stub/CMakeLists.darwin-arm64.txt @@ -7,15 +7,22 @@ -add_library(udf-service-stub) -target_compile_options(udf-service-stub PRIVATE +add_library(udf-service-stub INTERFACE) +target_link_libraries(udf-service-stub INTERFACE + contrib-libs-cxxsupp + yutil + yql-public-udf +) + +add_global_library_for(udf-service-stub.global udf-service-stub) +target_compile_options(udf-service-stub.global PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(udf-service-stub PUBLIC +target_link_libraries(udf-service-stub.global PUBLIC contrib-libs-cxxsupp yutil yql-public-udf ) -target_sources(udf-service-stub PRIVATE +target_sources(udf-service-stub.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/service/stub/udf_service.cpp ) diff --git a/ydb/library/yql/public/udf/service/stub/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/udf/service/stub/CMakeLists.darwin-x86_64.txt index dca6cc3d42b5..68cbe171d8a4 100644 --- a/ydb/library/yql/public/udf/service/stub/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/udf/service/stub/CMakeLists.darwin-x86_64.txt @@ -7,15 +7,22 @@ -add_library(udf-service-stub) -target_compile_options(udf-service-stub PRIVATE +add_library(udf-service-stub INTERFACE) +target_link_libraries(udf-service-stub INTERFACE + contrib-libs-cxxsupp + yutil + yql-public-udf +) + +add_global_library_for(udf-service-stub.global udf-service-stub) +target_compile_options(udf-service-stub.global PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(udf-service-stub PUBLIC +target_link_libraries(udf-service-stub.global PUBLIC contrib-libs-cxxsupp yutil yql-public-udf ) -target_sources(udf-service-stub PRIVATE +target_sources(udf-service-stub.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/service/stub/udf_service.cpp ) diff --git a/ydb/library/yql/public/udf/service/stub/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/udf/service/stub/CMakeLists.linux-aarch64.txt index fdf4e0405fd1..10051ef29fb6 100644 --- a/ydb/library/yql/public/udf/service/stub/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/udf/service/stub/CMakeLists.linux-aarch64.txt @@ -7,16 +7,24 @@ -add_library(udf-service-stub) -target_compile_options(udf-service-stub PRIVATE +add_library(udf-service-stub INTERFACE) +target_link_libraries(udf-service-stub INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + yql-public-udf +) + +add_global_library_for(udf-service-stub.global udf-service-stub) +target_compile_options(udf-service-stub.global PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(udf-service-stub PUBLIC +target_link_libraries(udf-service-stub.global PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil yql-public-udf ) -target_sources(udf-service-stub PRIVATE +target_sources(udf-service-stub.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/service/stub/udf_service.cpp ) diff --git a/ydb/library/yql/public/udf/service/stub/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/udf/service/stub/CMakeLists.linux-x86_64.txt index fdf4e0405fd1..10051ef29fb6 100644 --- a/ydb/library/yql/public/udf/service/stub/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/udf/service/stub/CMakeLists.linux-x86_64.txt @@ -7,16 +7,24 @@ -add_library(udf-service-stub) -target_compile_options(udf-service-stub PRIVATE +add_library(udf-service-stub INTERFACE) +target_link_libraries(udf-service-stub INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + yql-public-udf +) + +add_global_library_for(udf-service-stub.global udf-service-stub) +target_compile_options(udf-service-stub.global PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(udf-service-stub PUBLIC +target_link_libraries(udf-service-stub.global PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil yql-public-udf ) -target_sources(udf-service-stub PRIVATE +target_sources(udf-service-stub.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/service/stub/udf_service.cpp ) diff --git a/ydb/library/yql/public/udf/service/stub/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/udf/service/stub/CMakeLists.windows-x86_64.txt index dca6cc3d42b5..68cbe171d8a4 100644 --- a/ydb/library/yql/public/udf/service/stub/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/udf/service/stub/CMakeLists.windows-x86_64.txt @@ -7,15 +7,22 @@ -add_library(udf-service-stub) -target_compile_options(udf-service-stub PRIVATE +add_library(udf-service-stub INTERFACE) +target_link_libraries(udf-service-stub INTERFACE + contrib-libs-cxxsupp + yutil + yql-public-udf +) + +add_global_library_for(udf-service-stub.global udf-service-stub) +target_compile_options(udf-service-stub.global PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(udf-service-stub PUBLIC +target_link_libraries(udf-service-stub.global PUBLIC contrib-libs-cxxsupp yutil yql-public-udf ) -target_sources(udf-service-stub PRIVATE +target_sources(udf-service-stub.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/service/stub/udf_service.cpp ) diff --git a/ydb/library/yql/public/udf/service/terminate_policy/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/udf/service/terminate_policy/CMakeLists.darwin-arm64.txt index 83f4698355c6..e8e9310f775f 100644 --- a/ydb/library/yql/public/udf/service/terminate_policy/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/udf/service/terminate_policy/CMakeLists.darwin-arm64.txt @@ -7,16 +7,24 @@ -add_library(udf-service-terminate_policy) -target_compile_options(udf-service-terminate_policy PRIVATE +add_library(udf-service-terminate_policy INTERFACE) +target_link_libraries(udf-service-terminate_policy INTERFACE + contrib-libs-cxxsupp + yutil + library-yql-minikql + yql-public-udf +) + +add_global_library_for(udf-service-terminate_policy.global udf-service-terminate_policy) +target_compile_options(udf-service-terminate_policy.global PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(udf-service-terminate_policy PUBLIC +target_link_libraries(udf-service-terminate_policy.global PUBLIC contrib-libs-cxxsupp yutil library-yql-minikql yql-public-udf ) -target_sources(udf-service-terminate_policy PRIVATE +target_sources(udf-service-terminate_policy.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/service/terminate_policy/udf_service.cpp ) diff --git a/ydb/library/yql/public/udf/service/terminate_policy/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/udf/service/terminate_policy/CMakeLists.darwin-x86_64.txt index 83f4698355c6..e8e9310f775f 100644 --- a/ydb/library/yql/public/udf/service/terminate_policy/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/udf/service/terminate_policy/CMakeLists.darwin-x86_64.txt @@ -7,16 +7,24 @@ -add_library(udf-service-terminate_policy) -target_compile_options(udf-service-terminate_policy PRIVATE +add_library(udf-service-terminate_policy INTERFACE) +target_link_libraries(udf-service-terminate_policy INTERFACE + contrib-libs-cxxsupp + yutil + library-yql-minikql + yql-public-udf +) + +add_global_library_for(udf-service-terminate_policy.global udf-service-terminate_policy) +target_compile_options(udf-service-terminate_policy.global PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(udf-service-terminate_policy PUBLIC +target_link_libraries(udf-service-terminate_policy.global PUBLIC contrib-libs-cxxsupp yutil library-yql-minikql yql-public-udf ) -target_sources(udf-service-terminate_policy PRIVATE +target_sources(udf-service-terminate_policy.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/service/terminate_policy/udf_service.cpp ) diff --git a/ydb/library/yql/public/udf/service/terminate_policy/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/udf/service/terminate_policy/CMakeLists.linux-aarch64.txt index bb9ae9269713..2034704ce19c 100644 --- a/ydb/library/yql/public/udf/service/terminate_policy/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/udf/service/terminate_policy/CMakeLists.linux-aarch64.txt @@ -7,17 +7,26 @@ -add_library(udf-service-terminate_policy) -target_compile_options(udf-service-terminate_policy PRIVATE +add_library(udf-service-terminate_policy INTERFACE) +target_link_libraries(udf-service-terminate_policy INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-yql-minikql + yql-public-udf +) + +add_global_library_for(udf-service-terminate_policy.global udf-service-terminate_policy) +target_compile_options(udf-service-terminate_policy.global PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(udf-service-terminate_policy PUBLIC +target_link_libraries(udf-service-terminate_policy.global PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil library-yql-minikql yql-public-udf ) -target_sources(udf-service-terminate_policy PRIVATE +target_sources(udf-service-terminate_policy.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/service/terminate_policy/udf_service.cpp ) diff --git a/ydb/library/yql/public/udf/service/terminate_policy/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/udf/service/terminate_policy/CMakeLists.linux-x86_64.txt index bb9ae9269713..2034704ce19c 100644 --- a/ydb/library/yql/public/udf/service/terminate_policy/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/udf/service/terminate_policy/CMakeLists.linux-x86_64.txt @@ -7,17 +7,26 @@ -add_library(udf-service-terminate_policy) -target_compile_options(udf-service-terminate_policy PRIVATE +add_library(udf-service-terminate_policy INTERFACE) +target_link_libraries(udf-service-terminate_policy INTERFACE + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-yql-minikql + yql-public-udf +) + +add_global_library_for(udf-service-terminate_policy.global udf-service-terminate_policy) +target_compile_options(udf-service-terminate_policy.global PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(udf-service-terminate_policy PUBLIC +target_link_libraries(udf-service-terminate_policy.global PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil library-yql-minikql yql-public-udf ) -target_sources(udf-service-terminate_policy PRIVATE +target_sources(udf-service-terminate_policy.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/service/terminate_policy/udf_service.cpp ) diff --git a/ydb/library/yql/public/udf/service/terminate_policy/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/udf/service/terminate_policy/CMakeLists.windows-x86_64.txt index 83f4698355c6..e8e9310f775f 100644 --- a/ydb/library/yql/public/udf/service/terminate_policy/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/udf/service/terminate_policy/CMakeLists.windows-x86_64.txt @@ -7,16 +7,24 @@ -add_library(udf-service-terminate_policy) -target_compile_options(udf-service-terminate_policy PRIVATE +add_library(udf-service-terminate_policy INTERFACE) +target_link_libraries(udf-service-terminate_policy INTERFACE + contrib-libs-cxxsupp + yutil + library-yql-minikql + yql-public-udf +) + +add_global_library_for(udf-service-terminate_policy.global udf-service-terminate_policy) +target_compile_options(udf-service-terminate_policy.global PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(udf-service-terminate_policy PUBLIC +target_link_libraries(udf-service-terminate_policy.global PUBLIC contrib-libs-cxxsupp yutil library-yql-minikql yql-public-udf ) -target_sources(udf-service-terminate_policy PRIVATE +target_sources(udf-service-terminate_policy.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/service/terminate_policy/udf_service.cpp ) diff --git a/ydb/library/yql/public/udf/tz/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/udf/tz/CMakeLists.darwin-arm64.txt index 764f26f8b150..6b03da991044 100644 --- a/ydb/library/yql/public/udf/tz/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/udf/tz/CMakeLists.darwin-arm64.txt @@ -14,5 +14,6 @@ target_link_libraries(public-udf-tz PUBLIC yutil ) target_sources(public-udf-tz PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/tz/udf_tz.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/tz/udf_tz.cpp ) diff --git a/ydb/library/yql/public/udf/tz/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/udf/tz/CMakeLists.darwin-x86_64.txt index 764f26f8b150..6b03da991044 100644 --- a/ydb/library/yql/public/udf/tz/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/udf/tz/CMakeLists.darwin-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(public-udf-tz PUBLIC yutil ) target_sources(public-udf-tz PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/tz/udf_tz.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/tz/udf_tz.cpp ) diff --git a/ydb/library/yql/public/udf/tz/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/udf/tz/CMakeLists.linux-aarch64.txt index 85f78011a685..d3df14d5d59e 100644 --- a/ydb/library/yql/public/udf/tz/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/udf/tz/CMakeLists.linux-aarch64.txt @@ -15,5 +15,6 @@ target_link_libraries(public-udf-tz PUBLIC yutil ) target_sources(public-udf-tz PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/tz/udf_tz.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/tz/udf_tz.cpp ) diff --git a/ydb/library/yql/public/udf/tz/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/udf/tz/CMakeLists.linux-x86_64.txt index 85f78011a685..d3df14d5d59e 100644 --- a/ydb/library/yql/public/udf/tz/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/udf/tz/CMakeLists.linux-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(public-udf-tz PUBLIC yutil ) target_sources(public-udf-tz PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/tz/udf_tz.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/tz/udf_tz.cpp ) diff --git a/ydb/library/yql/public/udf/tz/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/udf/tz/CMakeLists.windows-x86_64.txt index 764f26f8b150..6b03da991044 100644 --- a/ydb/library/yql/public/udf/tz/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/udf/tz/CMakeLists.windows-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(public-udf-tz PUBLIC yutil ) target_sources(public-udf-tz PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/tz/udf_tz.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/tz/udf_tz.cpp ) diff --git a/ydb/library/yql/public/udf/tz/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/udf/tz/ut/CMakeLists.darwin-arm64.txt index 5008efd00001..c3087d57e4bb 100644 --- a/ydb/library/yql/public/udf/tz/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/udf/tz/ut/CMakeLists.darwin-arm64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/udf/tz/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/udf/tz/ut/CMakeLists.darwin-x86_64.txt index a26f52dd9861..5d8d8a54bb3a 100644 --- a/ydb/library/yql/public/udf/tz/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/udf/tz/ut/CMakeLists.darwin-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/udf/tz/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/udf/tz/ut/CMakeLists.linux-aarch64.txt index de01319ee970..347bc758039e 100644 --- a/ydb/library/yql/public/udf/tz/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/udf/tz/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-yql-public-udf-tz-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-public-udf-tz-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/tz/udf_tz_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/udf/tz/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/udf/tz/ut/CMakeLists.linux-x86_64.txt index d7f98a2a6c23..46c8d6d3761a 100644 --- a/ydb/library/yql/public/udf/tz/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/udf/tz/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-yql-public-udf-tz-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-public-udf-tz-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/tz/udf_tz_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/udf/tz/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/udf/tz/ut/CMakeLists.windows-x86_64.txt index fa8472deae75..9b70f9b63145 100644 --- a/ydb/library/yql/public/udf/tz/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/udf/tz/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/udf/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/public/udf/ut/CMakeLists.darwin-arm64.txt index 29683f107691..5be8e033417d 100644 --- a/ydb/library/yql/public/udf/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/public/udf/ut/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-library-yql-public-udf-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-public-udf-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_counter_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/udf/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/public/udf/ut/CMakeLists.darwin-x86_64.txt index ee73b96b6022..fad56e22856f 100644 --- a/ydb/library/yql/public/udf/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/public/udf/ut/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-library-yql-public-udf-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-public-udf-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_counter_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/udf/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/public/udf/ut/CMakeLists.linux-aarch64.txt index 635c2a5e757e..83073ea16a48 100644 --- a/ydb/library/yql/public/udf/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/public/udf/ut/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-library-yql-public-udf-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-public-udf-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_counter_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/udf/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/public/udf/ut/CMakeLists.linux-x86_64.txt index 77be018e0215..e8e7b16c3c0e 100644 --- a/ydb/library/yql/public/udf/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/public/udf/ut/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-library-yql-public-udf-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-public-udf-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udf_counter_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/public/udf/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/public/udf/ut/CMakeLists.windows-x86_64.txt index 23cf79558120..2ea653195f9f 100644 --- a/ydb/library/yql/public/udf/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/public/udf/ut/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/sql/pg/CMakeLists.darwin-arm64.txt b/ydb/library/yql/sql/pg/CMakeLists.darwin-arm64.txt index 709a61367801..c2a030de50f2 100644 --- a/ydb/library/yql/sql/pg/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/sql/pg/CMakeLists.darwin-arm64.txt @@ -13,7 +13,6 @@ target_compile_options(yql-sql-pg PRIVATE -Dpalloc0=yql_palloc0 -Dpfree=yql_pfree -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> ) target_include_directories(yql-sql-pg PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/include diff --git a/ydb/library/yql/sql/pg/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/sql/pg/CMakeLists.darwin-x86_64.txt index 709a61367801..c2a030de50f2 100644 --- a/ydb/library/yql/sql/pg/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/sql/pg/CMakeLists.darwin-x86_64.txt @@ -13,7 +13,6 @@ target_compile_options(yql-sql-pg PRIVATE -Dpalloc0=yql_palloc0 -Dpfree=yql_pfree -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> ) target_include_directories(yql-sql-pg PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/include diff --git a/ydb/library/yql/sql/pg/CMakeLists.linux-aarch64.txt b/ydb/library/yql/sql/pg/CMakeLists.linux-aarch64.txt index a158724b0f62..72f5cd10eda6 100644 --- a/ydb/library/yql/sql/pg/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/sql/pg/CMakeLists.linux-aarch64.txt @@ -13,7 +13,6 @@ target_compile_options(yql-sql-pg PRIVATE -Dpalloc0=yql_palloc0 -Dpfree=yql_pfree -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> ) target_include_directories(yql-sql-pg PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/include diff --git a/ydb/library/yql/sql/pg/CMakeLists.linux-x86_64.txt b/ydb/library/yql/sql/pg/CMakeLists.linux-x86_64.txt index a158724b0f62..72f5cd10eda6 100644 --- a/ydb/library/yql/sql/pg/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/sql/pg/CMakeLists.linux-x86_64.txt @@ -13,7 +13,6 @@ target_compile_options(yql-sql-pg PRIVATE -Dpalloc0=yql_palloc0 -Dpfree=yql_pfree -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> ) target_include_directories(yql-sql-pg PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/include diff --git a/ydb/library/yql/sql/pg/CMakeLists.windows-x86_64.txt b/ydb/library/yql/sql/pg/CMakeLists.windows-x86_64.txt index 25a4744632c3..97618be93e6b 100644 --- a/ydb/library/yql/sql/pg/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/sql/pg/CMakeLists.windows-x86_64.txt @@ -16,7 +16,6 @@ target_compile_options(yql-sql-pg PRIVATE -Dfstat=microsoft_native_fstat -Dstat=microsoft_native_stat -DUSE_CURRENT_UDF_ABI_VERSION - $,,-Wno-everything> ) target_include_directories(yql-sql-pg PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/include diff --git a/ydb/library/yql/sql/pg/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/sql/pg/ut/CMakeLists.darwin-arm64.txt index 56205d86ef37..42b46372a651 100644 --- a/ydb/library/yql/sql/pg/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/sql/pg/ut/CMakeLists.darwin-arm64.txt @@ -8,9 +8,6 @@ add_executable(ydb-library-yql-sql-pg-ut) -target_compile_options(ydb-library-yql-sql-pg-ut PRIVATE - $,,-Wno-everything> -) target_include_directories(ydb-library-yql-sql-pg-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/pg ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/include @@ -29,8 +26,6 @@ target_link_options(ydb-library-yql-sql-pg-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-sql-pg-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/pg/pg_sql_ut.cpp @@ -63,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/sql/pg/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/sql/pg/ut/CMakeLists.darwin-x86_64.txt index a0996ad8f0dc..570919556626 100644 --- a/ydb/library/yql/sql/pg/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/sql/pg/ut/CMakeLists.darwin-x86_64.txt @@ -8,9 +8,6 @@ add_executable(ydb-library-yql-sql-pg-ut) -target_compile_options(ydb-library-yql-sql-pg-ut PRIVATE - $,,-Wno-everything> -) target_include_directories(ydb-library-yql-sql-pg-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/pg ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/include @@ -30,8 +27,6 @@ target_link_options(ydb-library-yql-sql-pg-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-sql-pg-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/pg/pg_sql_ut.cpp @@ -64,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/sql/pg/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/sql/pg/ut/CMakeLists.linux-aarch64.txt index 578b34964149..31be5b6ca5ba 100644 --- a/ydb/library/yql/sql/pg/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/sql/pg/ut/CMakeLists.linux-aarch64.txt @@ -8,9 +8,6 @@ add_executable(ydb-library-yql-sql-pg-ut) -target_compile_options(ydb-library-yql-sql-pg-ut PRIVATE - $,,-Wno-everything> -) target_include_directories(ydb-library-yql-sql-pg-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/pg ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/include @@ -32,9 +29,6 @@ target_link_options(ydb-library-yql-sql-pg-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-sql-pg-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/pg/pg_sql_ut.cpp @@ -67,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/sql/pg/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/sql/pg/ut/CMakeLists.linux-x86_64.txt index 98c6e63806a1..d27db26fe267 100644 --- a/ydb/library/yql/sql/pg/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/sql/pg/ut/CMakeLists.linux-x86_64.txt @@ -8,9 +8,6 @@ add_executable(ydb-library-yql-sql-pg-ut) -target_compile_options(ydb-library-yql-sql-pg-ut PRIVATE - $,,-Wno-everything> -) target_include_directories(ydb-library-yql-sql-pg-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/pg ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/include @@ -33,9 +30,6 @@ target_link_options(ydb-library-yql-sql-pg-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-sql-pg-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/pg/pg_sql_ut.cpp @@ -68,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/sql/pg/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/sql/pg/ut/CMakeLists.windows-x86_64.txt index 1f3abeea56af..55b44b70e884 100644 --- a/ydb/library/yql/sql/pg/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/sql/pg/ut/CMakeLists.windows-x86_64.txt @@ -8,9 +8,6 @@ add_executable(ydb-library-yql-sql-pg-ut) -target_compile_options(ydb-library-yql-sql-pg-ut PRIVATE - $,,-Wno-everything> -) target_include_directories(ydb-library-yql-sql-pg-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/pg ${CMAKE_SOURCE_DIR}/ydb/library/yql/parser/pg_wrapper/postgresql/src/include @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/sql/settings/CMakeLists.darwin-arm64.txt b/ydb/library/yql/sql/settings/CMakeLists.darwin-arm64.txt index ccb58a596bd4..4849acab3c9a 100644 --- a/ydb/library/yql/sql/settings/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/sql/settings/CMakeLists.darwin-arm64.txt @@ -14,6 +14,7 @@ target_link_libraries(yql-sql-settings PUBLIC cpp-deprecated-split library-cpp-json yql-core-issue + yql-core-pg_settings core-issue-protos library-yql-utils ) diff --git a/ydb/library/yql/sql/settings/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/sql/settings/CMakeLists.darwin-x86_64.txt index ccb58a596bd4..4849acab3c9a 100644 --- a/ydb/library/yql/sql/settings/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/sql/settings/CMakeLists.darwin-x86_64.txt @@ -14,6 +14,7 @@ target_link_libraries(yql-sql-settings PUBLIC cpp-deprecated-split library-cpp-json yql-core-issue + yql-core-pg_settings core-issue-protos library-yql-utils ) diff --git a/ydb/library/yql/sql/settings/CMakeLists.linux-aarch64.txt b/ydb/library/yql/sql/settings/CMakeLists.linux-aarch64.txt index 115422bd4a62..ee788e907fd4 100644 --- a/ydb/library/yql/sql/settings/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/sql/settings/CMakeLists.linux-aarch64.txt @@ -15,6 +15,7 @@ target_link_libraries(yql-sql-settings PUBLIC cpp-deprecated-split library-cpp-json yql-core-issue + yql-core-pg_settings core-issue-protos library-yql-utils ) diff --git a/ydb/library/yql/sql/settings/CMakeLists.linux-x86_64.txt b/ydb/library/yql/sql/settings/CMakeLists.linux-x86_64.txt index 115422bd4a62..ee788e907fd4 100644 --- a/ydb/library/yql/sql/settings/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/sql/settings/CMakeLists.linux-x86_64.txt @@ -15,6 +15,7 @@ target_link_libraries(yql-sql-settings PUBLIC cpp-deprecated-split library-cpp-json yql-core-issue + yql-core-pg_settings core-issue-protos library-yql-utils ) diff --git a/ydb/library/yql/sql/settings/CMakeLists.windows-x86_64.txt b/ydb/library/yql/sql/settings/CMakeLists.windows-x86_64.txt index ccb58a596bd4..4849acab3c9a 100644 --- a/ydb/library/yql/sql/settings/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/sql/settings/CMakeLists.windows-x86_64.txt @@ -14,6 +14,7 @@ target_link_libraries(yql-sql-settings PUBLIC cpp-deprecated-split library-cpp-json yql-core-issue + yql-core-pg_settings core-issue-protos library-yql-utils ) diff --git a/ydb/library/yql/sql/v0/CMakeLists.darwin-arm64.txt b/ydb/library/yql/sql/v0/CMakeLists.darwin-arm64.txt index 3a805a5ebcab..1a6afee835e3 100644 --- a/ydb/library/yql/sql/v0/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/sql/v0/CMakeLists.darwin-arm64.txt @@ -33,6 +33,7 @@ target_link_libraries(yql-sql-v0 PUBLIC yql-parser-proto_ast parser-proto_ast-collect_issues proto_ast-gen-v0 + proto_ast-gen-v0_proto_split tools-enum_parser-enum_serialization_runtime ) target_sources(yql-sql-v0 PRIVATE diff --git a/ydb/library/yql/sql/v0/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/sql/v0/CMakeLists.darwin-x86_64.txt index 3a805a5ebcab..1a6afee835e3 100644 --- a/ydb/library/yql/sql/v0/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/sql/v0/CMakeLists.darwin-x86_64.txt @@ -33,6 +33,7 @@ target_link_libraries(yql-sql-v0 PUBLIC yql-parser-proto_ast parser-proto_ast-collect_issues proto_ast-gen-v0 + proto_ast-gen-v0_proto_split tools-enum_parser-enum_serialization_runtime ) target_sources(yql-sql-v0 PRIVATE diff --git a/ydb/library/yql/sql/v0/CMakeLists.linux-aarch64.txt b/ydb/library/yql/sql/v0/CMakeLists.linux-aarch64.txt index 52c5ad75fc23..4055fd632990 100644 --- a/ydb/library/yql/sql/v0/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/sql/v0/CMakeLists.linux-aarch64.txt @@ -34,6 +34,7 @@ target_link_libraries(yql-sql-v0 PUBLIC yql-parser-proto_ast parser-proto_ast-collect_issues proto_ast-gen-v0 + proto_ast-gen-v0_proto_split tools-enum_parser-enum_serialization_runtime ) target_sources(yql-sql-v0 PRIVATE diff --git a/ydb/library/yql/sql/v0/CMakeLists.linux-x86_64.txt b/ydb/library/yql/sql/v0/CMakeLists.linux-x86_64.txt index 52c5ad75fc23..4055fd632990 100644 --- a/ydb/library/yql/sql/v0/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/sql/v0/CMakeLists.linux-x86_64.txt @@ -34,6 +34,7 @@ target_link_libraries(yql-sql-v0 PUBLIC yql-parser-proto_ast parser-proto_ast-collect_issues proto_ast-gen-v0 + proto_ast-gen-v0_proto_split tools-enum_parser-enum_serialization_runtime ) target_sources(yql-sql-v0 PRIVATE diff --git a/ydb/library/yql/sql/v0/CMakeLists.windows-x86_64.txt b/ydb/library/yql/sql/v0/CMakeLists.windows-x86_64.txt index 3a805a5ebcab..1a6afee835e3 100644 --- a/ydb/library/yql/sql/v0/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/sql/v0/CMakeLists.windows-x86_64.txt @@ -33,6 +33,7 @@ target_link_libraries(yql-sql-v0 PUBLIC yql-parser-proto_ast parser-proto_ast-collect_issues proto_ast-gen-v0 + proto_ast-gen-v0_proto_split tools-enum_parser-enum_serialization_runtime ) target_sources(yql-sql-v0 PRIVATE diff --git a/ydb/library/yql/sql/v0/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/sql/v0/ut/CMakeLists.darwin-arm64.txt index 8f0f52496952..7efc62b43bfe 100644 --- a/ydb/library/yql/sql/v0/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/sql/v0/ut/CMakeLists.darwin-arm64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-library-yql-sql-v0-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-sql-v0-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/sql_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/sql/v0/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/sql/v0/ut/CMakeLists.darwin-x86_64.txt index dab39fc9adbe..710c6f271250 100644 --- a/ydb/library/yql/sql/v0/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/sql/v0/ut/CMakeLists.darwin-x86_64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-library-yql-sql-v0-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-sql-v0-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/sql_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/sql/v0/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/sql/v0/ut/CMakeLists.linux-aarch64.txt index 69099ea12003..1a5a296bbaa4 100644 --- a/ydb/library/yql/sql/v0/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/sql/v0/ut/CMakeLists.linux-aarch64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-library-yql-sql-v0-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-sql-v0-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/sql_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/sql/v0/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/sql/v0/ut/CMakeLists.linux-x86_64.txt index d39e61187c32..1c418366ef77 100644 --- a/ydb/library/yql/sql/v0/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/sql/v0/ut/CMakeLists.linux-x86_64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-library-yql-sql-v0-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-sql-v0-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v0/sql_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/sql/v0/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/sql/v0/ut/CMakeLists.windows-x86_64.txt index e8b26a38f798..fd3a9e5ccba0 100644 --- a/ydb/library/yql/sql/v0/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/sql/v0/ut/CMakeLists.windows-x86_64.txt @@ -49,6 +49,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/sql/v1/CMakeLists.darwin-arm64.txt b/ydb/library/yql/sql/v1/CMakeLists.darwin-arm64.txt index 6e0ae494e7da..b34e759b4cc7 100644 --- a/ydb/library/yql/sql/v1/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/sql/v1/CMakeLists.darwin-arm64.txt @@ -53,7 +53,7 @@ target_link_libraries(yql-sql-v1 PUBLIC parser-proto_ast-collect_issues proto_ast-gen-v1 proto_ast-gen-v1_ansi - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split yql-parser-pg_catalog sql-v1-lexer sql-v1-proto_parser diff --git a/ydb/library/yql/sql/v1/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/sql/v1/CMakeLists.darwin-x86_64.txt index 6e0ae494e7da..b34e759b4cc7 100644 --- a/ydb/library/yql/sql/v1/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/sql/v1/CMakeLists.darwin-x86_64.txt @@ -53,7 +53,7 @@ target_link_libraries(yql-sql-v1 PUBLIC parser-proto_ast-collect_issues proto_ast-gen-v1 proto_ast-gen-v1_ansi - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split yql-parser-pg_catalog sql-v1-lexer sql-v1-proto_parser diff --git a/ydb/library/yql/sql/v1/CMakeLists.linux-aarch64.txt b/ydb/library/yql/sql/v1/CMakeLists.linux-aarch64.txt index 17cb39be0ffa..7deea879f42a 100644 --- a/ydb/library/yql/sql/v1/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/sql/v1/CMakeLists.linux-aarch64.txt @@ -54,7 +54,7 @@ target_link_libraries(yql-sql-v1 PUBLIC parser-proto_ast-collect_issues proto_ast-gen-v1 proto_ast-gen-v1_ansi - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split yql-parser-pg_catalog sql-v1-lexer sql-v1-proto_parser diff --git a/ydb/library/yql/sql/v1/CMakeLists.linux-x86_64.txt b/ydb/library/yql/sql/v1/CMakeLists.linux-x86_64.txt index 17cb39be0ffa..7deea879f42a 100644 --- a/ydb/library/yql/sql/v1/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/sql/v1/CMakeLists.linux-x86_64.txt @@ -54,7 +54,7 @@ target_link_libraries(yql-sql-v1 PUBLIC parser-proto_ast-collect_issues proto_ast-gen-v1 proto_ast-gen-v1_ansi - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split yql-parser-pg_catalog sql-v1-lexer sql-v1-proto_parser diff --git a/ydb/library/yql/sql/v1/CMakeLists.windows-x86_64.txt b/ydb/library/yql/sql/v1/CMakeLists.windows-x86_64.txt index 6e0ae494e7da..b34e759b4cc7 100644 --- a/ydb/library/yql/sql/v1/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/sql/v1/CMakeLists.windows-x86_64.txt @@ -53,7 +53,7 @@ target_link_libraries(yql-sql-v1 PUBLIC parser-proto_ast-collect_issues proto_ast-gen-v1 proto_ast-gen-v1_ansi - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split yql-parser-pg_catalog sql-v1-lexer sql-v1-proto_parser diff --git a/ydb/library/yql/sql/v1/format/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/sql/v1/format/ut/CMakeLists.darwin-arm64.txt index 43eaa810dbe6..ad98664c073c 100644 --- a/ydb/library/yql/sql/v1/format/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/sql/v1/format/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-library-yql-sql-v1-format-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-sql-v1-format-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/format/sql_format_ut.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/sql/v1/format/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/sql/v1/format/ut/CMakeLists.darwin-x86_64.txt index 4a924acf8715..c9ad2b0d5d5b 100644 --- a/ydb/library/yql/sql/v1/format/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/sql/v1/format/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-library-yql-sql-v1-format-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-sql-v1-format-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/format/sql_format_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/sql/v1/format/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/sql/v1/format/ut/CMakeLists.linux-aarch64.txt index 9b78b99e8c03..4388eff41504 100644 --- a/ydb/library/yql/sql/v1/format/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/sql/v1/format/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-yql-sql-v1-format-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-sql-v1-format-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/format/sql_format_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/sql/v1/format/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/sql/v1/format/ut/CMakeLists.linux-x86_64.txt index d8fed6326eb6..aacebe32c49a 100644 --- a/ydb/library/yql/sql/v1/format/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/sql/v1/format/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-yql-sql-v1-format-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-sql-v1-format-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/format/sql_format_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/sql/v1/format/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/sql/v1/format/ut/CMakeLists.windows-x86_64.txt index c130d8785051..8875b096ca19 100644 --- a/ydb/library/yql/sql/v1/format/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/sql/v1/format/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/sql/v1/lexer/CMakeLists.darwin-arm64.txt b/ydb/library/yql/sql/v1/lexer/CMakeLists.darwin-arm64.txt index 39f7d128eee3..798e95e2c919 100644 --- a/ydb/library/yql/sql/v1/lexer/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/sql/v1/lexer/CMakeLists.darwin-arm64.txt @@ -15,7 +15,7 @@ target_link_libraries(sql-v1-lexer PUBLIC yql-parser-proto_ast proto_ast-gen-v1 proto_ast-gen-v1_ansi - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split ) target_sources(sql-v1-lexer PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/lexer/lexer.cpp diff --git a/ydb/library/yql/sql/v1/lexer/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/sql/v1/lexer/CMakeLists.darwin-x86_64.txt index 39f7d128eee3..798e95e2c919 100644 --- a/ydb/library/yql/sql/v1/lexer/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/sql/v1/lexer/CMakeLists.darwin-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(sql-v1-lexer PUBLIC yql-parser-proto_ast proto_ast-gen-v1 proto_ast-gen-v1_ansi - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split ) target_sources(sql-v1-lexer PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/lexer/lexer.cpp diff --git a/ydb/library/yql/sql/v1/lexer/CMakeLists.linux-aarch64.txt b/ydb/library/yql/sql/v1/lexer/CMakeLists.linux-aarch64.txt index 88b5433a1ff2..9f096e47ee52 100644 --- a/ydb/library/yql/sql/v1/lexer/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/sql/v1/lexer/CMakeLists.linux-aarch64.txt @@ -16,7 +16,7 @@ target_link_libraries(sql-v1-lexer PUBLIC yql-parser-proto_ast proto_ast-gen-v1 proto_ast-gen-v1_ansi - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split ) target_sources(sql-v1-lexer PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/lexer/lexer.cpp diff --git a/ydb/library/yql/sql/v1/lexer/CMakeLists.linux-x86_64.txt b/ydb/library/yql/sql/v1/lexer/CMakeLists.linux-x86_64.txt index 88b5433a1ff2..9f096e47ee52 100644 --- a/ydb/library/yql/sql/v1/lexer/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/sql/v1/lexer/CMakeLists.linux-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(sql-v1-lexer PUBLIC yql-parser-proto_ast proto_ast-gen-v1 proto_ast-gen-v1_ansi - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split ) target_sources(sql-v1-lexer PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/lexer/lexer.cpp diff --git a/ydb/library/yql/sql/v1/lexer/CMakeLists.windows-x86_64.txt b/ydb/library/yql/sql/v1/lexer/CMakeLists.windows-x86_64.txt index 39f7d128eee3..798e95e2c919 100644 --- a/ydb/library/yql/sql/v1/lexer/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/sql/v1/lexer/CMakeLists.windows-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(sql-v1-lexer PUBLIC yql-parser-proto_ast proto_ast-gen-v1 proto_ast-gen-v1_ansi - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split ) target_sources(sql-v1-lexer PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/lexer/lexer.cpp diff --git a/ydb/library/yql/sql/v1/perf/CMakeLists.darwin-arm64.txt b/ydb/library/yql/sql/v1/perf/CMakeLists.darwin-arm64.txt index c6361ac99be9..17f398c7776a 100644 --- a/ydb/library/yql/sql/v1/perf/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/sql/v1/perf/CMakeLists.darwin-arm64.txt @@ -20,8 +20,6 @@ target_link_options(perf PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(perf PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/perf/parse.cpp diff --git a/ydb/library/yql/sql/v1/perf/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/sql/v1/perf/CMakeLists.darwin-x86_64.txt index 72d47a87fddf..68fca80fafd6 100644 --- a/ydb/library/yql/sql/v1/perf/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/sql/v1/perf/CMakeLists.darwin-x86_64.txt @@ -21,8 +21,6 @@ target_link_options(perf PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(perf PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/perf/parse.cpp diff --git a/ydb/library/yql/sql/v1/perf/CMakeLists.linux-aarch64.txt b/ydb/library/yql/sql/v1/perf/CMakeLists.linux-aarch64.txt index 281da18021b5..ad17479a2f2a 100644 --- a/ydb/library/yql/sql/v1/perf/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/sql/v1/perf/CMakeLists.linux-aarch64.txt @@ -23,9 +23,6 @@ target_link_options(perf PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(perf PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/perf/parse.cpp diff --git a/ydb/library/yql/sql/v1/perf/CMakeLists.linux-x86_64.txt b/ydb/library/yql/sql/v1/perf/CMakeLists.linux-x86_64.txt index c7a3a02791e0..377df23e84ad 100644 --- a/ydb/library/yql/sql/v1/perf/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/sql/v1/perf/CMakeLists.linux-x86_64.txt @@ -24,9 +24,6 @@ target_link_options(perf PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(perf PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/perf/parse.cpp diff --git a/ydb/library/yql/sql/v1/proto_parser/CMakeLists.darwin-arm64.txt b/ydb/library/yql/sql/v1/proto_parser/CMakeLists.darwin-arm64.txt index 349b52115a91..5534498f55b1 100644 --- a/ydb/library/yql/sql/v1/proto_parser/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/sql/v1/proto_parser/CMakeLists.darwin-arm64.txt @@ -16,7 +16,7 @@ target_link_libraries(sql-v1-proto_parser PUBLIC parser-proto_ast-collect_issues proto_ast-gen-v1 proto_ast-gen-v1_ansi - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split ) target_sources(sql-v1-proto_parser PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/proto_parser/proto_parser.cpp diff --git a/ydb/library/yql/sql/v1/proto_parser/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/sql/v1/proto_parser/CMakeLists.darwin-x86_64.txt index 349b52115a91..5534498f55b1 100644 --- a/ydb/library/yql/sql/v1/proto_parser/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/sql/v1/proto_parser/CMakeLists.darwin-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(sql-v1-proto_parser PUBLIC parser-proto_ast-collect_issues proto_ast-gen-v1 proto_ast-gen-v1_ansi - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split ) target_sources(sql-v1-proto_parser PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/proto_parser/proto_parser.cpp diff --git a/ydb/library/yql/sql/v1/proto_parser/CMakeLists.linux-aarch64.txt b/ydb/library/yql/sql/v1/proto_parser/CMakeLists.linux-aarch64.txt index 6148a1c88e61..c3c979474e7c 100644 --- a/ydb/library/yql/sql/v1/proto_parser/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/sql/v1/proto_parser/CMakeLists.linux-aarch64.txt @@ -17,7 +17,7 @@ target_link_libraries(sql-v1-proto_parser PUBLIC parser-proto_ast-collect_issues proto_ast-gen-v1 proto_ast-gen-v1_ansi - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split ) target_sources(sql-v1-proto_parser PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/proto_parser/proto_parser.cpp diff --git a/ydb/library/yql/sql/v1/proto_parser/CMakeLists.linux-x86_64.txt b/ydb/library/yql/sql/v1/proto_parser/CMakeLists.linux-x86_64.txt index 6148a1c88e61..c3c979474e7c 100644 --- a/ydb/library/yql/sql/v1/proto_parser/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/sql/v1/proto_parser/CMakeLists.linux-x86_64.txt @@ -17,7 +17,7 @@ target_link_libraries(sql-v1-proto_parser PUBLIC parser-proto_ast-collect_issues proto_ast-gen-v1 proto_ast-gen-v1_ansi - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split ) target_sources(sql-v1-proto_parser PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/proto_parser/proto_parser.cpp diff --git a/ydb/library/yql/sql/v1/proto_parser/CMakeLists.windows-x86_64.txt b/ydb/library/yql/sql/v1/proto_parser/CMakeLists.windows-x86_64.txt index 349b52115a91..5534498f55b1 100644 --- a/ydb/library/yql/sql/v1/proto_parser/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/sql/v1/proto_parser/CMakeLists.windows-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(sql-v1-proto_parser PUBLIC parser-proto_ast-collect_issues proto_ast-gen-v1 proto_ast-gen-v1_ansi - proto_ast-gen-v1_proto + proto_ast-gen-v1_proto_split ) target_sources(sql-v1-proto_parser PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/proto_parser/proto_parser.cpp diff --git a/ydb/library/yql/sql/v1/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/sql/v1/ut/CMakeLists.darwin-arm64.txt index c39cfa618d89..ab783c02c5d9 100644 --- a/ydb/library/yql/sql/v1/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/sql/v1/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-library-yql-sql-v1-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-sql-v1-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/sql_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/sql/v1/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/sql/v1/ut/CMakeLists.darwin-x86_64.txt index 80dcef14ef01..5abc52106065 100644 --- a/ydb/library/yql/sql/v1/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/sql/v1/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-library-yql-sql-v1-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-sql-v1-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/sql_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/sql/v1/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/sql/v1/ut/CMakeLists.linux-aarch64.txt index 54041a090268..e99f2745ff2f 100644 --- a/ydb/library/yql/sql/v1/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/sql/v1/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-library-yql-sql-v1-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-sql-v1-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/sql_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/sql/v1/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/sql/v1/ut/CMakeLists.linux-x86_64.txt index 0cda4c5e185c..5e0666c78ac1 100644 --- a/ydb/library/yql/sql/v1/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/sql/v1/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-library-yql-sql-v1-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-sql-v1-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/sql/v1/sql_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/sql/v1/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/sql/v1/ut/CMakeLists.windows-x86_64.txt index 0e8469627aff..322df610ed49 100644 --- a/ydb/library/yql/sql/v1/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/sql/v1/ut/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/tools/CMakeLists.txt b/ydb/library/yql/tools/CMakeLists.txt index b662ca88934b..65879f169d0a 100644 --- a/ydb/library/yql/tools/CMakeLists.txt +++ b/ydb/library/yql/tools/CMakeLists.txt @@ -10,6 +10,7 @@ add_subdirectory(astdiff) add_subdirectory(dq) add_subdirectory(dqrun) add_subdirectory(mrjob) +add_subdirectory(mrrun) add_subdirectory(pgrun) add_subdirectory(sql2yql) add_subdirectory(sql_formatter) diff --git a/ydb/library/yql/tools/astdiff/CMakeLists.darwin-arm64.txt b/ydb/library/yql/tools/astdiff/CMakeLists.darwin-arm64.txt index 87c04a039c5f..673e6c2a1ca6 100644 --- a/ydb/library/yql/tools/astdiff/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/tools/astdiff/CMakeLists.darwin-arm64.txt @@ -20,8 +20,6 @@ target_link_options(astdiff PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(astdiff PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/astdiff/astdiff.cpp diff --git a/ydb/library/yql/tools/astdiff/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/tools/astdiff/CMakeLists.darwin-x86_64.txt index 0b4989a63216..1942beff69a2 100644 --- a/ydb/library/yql/tools/astdiff/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/tools/astdiff/CMakeLists.darwin-x86_64.txt @@ -21,8 +21,6 @@ target_link_options(astdiff PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(astdiff PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/astdiff/astdiff.cpp diff --git a/ydb/library/yql/tools/astdiff/CMakeLists.linux-aarch64.txt b/ydb/library/yql/tools/astdiff/CMakeLists.linux-aarch64.txt index bda84f3b09bc..98acdbbd72b4 100644 --- a/ydb/library/yql/tools/astdiff/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/tools/astdiff/CMakeLists.linux-aarch64.txt @@ -23,9 +23,6 @@ target_link_options(astdiff PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(astdiff PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/astdiff/astdiff.cpp diff --git a/ydb/library/yql/tools/astdiff/CMakeLists.linux-x86_64.txt b/ydb/library/yql/tools/astdiff/CMakeLists.linux-x86_64.txt index a49bc32e7208..c1adc83a84a1 100644 --- a/ydb/library/yql/tools/astdiff/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/tools/astdiff/CMakeLists.linux-x86_64.txt @@ -24,9 +24,6 @@ target_link_options(astdiff PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(astdiff PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/astdiff/astdiff.cpp diff --git a/ydb/library/yql/tools/dq/dq_cli/CMakeLists.darwin-arm64.txt b/ydb/library/yql/tools/dq/dq_cli/CMakeLists.darwin-arm64.txt index 04600c637afc..ae50379f4e2c 100644 --- a/ydb/library/yql/tools/dq/dq_cli/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/tools/dq/dq_cli/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(dq_cli PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(dq_cli PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/dq/dq_cli/main.cpp diff --git a/ydb/library/yql/tools/dq/dq_cli/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/tools/dq/dq_cli/CMakeLists.darwin-x86_64.txt index 929258583e1f..d398037ddcb4 100644 --- a/ydb/library/yql/tools/dq/dq_cli/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/tools/dq/dq_cli/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(dq_cli PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(dq_cli PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/dq/dq_cli/main.cpp diff --git a/ydb/library/yql/tools/dq/dq_cli/CMakeLists.linux-aarch64.txt b/ydb/library/yql/tools/dq/dq_cli/CMakeLists.linux-aarch64.txt index f0fd5e85845f..e45536ceda4f 100644 --- a/ydb/library/yql/tools/dq/dq_cli/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/tools/dq/dq_cli/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(dq_cli PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(dq_cli PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/dq/dq_cli/main.cpp diff --git a/ydb/library/yql/tools/dq/dq_cli/CMakeLists.linux-x86_64.txt b/ydb/library/yql/tools/dq/dq_cli/CMakeLists.linux-x86_64.txt index f3a18da1b39b..d8df104d02bf 100644 --- a/ydb/library/yql/tools/dq/dq_cli/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/tools/dq/dq_cli/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(dq_cli PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(dq_cli PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/dq/dq_cli/main.cpp diff --git a/ydb/library/yql/tools/dq/service_node/CMakeLists.darwin-arm64.txt b/ydb/library/yql/tools/dq/service_node/CMakeLists.darwin-arm64.txt index 5e131c34f9f8..62d7085d86fc 100644 --- a/ydb/library/yql/tools/dq/service_node/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/tools/dq/service_node/CMakeLists.darwin-arm64.txt @@ -24,7 +24,7 @@ target_link_libraries(service_node PUBLIC utils-log-proto providers-dq-provider dq-worker_manager-interface - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 yql-utils-backtrace providers-dq-service providers-dq-metrics @@ -32,14 +32,14 @@ target_link_libraries(service_node PUBLIC providers-yt-dq_task_preprocessor providers-dq-global_worker_manager dq-actors-yt + yt-comp_nodes-llvm14 + yt-codec-codegen yt-yt-client ) target_link_options(service_node PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(service_node PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/dq/service_node/main.cpp diff --git a/ydb/library/yql/tools/dq/service_node/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/tools/dq/service_node/CMakeLists.darwin-x86_64.txt index a9eb732340be..e55694ea0cc2 100644 --- a/ydb/library/yql/tools/dq/service_node/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/tools/dq/service_node/CMakeLists.darwin-x86_64.txt @@ -25,7 +25,7 @@ target_link_libraries(service_node PUBLIC utils-log-proto providers-dq-provider dq-worker_manager-interface - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 yql-utils-backtrace providers-dq-service providers-dq-metrics @@ -33,14 +33,14 @@ target_link_libraries(service_node PUBLIC providers-yt-dq_task_preprocessor providers-dq-global_worker_manager dq-actors-yt + yt-comp_nodes-llvm14 + yt-codec-codegen yt-yt-client ) target_link_options(service_node PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(service_node PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/dq/service_node/main.cpp diff --git a/ydb/library/yql/tools/dq/service_node/CMakeLists.linux-aarch64.txt b/ydb/library/yql/tools/dq/service_node/CMakeLists.linux-aarch64.txt index 822001577e01..d90a45f3ee02 100644 --- a/ydb/library/yql/tools/dq/service_node/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/tools/dq/service_node/CMakeLists.linux-aarch64.txt @@ -25,7 +25,7 @@ target_link_libraries(service_node PUBLIC utils-log-proto providers-dq-provider dq-worker_manager-interface - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 yql-utils-backtrace providers-dq-service providers-dq-metrics @@ -33,6 +33,8 @@ target_link_libraries(service_node PUBLIC providers-yt-dq_task_preprocessor providers-dq-global_worker_manager dq-actors-yt + yt-comp_nodes-llvm14 + yt-codec-codegen yt-yt-client ) target_link_options(service_node PRIVATE @@ -41,10 +43,6 @@ target_link_options(service_node PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(service_node PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/dq/service_node/main.cpp diff --git a/ydb/library/yql/tools/dq/service_node/CMakeLists.linux-x86_64.txt b/ydb/library/yql/tools/dq/service_node/CMakeLists.linux-x86_64.txt index 673a21b27885..1e453f56a83b 100644 --- a/ydb/library/yql/tools/dq/service_node/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/tools/dq/service_node/CMakeLists.linux-x86_64.txt @@ -26,7 +26,7 @@ target_link_libraries(service_node PUBLIC utils-log-proto providers-dq-provider dq-worker_manager-interface - minikql-invoke_builtins-llvm + minikql-invoke_builtins-llvm14 yql-utils-backtrace providers-dq-service providers-dq-metrics @@ -34,6 +34,8 @@ target_link_libraries(service_node PUBLIC providers-yt-dq_task_preprocessor providers-dq-global_worker_manager dq-actors-yt + yt-comp_nodes-llvm14 + yt-codec-codegen yt-yt-client ) target_link_options(service_node PRIVATE @@ -42,10 +44,6 @@ target_link_options(service_node PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(service_node PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/dq/service_node/main.cpp diff --git a/ydb/library/yql/tools/dq/worker_node/CMakeLists.darwin-arm64.txt b/ydb/library/yql/tools/dq/worker_node/CMakeLists.darwin-arm64.txt index 355cc365ec95..d907669f2694 100644 --- a/ydb/library/yql/tools/dq/worker_node/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/tools/dq/worker_node/CMakeLists.darwin-arm64.txt @@ -22,7 +22,7 @@ target_link_libraries(worker_node PUBLIC yql-dq-comp_nodes dq-integration-transform yql-dq-transform - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 providers-clickhouse-actors providers-common-comp_nodes providers-dq-runtime @@ -42,6 +42,8 @@ target_link_libraries(worker_node PUBLIC yql-utils-failure_injector yql-utils-backtrace yt-comp_nodes-dq + yt-comp_nodes-llvm14 + yt-codec-codegen providers-yt-mkql_dq dq-actors-yt providers-dq-global_worker_manager @@ -52,8 +54,6 @@ target_link_options(worker_node PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(worker_node PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/dq/worker_node/main.cpp diff --git a/ydb/library/yql/tools/dq/worker_node/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/tools/dq/worker_node/CMakeLists.darwin-x86_64.txt index 31b7fb97c136..9fafd3037430 100644 --- a/ydb/library/yql/tools/dq/worker_node/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/tools/dq/worker_node/CMakeLists.darwin-x86_64.txt @@ -23,7 +23,7 @@ target_link_libraries(worker_node PUBLIC yql-dq-comp_nodes dq-integration-transform yql-dq-transform - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 providers-clickhouse-actors providers-common-comp_nodes providers-dq-runtime @@ -43,6 +43,8 @@ target_link_libraries(worker_node PUBLIC yql-utils-failure_injector yql-utils-backtrace yt-comp_nodes-dq + yt-comp_nodes-llvm14 + yt-codec-codegen providers-yt-mkql_dq dq-actors-yt providers-dq-global_worker_manager @@ -53,8 +55,6 @@ target_link_options(worker_node PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(worker_node PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/dq/worker_node/main.cpp diff --git a/ydb/library/yql/tools/dq/worker_node/CMakeLists.linux-aarch64.txt b/ydb/library/yql/tools/dq/worker_node/CMakeLists.linux-aarch64.txt index ef56db89b79a..42e92deea520 100644 --- a/ydb/library/yql/tools/dq/worker_node/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/tools/dq/worker_node/CMakeLists.linux-aarch64.txt @@ -23,7 +23,7 @@ target_link_libraries(worker_node PUBLIC yql-dq-comp_nodes dq-integration-transform yql-dq-transform - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 providers-clickhouse-actors providers-common-comp_nodes providers-dq-runtime @@ -43,6 +43,8 @@ target_link_libraries(worker_node PUBLIC yql-utils-failure_injector yql-utils-backtrace yt-comp_nodes-dq + yt-comp_nodes-llvm14 + yt-codec-codegen providers-yt-mkql_dq dq-actors-yt providers-dq-global_worker_manager @@ -55,10 +57,6 @@ target_link_options(worker_node PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(worker_node PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/dq/worker_node/main.cpp diff --git a/ydb/library/yql/tools/dq/worker_node/CMakeLists.linux-x86_64.txt b/ydb/library/yql/tools/dq/worker_node/CMakeLists.linux-x86_64.txt index 3739d1ca709e..173280374527 100644 --- a/ydb/library/yql/tools/dq/worker_node/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/tools/dq/worker_node/CMakeLists.linux-x86_64.txt @@ -24,7 +24,7 @@ target_link_libraries(worker_node PUBLIC yql-dq-comp_nodes dq-integration-transform yql-dq-transform - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 providers-clickhouse-actors providers-common-comp_nodes providers-dq-runtime @@ -44,6 +44,8 @@ target_link_libraries(worker_node PUBLIC yql-utils-failure_injector yql-utils-backtrace yt-comp_nodes-dq + yt-comp_nodes-llvm14 + yt-codec-codegen providers-yt-mkql_dq dq-actors-yt providers-dq-global_worker_manager @@ -56,10 +58,6 @@ target_link_options(worker_node PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(worker_node PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/dq/worker_node/main.cpp diff --git a/ydb/library/yql/tools/dqrun/CMakeLists.darwin-arm64.txt b/ydb/library/yql/tools/dqrun/CMakeLists.darwin-arm64.txt index d963c4b238a1..bb2ee3fa4d34 100644 --- a/ydb/library/yql/tools/dqrun/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/tools/dqrun/CMakeLists.darwin-arm64.txt @@ -33,8 +33,8 @@ target_link_libraries(dqrun PUBLIC yql-dq-comp_nodes dq-integration-transform yql-dq-transform - minikql-comp_nodes-llvm - minikql-invoke_builtins-llvm + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 providers-clickhouse-actors providers-clickhouse-provider providers-common-comp_nodes @@ -67,8 +67,10 @@ target_link_libraries(dqrun PUBLIC providers-yt-dq_task_preprocessor yt-gateway-file yt-gateway-native + yt-codec-codegen providers-yt-mkql_dq providers-yt-provider + yt-comp_nodes-llvm14 yt-lib-yt_download yt-lib-yt_url_lister yt-lib-config_clusters @@ -83,8 +85,6 @@ target_link_options(dqrun PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(dqrun PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/dqrun/dqrun.cpp diff --git a/ydb/library/yql/tools/dqrun/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/tools/dqrun/CMakeLists.darwin-x86_64.txt index 895c759c5129..5844161875aa 100644 --- a/ydb/library/yql/tools/dqrun/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/tools/dqrun/CMakeLists.darwin-x86_64.txt @@ -34,8 +34,8 @@ target_link_libraries(dqrun PUBLIC yql-dq-comp_nodes dq-integration-transform yql-dq-transform - minikql-comp_nodes-llvm - minikql-invoke_builtins-llvm + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 providers-clickhouse-actors providers-clickhouse-provider providers-common-comp_nodes @@ -68,8 +68,10 @@ target_link_libraries(dqrun PUBLIC providers-yt-dq_task_preprocessor yt-gateway-file yt-gateway-native + yt-codec-codegen providers-yt-mkql_dq providers-yt-provider + yt-comp_nodes-llvm14 yt-lib-yt_download yt-lib-yt_url_lister yt-lib-config_clusters @@ -84,8 +86,6 @@ target_link_options(dqrun PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(dqrun PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/dqrun/dqrun.cpp diff --git a/ydb/library/yql/tools/dqrun/CMakeLists.linux-aarch64.txt b/ydb/library/yql/tools/dqrun/CMakeLists.linux-aarch64.txt index ecb0c3504bc4..e274cd5ee815 100644 --- a/ydb/library/yql/tools/dqrun/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/tools/dqrun/CMakeLists.linux-aarch64.txt @@ -34,8 +34,8 @@ target_link_libraries(dqrun PUBLIC yql-dq-comp_nodes dq-integration-transform yql-dq-transform - minikql-comp_nodes-llvm - minikql-invoke_builtins-llvm + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 providers-clickhouse-actors providers-clickhouse-provider providers-common-comp_nodes @@ -68,8 +68,10 @@ target_link_libraries(dqrun PUBLIC providers-yt-dq_task_preprocessor yt-gateway-file yt-gateway-native + yt-codec-codegen providers-yt-mkql_dq providers-yt-provider + yt-comp_nodes-llvm14 yt-lib-yt_download yt-lib-yt_url_lister yt-lib-config_clusters @@ -86,10 +88,6 @@ target_link_options(dqrun PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(dqrun PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/dqrun/dqrun.cpp diff --git a/ydb/library/yql/tools/dqrun/CMakeLists.linux-x86_64.txt b/ydb/library/yql/tools/dqrun/CMakeLists.linux-x86_64.txt index d98045e536e9..1223e290d1c6 100644 --- a/ydb/library/yql/tools/dqrun/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/tools/dqrun/CMakeLists.linux-x86_64.txt @@ -35,8 +35,8 @@ target_link_libraries(dqrun PUBLIC yql-dq-comp_nodes dq-integration-transform yql-dq-transform - minikql-comp_nodes-llvm - minikql-invoke_builtins-llvm + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 providers-clickhouse-actors providers-clickhouse-provider providers-common-comp_nodes @@ -69,8 +69,10 @@ target_link_libraries(dqrun PUBLIC providers-yt-dq_task_preprocessor yt-gateway-file yt-gateway-native + yt-codec-codegen providers-yt-mkql_dq providers-yt-provider + yt-comp_nodes-llvm14 yt-lib-yt_download yt-lib-yt_url_lister yt-lib-config_clusters @@ -87,10 +89,6 @@ target_link_options(dqrun PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(dqrun PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/dqrun/dqrun.cpp diff --git a/ydb/library/yql/tools/mrjob/CMakeLists.darwin-arm64.txt b/ydb/library/yql/tools/mrjob/CMakeLists.darwin-arm64.txt index b67410869c94..88061a8a4edf 100644 --- a/ydb/library/yql/tools/mrjob/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/tools/mrjob/CMakeLists.darwin-arm64.txt @@ -21,13 +21,16 @@ target_link_libraries(mrjob PUBLIC yql-parser-pg_wrapper yql-sql-pg providers-yt-job + yt-codec-codegen + yt-comp_nodes-llvm14 + minikql-computation-llvm14 + minikql-invoke_builtins-llvm14 + minikql-comp_nodes-llvm14 ) target_link_options(mrjob PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(mrjob PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/mrjob/mrjob.cpp diff --git a/ydb/library/yql/tools/mrjob/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/tools/mrjob/CMakeLists.darwin-x86_64.txt index 247502db46ab..d7cd30e73a34 100644 --- a/ydb/library/yql/tools/mrjob/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/tools/mrjob/CMakeLists.darwin-x86_64.txt @@ -22,13 +22,16 @@ target_link_libraries(mrjob PUBLIC yql-parser-pg_wrapper yql-sql-pg providers-yt-job + yt-codec-codegen + yt-comp_nodes-llvm14 + minikql-computation-llvm14 + minikql-invoke_builtins-llvm14 + minikql-comp_nodes-llvm14 ) target_link_options(mrjob PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(mrjob PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/mrjob/mrjob.cpp diff --git a/ydb/library/yql/tools/mrjob/CMakeLists.linux-aarch64.txt b/ydb/library/yql/tools/mrjob/CMakeLists.linux-aarch64.txt index af1caa79eddc..e1e3abf7d084 100644 --- a/ydb/library/yql/tools/mrjob/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/tools/mrjob/CMakeLists.linux-aarch64.txt @@ -22,6 +22,11 @@ target_link_libraries(mrjob PUBLIC yql-parser-pg_wrapper yql-sql-pg providers-yt-job + yt-codec-codegen + yt-comp_nodes-llvm14 + minikql-computation-llvm14 + minikql-invoke_builtins-llvm14 + minikql-comp_nodes-llvm14 ) target_link_options(mrjob PRIVATE -ldl @@ -29,10 +34,6 @@ target_link_options(mrjob PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(mrjob PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/mrjob/mrjob.cpp diff --git a/ydb/library/yql/tools/mrjob/CMakeLists.linux-x86_64.txt b/ydb/library/yql/tools/mrjob/CMakeLists.linux-x86_64.txt index 18e74ea77dfb..82b27e2e3024 100644 --- a/ydb/library/yql/tools/mrjob/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/tools/mrjob/CMakeLists.linux-x86_64.txt @@ -23,6 +23,11 @@ target_link_libraries(mrjob PUBLIC yql-parser-pg_wrapper yql-sql-pg providers-yt-job + yt-codec-codegen + yt-comp_nodes-llvm14 + minikql-computation-llvm14 + minikql-invoke_builtins-llvm14 + minikql-comp_nodes-llvm14 ) target_link_options(mrjob PRIVATE -ldl @@ -30,10 +35,6 @@ target_link_options(mrjob PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(mrjob PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/mrjob/mrjob.cpp diff --git a/ydb/library/yql/tools/mrjob/CMakeLists.windows-x86_64.txt b/ydb/library/yql/tools/mrjob/CMakeLists.windows-x86_64.txt index a2c958a6d016..e0c3b7176055 100644 --- a/ydb/library/yql/tools/mrjob/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/tools/mrjob/CMakeLists.windows-x86_64.txt @@ -22,6 +22,11 @@ target_link_libraries(mrjob PUBLIC yql-parser-pg_wrapper yql-sql-pg providers-yt-job + yt-codec-codegen + yt-comp_nodes-llvm14 + minikql-computation-llvm14 + minikql-invoke_builtins-llvm14 + minikql-comp_nodes-llvm14 ) target_sources(mrjob PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/mrjob/mrjob.cpp diff --git a/ydb/library/yql/tools/mrrun/CMakeLists.darwin-arm64.txt b/ydb/library/yql/tools/mrrun/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..2b588d3efdab --- /dev/null +++ b/ydb/library/yql/tools/mrrun/CMakeLists.darwin-arm64.txt @@ -0,0 +1,88 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(mrrun) +target_compile_options(mrrun PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(mrrun PUBLIC + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf + client-ydb_persqueue_public-codecs + cpp-digest-md5 + library-cpp-getopt + library-cpp-logger + library-cpp-resource + library-cpp-yson + cpp-yson-node + library-cpp-sighandler + cpp-mapreduce-client + cpp-mapreduce-common + ydb-core-util + yql-sql-pg + library-yql-core + yql-core-facade + core-file_storage-proto + core-file_storage-http_download + yql-core-file_storage + core-services-mounts + yql-core-url_lister + yql-dq-comp_nodes + dq-integration-transform + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 + library-yql-protos + providers-clickhouse-actors + providers-clickhouse-provider + providers-common-comp_nodes + providers-common-http_gateway + providers-common-proto + providers-common-udf_resolve + providers-dq-local_gateway + providers-dq-provider + dq-provider-exec + providers-pq-async_io + providers-s3-actors + providers-ydb-actors + providers-ydb-comp_nodes + providers-ydb-provider + providers-pg-provider + udf-service-terminate_policy + yql-utils-log + yql-utils-backtrace + yql-utils-failure_injector + cpp-client-ydb_driver + yql-core-url_preprocessing + yt-comp_nodes-dq + yt-comp_nodes-llvm14 + yt-codec-codegen + providers-yt-dq_task_preprocessor + yt-gateway-native + yt-lib-log + providers-yt-mkql_dq + yt-lib-yt_download + yt-lib-yt_url_lister + yt-lib-config_clusters + yql-parser-pg_wrapper + providers-dq-global_worker_manager +) +target_link_options(mrrun PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(mrrun PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/mrrun/mrrun.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/mrrun/mrrun.cpp +) +target_allocator(mrrun + cpp-malloc-jemalloc +) +vcs_info(mrrun) diff --git a/ydb/library/yql/tools/mrrun/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/tools/mrrun/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..ee82ba895cc2 --- /dev/null +++ b/ydb/library/yql/tools/mrrun/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,89 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(mrrun) +target_compile_options(mrrun PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(mrrun PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + contrib-libs-protobuf + client-ydb_persqueue_public-codecs + cpp-digest-md5 + library-cpp-getopt + library-cpp-logger + library-cpp-resource + library-cpp-yson + cpp-yson-node + library-cpp-sighandler + cpp-mapreduce-client + cpp-mapreduce-common + ydb-core-util + yql-sql-pg + library-yql-core + yql-core-facade + core-file_storage-proto + core-file_storage-http_download + yql-core-file_storage + core-services-mounts + yql-core-url_lister + yql-dq-comp_nodes + dq-integration-transform + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 + library-yql-protos + providers-clickhouse-actors + providers-clickhouse-provider + providers-common-comp_nodes + providers-common-http_gateway + providers-common-proto + providers-common-udf_resolve + providers-dq-local_gateway + providers-dq-provider + dq-provider-exec + providers-pq-async_io + providers-s3-actors + providers-ydb-actors + providers-ydb-comp_nodes + providers-ydb-provider + providers-pg-provider + udf-service-terminate_policy + yql-utils-log + yql-utils-backtrace + yql-utils-failure_injector + cpp-client-ydb_driver + yql-core-url_preprocessing + yt-comp_nodes-dq + yt-comp_nodes-llvm14 + yt-codec-codegen + providers-yt-dq_task_preprocessor + yt-gateway-native + yt-lib-log + providers-yt-mkql_dq + yt-lib-yt_download + yt-lib-yt_url_lister + yt-lib-config_clusters + yql-parser-pg_wrapper + providers-dq-global_worker_manager +) +target_link_options(mrrun PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(mrrun PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/mrrun/mrrun.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/mrrun/mrrun.cpp +) +target_allocator(mrrun + cpp-malloc-jemalloc +) +vcs_info(mrrun) diff --git a/ydb/library/yql/tools/mrrun/CMakeLists.linux-aarch64.txt b/ydb/library/yql/tools/mrrun/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..3e3d72f01aec --- /dev/null +++ b/ydb/library/yql/tools/mrrun/CMakeLists.linux-aarch64.txt @@ -0,0 +1,91 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(mrrun) +target_compile_options(mrrun PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(mrrun PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf + client-ydb_persqueue_public-codecs + cpp-digest-md5 + library-cpp-getopt + library-cpp-logger + library-cpp-resource + library-cpp-yson + cpp-yson-node + library-cpp-sighandler + cpp-mapreduce-client + cpp-mapreduce-common + ydb-core-util + yql-sql-pg + library-yql-core + yql-core-facade + core-file_storage-proto + core-file_storage-http_download + yql-core-file_storage + core-services-mounts + yql-core-url_lister + yql-dq-comp_nodes + dq-integration-transform + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 + library-yql-protos + providers-clickhouse-actors + providers-clickhouse-provider + providers-common-comp_nodes + providers-common-http_gateway + providers-common-proto + providers-common-udf_resolve + providers-dq-local_gateway + providers-dq-provider + dq-provider-exec + providers-pq-async_io + providers-s3-actors + providers-ydb-actors + providers-ydb-comp_nodes + providers-ydb-provider + providers-pg-provider + udf-service-terminate_policy + yql-utils-log + yql-utils-backtrace + yql-utils-failure_injector + cpp-client-ydb_driver + yql-core-url_preprocessing + yt-comp_nodes-dq + yt-comp_nodes-llvm14 + yt-codec-codegen + providers-yt-dq_task_preprocessor + yt-gateway-native + yt-lib-log + providers-yt-mkql_dq + yt-lib-yt_download + yt-lib-yt_url_lister + yt-lib-config_clusters + yql-parser-pg_wrapper + providers-dq-global_worker_manager +) +target_link_options(mrrun PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(mrrun PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/mrrun/mrrun.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/mrrun/mrrun.cpp +) +target_allocator(mrrun + cpp-malloc-jemalloc +) +vcs_info(mrrun) diff --git a/ydb/library/yql/tools/mrrun/CMakeLists.linux-x86_64.txt b/ydb/library/yql/tools/mrrun/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..ccc599b7dc1e --- /dev/null +++ b/ydb/library/yql/tools/mrrun/CMakeLists.linux-x86_64.txt @@ -0,0 +1,92 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(mrrun) +target_compile_options(mrrun PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(mrrun PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + contrib-libs-protobuf + client-ydb_persqueue_public-codecs + cpp-digest-md5 + library-cpp-getopt + library-cpp-logger + library-cpp-resource + library-cpp-yson + cpp-yson-node + library-cpp-sighandler + cpp-mapreduce-client + cpp-mapreduce-common + ydb-core-util + yql-sql-pg + library-yql-core + yql-core-facade + core-file_storage-proto + core-file_storage-http_download + yql-core-file_storage + core-services-mounts + yql-core-url_lister + yql-dq-comp_nodes + dq-integration-transform + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 + library-yql-protos + providers-clickhouse-actors + providers-clickhouse-provider + providers-common-comp_nodes + providers-common-http_gateway + providers-common-proto + providers-common-udf_resolve + providers-dq-local_gateway + providers-dq-provider + dq-provider-exec + providers-pq-async_io + providers-s3-actors + providers-ydb-actors + providers-ydb-comp_nodes + providers-ydb-provider + providers-pg-provider + udf-service-terminate_policy + yql-utils-log + yql-utils-backtrace + yql-utils-failure_injector + cpp-client-ydb_driver + yql-core-url_preprocessing + yt-comp_nodes-dq + yt-comp_nodes-llvm14 + yt-codec-codegen + providers-yt-dq_task_preprocessor + yt-gateway-native + yt-lib-log + providers-yt-mkql_dq + yt-lib-yt_download + yt-lib-yt_url_lister + yt-lib-config_clusters + yql-parser-pg_wrapper + providers-dq-global_worker_manager +) +target_link_options(mrrun PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(mrrun PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/mrrun/mrrun.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/mrrun/mrrun.cpp +) +target_allocator(mrrun + cpp-malloc-jemalloc +) +vcs_info(mrrun) diff --git a/ydb/library/yql/tools/mrrun/CMakeLists.txt b/ydb/library/yql/tools/mrrun/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/tools/mrrun/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/tools/mrrun/CMakeLists.windows-x86_64.txt b/ydb/library/yql/tools/mrrun/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..fc66053c9123 --- /dev/null +++ b/ydb/library/yql/tools/mrrun/CMakeLists.windows-x86_64.txt @@ -0,0 +1,83 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(mrrun) +target_compile_options(mrrun PRIVATE + -DUSE_CURRENT_UDF_ABI_VERSION +) +target_link_libraries(mrrun PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + contrib-libs-protobuf + client-ydb_persqueue_public-codecs + cpp-digest-md5 + library-cpp-getopt + library-cpp-logger + library-cpp-resource + library-cpp-yson + cpp-yson-node + library-cpp-sighandler + cpp-mapreduce-client + cpp-mapreduce-common + ydb-core-util + yql-sql-pg + library-yql-core + yql-core-facade + core-file_storage-proto + core-file_storage-http_download + yql-core-file_storage + core-services-mounts + yql-core-url_lister + yql-dq-comp_nodes + dq-integration-transform + minikql-comp_nodes-llvm14 + minikql-invoke_builtins-llvm14 + library-yql-protos + providers-clickhouse-actors + providers-clickhouse-provider + providers-common-comp_nodes + providers-common-http_gateway + providers-common-proto + providers-common-udf_resolve + providers-dq-local_gateway + providers-dq-provider + dq-provider-exec + providers-pq-async_io + providers-s3-actors + providers-ydb-actors + providers-ydb-comp_nodes + providers-ydb-provider + providers-pg-provider + udf-service-terminate_policy + yql-utils-log + yql-utils-backtrace + yql-utils-failure_injector + cpp-client-ydb_driver + yql-core-url_preprocessing + yt-comp_nodes-dq + yt-comp_nodes-llvm14 + yt-codec-codegen + providers-yt-dq_task_preprocessor + yt-gateway-native + yt-lib-log + providers-yt-mkql_dq + yt-lib-yt_download + yt-lib-yt_url_lister + yt-lib-config_clusters + yql-parser-pg_wrapper +) +target_sources(mrrun PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/mrrun/mrrun.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/mrrun/mrrun.cpp +) +target_allocator(mrrun + system_allocator +) +vcs_info(mrrun) diff --git a/ydb/library/yql/tools/pgrun/CMakeLists.darwin-arm64.txt b/ydb/library/yql/tools/pgrun/CMakeLists.darwin-arm64.txt index 0f049c974617..e2aa438f8891 100644 --- a/ydb/library/yql/tools/pgrun/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/tools/pgrun/CMakeLists.darwin-arm64.txt @@ -16,6 +16,7 @@ target_link_libraries(pgrun PUBLIC yutil contrib-libs-protobuf library-cpp-getopt + cpp-string_utils-base64 contrib-libs-fmt library-cpp-yson yql-sql-pg @@ -24,7 +25,7 @@ target_link_libraries(pgrun PUBLIC core-file_storage-proto core-file_storage-http_download core-services-mounts - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 library-yql-protos udf-service-exception_policy yql-utils-backtrace @@ -37,6 +38,9 @@ target_link_libraries(pgrun PUBLIC providers-common-udf_resolve providers-dq-provider yt-gateway-file + yt-comp_nodes-llvm14 + yt-codec-codegen + providers-pg-provider yql-core-url_preprocessing yql-parser-pg_wrapper ) @@ -44,8 +48,6 @@ target_link_options(pgrun PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(pgrun PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/pgrun/pgrun.cpp diff --git a/ydb/library/yql/tools/pgrun/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/tools/pgrun/CMakeLists.darwin-x86_64.txt index 359f46db6896..19b278ed4300 100644 --- a/ydb/library/yql/tools/pgrun/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/tools/pgrun/CMakeLists.darwin-x86_64.txt @@ -17,6 +17,7 @@ target_link_libraries(pgrun PUBLIC library-cpp-cpuid_check contrib-libs-protobuf library-cpp-getopt + cpp-string_utils-base64 contrib-libs-fmt library-cpp-yson yql-sql-pg @@ -25,7 +26,7 @@ target_link_libraries(pgrun PUBLIC core-file_storage-proto core-file_storage-http_download core-services-mounts - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 library-yql-protos udf-service-exception_policy yql-utils-backtrace @@ -38,6 +39,9 @@ target_link_libraries(pgrun PUBLIC providers-common-udf_resolve providers-dq-provider yt-gateway-file + yt-comp_nodes-llvm14 + yt-codec-codegen + providers-pg-provider yql-core-url_preprocessing yql-parser-pg_wrapper ) @@ -45,8 +49,6 @@ target_link_options(pgrun PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(pgrun PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/pgrun/pgrun.cpp diff --git a/ydb/library/yql/tools/pgrun/CMakeLists.linux-aarch64.txt b/ydb/library/yql/tools/pgrun/CMakeLists.linux-aarch64.txt index c88b5ad999ae..0221a90b0ccc 100644 --- a/ydb/library/yql/tools/pgrun/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/tools/pgrun/CMakeLists.linux-aarch64.txt @@ -17,6 +17,7 @@ target_link_libraries(pgrun PUBLIC yutil contrib-libs-protobuf library-cpp-getopt + cpp-string_utils-base64 contrib-libs-fmt library-cpp-yson yql-sql-pg @@ -25,7 +26,7 @@ target_link_libraries(pgrun PUBLIC core-file_storage-proto core-file_storage-http_download core-services-mounts - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 library-yql-protos udf-service-exception_policy yql-utils-backtrace @@ -38,6 +39,9 @@ target_link_libraries(pgrun PUBLIC providers-common-udf_resolve providers-dq-provider yt-gateway-file + yt-comp_nodes-llvm14 + yt-codec-codegen + providers-pg-provider yql-core-url_preprocessing yql-parser-pg_wrapper ) @@ -47,10 +51,6 @@ target_link_options(pgrun PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(pgrun PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/pgrun/pgrun.cpp diff --git a/ydb/library/yql/tools/pgrun/CMakeLists.linux-x86_64.txt b/ydb/library/yql/tools/pgrun/CMakeLists.linux-x86_64.txt index a57a34a2049a..4e76307d0208 100644 --- a/ydb/library/yql/tools/pgrun/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/tools/pgrun/CMakeLists.linux-x86_64.txt @@ -18,6 +18,7 @@ target_link_libraries(pgrun PUBLIC library-cpp-cpuid_check contrib-libs-protobuf library-cpp-getopt + cpp-string_utils-base64 contrib-libs-fmt library-cpp-yson yql-sql-pg @@ -26,7 +27,7 @@ target_link_libraries(pgrun PUBLIC core-file_storage-proto core-file_storage-http_download core-services-mounts - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 library-yql-protos udf-service-exception_policy yql-utils-backtrace @@ -39,6 +40,9 @@ target_link_libraries(pgrun PUBLIC providers-common-udf_resolve providers-dq-provider yt-gateway-file + yt-comp_nodes-llvm14 + yt-codec-codegen + providers-pg-provider yql-core-url_preprocessing yql-parser-pg_wrapper ) @@ -48,10 +52,6 @@ target_link_options(pgrun PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(pgrun PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/pgrun/pgrun.cpp diff --git a/ydb/library/yql/tools/pgrun/CMakeLists.windows-x86_64.txt b/ydb/library/yql/tools/pgrun/CMakeLists.windows-x86_64.txt index 23156e952fa4..753bd96756c7 100644 --- a/ydb/library/yql/tools/pgrun/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/tools/pgrun/CMakeLists.windows-x86_64.txt @@ -17,6 +17,7 @@ target_link_libraries(pgrun PUBLIC library-cpp-cpuid_check contrib-libs-protobuf library-cpp-getopt + cpp-string_utils-base64 contrib-libs-fmt library-cpp-yson yql-sql-pg @@ -25,7 +26,7 @@ target_link_libraries(pgrun PUBLIC core-file_storage-proto core-file_storage-http_download core-services-mounts - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 library-yql-protos udf-service-exception_policy yql-utils-backtrace @@ -38,6 +39,9 @@ target_link_libraries(pgrun PUBLIC providers-common-udf_resolve providers-dq-provider yt-gateway-file + yt-comp_nodes-llvm14 + yt-codec-codegen + providers-pg-provider yql-core-url_preprocessing yql-parser-pg_wrapper ) diff --git a/ydb/library/yql/tools/sql2yql/CMakeLists.darwin-arm64.txt b/ydb/library/yql/tools/sql2yql/CMakeLists.darwin-arm64.txt index 75c88bee992c..b13fe89ab5f3 100644 --- a/ydb/library/yql/tools/sql2yql/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/tools/sql2yql/CMakeLists.darwin-arm64.txt @@ -8,9 +8,6 @@ add_executable(sql2yql) -target_compile_options(sql2yql PRIVATE - $,,-Wno-everything> -) target_link_libraries(sql2yql PUBLIC contrib-libs-cxxsupp yutil @@ -28,8 +25,6 @@ target_link_options(sql2yql PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(sql2yql PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/sql2yql/sql2yql.cpp diff --git a/ydb/library/yql/tools/sql2yql/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/tools/sql2yql/CMakeLists.darwin-x86_64.txt index 6490a346a351..7d8a8887b798 100644 --- a/ydb/library/yql/tools/sql2yql/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/tools/sql2yql/CMakeLists.darwin-x86_64.txt @@ -8,9 +8,6 @@ add_executable(sql2yql) -target_compile_options(sql2yql PRIVATE - $,,-Wno-everything> -) target_link_libraries(sql2yql PUBLIC contrib-libs-cxxsupp yutil @@ -29,8 +26,6 @@ target_link_options(sql2yql PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(sql2yql PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/sql2yql/sql2yql.cpp diff --git a/ydb/library/yql/tools/sql2yql/CMakeLists.linux-aarch64.txt b/ydb/library/yql/tools/sql2yql/CMakeLists.linux-aarch64.txt index d2bf38f9c09d..4b05d5ae69f3 100644 --- a/ydb/library/yql/tools/sql2yql/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/tools/sql2yql/CMakeLists.linux-aarch64.txt @@ -8,9 +8,6 @@ add_executable(sql2yql) -target_compile_options(sql2yql PRIVATE - $,,-Wno-everything> -) target_link_libraries(sql2yql PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp @@ -31,9 +28,6 @@ target_link_options(sql2yql PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(sql2yql PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/sql2yql/sql2yql.cpp diff --git a/ydb/library/yql/tools/sql2yql/CMakeLists.linux-x86_64.txt b/ydb/library/yql/tools/sql2yql/CMakeLists.linux-x86_64.txt index a0e8f3864a00..b4598b69d624 100644 --- a/ydb/library/yql/tools/sql2yql/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/tools/sql2yql/CMakeLists.linux-x86_64.txt @@ -8,9 +8,6 @@ add_executable(sql2yql) -target_compile_options(sql2yql PRIVATE - $,,-Wno-everything> -) target_link_libraries(sql2yql PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp @@ -32,9 +29,6 @@ target_link_options(sql2yql PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(sql2yql PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/sql2yql/sql2yql.cpp diff --git a/ydb/library/yql/tools/sql2yql/CMakeLists.windows-x86_64.txt b/ydb/library/yql/tools/sql2yql/CMakeLists.windows-x86_64.txt index 2ee47824b416..b0b1a8326f86 100644 --- a/ydb/library/yql/tools/sql2yql/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/tools/sql2yql/CMakeLists.windows-x86_64.txt @@ -8,9 +8,6 @@ add_executable(sql2yql) -target_compile_options(sql2yql PRIVATE - $,,-Wno-everything> -) target_link_libraries(sql2yql PUBLIC contrib-libs-cxxsupp yutil diff --git a/ydb/library/yql/tools/sql_formatter/CMakeLists.darwin-arm64.txt b/ydb/library/yql/tools/sql_formatter/CMakeLists.darwin-arm64.txt index 3c0daff9400e..3c4d46a0da24 100644 --- a/ydb/library/yql/tools/sql_formatter/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/tools/sql_formatter/CMakeLists.darwin-arm64.txt @@ -19,8 +19,6 @@ target_link_options(sql_formatter PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(sql_formatter PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/sql_formatter/sql_formatter.cpp diff --git a/ydb/library/yql/tools/sql_formatter/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/tools/sql_formatter/CMakeLists.darwin-x86_64.txt index 7fc0c27e3f51..6788b1af2d4b 100644 --- a/ydb/library/yql/tools/sql_formatter/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/tools/sql_formatter/CMakeLists.darwin-x86_64.txt @@ -20,8 +20,6 @@ target_link_options(sql_formatter PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(sql_formatter PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/sql_formatter/sql_formatter.cpp diff --git a/ydb/library/yql/tools/sql_formatter/CMakeLists.linux-aarch64.txt b/ydb/library/yql/tools/sql_formatter/CMakeLists.linux-aarch64.txt index af05b914a5e8..698ef666ccc0 100644 --- a/ydb/library/yql/tools/sql_formatter/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/tools/sql_formatter/CMakeLists.linux-aarch64.txt @@ -22,9 +22,6 @@ target_link_options(sql_formatter PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(sql_formatter PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/sql_formatter/sql_formatter.cpp diff --git a/ydb/library/yql/tools/sql_formatter/CMakeLists.linux-x86_64.txt b/ydb/library/yql/tools/sql_formatter/CMakeLists.linux-x86_64.txt index 56f07291b9ef..e4d785d91001 100644 --- a/ydb/library/yql/tools/sql_formatter/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/tools/sql_formatter/CMakeLists.linux-x86_64.txt @@ -23,9 +23,6 @@ target_link_options(sql_formatter PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(sql_formatter PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/sql_formatter/sql_formatter.cpp diff --git a/ydb/library/yql/tools/udf_dep_stub/CMakeLists.linux-aarch64.txt b/ydb/library/yql/tools/udf_dep_stub/CMakeLists.linux-aarch64.txt index 4cc94a170c02..2d1536a7118f 100644 --- a/ydb/library/yql/tools/udf_dep_stub/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/tools/udf_dep_stub/CMakeLists.linux-aarch64.txt @@ -20,9 +20,6 @@ target_link_options(yql_udf_dep_stub PRIVATE -fPIC -Wl,-z,notext -fPIC - -lpthread - -lrt - -ldl ) target_sources(yql_udf_dep_stub PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/udf_dep_stub/main.cpp diff --git a/ydb/library/yql/tools/udf_dep_stub/CMakeLists.linux-x86_64.txt b/ydb/library/yql/tools/udf_dep_stub/CMakeLists.linux-x86_64.txt index 4cc94a170c02..2d1536a7118f 100644 --- a/ydb/library/yql/tools/udf_dep_stub/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/tools/udf_dep_stub/CMakeLists.linux-x86_64.txt @@ -20,9 +20,6 @@ target_link_options(yql_udf_dep_stub PRIVATE -fPIC -Wl,-z,notext -fPIC - -lpthread - -lrt - -ldl ) target_sources(yql_udf_dep_stub PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/udf_dep_stub/main.cpp diff --git a/ydb/library/yql/tools/udf_probe/CMakeLists.darwin-arm64.txt b/ydb/library/yql/tools/udf_probe/CMakeLists.darwin-arm64.txt index 44e6f2d2996f..4ddea215b85a 100644 --- a/ydb/library/yql/tools/udf_probe/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/tools/udf_probe/CMakeLists.darwin-arm64.txt @@ -22,8 +22,6 @@ target_link_options(udf_probe PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(udf_probe PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/udf_probe/udf_probe.cpp diff --git a/ydb/library/yql/tools/udf_probe/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/tools/udf_probe/CMakeLists.darwin-x86_64.txt index 1edbd44aebde..40546f9418f7 100644 --- a/ydb/library/yql/tools/udf_probe/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/tools/udf_probe/CMakeLists.darwin-x86_64.txt @@ -23,8 +23,6 @@ target_link_options(udf_probe PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(udf_probe PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/udf_probe/udf_probe.cpp diff --git a/ydb/library/yql/tools/udf_probe/CMakeLists.linux-aarch64.txt b/ydb/library/yql/tools/udf_probe/CMakeLists.linux-aarch64.txt index 98f390f52392..557e4e463993 100644 --- a/ydb/library/yql/tools/udf_probe/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/tools/udf_probe/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(udf_probe PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(udf_probe PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/udf_probe/udf_probe.cpp diff --git a/ydb/library/yql/tools/udf_probe/CMakeLists.linux-x86_64.txt b/ydb/library/yql/tools/udf_probe/CMakeLists.linux-x86_64.txt index abc6b25228f3..9b7ce321fa65 100644 --- a/ydb/library/yql/tools/udf_probe/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/tools/udf_probe/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(udf_probe PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(udf_probe PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/udf_probe/udf_probe.cpp diff --git a/ydb/library/yql/tools/udf_resolver/CMakeLists.darwin-arm64.txt b/ydb/library/yql/tools/udf_resolver/CMakeLists.darwin-arm64.txt index 9019b69f7cdd..306c446f892f 100644 --- a/ydb/library/yql/tools/udf_resolver/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/tools/udf_resolver/CMakeLists.darwin-arm64.txt @@ -29,8 +29,6 @@ target_link_options(udf_resolver PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(udf_resolver PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/udf_resolver/udf_resolver.cpp diff --git a/ydb/library/yql/tools/udf_resolver/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/tools/udf_resolver/CMakeLists.darwin-x86_64.txt index 553a90185ca9..93354000537b 100644 --- a/ydb/library/yql/tools/udf_resolver/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/tools/udf_resolver/CMakeLists.darwin-x86_64.txt @@ -30,8 +30,6 @@ target_link_options(udf_resolver PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(udf_resolver PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/udf_resolver/udf_resolver.cpp diff --git a/ydb/library/yql/tools/udf_resolver/CMakeLists.linux-aarch64.txt b/ydb/library/yql/tools/udf_resolver/CMakeLists.linux-aarch64.txt index a614caa4eaf2..312b3b55038b 100644 --- a/ydb/library/yql/tools/udf_resolver/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/tools/udf_resolver/CMakeLists.linux-aarch64.txt @@ -33,9 +33,6 @@ target_link_options(udf_resolver PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(udf_resolver PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/udf_resolver/udf_resolver.cpp diff --git a/ydb/library/yql/tools/udf_resolver/CMakeLists.linux-x86_64.txt b/ydb/library/yql/tools/udf_resolver/CMakeLists.linux-x86_64.txt index c3223efa173a..cefe97e209a8 100644 --- a/ydb/library/yql/tools/udf_resolver/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/tools/udf_resolver/CMakeLists.linux-x86_64.txt @@ -34,9 +34,6 @@ target_link_options(udf_resolver PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(udf_resolver PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/udf_resolver/udf_resolver.cpp diff --git a/ydb/library/yql/tools/yqlrun/CMakeLists.darwin-arm64.txt b/ydb/library/yql/tools/yqlrun/CMakeLists.darwin-arm64.txt index 31b2a2b422fd..ef22d21da3e8 100644 --- a/ydb/library/yql/tools/yqlrun/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/tools/yqlrun/CMakeLists.darwin-arm64.txt @@ -25,7 +25,7 @@ target_link_libraries(yqlrun PUBLIC core-file_storage-proto core-file_storage-http_download core-services-mounts - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 library-yql-protos udf-service-exception_policy yql-utils-backtrace @@ -38,6 +38,8 @@ target_link_libraries(yqlrun PUBLIC providers-common-udf_resolve providers-dq-provider yt-gateway-file + yt-codec-codegen + yt-comp_nodes-llvm14 yql-core-url_preprocessing tools-yqlrun-http yql-parser-pg_wrapper @@ -46,21 +48,11 @@ target_link_options(yqlrun PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(yqlrun PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/yqlrun.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/gateway_spec.cpp ) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/ui.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/ui.sh -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/uig.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/uig.sh -) target_allocator(yqlrun cpp-malloc-jemalloc ) diff --git a/ydb/library/yql/tools/yqlrun/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/tools/yqlrun/CMakeLists.darwin-x86_64.txt index 1cfaf9478895..bd3f3cc87423 100644 --- a/ydb/library/yql/tools/yqlrun/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/tools/yqlrun/CMakeLists.darwin-x86_64.txt @@ -26,7 +26,7 @@ target_link_libraries(yqlrun PUBLIC core-file_storage-proto core-file_storage-http_download core-services-mounts - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 library-yql-protos udf-service-exception_policy yql-utils-backtrace @@ -39,6 +39,8 @@ target_link_libraries(yqlrun PUBLIC providers-common-udf_resolve providers-dq-provider yt-gateway-file + yt-codec-codegen + yt-comp_nodes-llvm14 yql-core-url_preprocessing tools-yqlrun-http yql-parser-pg_wrapper @@ -47,21 +49,11 @@ target_link_options(yqlrun PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(yqlrun PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/yqlrun.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/gateway_spec.cpp ) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/ui.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/ui.sh -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/uig.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/uig.sh -) target_allocator(yqlrun cpp-malloc-jemalloc ) diff --git a/ydb/library/yql/tools/yqlrun/CMakeLists.linux-aarch64.txt b/ydb/library/yql/tools/yqlrun/CMakeLists.linux-aarch64.txt index b9906b532184..0c2f26fdc821 100644 --- a/ydb/library/yql/tools/yqlrun/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/tools/yqlrun/CMakeLists.linux-aarch64.txt @@ -26,7 +26,7 @@ target_link_libraries(yqlrun PUBLIC core-file_storage-proto core-file_storage-http_download core-services-mounts - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 library-yql-protos udf-service-exception_policy yql-utils-backtrace @@ -39,6 +39,8 @@ target_link_libraries(yqlrun PUBLIC providers-common-udf_resolve providers-dq-provider yt-gateway-file + yt-codec-codegen + yt-comp_nodes-llvm14 yql-core-url_preprocessing tools-yqlrun-http yql-parser-pg_wrapper @@ -49,23 +51,11 @@ target_link_options(yqlrun PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(yqlrun PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/yqlrun.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/gateway_spec.cpp ) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/ui.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/ui.sh -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/uig.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/uig.sh -) target_allocator(yqlrun cpp-malloc-jemalloc ) diff --git a/ydb/library/yql/tools/yqlrun/CMakeLists.linux-x86_64.txt b/ydb/library/yql/tools/yqlrun/CMakeLists.linux-x86_64.txt index c4fd1665765d..2ec9357a7873 100644 --- a/ydb/library/yql/tools/yqlrun/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/tools/yqlrun/CMakeLists.linux-x86_64.txt @@ -27,7 +27,7 @@ target_link_libraries(yqlrun PUBLIC core-file_storage-proto core-file_storage-http_download core-services-mounts - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 library-yql-protos udf-service-exception_policy yql-utils-backtrace @@ -40,6 +40,8 @@ target_link_libraries(yqlrun PUBLIC providers-common-udf_resolve providers-dq-provider yt-gateway-file + yt-codec-codegen + yt-comp_nodes-llvm14 yql-core-url_preprocessing tools-yqlrun-http yql-parser-pg_wrapper @@ -50,23 +52,11 @@ target_link_options(yqlrun PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(yqlrun PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/yqlrun.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/gateway_spec.cpp ) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/ui.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/ui.sh -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/uig.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/uig.sh -) target_allocator(yqlrun cpp-malloc-jemalloc ) diff --git a/ydb/library/yql/tools/yqlrun/CMakeLists.windows-x86_64.txt b/ydb/library/yql/tools/yqlrun/CMakeLists.windows-x86_64.txt index 8a95ad8a7ef5..58663956bf2a 100644 --- a/ydb/library/yql/tools/yqlrun/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/tools/yqlrun/CMakeLists.windows-x86_64.txt @@ -26,7 +26,7 @@ target_link_libraries(yqlrun PUBLIC core-file_storage-proto core-file_storage-http_download core-services-mounts - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 library-yql-protos udf-service-exception_policy yql-utils-backtrace @@ -39,6 +39,8 @@ target_link_libraries(yqlrun PUBLIC providers-common-udf_resolve providers-dq-provider yt-gateway-file + yt-codec-codegen + yt-comp_nodes-llvm14 yql-core-url_preprocessing tools-yqlrun-http yql-parser-pg_wrapper @@ -47,14 +49,6 @@ target_sources(yqlrun PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/yqlrun.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/gateway_spec.cpp ) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/ui.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/ui.sh -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/uig.sh - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/uig.sh -) target_allocator(yqlrun system_allocator ) diff --git a/ydb/library/yql/tools/yqlrun/http/CMakeLists.darwin-arm64.txt b/ydb/library/yql/tools/yqlrun/http/CMakeLists.darwin-arm64.txt index 47268f2584ae..d1f24d7c378f 100644 --- a/ydb/library/yql/tools/yqlrun/http/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/tools/yqlrun/http/CMakeLists.darwin-arm64.txt @@ -44,51 +44,3 @@ target_sources(tools-yqlrun-http PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/yql_servlet.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/yql_server.cpp ) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/bower.json - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/bower.json -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/favicon.ico - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/favicon.ico -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/file-index.html - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/file-index.html -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/css/base.css - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/css/base.css -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/ace.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/ace.min.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/app.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/app.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/dagre-d3.core.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/dagre-d3.core.min.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/dagre.core.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/dagre.core.min.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/graphlib.core.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/graphlib.core.min.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/mode-sql.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/mode-sql.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/mode-yql.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/mode-yql.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/theme-tomorrow.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/theme-tomorrow.min.js -) diff --git a/ydb/library/yql/tools/yqlrun/http/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/tools/yqlrun/http/CMakeLists.darwin-x86_64.txt index 47268f2584ae..d1f24d7c378f 100644 --- a/ydb/library/yql/tools/yqlrun/http/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/tools/yqlrun/http/CMakeLists.darwin-x86_64.txt @@ -44,51 +44,3 @@ target_sources(tools-yqlrun-http PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/yql_servlet.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/yql_server.cpp ) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/bower.json - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/bower.json -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/favicon.ico - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/favicon.ico -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/file-index.html - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/file-index.html -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/css/base.css - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/css/base.css -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/ace.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/ace.min.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/app.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/app.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/dagre-d3.core.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/dagre-d3.core.min.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/dagre.core.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/dagre.core.min.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/graphlib.core.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/graphlib.core.min.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/mode-sql.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/mode-sql.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/mode-yql.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/mode-yql.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/theme-tomorrow.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/theme-tomorrow.min.js -) diff --git a/ydb/library/yql/tools/yqlrun/http/CMakeLists.linux-aarch64.txt b/ydb/library/yql/tools/yqlrun/http/CMakeLists.linux-aarch64.txt index 12516cb5055c..6b038befd0dc 100644 --- a/ydb/library/yql/tools/yqlrun/http/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/tools/yqlrun/http/CMakeLists.linux-aarch64.txt @@ -45,51 +45,3 @@ target_sources(tools-yqlrun-http PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/yql_servlet.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/yql_server.cpp ) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/bower.json - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/bower.json -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/favicon.ico - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/favicon.ico -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/file-index.html - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/file-index.html -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/css/base.css - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/css/base.css -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/ace.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/ace.min.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/app.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/app.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/dagre-d3.core.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/dagre-d3.core.min.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/dagre.core.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/dagre.core.min.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/graphlib.core.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/graphlib.core.min.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/mode-sql.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/mode-sql.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/mode-yql.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/mode-yql.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/theme-tomorrow.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/theme-tomorrow.min.js -) diff --git a/ydb/library/yql/tools/yqlrun/http/CMakeLists.linux-x86_64.txt b/ydb/library/yql/tools/yqlrun/http/CMakeLists.linux-x86_64.txt index 12516cb5055c..6b038befd0dc 100644 --- a/ydb/library/yql/tools/yqlrun/http/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/tools/yqlrun/http/CMakeLists.linux-x86_64.txt @@ -45,51 +45,3 @@ target_sources(tools-yqlrun-http PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/yql_servlet.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/yql_server.cpp ) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/bower.json - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/bower.json -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/favicon.ico - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/favicon.ico -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/file-index.html - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/file-index.html -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/css/base.css - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/css/base.css -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/ace.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/ace.min.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/app.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/app.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/dagre-d3.core.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/dagre-d3.core.min.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/dagre.core.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/dagre.core.min.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/graphlib.core.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/graphlib.core.min.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/mode-sql.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/mode-sql.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/mode-yql.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/mode-yql.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/theme-tomorrow.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/theme-tomorrow.min.js -) diff --git a/ydb/library/yql/tools/yqlrun/http/CMakeLists.windows-x86_64.txt b/ydb/library/yql/tools/yqlrun/http/CMakeLists.windows-x86_64.txt index 47268f2584ae..d1f24d7c378f 100644 --- a/ydb/library/yql/tools/yqlrun/http/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/tools/yqlrun/http/CMakeLists.windows-x86_64.txt @@ -44,51 +44,3 @@ target_sources(tools-yqlrun-http PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/yql_servlet.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/yql_server.cpp ) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/bower.json - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/bower.json -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/favicon.ico - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/favicon.ico -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/file-index.html - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/file-index.html -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/css/base.css - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/css/base.css -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/ace.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/ace.min.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/app.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/app.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/dagre-d3.core.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/dagre-d3.core.min.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/dagre.core.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/dagre.core.min.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/graphlib.core.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/graphlib.core.min.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/mode-sql.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/mode-sql.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/mode-yql.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/mode-yql.js -) -copy_file( - ${CMAKE_SOURCE_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/theme-tomorrow.min.js - ${CMAKE_BINARY_DIR}/ydb/library/yql/tools/yqlrun/http/www/js/theme-tomorrow.min.js -) diff --git a/ydb/library/yql/udfs/common/clickhouse/client/CMakeLists.darwin-arm64.txt b/ydb/library/yql/udfs/common/clickhouse/client/CMakeLists.darwin-arm64.txt index 01c796b5a3eb..fb1a43c32206 100644 --- a/ydb/library/yql/udfs/common/clickhouse/client/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/udfs/common/clickhouse/client/CMakeLists.darwin-arm64.txt @@ -524,8 +524,6 @@ target_link_options(clickhouse_client_udf.dyn PRIVATE -undefined dynamic_lookup -fPIC - -framework - CoreFoundation ) target_sources(clickhouse_client_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/clickhouse/client/clickhouse_client_udf.cpp diff --git a/ydb/library/yql/udfs/common/clickhouse/client/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/udfs/common/clickhouse/client/CMakeLists.darwin-x86_64.txt index 01c796b5a3eb..fb1a43c32206 100644 --- a/ydb/library/yql/udfs/common/clickhouse/client/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/udfs/common/clickhouse/client/CMakeLists.darwin-x86_64.txt @@ -524,8 +524,6 @@ target_link_options(clickhouse_client_udf.dyn PRIVATE -undefined dynamic_lookup -fPIC - -framework - CoreFoundation ) target_sources(clickhouse_client_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/clickhouse/client/clickhouse_client_udf.cpp diff --git a/ydb/library/yql/udfs/common/clickhouse/client/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/clickhouse/client/CMakeLists.linux-aarch64.txt index 70d8d1a13944..c3b96845690f 100644 --- a/ydb/library/yql/udfs/common/clickhouse/client/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/clickhouse/client/CMakeLists.linux-aarch64.txt @@ -529,9 +529,6 @@ target_link_options(clickhouse_client_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(clickhouse_client_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/clickhouse/client/clickhouse_client_udf.cpp diff --git a/ydb/library/yql/udfs/common/clickhouse/client/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/clickhouse/client/CMakeLists.linux-x86_64.txt index 70d8d1a13944..c3b96845690f 100644 --- a/ydb/library/yql/udfs/common/clickhouse/client/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/clickhouse/client/CMakeLists.linux-x86_64.txt @@ -529,9 +529,6 @@ target_link_options(clickhouse_client_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(clickhouse_client_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/clickhouse/client/clickhouse_client_udf.cpp diff --git a/ydb/library/yql/udfs/common/compress_base/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/compress_base/CMakeLists.linux-aarch64.txt index ef6f71bda19e..11b349069b09 100644 --- a/ydb/library/yql/udfs/common/compress_base/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/compress_base/CMakeLists.linux-aarch64.txt @@ -62,9 +62,6 @@ target_link_options(compress_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(compress_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/compress_base/compress_udf.cpp diff --git a/ydb/library/yql/udfs/common/compress_base/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/compress_base/CMakeLists.linux-x86_64.txt index ef6f71bda19e..11b349069b09 100644 --- a/ydb/library/yql/udfs/common/compress_base/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/compress_base/CMakeLists.linux-x86_64.txt @@ -62,9 +62,6 @@ target_link_options(compress_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(compress_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/compress_base/compress_udf.cpp diff --git a/ydb/library/yql/udfs/common/datetime/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/datetime/CMakeLists.linux-aarch64.txt index 38d475c85fa3..4347f1937bcd 100644 --- a/ydb/library/yql/udfs/common/datetime/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/datetime/CMakeLists.linux-aarch64.txt @@ -64,9 +64,6 @@ target_link_options(datetime_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(datetime_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/datetime/datetime_udf.cpp diff --git a/ydb/library/yql/udfs/common/datetime/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/datetime/CMakeLists.linux-x86_64.txt index 38d475c85fa3..4347f1937bcd 100644 --- a/ydb/library/yql/udfs/common/datetime/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/datetime/CMakeLists.linux-x86_64.txt @@ -64,9 +64,6 @@ target_link_options(datetime_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(datetime_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/datetime/datetime_udf.cpp diff --git a/ydb/library/yql/udfs/common/datetime2/CMakeLists.darwin-arm64.txt b/ydb/library/yql/udfs/common/datetime2/CMakeLists.darwin-arm64.txt index a4d4d342741c..4030e300f40f 100644 --- a/ydb/library/yql/udfs/common/datetime2/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/udfs/common/datetime2/CMakeLists.darwin-arm64.txt @@ -68,8 +68,6 @@ target_link_options(datetime2_udf.dyn PRIVATE -undefined dynamic_lookup -fPIC - -framework - CoreFoundation ) target_sources(datetime2_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/datetime2/datetime_udf.cpp diff --git a/ydb/library/yql/udfs/common/datetime2/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/udfs/common/datetime2/CMakeLists.darwin-x86_64.txt index a4d4d342741c..4030e300f40f 100644 --- a/ydb/library/yql/udfs/common/datetime2/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/udfs/common/datetime2/CMakeLists.darwin-x86_64.txt @@ -68,8 +68,6 @@ target_link_options(datetime2_udf.dyn PRIVATE -undefined dynamic_lookup -fPIC - -framework - CoreFoundation ) target_sources(datetime2_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/datetime2/datetime_udf.cpp diff --git a/ydb/library/yql/udfs/common/datetime2/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/datetime2/CMakeLists.linux-aarch64.txt index 166ca178103d..316300fd6d97 100644 --- a/ydb/library/yql/udfs/common/datetime2/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/datetime2/CMakeLists.linux-aarch64.txt @@ -73,9 +73,6 @@ target_link_options(datetime2_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(datetime2_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/datetime2/datetime_udf.cpp diff --git a/ydb/library/yql/udfs/common/datetime2/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/datetime2/CMakeLists.linux-x86_64.txt index 166ca178103d..316300fd6d97 100644 --- a/ydb/library/yql/udfs/common/datetime2/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/datetime2/CMakeLists.linux-x86_64.txt @@ -73,9 +73,6 @@ target_link_options(datetime2_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(datetime2_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/datetime2/datetime_udf.cpp diff --git a/ydb/library/yql/udfs/common/digest/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/digest/CMakeLists.linux-aarch64.txt index b87acb48be39..0d16b8e05fd0 100644 --- a/ydb/library/yql/udfs/common/digest/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/digest/CMakeLists.linux-aarch64.txt @@ -91,9 +91,6 @@ target_link_options(digest_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(digest_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/digest/digest_udf.cpp diff --git a/ydb/library/yql/udfs/common/digest/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/digest/CMakeLists.linux-x86_64.txt index b87acb48be39..0d16b8e05fd0 100644 --- a/ydb/library/yql/udfs/common/digest/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/digest/CMakeLists.linux-x86_64.txt @@ -91,9 +91,6 @@ target_link_options(digest_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(digest_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/digest/digest_udf.cpp diff --git a/ydb/library/yql/udfs/common/file/CMakeLists.darwin-arm64.txt b/ydb/library/yql/udfs/common/file/CMakeLists.darwin-arm64.txt index a5093aaeef3f..7d5029603cd5 100644 --- a/ydb/library/yql/udfs/common/file/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/udfs/common/file/CMakeLists.darwin-arm64.txt @@ -30,8 +30,6 @@ target_link_options(file_udf.dyn PRIVATE -undefined dynamic_lookup -fPIC - -framework - CoreFoundation ) target_sources(file_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/file/file_udf.cpp diff --git a/ydb/library/yql/udfs/common/file/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/udfs/common/file/CMakeLists.darwin-x86_64.txt index a5093aaeef3f..7d5029603cd5 100644 --- a/ydb/library/yql/udfs/common/file/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/udfs/common/file/CMakeLists.darwin-x86_64.txt @@ -30,8 +30,6 @@ target_link_options(file_udf.dyn PRIVATE -undefined dynamic_lookup -fPIC - -framework - CoreFoundation ) target_sources(file_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/file/file_udf.cpp diff --git a/ydb/library/yql/udfs/common/file/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/file/CMakeLists.linux-aarch64.txt index e9410d24a01b..e40207692a87 100644 --- a/ydb/library/yql/udfs/common/file/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/file/CMakeLists.linux-aarch64.txt @@ -33,9 +33,6 @@ target_link_options(file_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(file_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/file/file_udf.cpp diff --git a/ydb/library/yql/udfs/common/file/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/file/CMakeLists.linux-x86_64.txt index e9410d24a01b..e40207692a87 100644 --- a/ydb/library/yql/udfs/common/file/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/file/CMakeLists.linux-x86_64.txt @@ -33,9 +33,6 @@ target_link_options(file_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(file_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/file/file_udf.cpp diff --git a/ydb/library/yql/udfs/common/histogram/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/histogram/CMakeLists.linux-aarch64.txt index bd397b46765a..b12cd2b823cf 100644 --- a/ydb/library/yql/udfs/common/histogram/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/histogram/CMakeLists.linux-aarch64.txt @@ -61,9 +61,6 @@ target_link_options(histogram_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(histogram_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/histogram/histogram_udf.cpp diff --git a/ydb/library/yql/udfs/common/histogram/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/histogram/CMakeLists.linux-x86_64.txt index bd397b46765a..b12cd2b823cf 100644 --- a/ydb/library/yql/udfs/common/histogram/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/histogram/CMakeLists.linux-x86_64.txt @@ -61,9 +61,6 @@ target_link_options(histogram_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(histogram_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/histogram/histogram_udf.cpp diff --git a/ydb/library/yql/udfs/common/hyperloglog/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/hyperloglog/CMakeLists.linux-aarch64.txt index 93cc7a37063f..93eac0cd4a94 100644 --- a/ydb/library/yql/udfs/common/hyperloglog/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/hyperloglog/CMakeLists.linux-aarch64.txt @@ -61,9 +61,6 @@ target_link_options(hyperloglog_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(hyperloglog_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/hyperloglog/hyperloglog_udf.cpp diff --git a/ydb/library/yql/udfs/common/hyperloglog/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/hyperloglog/CMakeLists.linux-x86_64.txt index 93cc7a37063f..93eac0cd4a94 100644 --- a/ydb/library/yql/udfs/common/hyperloglog/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/hyperloglog/CMakeLists.linux-x86_64.txt @@ -61,9 +61,6 @@ target_link_options(hyperloglog_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(hyperloglog_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/hyperloglog/hyperloglog_udf.cpp diff --git a/ydb/library/yql/udfs/common/hyperscan/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/hyperscan/CMakeLists.linux-x86_64.txt index 18cf2b78c938..858d4fff9347 100644 --- a/ydb/library/yql/udfs/common/hyperscan/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/hyperscan/CMakeLists.linux-x86_64.txt @@ -64,9 +64,6 @@ target_link_options(hyperscan_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(hyperscan_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/hyperscan/hyperscan_udf.cpp diff --git a/ydb/library/yql/udfs/common/ip_base/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/ip_base/CMakeLists.linux-aarch64.txt index f868a2ec44ea..75d6e5598aa0 100644 --- a/ydb/library/yql/udfs/common/ip_base/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/ip_base/CMakeLists.linux-aarch64.txt @@ -62,9 +62,6 @@ target_link_options(ip_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(ip_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/ip_base/ip_base.cpp diff --git a/ydb/library/yql/udfs/common/ip_base/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/ip_base/CMakeLists.linux-x86_64.txt index f868a2ec44ea..75d6e5598aa0 100644 --- a/ydb/library/yql/udfs/common/ip_base/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/ip_base/CMakeLists.linux-x86_64.txt @@ -62,9 +62,6 @@ target_link_options(ip_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(ip_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/ip_base/ip_base.cpp diff --git a/ydb/library/yql/udfs/common/ip_base/lib/CMakeLists.darwin-arm64.txt b/ydb/library/yql/udfs/common/ip_base/lib/CMakeLists.darwin-arm64.txt index 5c41eeae1a4c..b17eecc1e1cc 100644 --- a/ydb/library/yql/udfs/common/ip_base/lib/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/udfs/common/ip_base/lib/CMakeLists.darwin-arm64.txt @@ -17,6 +17,8 @@ target_link_libraries(common-ip_base-lib PUBLIC contrib-libs-cxxsupp yutil yql-public-udf + library-cpp-ipmath + library-cpp-ipv6_address ) target_sources(common-ip_base-lib PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/ip_base/lib/ip_base_udf.cpp diff --git a/ydb/library/yql/udfs/common/ip_base/lib/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/udfs/common/ip_base/lib/CMakeLists.darwin-x86_64.txt index 5c41eeae1a4c..b17eecc1e1cc 100644 --- a/ydb/library/yql/udfs/common/ip_base/lib/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/udfs/common/ip_base/lib/CMakeLists.darwin-x86_64.txt @@ -17,6 +17,8 @@ target_link_libraries(common-ip_base-lib PUBLIC contrib-libs-cxxsupp yutil yql-public-udf + library-cpp-ipmath + library-cpp-ipv6_address ) target_sources(common-ip_base-lib PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/ip_base/lib/ip_base_udf.cpp diff --git a/ydb/library/yql/udfs/common/ip_base/lib/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/ip_base/lib/CMakeLists.linux-aarch64.txt index 347d03fbe00d..01d3cf22b141 100644 --- a/ydb/library/yql/udfs/common/ip_base/lib/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/ip_base/lib/CMakeLists.linux-aarch64.txt @@ -18,6 +18,8 @@ target_link_libraries(common-ip_base-lib PUBLIC contrib-libs-cxxsupp yutil yql-public-udf + library-cpp-ipmath + library-cpp-ipv6_address ) target_sources(common-ip_base-lib PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/ip_base/lib/ip_base_udf.cpp diff --git a/ydb/library/yql/udfs/common/ip_base/lib/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/ip_base/lib/CMakeLists.linux-x86_64.txt index 347d03fbe00d..01d3cf22b141 100644 --- a/ydb/library/yql/udfs/common/ip_base/lib/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/ip_base/lib/CMakeLists.linux-x86_64.txt @@ -18,6 +18,8 @@ target_link_libraries(common-ip_base-lib PUBLIC contrib-libs-cxxsupp yutil yql-public-udf + library-cpp-ipmath + library-cpp-ipv6_address ) target_sources(common-ip_base-lib PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/ip_base/lib/ip_base_udf.cpp diff --git a/ydb/library/yql/udfs/common/ip_base/lib/CMakeLists.windows-x86_64.txt b/ydb/library/yql/udfs/common/ip_base/lib/CMakeLists.windows-x86_64.txt index 5c41eeae1a4c..b17eecc1e1cc 100644 --- a/ydb/library/yql/udfs/common/ip_base/lib/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/udfs/common/ip_base/lib/CMakeLists.windows-x86_64.txt @@ -17,6 +17,8 @@ target_link_libraries(common-ip_base-lib PUBLIC contrib-libs-cxxsupp yutil yql-public-udf + library-cpp-ipmath + library-cpp-ipv6_address ) target_sources(common-ip_base-lib PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/ip_base/lib/ip_base_udf.cpp diff --git a/ydb/library/yql/udfs/common/json/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/json/CMakeLists.linux-aarch64.txt index 62f5b11617cc..6fe03bbdad86 100644 --- a/ydb/library/yql/udfs/common/json/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/json/CMakeLists.linux-aarch64.txt @@ -61,9 +61,6 @@ target_link_options(json_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(json_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/json/json_udf.cpp diff --git a/ydb/library/yql/udfs/common/json/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/json/CMakeLists.linux-x86_64.txt index 62f5b11617cc..6fe03bbdad86 100644 --- a/ydb/library/yql/udfs/common/json/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/json/CMakeLists.linux-x86_64.txt @@ -61,9 +61,6 @@ target_link_options(json_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(json_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/json/json_udf.cpp diff --git a/ydb/library/yql/udfs/common/json2/CMakeLists.darwin-arm64.txt b/ydb/library/yql/udfs/common/json2/CMakeLists.darwin-arm64.txt index a952f4ce4613..5b1dd9dbeba2 100644 --- a/ydb/library/yql/udfs/common/json2/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/udfs/common/json2/CMakeLists.darwin-arm64.txt @@ -62,8 +62,6 @@ target_link_options(json2_udf.dyn PRIVATE -undefined dynamic_lookup -fPIC - -framework - CoreFoundation ) target_sources(json2_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/json2/json2_udf.cpp diff --git a/ydb/library/yql/udfs/common/json2/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/udfs/common/json2/CMakeLists.darwin-x86_64.txt index a952f4ce4613..5b1dd9dbeba2 100644 --- a/ydb/library/yql/udfs/common/json2/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/udfs/common/json2/CMakeLists.darwin-x86_64.txt @@ -62,8 +62,6 @@ target_link_options(json2_udf.dyn PRIVATE -undefined dynamic_lookup -fPIC - -framework - CoreFoundation ) target_sources(json2_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/json2/json2_udf.cpp diff --git a/ydb/library/yql/udfs/common/json2/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/json2/CMakeLists.linux-aarch64.txt index cfc0cea2b1a8..16b4532aec76 100644 --- a/ydb/library/yql/udfs/common/json2/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/json2/CMakeLists.linux-aarch64.txt @@ -67,9 +67,6 @@ target_link_options(json2_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(json2_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/json2/json2_udf.cpp diff --git a/ydb/library/yql/udfs/common/json2/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/json2/CMakeLists.linux-x86_64.txt index cfc0cea2b1a8..16b4532aec76 100644 --- a/ydb/library/yql/udfs/common/json2/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/json2/CMakeLists.linux-x86_64.txt @@ -67,9 +67,6 @@ target_link_options(json2_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(json2_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/json2/json2_udf.cpp diff --git a/ydb/library/yql/udfs/common/math/CMakeLists.darwin-arm64.txt b/ydb/library/yql/udfs/common/math/CMakeLists.darwin-arm64.txt index 22a9599041de..fe5d0146f5a5 100644 --- a/ydb/library/yql/udfs/common/math/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/udfs/common/math/CMakeLists.darwin-arm64.txt @@ -7,18 +7,6 @@ add_subdirectory(lib) -get_built_tool_path( - TOOL_rescompiler_bin - TOOL_rescompiler_dependency - tools/rescompiler/bin - rescompiler -) -get_built_tool_path( - TOOL_rescompiler_bin - TOOL_rescompiler_dependency - tools/rescompiler/bin - rescompiler -) add_library(math_udf INTERFACE) target_link_libraries(math_udf INTERFACE @@ -27,7 +15,6 @@ target_link_libraries(math_udf INTERFACE yql-public-udf public-udf-support common-math-lib - library-cpp-resource ) add_global_library_for(math_udf.global math_udf) @@ -42,58 +29,9 @@ target_link_libraries(math_udf.global PUBLIC yql-public-udf public-udf-support common-math-lib - library-cpp-resource ) target_sources(math_udf.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/math_udf.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/d7ae26bd65dd2aef1aa80f78b00c6984.cpp -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.udfs.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.udfs.bc - COMMAND - ${LLVMOPT} - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.udfs.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.udfs.bc - -internalize-public-api-list=PiIR#EIR#EpsIR#RoundDownwardIR#RoundToNearestIR#RoundTowardZeroIR#RoundUpwardIR#AbsIR#AcosIR#AsinIR#AsinhIR#AtanIR#CbrtIR#CeilIR#CosIR#CoshIR#ErfIR#ErfInvIR#ErfcInvIR#ExpIR#Exp2IR#FabsIR#FloorIR#LgammaIR#RintIR#SinIR#SinhIR#SqrtIR#TanIR#TanhIR#TgammaIR#TruncIR#IsFiniteIR#IsInfIR#IsNaNIR#Atan2IR#FmodIR#HypotIR#RemainderIR#PowIR#LdexpIR#LogIR#Log2IR#Log10IR#SigmoidIR#FuzzyEqualsIR#RoundIR#ModIR#RemIR - -passes="default,globalopt,globaldce,internalize" -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.udfs.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.udfs.bc - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.udfs.bc - COMMAND - ${LLVMLINK} - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.udfs.bc - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.udfs.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.udfs.bc -) -llvm_compile_cxx(math_udf.global - ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.udfs.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -llvm_compile_cxx(math_udf.global - ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.udfs.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -resources(math_udf.global - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/d7ae26bd65dd2aef1aa80f78b00c6984.cpp - INPUTS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.udfs.bc - KEYS - /llvm_bc/Math ) add_shared_library(math_udf.dyn) @@ -112,7 +50,6 @@ target_link_libraries(math_udf.dyn PUBLIC yql-public-udf public-udf-support common-math-lib - library-cpp-resource ) target_link_options(math_udf.dyn PRIVATE -Wl,-platform_version,macos,11.0,11.0 @@ -123,54 +60,6 @@ target_link_options(math_udf.dyn PRIVATE ) target_sources(math_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/math_udf.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/e16170b202418194bf58dc2778af9bd8.cpp -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.bc - COMMAND - ${LLVMOPT} - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.bc - -internalize-public-api-list=PiIR#EIR#EpsIR#RoundDownwardIR#RoundToNearestIR#RoundTowardZeroIR#RoundUpwardIR#AbsIR#AcosIR#AsinIR#AsinhIR#AtanIR#CbrtIR#CeilIR#CosIR#CoshIR#ErfIR#ErfInvIR#ErfcInvIR#ExpIR#Exp2IR#FabsIR#FloorIR#LgammaIR#RintIR#SinIR#SinhIR#SqrtIR#TanIR#TanhIR#TgammaIR#TruncIR#IsFiniteIR#IsInfIR#IsNaNIR#Atan2IR#FmodIR#HypotIR#RemainderIR#PowIR#LdexpIR#LogIR#Log2IR#Log10IR#SigmoidIR#FuzzyEqualsIR#RoundIR#ModIR#RemIR - -passes="default,globalopt,globaldce,internalize" -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.bc - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.bc - COMMAND - ${LLVMLINK} - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.bc - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.bc -) -llvm_compile_cxx(math_udf.dyn - ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -llvm_compile_cxx(math_udf.dyn - ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -resources(math_udf.dyn - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/e16170b202418194bf58dc2778af9bd8.cpp - INPUTS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.bc - KEYS - /llvm_bc/Math ) use_export_script(math_udf.dyn ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udfs_exports.exports diff --git a/ydb/library/yql/udfs/common/math/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/udfs/common/math/CMakeLists.darwin-x86_64.txt index 22a9599041de..fe5d0146f5a5 100644 --- a/ydb/library/yql/udfs/common/math/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/udfs/common/math/CMakeLists.darwin-x86_64.txt @@ -7,18 +7,6 @@ add_subdirectory(lib) -get_built_tool_path( - TOOL_rescompiler_bin - TOOL_rescompiler_dependency - tools/rescompiler/bin - rescompiler -) -get_built_tool_path( - TOOL_rescompiler_bin - TOOL_rescompiler_dependency - tools/rescompiler/bin - rescompiler -) add_library(math_udf INTERFACE) target_link_libraries(math_udf INTERFACE @@ -27,7 +15,6 @@ target_link_libraries(math_udf INTERFACE yql-public-udf public-udf-support common-math-lib - library-cpp-resource ) add_global_library_for(math_udf.global math_udf) @@ -42,58 +29,9 @@ target_link_libraries(math_udf.global PUBLIC yql-public-udf public-udf-support common-math-lib - library-cpp-resource ) target_sources(math_udf.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/math_udf.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/d7ae26bd65dd2aef1aa80f78b00c6984.cpp -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.udfs.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.udfs.bc - COMMAND - ${LLVMOPT} - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.udfs.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.udfs.bc - -internalize-public-api-list=PiIR#EIR#EpsIR#RoundDownwardIR#RoundToNearestIR#RoundTowardZeroIR#RoundUpwardIR#AbsIR#AcosIR#AsinIR#AsinhIR#AtanIR#CbrtIR#CeilIR#CosIR#CoshIR#ErfIR#ErfInvIR#ErfcInvIR#ExpIR#Exp2IR#FabsIR#FloorIR#LgammaIR#RintIR#SinIR#SinhIR#SqrtIR#TanIR#TanhIR#TgammaIR#TruncIR#IsFiniteIR#IsInfIR#IsNaNIR#Atan2IR#FmodIR#HypotIR#RemainderIR#PowIR#LdexpIR#LogIR#Log2IR#Log10IR#SigmoidIR#FuzzyEqualsIR#RoundIR#ModIR#RemIR - -passes="default,globalopt,globaldce,internalize" -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.udfs.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.udfs.bc - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.udfs.bc - COMMAND - ${LLVMLINK} - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.udfs.bc - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.udfs.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.udfs.bc -) -llvm_compile_cxx(math_udf.global - ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.udfs.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -llvm_compile_cxx(math_udf.global - ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.udfs.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -resources(math_udf.global - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/d7ae26bd65dd2aef1aa80f78b00c6984.cpp - INPUTS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.udfs.bc - KEYS - /llvm_bc/Math ) add_shared_library(math_udf.dyn) @@ -112,7 +50,6 @@ target_link_libraries(math_udf.dyn PUBLIC yql-public-udf public-udf-support common-math-lib - library-cpp-resource ) target_link_options(math_udf.dyn PRIVATE -Wl,-platform_version,macos,11.0,11.0 @@ -123,54 +60,6 @@ target_link_options(math_udf.dyn PRIVATE ) target_sources(math_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/math_udf.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/e16170b202418194bf58dc2778af9bd8.cpp -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.bc - COMMAND - ${LLVMOPT} - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.bc - -internalize-public-api-list=PiIR#EIR#EpsIR#RoundDownwardIR#RoundToNearestIR#RoundTowardZeroIR#RoundUpwardIR#AbsIR#AcosIR#AsinIR#AsinhIR#AtanIR#CbrtIR#CeilIR#CosIR#CoshIR#ErfIR#ErfInvIR#ErfcInvIR#ExpIR#Exp2IR#FabsIR#FloorIR#LgammaIR#RintIR#SinIR#SinhIR#SqrtIR#TanIR#TanhIR#TgammaIR#TruncIR#IsFiniteIR#IsInfIR#IsNaNIR#Atan2IR#FmodIR#HypotIR#RemainderIR#PowIR#LdexpIR#LogIR#Log2IR#Log10IR#SigmoidIR#FuzzyEqualsIR#RoundIR#ModIR#RemIR - -passes="default,globalopt,globaldce,internalize" -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.bc - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.bc - COMMAND - ${LLVMLINK} - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.bc - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.bc -) -llvm_compile_cxx(math_udf.dyn - ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -llvm_compile_cxx(math_udf.dyn - ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -resources(math_udf.dyn - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/e16170b202418194bf58dc2778af9bd8.cpp - INPUTS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.bc - KEYS - /llvm_bc/Math ) use_export_script(math_udf.dyn ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udfs_exports.exports diff --git a/ydb/library/yql/udfs/common/math/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/math/CMakeLists.linux-aarch64.txt index 07c4251d6169..e96164d76693 100644 --- a/ydb/library/yql/udfs/common/math/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/math/CMakeLists.linux-aarch64.txt @@ -7,18 +7,6 @@ add_subdirectory(lib) -get_built_tool_path( - TOOL_rescompiler_bin - TOOL_rescompiler_dependency - tools/rescompiler/bin - rescompiler -) -get_built_tool_path( - TOOL_rescompiler_bin - TOOL_rescompiler_dependency - tools/rescompiler/bin - rescompiler -) add_library(math_udf INTERFACE) target_link_libraries(math_udf INTERFACE @@ -28,7 +16,6 @@ target_link_libraries(math_udf INTERFACE yql-public-udf public-udf-support common-math-lib - library-cpp-resource ) add_global_library_for(math_udf.global math_udf) @@ -44,58 +31,9 @@ target_link_libraries(math_udf.global PUBLIC yql-public-udf public-udf-support common-math-lib - library-cpp-resource ) target_sources(math_udf.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/math_udf.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/d7ae26bd65dd2aef1aa80f78b00c6984.cpp -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.udfs.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.udfs.bc - COMMAND - ${LLVMOPT} - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.udfs.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.udfs.bc - -internalize-public-api-list=PiIR#EIR#EpsIR#RoundDownwardIR#RoundToNearestIR#RoundTowardZeroIR#RoundUpwardIR#AbsIR#AcosIR#AsinIR#AsinhIR#AtanIR#CbrtIR#CeilIR#CosIR#CoshIR#ErfIR#ErfInvIR#ErfcInvIR#ExpIR#Exp2IR#FabsIR#FloorIR#LgammaIR#RintIR#SinIR#SinhIR#SqrtIR#TanIR#TanhIR#TgammaIR#TruncIR#IsFiniteIR#IsInfIR#IsNaNIR#Atan2IR#FmodIR#HypotIR#RemainderIR#PowIR#LdexpIR#LogIR#Log2IR#Log10IR#SigmoidIR#FuzzyEqualsIR#RoundIR#ModIR#RemIR - -passes="default,globalopt,globaldce,internalize" -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.udfs.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.udfs.bc - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.udfs.bc - COMMAND - ${LLVMLINK} - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.udfs.bc - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.udfs.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.udfs.bc -) -llvm_compile_cxx(math_udf.global - ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.udfs.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -llvm_compile_cxx(math_udf.global - ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.udfs.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -resources(math_udf.global - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/d7ae26bd65dd2aef1aa80f78b00c6984.cpp - INPUTS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.udfs.bc - KEYS - /llvm_bc/Math ) add_shared_library(math_udf.dyn) @@ -115,7 +53,6 @@ target_link_libraries(math_udf.dyn PUBLIC yql-public-udf public-udf-support common-math-lib - library-cpp-resource ) target_link_options(math_udf.dyn PRIVATE -ldl @@ -125,60 +62,9 @@ target_link_options(math_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(math_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/math_udf.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/e16170b202418194bf58dc2778af9bd8.cpp -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.bc - COMMAND - ${LLVMOPT} - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.bc - -internalize-public-api-list=PiIR#EIR#EpsIR#RoundDownwardIR#RoundToNearestIR#RoundTowardZeroIR#RoundUpwardIR#AbsIR#AcosIR#AsinIR#AsinhIR#AtanIR#CbrtIR#CeilIR#CosIR#CoshIR#ErfIR#ErfInvIR#ErfcInvIR#ExpIR#Exp2IR#FabsIR#FloorIR#LgammaIR#RintIR#SinIR#SinhIR#SqrtIR#TanIR#TanhIR#TgammaIR#TruncIR#IsFiniteIR#IsInfIR#IsNaNIR#Atan2IR#FmodIR#HypotIR#RemainderIR#PowIR#LdexpIR#LogIR#Log2IR#Log10IR#SigmoidIR#FuzzyEqualsIR#RoundIR#ModIR#RemIR - -passes="default,globalopt,globaldce,internalize" -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.bc - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.bc - COMMAND - ${LLVMLINK} - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.bc - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.bc -) -llvm_compile_cxx(math_udf.dyn - ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -llvm_compile_cxx(math_udf.dyn - ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -resources(math_udf.dyn - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/e16170b202418194bf58dc2778af9bd8.cpp - INPUTS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.bc - KEYS - /llvm_bc/Math ) use_export_script(math_udf.dyn ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udfs_exports.exports diff --git a/ydb/library/yql/udfs/common/math/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/math/CMakeLists.linux-x86_64.txt index 07c4251d6169..e96164d76693 100644 --- a/ydb/library/yql/udfs/common/math/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/math/CMakeLists.linux-x86_64.txt @@ -7,18 +7,6 @@ add_subdirectory(lib) -get_built_tool_path( - TOOL_rescompiler_bin - TOOL_rescompiler_dependency - tools/rescompiler/bin - rescompiler -) -get_built_tool_path( - TOOL_rescompiler_bin - TOOL_rescompiler_dependency - tools/rescompiler/bin - rescompiler -) add_library(math_udf INTERFACE) target_link_libraries(math_udf INTERFACE @@ -28,7 +16,6 @@ target_link_libraries(math_udf INTERFACE yql-public-udf public-udf-support common-math-lib - library-cpp-resource ) add_global_library_for(math_udf.global math_udf) @@ -44,58 +31,9 @@ target_link_libraries(math_udf.global PUBLIC yql-public-udf public-udf-support common-math-lib - library-cpp-resource ) target_sources(math_udf.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/math_udf.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/d7ae26bd65dd2aef1aa80f78b00c6984.cpp -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.udfs.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.udfs.bc - COMMAND - ${LLVMOPT} - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.udfs.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.udfs.bc - -internalize-public-api-list=PiIR#EIR#EpsIR#RoundDownwardIR#RoundToNearestIR#RoundTowardZeroIR#RoundUpwardIR#AbsIR#AcosIR#AsinIR#AsinhIR#AtanIR#CbrtIR#CeilIR#CosIR#CoshIR#ErfIR#ErfInvIR#ErfcInvIR#ExpIR#Exp2IR#FabsIR#FloorIR#LgammaIR#RintIR#SinIR#SinhIR#SqrtIR#TanIR#TanhIR#TgammaIR#TruncIR#IsFiniteIR#IsInfIR#IsNaNIR#Atan2IR#FmodIR#HypotIR#RemainderIR#PowIR#LdexpIR#LogIR#Log2IR#Log10IR#SigmoidIR#FuzzyEqualsIR#RoundIR#ModIR#RemIR - -passes="default,globalopt,globaldce,internalize" -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.udfs.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.udfs.bc - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.udfs.bc - COMMAND - ${LLVMLINK} - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.udfs.bc - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.udfs.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.udfs.bc -) -llvm_compile_cxx(math_udf.global - ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.udfs.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -llvm_compile_cxx(math_udf.global - ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.udfs.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -resources(math_udf.global - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/d7ae26bd65dd2aef1aa80f78b00c6984.cpp - INPUTS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.udfs.bc - KEYS - /llvm_bc/Math ) add_shared_library(math_udf.dyn) @@ -115,7 +53,6 @@ target_link_libraries(math_udf.dyn PUBLIC yql-public-udf public-udf-support common-math-lib - library-cpp-resource ) target_link_options(math_udf.dyn PRIVATE -ldl @@ -125,60 +62,9 @@ target_link_options(math_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(math_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/math_udf.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/e16170b202418194bf58dc2778af9bd8.cpp -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.bc - COMMAND - ${LLVMOPT} - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.bc - -internalize-public-api-list=PiIR#EIR#EpsIR#RoundDownwardIR#RoundToNearestIR#RoundTowardZeroIR#RoundUpwardIR#AbsIR#AcosIR#AsinIR#AsinhIR#AtanIR#CbrtIR#CeilIR#CosIR#CoshIR#ErfIR#ErfInvIR#ErfcInvIR#ExpIR#Exp2IR#FabsIR#FloorIR#LgammaIR#RintIR#SinIR#SinhIR#SqrtIR#TanIR#TanhIR#TgammaIR#TruncIR#IsFiniteIR#IsInfIR#IsNaNIR#Atan2IR#FmodIR#HypotIR#RemainderIR#PowIR#LdexpIR#LogIR#Log2IR#Log10IR#SigmoidIR#FuzzyEqualsIR#RoundIR#ModIR#RemIR - -passes="default,globalopt,globaldce,internalize" -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.bc - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.bc - COMMAND - ${LLVMLINK} - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.bc - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.bc -) -llvm_compile_cxx(math_udf.dyn - ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -llvm_compile_cxx(math_udf.dyn - ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -resources(math_udf.dyn - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/e16170b202418194bf58dc2778af9bd8.cpp - INPUTS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.bc - KEYS - /llvm_bc/Math ) use_export_script(math_udf.dyn ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udfs_exports.exports diff --git a/ydb/library/yql/udfs/common/math/CMakeLists.windows-x86_64.txt b/ydb/library/yql/udfs/common/math/CMakeLists.windows-x86_64.txt index 6fea6a625c3f..ed40e622104e 100644 --- a/ydb/library/yql/udfs/common/math/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/udfs/common/math/CMakeLists.windows-x86_64.txt @@ -7,18 +7,6 @@ add_subdirectory(lib) -get_built_tool_path( - TOOL_rescompiler_bin - TOOL_rescompiler_dependency - tools/rescompiler/bin - rescompiler -) -get_built_tool_path( - TOOL_rescompiler_bin - TOOL_rescompiler_dependency - tools/rescompiler/bin - rescompiler -) add_library(math_udf INTERFACE) target_link_libraries(math_udf INTERFACE @@ -27,7 +15,6 @@ target_link_libraries(math_udf INTERFACE yql-public-udf public-udf-support common-math-lib - library-cpp-resource ) add_global_library_for(math_udf.global math_udf) @@ -42,58 +29,9 @@ target_link_libraries(math_udf.global PUBLIC yql-public-udf public-udf-support common-math-lib - library-cpp-resource ) target_sources(math_udf.global PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/math_udf.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/d7ae26bd65dd2aef1aa80f78b00c6984.cpp -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.udfs.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.udfs.bc - COMMAND - ${LLVMOPT} - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.udfs.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.udfs.bc - -internalize-public-api-list=PiIR#EIR#EpsIR#RoundDownwardIR#RoundToNearestIR#RoundTowardZeroIR#RoundUpwardIR#AbsIR#AcosIR#AsinIR#AsinhIR#AtanIR#CbrtIR#CeilIR#CosIR#CoshIR#ErfIR#ErfInvIR#ErfcInvIR#ExpIR#Exp2IR#FabsIR#FloorIR#LgammaIR#RintIR#SinIR#SinhIR#SqrtIR#TanIR#TanhIR#TgammaIR#TruncIR#IsFiniteIR#IsInfIR#IsNaNIR#Atan2IR#FmodIR#HypotIR#RemainderIR#PowIR#LdexpIR#LogIR#Log2IR#Log10IR#SigmoidIR#FuzzyEqualsIR#RoundIR#ModIR#RemIR - -passes="default,globalopt,globaldce,internalize" -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.udfs.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.udfs.bc - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.udfs.bc - COMMAND - ${LLVMLINK} - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.udfs.bc - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.udfs.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.udfs.bc -) -llvm_compile_cxx(math_udf.global - ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.udfs.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -llvm_compile_cxx(math_udf.global - ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.udfs.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -resources(math_udf.global - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/d7ae26bd65dd2aef1aa80f78b00c6984.cpp - INPUTS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.udfs.bc - KEYS - /llvm_bc/Math ) add_shared_library(math_udf.dyn) @@ -112,58 +50,9 @@ target_link_libraries(math_udf.dyn PUBLIC yql-public-udf public-udf-support common-math-lib - library-cpp-resource ) target_sources(math_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/math_udf.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/e16170b202418194bf58dc2778af9bd8.cpp -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.bc - COMMAND - ${LLVMOPT} - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.bc - -internalize-public-api-list=PiIR#EIR#EpsIR#RoundDownwardIR#RoundToNearestIR#RoundTowardZeroIR#RoundUpwardIR#AbsIR#AcosIR#AsinIR#AsinhIR#AtanIR#CbrtIR#CeilIR#CosIR#CoshIR#ErfIR#ErfInvIR#ErfcInvIR#ExpIR#Exp2IR#FabsIR#FloorIR#LgammaIR#RintIR#SinIR#SinhIR#SqrtIR#TanIR#TanhIR#TgammaIR#TruncIR#IsFiniteIR#IsInfIR#IsNaNIR#Atan2IR#FmodIR#HypotIR#RemainderIR#PowIR#LdexpIR#LogIR#Log2IR#Log10IR#SigmoidIR#FuzzyEqualsIR#RoundIR#ModIR#RemIR - -passes="default,globalopt,globaldce,internalize" -) -add_custom_command( - OUTPUT - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.bc - DEPENDS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.bc - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.bc - COMMAND - ${LLVMLINK} - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.bc - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.bc - -o - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_merged.bc -) -llvm_compile_cxx(math_udf.dyn - ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/math_ir.cpp.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -llvm_compile_cxx(math_udf.dyn - ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/lib/erfinv.cpp.bc - ${CLANGPLUSPLUS} - -Wno-unknown-warning-option - -emit-llvm -) -resources(math_udf.dyn - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/e16170b202418194bf58dc2778af9bd8.cpp - INPUTS - ${CMAKE_BINARY_DIR}/ydb/library/yql/udfs/common/math/Math_optimized.bc - KEYS - /llvm_bc/Math ) use_export_script(math_udf.dyn ${CMAKE_SOURCE_DIR}/ydb/library/yql/public/udf/udfs_exports.exports diff --git a/ydb/library/yql/udfs/common/pire/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/pire/CMakeLists.linux-aarch64.txt index 0e418dabd089..2f8cbc7a9ccf 100644 --- a/ydb/library/yql/udfs/common/pire/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/pire/CMakeLists.linux-aarch64.txt @@ -61,9 +61,6 @@ target_link_options(pire_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(pire_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/pire/pire_udf.cpp diff --git a/ydb/library/yql/udfs/common/pire/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/pire/CMakeLists.linux-x86_64.txt index 0e418dabd089..2f8cbc7a9ccf 100644 --- a/ydb/library/yql/udfs/common/pire/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/pire/CMakeLists.linux-x86_64.txt @@ -61,9 +61,6 @@ target_link_options(pire_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(pire_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/pire/pire_udf.cpp diff --git a/ydb/library/yql/udfs/common/protobuf/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/protobuf/CMakeLists.linux-aarch64.txt index 1fab62cf3061..4f16d9afde8d 100644 --- a/ydb/library/yql/udfs/common/protobuf/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/protobuf/CMakeLists.linux-aarch64.txt @@ -34,9 +34,6 @@ target_link_options(protobuf_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(protobuf_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/protobuf/protobuf_udf.cpp diff --git a/ydb/library/yql/udfs/common/protobuf/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/protobuf/CMakeLists.linux-x86_64.txt index 1fab62cf3061..4f16d9afde8d 100644 --- a/ydb/library/yql/udfs/common/protobuf/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/protobuf/CMakeLists.linux-x86_64.txt @@ -34,9 +34,6 @@ target_link_options(protobuf_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(protobuf_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/protobuf/protobuf_udf.cpp diff --git a/ydb/library/yql/udfs/common/re2/CMakeLists.darwin-arm64.txt b/ydb/library/yql/udfs/common/re2/CMakeLists.darwin-arm64.txt index 4c5d1d039174..64324683819f 100644 --- a/ydb/library/yql/udfs/common/re2/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/udfs/common/re2/CMakeLists.darwin-arm64.txt @@ -59,8 +59,6 @@ target_link_options(re2_udf.dyn PRIVATE -undefined dynamic_lookup -fPIC - -framework - CoreFoundation ) target_sources(re2_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/re2/re2_udf.cpp diff --git a/ydb/library/yql/udfs/common/re2/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/udfs/common/re2/CMakeLists.darwin-x86_64.txt index 4c5d1d039174..64324683819f 100644 --- a/ydb/library/yql/udfs/common/re2/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/udfs/common/re2/CMakeLists.darwin-x86_64.txt @@ -59,8 +59,6 @@ target_link_options(re2_udf.dyn PRIVATE -undefined dynamic_lookup -fPIC - -framework - CoreFoundation ) target_sources(re2_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/re2/re2_udf.cpp diff --git a/ydb/library/yql/udfs/common/re2/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/re2/CMakeLists.linux-aarch64.txt index 21075ec6cfe7..688c9ff4b660 100644 --- a/ydb/library/yql/udfs/common/re2/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/re2/CMakeLists.linux-aarch64.txt @@ -64,9 +64,6 @@ target_link_options(re2_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(re2_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/re2/re2_udf.cpp diff --git a/ydb/library/yql/udfs/common/re2/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/re2/CMakeLists.linux-x86_64.txt index 21075ec6cfe7..688c9ff4b660 100644 --- a/ydb/library/yql/udfs/common/re2/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/re2/CMakeLists.linux-x86_64.txt @@ -64,9 +64,6 @@ target_link_options(re2_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(re2_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/re2/re2_udf.cpp diff --git a/ydb/library/yql/udfs/common/set/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/set/CMakeLists.linux-aarch64.txt index 7dae015a39ac..21f37777dada 100644 --- a/ydb/library/yql/udfs/common/set/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/set/CMakeLists.linux-aarch64.txt @@ -58,9 +58,6 @@ target_link_options(set_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(set_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/set/set_udf.cpp diff --git a/ydb/library/yql/udfs/common/set/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/set/CMakeLists.linux-x86_64.txt index 7dae015a39ac..21f37777dada 100644 --- a/ydb/library/yql/udfs/common/set/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/set/CMakeLists.linux-x86_64.txt @@ -58,9 +58,6 @@ target_link_options(set_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(set_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/set/set_udf.cpp diff --git a/ydb/library/yql/udfs/common/stat/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/stat/CMakeLists.linux-aarch64.txt index 1f56316a8aa8..1516f23daebf 100644 --- a/ydb/library/yql/udfs/common/stat/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/stat/CMakeLists.linux-aarch64.txt @@ -63,9 +63,6 @@ target_link_options(stat_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(stat_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/stat/stat_udf.cpp diff --git a/ydb/library/yql/udfs/common/stat/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/stat/CMakeLists.linux-x86_64.txt index 1f56316a8aa8..1516f23daebf 100644 --- a/ydb/library/yql/udfs/common/stat/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/stat/CMakeLists.linux-x86_64.txt @@ -63,9 +63,6 @@ target_link_options(stat_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(stat_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/stat/stat_udf.cpp diff --git a/ydb/library/yql/udfs/common/stat/static/CMakeLists.darwin-arm64.txt b/ydb/library/yql/udfs/common/stat/static/CMakeLists.darwin-arm64.txt index 7dee63a8c0c9..ed93ef452833 100644 --- a/ydb/library/yql/udfs/common/stat/static/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/udfs/common/stat/static/CMakeLists.darwin-arm64.txt @@ -20,5 +20,6 @@ target_link_libraries(common-stat-static PUBLIC library-cpp-tdigest ) target_sources(common-stat-static PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/stat/static/stat_udf.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/stat/static/static_udf.cpp ) diff --git a/ydb/library/yql/udfs/common/stat/static/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/udfs/common/stat/static/CMakeLists.darwin-x86_64.txt index 7dee63a8c0c9..ed93ef452833 100644 --- a/ydb/library/yql/udfs/common/stat/static/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/udfs/common/stat/static/CMakeLists.darwin-x86_64.txt @@ -20,5 +20,6 @@ target_link_libraries(common-stat-static PUBLIC library-cpp-tdigest ) target_sources(common-stat-static PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/stat/static/stat_udf.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/stat/static/static_udf.cpp ) diff --git a/ydb/library/yql/udfs/common/stat/static/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/stat/static/CMakeLists.linux-aarch64.txt index 9302da9ae4d1..dabe2e6a213f 100644 --- a/ydb/library/yql/udfs/common/stat/static/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/stat/static/CMakeLists.linux-aarch64.txt @@ -21,5 +21,6 @@ target_link_libraries(common-stat-static PUBLIC library-cpp-tdigest ) target_sources(common-stat-static PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/stat/static/stat_udf.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/stat/static/static_udf.cpp ) diff --git a/ydb/library/yql/udfs/common/stat/static/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/stat/static/CMakeLists.linux-x86_64.txt index 9302da9ae4d1..dabe2e6a213f 100644 --- a/ydb/library/yql/udfs/common/stat/static/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/stat/static/CMakeLists.linux-x86_64.txt @@ -21,5 +21,6 @@ target_link_libraries(common-stat-static PUBLIC library-cpp-tdigest ) target_sources(common-stat-static PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/stat/static/stat_udf.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/stat/static/static_udf.cpp ) diff --git a/ydb/library/yql/udfs/common/stat/static/CMakeLists.windows-x86_64.txt b/ydb/library/yql/udfs/common/stat/static/CMakeLists.windows-x86_64.txt index 7dee63a8c0c9..ed93ef452833 100644 --- a/ydb/library/yql/udfs/common/stat/static/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/udfs/common/stat/static/CMakeLists.windows-x86_64.txt @@ -20,5 +20,6 @@ target_link_libraries(common-stat-static PUBLIC library-cpp-tdigest ) target_sources(common-stat-static PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/stat/static/stat_udf.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/stat/static/static_udf.cpp ) diff --git a/ydb/library/yql/udfs/common/stat/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/udfs/common/stat/ut/CMakeLists.darwin-arm64.txt index da941d939b2d..a6892759c505 100644 --- a/ydb/library/yql/udfs/common/stat/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/udfs/common/stat/ut/CMakeLists.darwin-arm64.txt @@ -19,7 +19,7 @@ target_link_libraries(ydb-library-yql-udfs-common-stat-ut PUBLIC yutil cpp-testing-unittest_main common-stat-static - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 udf-service-exception_policy yql-sql-pg_dummy ) @@ -27,8 +27,6 @@ target_link_options(ydb-library-yql-udfs-common-stat-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-udfs-common-stat-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/stat/stat_udf_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/udfs/common/stat/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/udfs/common/stat/ut/CMakeLists.darwin-x86_64.txt index e39ac7c38e40..f90d95bddf7d 100644 --- a/ydb/library/yql/udfs/common/stat/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/udfs/common/stat/ut/CMakeLists.darwin-x86_64.txt @@ -20,7 +20,7 @@ target_link_libraries(ydb-library-yql-udfs-common-stat-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main common-stat-static - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 udf-service-exception_policy yql-sql-pg_dummy ) @@ -28,8 +28,6 @@ target_link_options(ydb-library-yql-udfs-common-stat-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-udfs-common-stat-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/stat/stat_udf_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/udfs/common/stat/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/stat/ut/CMakeLists.linux-aarch64.txt index 4abfa4fc9af7..961b7d57875e 100644 --- a/ydb/library/yql/udfs/common/stat/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/stat/ut/CMakeLists.linux-aarch64.txt @@ -20,7 +20,7 @@ target_link_libraries(ydb-library-yql-udfs-common-stat-ut PUBLIC yutil cpp-testing-unittest_main common-stat-static - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 udf-service-exception_policy yql-sql-pg_dummy ) @@ -30,9 +30,6 @@ target_link_options(ydb-library-yql-udfs-common-stat-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-udfs-common-stat-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/stat/stat_udf_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/udfs/common/stat/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/stat/ut/CMakeLists.linux-x86_64.txt index 3bab713e43b7..4cc3eae66aa1 100644 --- a/ydb/library/yql/udfs/common/stat/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/stat/ut/CMakeLists.linux-x86_64.txt @@ -21,7 +21,7 @@ target_link_libraries(ydb-library-yql-udfs-common-stat-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main common-stat-static - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 udf-service-exception_policy yql-sql-pg_dummy ) @@ -31,9 +31,6 @@ target_link_options(ydb-library-yql-udfs-common-stat-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-udfs-common-stat-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/stat/stat_udf_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/udfs/common/stat/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/udfs/common/stat/ut/CMakeLists.windows-x86_64.txt index a26c302b4d6d..042f38848776 100644 --- a/ydb/library/yql/udfs/common/stat/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/udfs/common/stat/ut/CMakeLists.windows-x86_64.txt @@ -20,7 +20,7 @@ target_link_libraries(ydb-library-yql-udfs-common-stat-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main common-stat-static - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 udf-service-exception_policy yql-sql-pg_dummy ) @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/udfs/common/streaming/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/streaming/CMakeLists.linux-aarch64.txt index c5805213d7b5..18258effa951 100644 --- a/ydb/library/yql/udfs/common/streaming/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/streaming/CMakeLists.linux-aarch64.txt @@ -33,9 +33,6 @@ target_link_options(streaming_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(streaming_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/streaming/streaming_udf.cpp diff --git a/ydb/library/yql/udfs/common/streaming/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/streaming/CMakeLists.linux-x86_64.txt index c5805213d7b5..18258effa951 100644 --- a/ydb/library/yql/udfs/common/streaming/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/streaming/CMakeLists.linux-x86_64.txt @@ -33,9 +33,6 @@ target_link_options(streaming_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(streaming_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/streaming/streaming_udf.cpp diff --git a/ydb/library/yql/udfs/common/string/CMakeLists.darwin-arm64.txt b/ydb/library/yql/udfs/common/string/CMakeLists.darwin-arm64.txt index 93a05508d72c..e3329b889713 100644 --- a/ydb/library/yql/udfs/common/string/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/udfs/common/string/CMakeLists.darwin-arm64.txt @@ -77,8 +77,6 @@ target_link_options(string_udf.dyn PRIVATE -undefined dynamic_lookup -fPIC - -framework - CoreFoundation ) target_sources(string_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/string/string_udf.cpp diff --git a/ydb/library/yql/udfs/common/string/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/udfs/common/string/CMakeLists.darwin-x86_64.txt index 93a05508d72c..e3329b889713 100644 --- a/ydb/library/yql/udfs/common/string/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/udfs/common/string/CMakeLists.darwin-x86_64.txt @@ -77,8 +77,6 @@ target_link_options(string_udf.dyn PRIVATE -undefined dynamic_lookup -fPIC - -framework - CoreFoundation ) target_sources(string_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/string/string_udf.cpp diff --git a/ydb/library/yql/udfs/common/string/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/string/CMakeLists.linux-aarch64.txt index de90a655d0bb..09ba72e1484f 100644 --- a/ydb/library/yql/udfs/common/string/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/string/CMakeLists.linux-aarch64.txt @@ -82,9 +82,6 @@ target_link_options(string_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(string_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/string/string_udf.cpp diff --git a/ydb/library/yql/udfs/common/string/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/string/CMakeLists.linux-x86_64.txt index de90a655d0bb..09ba72e1484f 100644 --- a/ydb/library/yql/udfs/common/string/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/string/CMakeLists.linux-x86_64.txt @@ -82,9 +82,6 @@ target_link_options(string_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(string_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/string/string_udf.cpp diff --git a/ydb/library/yql/udfs/common/top/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/top/CMakeLists.linux-aarch64.txt index 6cfab7c009a8..825a168d3dd4 100644 --- a/ydb/library/yql/udfs/common/top/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/top/CMakeLists.linux-aarch64.txt @@ -61,9 +61,6 @@ target_link_options(top_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(top_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/top/top_udf.cpp diff --git a/ydb/library/yql/udfs/common/top/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/top/CMakeLists.linux-x86_64.txt index 6cfab7c009a8..825a168d3dd4 100644 --- a/ydb/library/yql/udfs/common/top/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/top/CMakeLists.linux-x86_64.txt @@ -61,9 +61,6 @@ target_link_options(top_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(top_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/top/top_udf.cpp diff --git a/ydb/library/yql/udfs/common/topfreq/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/topfreq/CMakeLists.linux-aarch64.txt index 0133493e2c9f..5cd0701d3ebc 100644 --- a/ydb/library/yql/udfs/common/topfreq/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/topfreq/CMakeLists.linux-aarch64.txt @@ -63,9 +63,6 @@ target_link_options(topfreq_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(topfreq_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/topfreq/topfreq_udf.cpp diff --git a/ydb/library/yql/udfs/common/topfreq/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/topfreq/CMakeLists.linux-x86_64.txt index 0133493e2c9f..5cd0701d3ebc 100644 --- a/ydb/library/yql/udfs/common/topfreq/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/topfreq/CMakeLists.linux-x86_64.txt @@ -63,9 +63,6 @@ target_link_options(topfreq_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(topfreq_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/topfreq/topfreq_udf.cpp diff --git a/ydb/library/yql/udfs/common/topfreq/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/udfs/common/topfreq/ut/CMakeLists.darwin-arm64.txt index 87d89dfd0277..b0d957485785 100644 --- a/ydb/library/yql/udfs/common/topfreq/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/udfs/common/topfreq/ut/CMakeLists.darwin-arm64.txt @@ -19,7 +19,7 @@ target_link_libraries(ydb-library-yql-udfs-common-topfreq-ut PUBLIC yutil cpp-testing-unittest_main common-topfreq-static - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 udf-service-exception_policy yql-sql-pg_dummy ) @@ -27,8 +27,6 @@ target_link_options(ydb-library-yql-udfs-common-topfreq-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-udfs-common-topfreq-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/topfreq/topfreq_udf_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/udfs/common/topfreq/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/udfs/common/topfreq/ut/CMakeLists.darwin-x86_64.txt index 400fb61d7eac..eca62483347e 100644 --- a/ydb/library/yql/udfs/common/topfreq/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/udfs/common/topfreq/ut/CMakeLists.darwin-x86_64.txt @@ -20,7 +20,7 @@ target_link_libraries(ydb-library-yql-udfs-common-topfreq-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main common-topfreq-static - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 udf-service-exception_policy yql-sql-pg_dummy ) @@ -28,8 +28,6 @@ target_link_options(ydb-library-yql-udfs-common-topfreq-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-udfs-common-topfreq-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/topfreq/topfreq_udf_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/udfs/common/topfreq/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/topfreq/ut/CMakeLists.linux-aarch64.txt index 0fb361ea785d..8ec0adc83959 100644 --- a/ydb/library/yql/udfs/common/topfreq/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/topfreq/ut/CMakeLists.linux-aarch64.txt @@ -20,7 +20,7 @@ target_link_libraries(ydb-library-yql-udfs-common-topfreq-ut PUBLIC yutil cpp-testing-unittest_main common-topfreq-static - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 udf-service-exception_policy yql-sql-pg_dummy ) @@ -30,9 +30,6 @@ target_link_options(ydb-library-yql-udfs-common-topfreq-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-udfs-common-topfreq-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/topfreq/topfreq_udf_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/udfs/common/topfreq/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/topfreq/ut/CMakeLists.linux-x86_64.txt index a572bc4ebcac..bfca9488c07f 100644 --- a/ydb/library/yql/udfs/common/topfreq/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/topfreq/ut/CMakeLists.linux-x86_64.txt @@ -21,7 +21,7 @@ target_link_libraries(ydb-library-yql-udfs-common-topfreq-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main common-topfreq-static - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 udf-service-exception_policy yql-sql-pg_dummy ) @@ -31,9 +31,6 @@ target_link_options(ydb-library-yql-udfs-common-topfreq-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-udfs-common-topfreq-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/topfreq/topfreq_udf_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/udfs/common/topfreq/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/udfs/common/topfreq/ut/CMakeLists.windows-x86_64.txt index ae2c0638d6c9..5f85c344b5d7 100644 --- a/ydb/library/yql/udfs/common/topfreq/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/udfs/common/topfreq/ut/CMakeLists.windows-x86_64.txt @@ -20,7 +20,7 @@ target_link_libraries(ydb-library-yql-udfs-common-topfreq-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main common-topfreq-static - minikql-comp_nodes-llvm + minikql-comp_nodes-llvm14 udf-service-exception_policy yql-sql-pg_dummy ) @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/udfs/common/unicode_base/CMakeLists.darwin-arm64.txt b/ydb/library/yql/udfs/common/unicode_base/CMakeLists.darwin-arm64.txt index 8f0ecb8b6f1a..06ed9015e9f6 100644 --- a/ydb/library/yql/udfs/common/unicode_base/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/udfs/common/unicode_base/CMakeLists.darwin-arm64.txt @@ -57,8 +57,6 @@ target_link_options(unicode_udf.dyn PRIVATE -undefined dynamic_lookup -fPIC - -framework - CoreFoundation ) target_sources(unicode_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/unicode_base/unicode_base.cpp diff --git a/ydb/library/yql/udfs/common/unicode_base/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/udfs/common/unicode_base/CMakeLists.darwin-x86_64.txt index 8f0ecb8b6f1a..06ed9015e9f6 100644 --- a/ydb/library/yql/udfs/common/unicode_base/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/udfs/common/unicode_base/CMakeLists.darwin-x86_64.txt @@ -57,8 +57,6 @@ target_link_options(unicode_udf.dyn PRIVATE -undefined dynamic_lookup -fPIC - -framework - CoreFoundation ) target_sources(unicode_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/unicode_base/unicode_base.cpp diff --git a/ydb/library/yql/udfs/common/unicode_base/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/unicode_base/CMakeLists.linux-aarch64.txt index 3ce78359ae1e..7e6be79748c6 100644 --- a/ydb/library/yql/udfs/common/unicode_base/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/unicode_base/CMakeLists.linux-aarch64.txt @@ -62,9 +62,6 @@ target_link_options(unicode_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(unicode_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/unicode_base/unicode_base.cpp diff --git a/ydb/library/yql/udfs/common/unicode_base/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/unicode_base/CMakeLists.linux-x86_64.txt index 3ce78359ae1e..7e6be79748c6 100644 --- a/ydb/library/yql/udfs/common/unicode_base/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/unicode_base/CMakeLists.linux-x86_64.txt @@ -62,9 +62,6 @@ target_link_options(unicode_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(unicode_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/unicode_base/unicode_base.cpp diff --git a/ydb/library/yql/udfs/common/url_base/CMakeLists.darwin-arm64.txt b/ydb/library/yql/udfs/common/url_base/CMakeLists.darwin-arm64.txt index a70ee1d09338..f1c20511cb9c 100644 --- a/ydb/library/yql/udfs/common/url_base/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/udfs/common/url_base/CMakeLists.darwin-arm64.txt @@ -57,8 +57,6 @@ target_link_options(url_udf.dyn PRIVATE -undefined dynamic_lookup -fPIC - -framework - CoreFoundation ) target_sources(url_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/url_base/url_base.cpp diff --git a/ydb/library/yql/udfs/common/url_base/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/udfs/common/url_base/CMakeLists.darwin-x86_64.txt index a70ee1d09338..f1c20511cb9c 100644 --- a/ydb/library/yql/udfs/common/url_base/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/udfs/common/url_base/CMakeLists.darwin-x86_64.txt @@ -57,8 +57,6 @@ target_link_options(url_udf.dyn PRIVATE -undefined dynamic_lookup -fPIC - -framework - CoreFoundation ) target_sources(url_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/url_base/url_base.cpp diff --git a/ydb/library/yql/udfs/common/url_base/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/url_base/CMakeLists.linux-aarch64.txt index c7bb69173a29..45698aec83b5 100644 --- a/ydb/library/yql/udfs/common/url_base/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/url_base/CMakeLists.linux-aarch64.txt @@ -62,9 +62,6 @@ target_link_options(url_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(url_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/url_base/url_base.cpp diff --git a/ydb/library/yql/udfs/common/url_base/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/url_base/CMakeLists.linux-x86_64.txt index c7bb69173a29..45698aec83b5 100644 --- a/ydb/library/yql/udfs/common/url_base/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/url_base/CMakeLists.linux-x86_64.txt @@ -62,9 +62,6 @@ target_link_options(url_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(url_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/url_base/url_base.cpp diff --git a/ydb/library/yql/udfs/common/yson2/CMakeLists.darwin-arm64.txt b/ydb/library/yql/udfs/common/yson2/CMakeLists.darwin-arm64.txt index 6eebbe0d8839..c19999f588fb 100644 --- a/ydb/library/yql/udfs/common/yson2/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/udfs/common/yson2/CMakeLists.darwin-arm64.txt @@ -62,8 +62,6 @@ target_link_options(yson2_udf.dyn PRIVATE -undefined dynamic_lookup -fPIC - -framework - CoreFoundation ) target_sources(yson2_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/yson2/yson2_udf.cpp diff --git a/ydb/library/yql/udfs/common/yson2/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/udfs/common/yson2/CMakeLists.darwin-x86_64.txt index 6eebbe0d8839..c19999f588fb 100644 --- a/ydb/library/yql/udfs/common/yson2/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/udfs/common/yson2/CMakeLists.darwin-x86_64.txt @@ -62,8 +62,6 @@ target_link_options(yson2_udf.dyn PRIVATE -undefined dynamic_lookup -fPIC - -framework - CoreFoundation ) target_sources(yson2_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/yson2/yson2_udf.cpp diff --git a/ydb/library/yql/udfs/common/yson2/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/common/yson2/CMakeLists.linux-aarch64.txt index f622c7817ad9..73406107375c 100644 --- a/ydb/library/yql/udfs/common/yson2/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/common/yson2/CMakeLists.linux-aarch64.txt @@ -67,9 +67,6 @@ target_link_options(yson2_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(yson2_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/yson2/yson2_udf.cpp diff --git a/ydb/library/yql/udfs/common/yson2/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/common/yson2/CMakeLists.linux-x86_64.txt index f622c7817ad9..73406107375c 100644 --- a/ydb/library/yql/udfs/common/yson2/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/common/yson2/CMakeLists.linux-x86_64.txt @@ -67,9 +67,6 @@ target_link_options(yson2_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(yson2_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/common/yson2/yson2_udf.cpp diff --git a/ydb/library/yql/udfs/examples/callables/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/examples/callables/CMakeLists.linux-aarch64.txt index aee691422fde..2514dd48691e 100644 --- a/ydb/library/yql/udfs/examples/callables/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/examples/callables/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(callables_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(callables_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/examples/callables/callables_udf.cpp diff --git a/ydb/library/yql/udfs/examples/callables/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/examples/callables/CMakeLists.linux-x86_64.txt index aee691422fde..2514dd48691e 100644 --- a/ydb/library/yql/udfs/examples/callables/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/examples/callables/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(callables_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(callables_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/examples/callables/callables_udf.cpp diff --git a/ydb/library/yql/udfs/examples/dicts/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/examples/dicts/CMakeLists.linux-aarch64.txt index d2be991c3fd4..a65e7736103e 100644 --- a/ydb/library/yql/udfs/examples/dicts/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/examples/dicts/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(dicts_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(dicts_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/examples/dicts/dicts_udf.cpp diff --git a/ydb/library/yql/udfs/examples/dicts/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/examples/dicts/CMakeLists.linux-x86_64.txt index d2be991c3fd4..a65e7736103e 100644 --- a/ydb/library/yql/udfs/examples/dicts/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/examples/dicts/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(dicts_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(dicts_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/examples/dicts/dicts_udf.cpp diff --git a/ydb/library/yql/udfs/examples/dummylog/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/examples/dummylog/CMakeLists.linux-aarch64.txt index 3119053e45ca..adf84ac0d2e6 100644 --- a/ydb/library/yql/udfs/examples/dummylog/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/examples/dummylog/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(dummylog.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(dummylog.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/examples/dummylog/dummylog_udf.cpp diff --git a/ydb/library/yql/udfs/examples/dummylog/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/examples/dummylog/CMakeLists.linux-x86_64.txt index 3119053e45ca..adf84ac0d2e6 100644 --- a/ydb/library/yql/udfs/examples/dummylog/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/examples/dummylog/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(dummylog.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(dummylog.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/examples/dummylog/dummylog_udf.cpp diff --git a/ydb/library/yql/udfs/examples/lists/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/examples/lists/CMakeLists.linux-aarch64.txt index 2ea6cdd9c81f..a71446829ba6 100644 --- a/ydb/library/yql/udfs/examples/lists/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/examples/lists/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(lists_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(lists_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/examples/lists/lists_udf.cpp diff --git a/ydb/library/yql/udfs/examples/lists/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/examples/lists/CMakeLists.linux-x86_64.txt index 2ea6cdd9c81f..a71446829ba6 100644 --- a/ydb/library/yql/udfs/examples/lists/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/examples/lists/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(lists_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(lists_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/examples/lists/lists_udf.cpp diff --git a/ydb/library/yql/udfs/examples/structs/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/examples/structs/CMakeLists.linux-aarch64.txt index 5471f039a0f3..3562ed04f5fa 100644 --- a/ydb/library/yql/udfs/examples/structs/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/examples/structs/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(structs_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(structs_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/examples/structs/structs_udf.cpp diff --git a/ydb/library/yql/udfs/examples/structs/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/examples/structs/CMakeLists.linux-x86_64.txt index 5471f039a0f3..3562ed04f5fa 100644 --- a/ydb/library/yql/udfs/examples/structs/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/examples/structs/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(structs_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(structs_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/examples/structs/structs_udf.cpp diff --git a/ydb/library/yql/udfs/examples/tagged/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/examples/tagged/CMakeLists.linux-aarch64.txt index 16f05b930485..9b2d9e743f2d 100644 --- a/ydb/library/yql/udfs/examples/tagged/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/examples/tagged/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(tagged_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(tagged_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/examples/tagged/tagged_udf.cpp diff --git a/ydb/library/yql/udfs/examples/tagged/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/examples/tagged/CMakeLists.linux-x86_64.txt index 16f05b930485..9b2d9e743f2d 100644 --- a/ydb/library/yql/udfs/examples/tagged/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/examples/tagged/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(tagged_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(tagged_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/examples/tagged/tagged_udf.cpp diff --git a/ydb/library/yql/udfs/examples/type_inspection/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/examples/type_inspection/CMakeLists.linux-aarch64.txt index 93b97b41bdd0..8f3f4ff2e73d 100644 --- a/ydb/library/yql/udfs/examples/type_inspection/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/examples/type_inspection/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(type_inspection_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(type_inspection_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/examples/type_inspection/type_inspection_udf.cpp diff --git a/ydb/library/yql/udfs/examples/type_inspection/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/examples/type_inspection/CMakeLists.linux-x86_64.txt index 93b97b41bdd0..8f3f4ff2e73d 100644 --- a/ydb/library/yql/udfs/examples/type_inspection/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/examples/type_inspection/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(type_inspection_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(type_inspection_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/examples/type_inspection/type_inspection_udf.cpp diff --git a/ydb/library/yql/udfs/logs/dsv/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/logs/dsv/CMakeLists.linux-aarch64.txt index ce6da0c75350..8cb269f55a62 100644 --- a/ydb/library/yql/udfs/logs/dsv/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/logs/dsv/CMakeLists.linux-aarch64.txt @@ -61,9 +61,6 @@ target_link_options(dsv_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(dsv_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/logs/dsv/dsv_udf.cpp diff --git a/ydb/library/yql/udfs/logs/dsv/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/logs/dsv/CMakeLists.linux-x86_64.txt index ce6da0c75350..8cb269f55a62 100644 --- a/ydb/library/yql/udfs/logs/dsv/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/logs/dsv/CMakeLists.linux-x86_64.txt @@ -61,9 +61,6 @@ target_link_options(dsv_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(dsv_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/logs/dsv/dsv_udf.cpp diff --git a/ydb/library/yql/udfs/test/simple/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/test/simple/CMakeLists.linux-aarch64.txt index b4cc69f406b1..047476dbc389 100644 --- a/ydb/library/yql/udfs/test/simple/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/test/simple/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(simple_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(simple_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/test/simple/simple_udf.cpp diff --git a/ydb/library/yql/udfs/test/simple/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/test/simple/CMakeLists.linux-x86_64.txt index b4cc69f406b1..047476dbc389 100644 --- a/ydb/library/yql/udfs/test/simple/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/test/simple/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(simple_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(simple_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/test/simple/simple_udf.cpp diff --git a/ydb/library/yql/udfs/test/test_import/CMakeLists.linux-aarch64.txt b/ydb/library/yql/udfs/test/test_import/CMakeLists.linux-aarch64.txt index 4aaa550a0778..4c1747b45c40 100644 --- a/ydb/library/yql/udfs/test/test_import/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/udfs/test/test_import/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(test_import_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(test_import_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/test/test_import/test_import_udf.cpp diff --git a/ydb/library/yql/udfs/test/test_import/CMakeLists.linux-x86_64.txt b/ydb/library/yql/udfs/test/test_import/CMakeLists.linux-x86_64.txt index 4aaa550a0778..4c1747b45c40 100644 --- a/ydb/library/yql/udfs/test/test_import/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/udfs/test/test_import/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(test_import_udf.dyn PRIVATE -Wl,-z,notext -Wl,-Bsymbolic -fPIC - -lpthread - -lrt - -ldl ) target_sources(test_import_udf.dyn PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/udfs/test/test_import/test_import_udf.cpp diff --git a/ydb/library/yql/utils/CMakeLists.darwin-arm64.txt b/ydb/library/yql/utils/CMakeLists.darwin-arm64.txt index 4ebccd3a7549..1b35bb2b9be2 100644 --- a/ydb/library/yql/utils/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/utils/CMakeLists.darwin-arm64.txt @@ -15,6 +15,7 @@ add_subdirectory(failure_injector) add_subdirectory(fetch) add_subdirectory(log) add_subdirectory(plan) +add_subdirectory(signals) add_subdirectory(simd) add_subdirectory(sys) add_subdirectory(test_http_server) @@ -34,6 +35,24 @@ target_link_libraries(library-yql-utils PUBLIC contrib-libs-miniselect ) target_sources(library-yql-utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/bind_in_range.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/cast.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/debug_info.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/future_action.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/hash.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/md5_stream.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/method_index.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/multi_resource_lock.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/parse_double.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/proc_alive.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/rand_guid.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/resetable_setting.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/retry.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/rope_over_buffer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sort.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/swap_bytes.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/yql_panic.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/yql_paths.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/bind_in_range.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/debug_info.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/future_action.cpp diff --git a/ydb/library/yql/utils/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/utils/CMakeLists.darwin-x86_64.txt index 4ebccd3a7549..1b35bb2b9be2 100644 --- a/ydb/library/yql/utils/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/utils/CMakeLists.darwin-x86_64.txt @@ -15,6 +15,7 @@ add_subdirectory(failure_injector) add_subdirectory(fetch) add_subdirectory(log) add_subdirectory(plan) +add_subdirectory(signals) add_subdirectory(simd) add_subdirectory(sys) add_subdirectory(test_http_server) @@ -34,6 +35,24 @@ target_link_libraries(library-yql-utils PUBLIC contrib-libs-miniselect ) target_sources(library-yql-utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/bind_in_range.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/cast.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/debug_info.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/future_action.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/hash.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/md5_stream.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/method_index.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/multi_resource_lock.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/parse_double.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/proc_alive.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/rand_guid.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/resetable_setting.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/retry.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/rope_over_buffer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sort.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/swap_bytes.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/yql_panic.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/yql_paths.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/bind_in_range.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/debug_info.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/future_action.cpp diff --git a/ydb/library/yql/utils/CMakeLists.linux-aarch64.txt b/ydb/library/yql/utils/CMakeLists.linux-aarch64.txt index c2c2785e4c3b..419af3afb917 100644 --- a/ydb/library/yql/utils/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/utils/CMakeLists.linux-aarch64.txt @@ -15,6 +15,7 @@ add_subdirectory(failure_injector) add_subdirectory(fetch) add_subdirectory(log) add_subdirectory(plan) +add_subdirectory(signals) add_subdirectory(simd) add_subdirectory(sys) add_subdirectory(test_http_server) @@ -35,6 +36,24 @@ target_link_libraries(library-yql-utils PUBLIC contrib-libs-miniselect ) target_sources(library-yql-utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/bind_in_range.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/cast.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/debug_info.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/future_action.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/hash.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/md5_stream.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/method_index.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/multi_resource_lock.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/parse_double.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/proc_alive.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/rand_guid.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/resetable_setting.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/retry.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/rope_over_buffer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sort.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/swap_bytes.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/yql_panic.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/yql_paths.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/bind_in_range.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/debug_info.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/future_action.cpp diff --git a/ydb/library/yql/utils/CMakeLists.linux-x86_64.txt b/ydb/library/yql/utils/CMakeLists.linux-x86_64.txt index c2c2785e4c3b..419af3afb917 100644 --- a/ydb/library/yql/utils/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/utils/CMakeLists.linux-x86_64.txt @@ -15,6 +15,7 @@ add_subdirectory(failure_injector) add_subdirectory(fetch) add_subdirectory(log) add_subdirectory(plan) +add_subdirectory(signals) add_subdirectory(simd) add_subdirectory(sys) add_subdirectory(test_http_server) @@ -35,6 +36,24 @@ target_link_libraries(library-yql-utils PUBLIC contrib-libs-miniselect ) target_sources(library-yql-utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/bind_in_range.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/cast.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/debug_info.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/future_action.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/hash.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/md5_stream.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/method_index.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/multi_resource_lock.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/parse_double.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/proc_alive.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/rand_guid.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/resetable_setting.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/retry.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/rope_over_buffer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sort.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/swap_bytes.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/yql_panic.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/yql_paths.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/bind_in_range.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/debug_info.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/future_action.cpp diff --git a/ydb/library/yql/utils/CMakeLists.windows-x86_64.txt b/ydb/library/yql/utils/CMakeLists.windows-x86_64.txt index 4ebccd3a7549..1b35bb2b9be2 100644 --- a/ydb/library/yql/utils/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/utils/CMakeLists.windows-x86_64.txt @@ -15,6 +15,7 @@ add_subdirectory(failure_injector) add_subdirectory(fetch) add_subdirectory(log) add_subdirectory(plan) +add_subdirectory(signals) add_subdirectory(simd) add_subdirectory(sys) add_subdirectory(test_http_server) @@ -34,6 +35,24 @@ target_link_libraries(library-yql-utils PUBLIC contrib-libs-miniselect ) target_sources(library-yql-utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/bind_in_range.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/cast.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/debug_info.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/future_action.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/hash.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/md5_stream.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/method_index.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/multi_resource_lock.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/parse_double.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/proc_alive.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/rand_guid.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/resetable_setting.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/retry.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/rope_over_buffer.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sort.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/swap_bytes.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/yql_panic.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/yql_paths.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/bind_in_range.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/debug_info.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/future_action.cpp diff --git a/ydb/library/yql/utils/actor_system/CMakeLists.darwin-arm64.txt b/ydb/library/yql/utils/actor_system/CMakeLists.darwin-arm64.txt index e15bd8c09099..e8dfb29604c8 100644 --- a/ydb/library/yql/utils/actor_system/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/utils/actor_system/CMakeLists.darwin-arm64.txt @@ -17,5 +17,6 @@ target_link_libraries(yql-utils-actor_system PUBLIC library-yql-utils ) target_sources(yql-utils-actor_system PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/actor_system/manager.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/actor_system/manager.cpp ) diff --git a/ydb/library/yql/utils/actor_system/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/utils/actor_system/CMakeLists.darwin-x86_64.txt index e15bd8c09099..e8dfb29604c8 100644 --- a/ydb/library/yql/utils/actor_system/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/utils/actor_system/CMakeLists.darwin-x86_64.txt @@ -17,5 +17,6 @@ target_link_libraries(yql-utils-actor_system PUBLIC library-yql-utils ) target_sources(yql-utils-actor_system PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/actor_system/manager.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/actor_system/manager.cpp ) diff --git a/ydb/library/yql/utils/actor_system/CMakeLists.linux-aarch64.txt b/ydb/library/yql/utils/actor_system/CMakeLists.linux-aarch64.txt index 31f2c67a5f24..c7cd339e3416 100644 --- a/ydb/library/yql/utils/actor_system/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/utils/actor_system/CMakeLists.linux-aarch64.txt @@ -18,5 +18,6 @@ target_link_libraries(yql-utils-actor_system PUBLIC library-yql-utils ) target_sources(yql-utils-actor_system PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/actor_system/manager.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/actor_system/manager.cpp ) diff --git a/ydb/library/yql/utils/actor_system/CMakeLists.linux-x86_64.txt b/ydb/library/yql/utils/actor_system/CMakeLists.linux-x86_64.txt index 31f2c67a5f24..c7cd339e3416 100644 --- a/ydb/library/yql/utils/actor_system/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/utils/actor_system/CMakeLists.linux-x86_64.txt @@ -18,5 +18,6 @@ target_link_libraries(yql-utils-actor_system PUBLIC library-yql-utils ) target_sources(yql-utils-actor_system PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/actor_system/manager.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/actor_system/manager.cpp ) diff --git a/ydb/library/yql/utils/actor_system/CMakeLists.windows-x86_64.txt b/ydb/library/yql/utils/actor_system/CMakeLists.windows-x86_64.txt index e15bd8c09099..e8dfb29604c8 100644 --- a/ydb/library/yql/utils/actor_system/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/utils/actor_system/CMakeLists.windows-x86_64.txt @@ -17,5 +17,6 @@ target_link_libraries(yql-utils-actor_system PUBLIC library-yql-utils ) target_sources(yql-utils-actor_system PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/actor_system/manager.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/actor_system/manager.cpp ) diff --git a/ydb/library/yql/utils/actors/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/utils/actors/ut/CMakeLists.darwin-arm64.txt index b08582f0ad72..824b3de07958 100644 --- a/ydb/library/yql/utils/actors/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/utils/actors/ut/CMakeLists.darwin-arm64.txt @@ -17,13 +17,12 @@ target_link_libraries(ydb-library-yql-utils-actors-ut PUBLIC cpp-testing-unittest_main yql-utils-actors testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-library-yql-utils-actors-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-utils-actors-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/actors/http_sender_actor_ut.cpp @@ -53,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/actors/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/utils/actors/ut/CMakeLists.darwin-x86_64.txt index 3ae843ac4042..735a2ceb57b8 100644 --- a/ydb/library/yql/utils/actors/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/utils/actors/ut/CMakeLists.darwin-x86_64.txt @@ -18,13 +18,12 @@ target_link_libraries(ydb-library-yql-utils-actors-ut PUBLIC cpp-testing-unittest_main yql-utils-actors testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-library-yql-utils-actors-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-utils-actors-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/actors/http_sender_actor_ut.cpp @@ -54,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/actors/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/utils/actors/ut/CMakeLists.linux-aarch64.txt index 8f0ddb98fdba..0eb5c03ca76e 100644 --- a/ydb/library/yql/utils/actors/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/utils/actors/ut/CMakeLists.linux-aarch64.txt @@ -18,6 +18,7 @@ target_link_libraries(ydb-library-yql-utils-actors-ut PUBLIC cpp-testing-unittest_main yql-utils-actors testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-library-yql-utils-actors-ut PRIVATE -ldl @@ -25,9 +26,6 @@ target_link_options(ydb-library-yql-utils-actors-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-utils-actors-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/actors/http_sender_actor_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/actors/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/utils/actors/ut/CMakeLists.linux-x86_64.txt index 264cde4a66a9..9c779da5dcf5 100644 --- a/ydb/library/yql/utils/actors/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/utils/actors/ut/CMakeLists.linux-x86_64.txt @@ -19,6 +19,7 @@ target_link_libraries(ydb-library-yql-utils-actors-ut PUBLIC cpp-testing-unittest_main yql-utils-actors testlib-basics-default + minikql-comp_nodes-llvm14 ) target_link_options(ydb-library-yql-utils-actors-ut PRIVATE -ldl @@ -26,9 +27,6 @@ target_link_options(ydb-library-yql-utils-actors-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-utils-actors-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/actors/http_sender_actor_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/backtrace/CMakeLists.darwin-arm64.txt b/ydb/library/yql/utils/backtrace/CMakeLists.darwin-arm64.txt index eec03a6e782e..3d4d1d9ccf1a 100644 --- a/ydb/library/yql/utils/backtrace/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/utils/backtrace/CMakeLists.darwin-arm64.txt @@ -6,15 +6,12 @@ # original buildsystem will not be accepted. -add_subdirectory(fake_llvm_symbolizer) add_subdirectory(ut) add_library(yql-utils-backtrace) target_link_libraries(yql-utils-backtrace PUBLIC contrib-libs-cxxsupp yutil - utils-backtrace-fake_llvm_symbolizer - lib-DebugInfo-Symbolize cpp-deprecated-atomic ) target_sources(yql-utils-backtrace PRIVATE diff --git a/ydb/library/yql/utils/backtrace/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/utils/backtrace/CMakeLists.darwin-x86_64.txt index eec03a6e782e..3d4d1d9ccf1a 100644 --- a/ydb/library/yql/utils/backtrace/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/utils/backtrace/CMakeLists.darwin-x86_64.txt @@ -6,15 +6,12 @@ # original buildsystem will not be accepted. -add_subdirectory(fake_llvm_symbolizer) add_subdirectory(ut) add_library(yql-utils-backtrace) target_link_libraries(yql-utils-backtrace PUBLIC contrib-libs-cxxsupp yutil - utils-backtrace-fake_llvm_symbolizer - lib-DebugInfo-Symbolize cpp-deprecated-atomic ) target_sources(yql-utils-backtrace PRIVATE diff --git a/ydb/library/yql/utils/backtrace/CMakeLists.linux-aarch64.txt b/ydb/library/yql/utils/backtrace/CMakeLists.linux-aarch64.txt index 2ac25c993aaf..f3af34382f55 100644 --- a/ydb/library/yql/utils/backtrace/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/utils/backtrace/CMakeLists.linux-aarch64.txt @@ -6,7 +6,6 @@ # original buildsystem will not be accepted. -add_subdirectory(fake_llvm_symbolizer) add_subdirectory(ut) add_library(yql-utils-backtrace) @@ -14,8 +13,6 @@ target_link_libraries(yql-utils-backtrace PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - utils-backtrace-fake_llvm_symbolizer - lib-DebugInfo-Symbolize cpp-deprecated-atomic ) target_sources(yql-utils-backtrace PRIVATE diff --git a/ydb/library/yql/utils/backtrace/CMakeLists.linux-x86_64.txt b/ydb/library/yql/utils/backtrace/CMakeLists.linux-x86_64.txt index 505dcd7252f5..bed4f084364e 100644 --- a/ydb/library/yql/utils/backtrace/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/utils/backtrace/CMakeLists.linux-x86_64.txt @@ -6,7 +6,6 @@ # original buildsystem will not be accepted. -add_subdirectory(fake_llvm_symbolizer) add_subdirectory(ut) add_library(yql-utils-backtrace) @@ -14,9 +13,8 @@ target_link_libraries(yql-utils-backtrace PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - utils-backtrace-fake_llvm_symbolizer contrib-libs-libunwind - lib-DebugInfo-Symbolize + library-cpp-dwarf_backtrace cpp-deprecated-atomic ) target_sources(yql-utils-backtrace PRIVATE diff --git a/ydb/library/yql/utils/backtrace/CMakeLists.windows-x86_64.txt b/ydb/library/yql/utils/backtrace/CMakeLists.windows-x86_64.txt index eec03a6e782e..3d4d1d9ccf1a 100644 --- a/ydb/library/yql/utils/backtrace/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/utils/backtrace/CMakeLists.windows-x86_64.txt @@ -6,15 +6,12 @@ # original buildsystem will not be accepted. -add_subdirectory(fake_llvm_symbolizer) add_subdirectory(ut) add_library(yql-utils-backtrace) target_link_libraries(yql-utils-backtrace PUBLIC contrib-libs-cxxsupp yutil - utils-backtrace-fake_llvm_symbolizer - lib-DebugInfo-Symbolize cpp-deprecated-atomic ) target_sources(yql-utils-backtrace PRIVATE diff --git a/ydb/library/yql/utils/backtrace/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/utils/backtrace/ut/CMakeLists.darwin-arm64.txt index 908415e23d24..d880ef5af778 100644 --- a/ydb/library/yql/utils/backtrace/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/utils/backtrace/ut/CMakeLists.darwin-arm64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/backtrace/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/utils/backtrace/ut/CMakeLists.darwin-x86_64.txt index 404418f5cba5..2dc9e3893eab 100644 --- a/ydb/library/yql/utils/backtrace/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/utils/backtrace/ut/CMakeLists.darwin-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/backtrace/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/utils/backtrace/ut/CMakeLists.linux-aarch64.txt index 2ff3f2232959..37af60f1b4b8 100644 --- a/ydb/library/yql/utils/backtrace/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/utils/backtrace/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-yql-utils-backtrace-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-utils-backtrace-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/backtrace/backtrace_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/backtrace/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/utils/backtrace/ut/CMakeLists.linux-x86_64.txt index 64250ca5db69..ff92b992001a 100644 --- a/ydb/library/yql/utils/backtrace/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/utils/backtrace/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-yql-utils-backtrace-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-utils-backtrace-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/backtrace/backtrace_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/backtrace/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/utils/backtrace/ut/CMakeLists.windows-x86_64.txt index a30274e5f05a..8f29fac3aa7a 100644 --- a/ydb/library/yql/utils/backtrace/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/utils/backtrace/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/bindings/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/utils/bindings/ut/CMakeLists.darwin-arm64.txt index 685e63d5edd0..e78b6f7e30b9 100644 --- a/ydb/library/yql/utils/bindings/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/utils/bindings/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-library-yql-utils-bindings-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-utils-bindings-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/bindings/utils_ut.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/bindings/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/utils/bindings/ut/CMakeLists.darwin-x86_64.txt index cd892f3b41b3..88f573066848 100644 --- a/ydb/library/yql/utils/bindings/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/utils/bindings/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-library-yql-utils-bindings-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-utils-bindings-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/bindings/utils_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/bindings/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/utils/bindings/ut/CMakeLists.linux-aarch64.txt index 2315efa9aeea..770c165c48f4 100644 --- a/ydb/library/yql/utils/bindings/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/utils/bindings/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-yql-utils-bindings-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-utils-bindings-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/bindings/utils_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/bindings/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/utils/bindings/ut/CMakeLists.linux-x86_64.txt index b0d5a389c6bd..9b6ffc8ed74a 100644 --- a/ydb/library/yql/utils/bindings/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/utils/bindings/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-yql-utils-bindings-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-utils-bindings-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/bindings/utils_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/bindings/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/utils/bindings/ut/CMakeLists.windows-x86_64.txt index b5bd5b0763d1..d91b99596f08 100644 --- a/ydb/library/yql/utils/bindings/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/utils/bindings/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/failure_injector/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/utils/failure_injector/ut/CMakeLists.darwin-arm64.txt index ba992194f807..a43068c79c8e 100644 --- a/ydb/library/yql/utils/failure_injector/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/utils/failure_injector/ut/CMakeLists.darwin-arm64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-library-yql-utils-failure_injector-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-utils-failure_injector-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/failure_injector/failure_injector_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/failure_injector/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/utils/failure_injector/ut/CMakeLists.darwin-x86_64.txt index a6ea9d7d8036..58ac2ee89536 100644 --- a/ydb/library/yql/utils/failure_injector/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/utils/failure_injector/ut/CMakeLists.darwin-x86_64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-library-yql-utils-failure_injector-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-utils-failure_injector-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/failure_injector/failure_injector_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/failure_injector/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/utils/failure_injector/ut/CMakeLists.linux-aarch64.txt index ce6281064f96..3b391c75084c 100644 --- a/ydb/library/yql/utils/failure_injector/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/utils/failure_injector/ut/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-yql-utils-failure_injector-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-utils-failure_injector-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/failure_injector/failure_injector_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/failure_injector/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/utils/failure_injector/ut/CMakeLists.linux-x86_64.txt index 3c3f6bfe11f0..503d6136ba62 100644 --- a/ydb/library/yql/utils/failure_injector/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/utils/failure_injector/ut/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-library-yql-utils-failure_injector-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-utils-failure_injector-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/failure_injector/failure_injector_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/log/proto/CMakeLists.darwin-arm64.txt b/ydb/library/yql/utils/log/proto/CMakeLists.darwin-arm64.txt index d4898e8a174e..927b2b450583 100644 --- a/ydb/library/yql/utils/log/proto/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/utils/log/proto/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(utils-log-proto PUBLIC target_proto_messages(utils-log-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/log/proto/logger_config.proto ) +target_sources(utils-log-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/utils/log/proto/logger_config.pb.h +) target_proto_addincls(utils-log-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/utils/log/proto/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/utils/log/proto/CMakeLists.darwin-x86_64.txt index d4898e8a174e..927b2b450583 100644 --- a/ydb/library/yql/utils/log/proto/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/utils/log/proto/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(utils-log-proto PUBLIC target_proto_messages(utils-log-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/log/proto/logger_config.proto ) +target_sources(utils-log-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/utils/log/proto/logger_config.pb.h +) target_proto_addincls(utils-log-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/utils/log/proto/CMakeLists.linux-aarch64.txt b/ydb/library/yql/utils/log/proto/CMakeLists.linux-aarch64.txt index e853dc92651b..83d1e9caac25 100644 --- a/ydb/library/yql/utils/log/proto/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/utils/log/proto/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(utils-log-proto PUBLIC target_proto_messages(utils-log-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/log/proto/logger_config.proto ) +target_sources(utils-log-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/utils/log/proto/logger_config.pb.h +) target_proto_addincls(utils-log-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/utils/log/proto/CMakeLists.linux-x86_64.txt b/ydb/library/yql/utils/log/proto/CMakeLists.linux-x86_64.txt index e853dc92651b..83d1e9caac25 100644 --- a/ydb/library/yql/utils/log/proto/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/utils/log/proto/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(utils-log-proto PUBLIC target_proto_messages(utils-log-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/log/proto/logger_config.proto ) +target_sources(utils-log-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/utils/log/proto/logger_config.pb.h +) target_proto_addincls(utils-log-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/utils/log/proto/CMakeLists.windows-x86_64.txt b/ydb/library/yql/utils/log/proto/CMakeLists.windows-x86_64.txt index d4898e8a174e..927b2b450583 100644 --- a/ydb/library/yql/utils/log/proto/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/utils/log/proto/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(utils-log-proto PUBLIC target_proto_messages(utils-log-proto PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/log/proto/logger_config.proto ) +target_sources(utils-log-proto PRIVATE + ${CMAKE_BINARY_DIR}/ydb/library/yql/utils/log/proto/logger_config.pb.h +) target_proto_addincls(utils-log-proto ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/library/yql/utils/log/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/utils/log/ut/CMakeLists.darwin-arm64.txt index f1923d17acec..19920571c6cd 100644 --- a/ydb/library/yql/utils/log/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/utils/log/ut/CMakeLists.darwin-arm64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/log/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/utils/log/ut/CMakeLists.darwin-x86_64.txt index cfd266b90ac1..9b20c9613f7b 100644 --- a/ydb/library/yql/utils/log/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/utils/log/ut/CMakeLists.darwin-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/log/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/utils/log/ut/CMakeLists.linux-aarch64.txt index 89eaf1d6aa5b..8698def6cf38 100644 --- a/ydb/library/yql/utils/log/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/utils/log/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-yql-utils-log-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-utils-log-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/log/log_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/log/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/utils/log/ut/CMakeLists.linux-x86_64.txt index 8a097ac0d5b1..e102e496c0bf 100644 --- a/ydb/library/yql/utils/log/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/utils/log/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-yql-utils-log-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-utils-log-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/log/log_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/log/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/utils/log/ut/CMakeLists.windows-x86_64.txt index 394f27cff06f..bdd3fd8bd5df 100644 --- a/ydb/library/yql/utils/log/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/utils/log/ut/CMakeLists.windows-x86_64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/plan/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/utils/plan/ut/CMakeLists.darwin-arm64.txt index 85757d6ead2e..6e4daec1e6e7 100644 --- a/ydb/library/yql/utils/plan/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/utils/plan/ut/CMakeLists.darwin-arm64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-library-yql-utils-plan-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-utils-plan-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/plan/plan_utils_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/plan/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/utils/plan/ut/CMakeLists.darwin-x86_64.txt index f0993ecba4f7..a55bbf3a1ceb 100644 --- a/ydb/library/yql/utils/plan/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/utils/plan/ut/CMakeLists.darwin-x86_64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-library-yql-utils-plan-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-utils-plan-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/plan/plan_utils_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/plan/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/utils/plan/ut/CMakeLists.linux-aarch64.txt index 9a243ec55e43..75ca43e3a41c 100644 --- a/ydb/library/yql/utils/plan/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/utils/plan/ut/CMakeLists.linux-aarch64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-library-yql-utils-plan-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-utils-plan-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/plan/plan_utils_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/plan/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/utils/plan/ut/CMakeLists.linux-x86_64.txt index 333c096d4606..42fe2992f4b1 100644 --- a/ydb/library/yql/utils/plan/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/utils/plan/ut/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-library-yql-utils-plan-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-utils-plan-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/plan/plan_utils_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/plan/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/utils/plan/ut/CMakeLists.windows-x86_64.txt index a80bb850fa7a..9a6159f24e87 100644 --- a/ydb/library/yql/utils/plan/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/utils/plan/ut/CMakeLists.windows-x86_64.txt @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/signals/CMakeLists.darwin-arm64.txt b/ydb/library/yql/utils/signals/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..aa9567a75fb2 --- /dev/null +++ b/ydb/library/yql/utils/signals/CMakeLists.darwin-arm64.txt @@ -0,0 +1,27 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yql-utils-signals) +target_link_libraries(yql-utils-signals PUBLIC + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf + cpp-logger-global + cpp-protobuf-json + cpp-json-yson + yql-utils-log + yql-utils-backtrace + yt-lib-log +) +target_sources(yql-utils-signals PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/signals/signals.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/signals/utils.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/signals/signals.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/signals/utils.cpp +) diff --git a/ydb/library/yql/utils/signals/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/utils/signals/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..aa9567a75fb2 --- /dev/null +++ b/ydb/library/yql/utils/signals/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,27 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yql-utils-signals) +target_link_libraries(yql-utils-signals PUBLIC + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf + cpp-logger-global + cpp-protobuf-json + cpp-json-yson + yql-utils-log + yql-utils-backtrace + yt-lib-log +) +target_sources(yql-utils-signals PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/signals/signals.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/signals/utils.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/signals/signals.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/signals/utils.cpp +) diff --git a/ydb/library/yql/utils/signals/CMakeLists.linux-aarch64.txt b/ydb/library/yql/utils/signals/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..c3c2c9b07fbc --- /dev/null +++ b/ydb/library/yql/utils/signals/CMakeLists.linux-aarch64.txt @@ -0,0 +1,28 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yql-utils-signals) +target_link_libraries(yql-utils-signals PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf + cpp-logger-global + cpp-protobuf-json + cpp-json-yson + yql-utils-log + yql-utils-backtrace + yt-lib-log +) +target_sources(yql-utils-signals PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/signals/signals.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/signals/utils.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/signals/signals.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/signals/utils.cpp +) diff --git a/ydb/library/yql/utils/signals/CMakeLists.linux-x86_64.txt b/ydb/library/yql/utils/signals/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..c3c2c9b07fbc --- /dev/null +++ b/ydb/library/yql/utils/signals/CMakeLists.linux-x86_64.txt @@ -0,0 +1,28 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yql-utils-signals) +target_link_libraries(yql-utils-signals PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf + cpp-logger-global + cpp-protobuf-json + cpp-json-yson + yql-utils-log + yql-utils-backtrace + yt-lib-log +) +target_sources(yql-utils-signals PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/signals/signals.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/signals/utils.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/signals/signals.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/signals/utils.cpp +) diff --git a/ydb/library/yql/utils/signals/CMakeLists.txt b/ydb/library/yql/utils/signals/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/utils/signals/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/utils/signals/CMakeLists.windows-x86_64.txt b/ydb/library/yql/utils/signals/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..aa9567a75fb2 --- /dev/null +++ b/ydb/library/yql/utils/signals/CMakeLists.windows-x86_64.txt @@ -0,0 +1,27 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(yql-utils-signals) +target_link_libraries(yql-utils-signals PUBLIC + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf + cpp-logger-global + cpp-protobuf-json + cpp-json-yson + yql-utils-log + yql-utils-backtrace + yt-lib-log +) +target_sources(yql-utils-signals PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/signals/signals.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/signals/utils.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/signals/signals.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/signals/utils.cpp +) diff --git a/ydb/library/yql/utils/simd/exec/CMakeLists.txt b/ydb/library/yql/utils/simd/exec/CMakeLists.txt index ecb5351e0897..80182039d023 100644 --- a/ydb/library/yql/utils/simd/exec/CMakeLists.txt +++ b/ydb/library/yql/utils/simd/exec/CMakeLists.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(add_columns) add_subdirectory(pack_tuple) add_subdirectory(stream_store) add_subdirectory(tuples_to_bucket) diff --git a/ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.darwin-arm64.txt b/ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..25c87c2d02ff --- /dev/null +++ b/ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.darwin-arm64.txt @@ -0,0 +1,30 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(add_columns) +target_compile_options(add_columns PRIVATE + -mavx2 +) +target_link_libraries(add_columns PUBLIC + contrib-libs-cxxsupp + yutil + yql-utils-simd +) +target_link_options(add_columns PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(add_columns PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/simd/exec/add_columns/main.cpp +) +target_allocator(add_columns + system_allocator +) +vcs_info(add_columns) diff --git a/ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..e5a0139aed66 --- /dev/null +++ b/ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,31 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(add_columns) +target_compile_options(add_columns PRIVATE + -mavx2 +) +target_link_libraries(add_columns PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + yql-utils-simd +) +target_link_options(add_columns PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(add_columns PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/simd/exec/add_columns/main.cpp +) +target_allocator(add_columns + system_allocator +) +vcs_info(add_columns) diff --git a/ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.linux-aarch64.txt b/ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..0d1883ada810 --- /dev/null +++ b/ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.linux-aarch64.txt @@ -0,0 +1,33 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(add_columns) +target_compile_options(add_columns PRIVATE + -mavx2 +) +target_link_libraries(add_columns PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + yql-utils-simd +) +target_link_options(add_columns PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(add_columns PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/simd/exec/add_columns/main.cpp +) +target_allocator(add_columns + cpp-malloc-jemalloc +) +vcs_info(add_columns) diff --git a/ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.linux-x86_64.txt b/ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..bb8b3dc7c1bc --- /dev/null +++ b/ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.linux-x86_64.txt @@ -0,0 +1,35 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(add_columns) +target_compile_options(add_columns PRIVATE + -mavx2 +) +target_link_libraries(add_columns PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + yql-utils-simd +) +target_link_options(add_columns PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(add_columns PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/simd/exec/add_columns/main.cpp +) +target_allocator(add_columns + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(add_columns) diff --git a/ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.txt b/ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.windows-x86_64.txt b/ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..70742198e3c0 --- /dev/null +++ b/ydb/library/yql/utils/simd/exec/add_columns/CMakeLists.windows-x86_64.txt @@ -0,0 +1,26 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(add_columns) +target_compile_options(add_columns PRIVATE + -mavx2 +) +target_link_libraries(add_columns PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + yql-utils-simd +) +target_sources(add_columns PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/simd/exec/add_columns/main.cpp +) +target_allocator(add_columns + system_allocator +) +vcs_info(add_columns) diff --git a/ydb/library/yql/utils/simd/exec/pack_tuple/CMakeLists.linux-aarch64.txt b/ydb/library/yql/utils/simd/exec/pack_tuple/CMakeLists.linux-aarch64.txt index 2d3669066755..8f0343e297fd 100644 --- a/ydb/library/yql/utils/simd/exec/pack_tuple/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/utils/simd/exec/pack_tuple/CMakeLists.linux-aarch64.txt @@ -23,9 +23,6 @@ target_link_options(pack_tuple PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(pack_tuple PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/simd/exec/pack_tuple/main.cpp diff --git a/ydb/library/yql/utils/simd/exec/pack_tuple/CMakeLists.linux-x86_64.txt b/ydb/library/yql/utils/simd/exec/pack_tuple/CMakeLists.linux-x86_64.txt index 6299f9b65a81..3dfb810d8143 100644 --- a/ydb/library/yql/utils/simd/exec/pack_tuple/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/utils/simd/exec/pack_tuple/CMakeLists.linux-x86_64.txt @@ -24,9 +24,6 @@ target_link_options(pack_tuple PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(pack_tuple PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/simd/exec/pack_tuple/main.cpp diff --git a/ydb/library/yql/utils/simd/exec/stream_store/CMakeLists.linux-aarch64.txt b/ydb/library/yql/utils/simd/exec/stream_store/CMakeLists.linux-aarch64.txt index d4dd5985c4ed..60f00ecbb780 100644 --- a/ydb/library/yql/utils/simd/exec/stream_store/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/utils/simd/exec/stream_store/CMakeLists.linux-aarch64.txt @@ -20,9 +20,6 @@ target_link_options(stream_store PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(stream_store PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/simd/exec/stream_store/main.cpp diff --git a/ydb/library/yql/utils/simd/exec/stream_store/CMakeLists.linux-x86_64.txt b/ydb/library/yql/utils/simd/exec/stream_store/CMakeLists.linux-x86_64.txt index 2dbcba4a9eef..a4a23be31d73 100644 --- a/ydb/library/yql/utils/simd/exec/stream_store/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/utils/simd/exec/stream_store/CMakeLists.linux-x86_64.txt @@ -21,9 +21,6 @@ target_link_options(stream_store PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(stream_store PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/simd/exec/stream_store/main.cpp diff --git a/ydb/library/yql/utils/simd/exec/tuples_to_bucket/CMakeLists.linux-aarch64.txt b/ydb/library/yql/utils/simd/exec/tuples_to_bucket/CMakeLists.linux-aarch64.txt index 36edc4e5e3bc..7149f312dc95 100644 --- a/ydb/library/yql/utils/simd/exec/tuples_to_bucket/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/utils/simd/exec/tuples_to_bucket/CMakeLists.linux-aarch64.txt @@ -20,9 +20,6 @@ target_link_options(tuples_to_bucket PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(tuples_to_bucket PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/simd/exec/tuples_to_bucket/main.cpp diff --git a/ydb/library/yql/utils/simd/exec/tuples_to_bucket/CMakeLists.linux-x86_64.txt b/ydb/library/yql/utils/simd/exec/tuples_to_bucket/CMakeLists.linux-x86_64.txt index 0114e548deac..d09ee38dc425 100644 --- a/ydb/library/yql/utils/simd/exec/tuples_to_bucket/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/utils/simd/exec/tuples_to_bucket/CMakeLists.linux-x86_64.txt @@ -21,9 +21,6 @@ target_link_options(tuples_to_bucket PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(tuples_to_bucket PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/simd/exec/tuples_to_bucket/main.cpp diff --git a/ydb/library/yql/utils/simd/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/utils/simd/ut/CMakeLists.darwin-arm64.txt index 8a0ecfef7588..ea3586c7593f 100644 --- a/ydb/library/yql/utils/simd/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/utils/simd/ut/CMakeLists.darwin-arm64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/simd/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/utils/simd/ut/CMakeLists.darwin-x86_64.txt index e03efb8a13fb..4a2572c0c1c5 100644 --- a/ydb/library/yql/utils/simd/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/utils/simd/ut/CMakeLists.darwin-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/simd/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/utils/simd/ut/CMakeLists.linux-aarch64.txt index 4c8657d7a5a7..a7c525f8ed21 100644 --- a/ydb/library/yql/utils/simd/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/utils/simd/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-yql-utils-simd-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-utils-simd-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/simd/simd_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/simd/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/utils/simd/ut/CMakeLists.linux-x86_64.txt index fc49024e6956..7ce12574b780 100644 --- a/ydb/library/yql/utils/simd/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/utils/simd/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-yql-utils-simd-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-utils-simd-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/simd/simd_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/simd/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/utils/simd/ut/CMakeLists.windows-x86_64.txt index 66276687c8a4..580fbc74c7ba 100644 --- a/ydb/library/yql/utils/simd/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/utils/simd/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/sys/CMakeLists.darwin-arm64.txt b/ydb/library/yql/utils/sys/CMakeLists.darwin-arm64.txt index 2a8129ae24e7..dcf7a81a31f9 100644 --- a/ydb/library/yql/utils/sys/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/utils/sys/CMakeLists.darwin-arm64.txt @@ -13,6 +13,8 @@ target_link_libraries(yql-utils-sys PUBLIC yutil ) target_sources(yql-utils-sys PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sys/become_user.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sys/linux_version.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sys/become_user_dummy.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sys/linux_version.cpp ) diff --git a/ydb/library/yql/utils/sys/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/utils/sys/CMakeLists.darwin-x86_64.txt index 2a8129ae24e7..dcf7a81a31f9 100644 --- a/ydb/library/yql/utils/sys/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/utils/sys/CMakeLists.darwin-x86_64.txt @@ -13,6 +13,8 @@ target_link_libraries(yql-utils-sys PUBLIC yutil ) target_sources(yql-utils-sys PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sys/become_user.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sys/linux_version.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sys/become_user_dummy.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sys/linux_version.cpp ) diff --git a/ydb/library/yql/utils/sys/CMakeLists.linux-aarch64.txt b/ydb/library/yql/utils/sys/CMakeLists.linux-aarch64.txt index 98acee73f568..0509b8d6f4ed 100644 --- a/ydb/library/yql/utils/sys/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/utils/sys/CMakeLists.linux-aarch64.txt @@ -15,6 +15,8 @@ target_link_libraries(yql-utils-sys PUBLIC contrib-libs-libcap ) target_sources(yql-utils-sys PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sys/become_user.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sys/linux_version.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sys/become_user_dummy.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sys/linux_version.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sys/become_user.cpp diff --git a/ydb/library/yql/utils/sys/CMakeLists.linux-x86_64.txt b/ydb/library/yql/utils/sys/CMakeLists.linux-x86_64.txt index 98acee73f568..0509b8d6f4ed 100644 --- a/ydb/library/yql/utils/sys/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/utils/sys/CMakeLists.linux-x86_64.txt @@ -15,6 +15,8 @@ target_link_libraries(yql-utils-sys PUBLIC contrib-libs-libcap ) target_sources(yql-utils-sys PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sys/become_user.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sys/linux_version.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sys/become_user_dummy.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sys/linux_version.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sys/become_user.cpp diff --git a/ydb/library/yql/utils/sys/CMakeLists.windows-x86_64.txt b/ydb/library/yql/utils/sys/CMakeLists.windows-x86_64.txt index 2a8129ae24e7..dcf7a81a31f9 100644 --- a/ydb/library/yql/utils/sys/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/utils/sys/CMakeLists.windows-x86_64.txt @@ -13,6 +13,8 @@ target_link_libraries(yql-utils-sys PUBLIC yutil ) target_sources(yql-utils-sys PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sys/become_user.h + ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sys/linux_version.h ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sys/become_user_dummy.cpp ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/sys/linux_version.cpp ) diff --git a/ydb/library/yql/utils/ut/CMakeLists.darwin-arm64.txt b/ydb/library/yql/utils/ut/CMakeLists.darwin-arm64.txt index 51b5a24b65a0..24a26944166c 100644 --- a/ydb/library/yql/utils/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yql/utils/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-library-yql-utils-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-utils-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/fp_bits_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/ut/CMakeLists.darwin-x86_64.txt b/ydb/library/yql/utils/ut/CMakeLists.darwin-x86_64.txt index 7ca160482969..0e808aedb5bd 100644 --- a/ydb/library/yql/utils/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yql/utils/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-library-yql-utils-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-library-yql-utils-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/fp_bits_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/ut/CMakeLists.linux-aarch64.txt b/ydb/library/yql/utils/ut/CMakeLists.linux-aarch64.txt index 7115c27f6ee2..8bdc5d882f81 100644 --- a/ydb/library/yql/utils/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/utils/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-library-yql-utils-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-utils-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/fp_bits_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/ut/CMakeLists.linux-x86_64.txt b/ydb/library/yql/utils/ut/CMakeLists.linux-x86_64.txt index 97c369b43611..838d3947d967 100644 --- a/ydb/library/yql/utils/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/utils/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-library-yql-utils-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-library-yql-utils-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/library/yql/utils/fp_bits_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/utils/ut/CMakeLists.windows-x86_64.txt b/ydb/library/yql/utils/ut/CMakeLists.windows-x86_64.txt index 9d75569a31d2..69870ddd94ec 100644 --- a/ydb/library/yql/utils/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yql/utils/ut/CMakeLists.windows-x86_64.txt @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/library/yql/yt/CMakeLists.linux-aarch64.txt b/ydb/library/yql/yt/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..e23f01db1e64 --- /dev/null +++ b/ydb/library/yql/yt/CMakeLists.linux-aarch64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(dynamic) +add_subdirectory(native) + +add_library(library-yql-yt) +target_link_libraries(library-yql-yt PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil +) +target_sources(library-yql-yt PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/yt/plugin.cpp +) diff --git a/ydb/library/yql/yt/CMakeLists.linux-x86_64.txt b/ydb/library/yql/yt/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..e23f01db1e64 --- /dev/null +++ b/ydb/library/yql/yt/CMakeLists.linux-x86_64.txt @@ -0,0 +1,20 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(dynamic) +add_subdirectory(native) + +add_library(library-yql-yt) +target_link_libraries(library-yql-yt PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil +) +target_sources(library-yql-yt PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/yt/plugin.cpp +) diff --git a/ydb/library/yql/yt/CMakeLists.txt b/ydb/library/yql/yt/CMakeLists.txt new file mode 100644 index 000000000000..d6c5c0bbeb44 --- /dev/null +++ b/ydb/library/yql/yt/CMakeLists.txt @@ -0,0 +1,13 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +endif() diff --git a/ydb/library/yql/yt/dynamic/CMakeLists.linux-aarch64.txt b/ydb/library/yql/yt/dynamic/CMakeLists.linux-aarch64.txt index 63edf774f285..a60f0b89f78f 100644 --- a/ydb/library/yql/yt/dynamic/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/yt/dynamic/CMakeLists.linux-aarch64.txt @@ -12,7 +12,7 @@ target_link_libraries(yqlplugin PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - yql-plugin-native + yql-yt-native ) target_link_options(yqlplugin PRIVATE -ldl @@ -21,15 +21,11 @@ target_link_options(yqlplugin PRIVATE -fPIC -Wl,-z,notext -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(yqlplugin PRIVATE - ${CMAKE_SOURCE_DIR}/yt/yql/plugin/dynamic/impl.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/yt/dynamic/impl.cpp ) use_export_script(yqlplugin - ${CMAKE_SOURCE_DIR}/yt/yql/plugin/dynamic/dylib.exports + ${CMAKE_SOURCE_DIR}/ydb/library/yql/yt/dynamic/dylib.exports ) vcs_info(yqlplugin) diff --git a/ydb/library/yql/yt/dynamic/CMakeLists.linux-x86_64.txt b/ydb/library/yql/yt/dynamic/CMakeLists.linux-x86_64.txt index 63edf774f285..a60f0b89f78f 100644 --- a/ydb/library/yql/yt/dynamic/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/yt/dynamic/CMakeLists.linux-x86_64.txt @@ -12,7 +12,7 @@ target_link_libraries(yqlplugin PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil - yql-plugin-native + yql-yt-native ) target_link_options(yqlplugin PRIVATE -ldl @@ -21,15 +21,11 @@ target_link_options(yqlplugin PRIVATE -fPIC -Wl,-z,notext -fPIC - -lpthread - -lrt - -ldl - -lutil ) target_sources(yqlplugin PRIVATE - ${CMAKE_SOURCE_DIR}/yt/yql/plugin/dynamic/impl.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/yt/dynamic/impl.cpp ) use_export_script(yqlplugin - ${CMAKE_SOURCE_DIR}/yt/yql/plugin/dynamic/dylib.exports + ${CMAKE_SOURCE_DIR}/ydb/library/yql/yt/dynamic/dylib.exports ) vcs_info(yqlplugin) diff --git a/ydb/library/yql/yt/dynamic/CMakeLists.txt b/ydb/library/yql/yt/dynamic/CMakeLists.txt index d863ebd18067..d6c5c0bbeb44 100644 --- a/ydb/library/yql/yt/dynamic/CMakeLists.txt +++ b/ydb/library/yql/yt/dynamic/CMakeLists.txt @@ -10,10 +10,4 @@ if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_ include(CMakeLists.linux-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) endif() diff --git a/ydb/library/yql/yt/native/CMakeLists.linux-aarch64.txt b/ydb/library/yql/yt/native/CMakeLists.linux-aarch64.txt index b9ac27203cd6..2bc97adc47d9 100644 --- a/ydb/library/yql/yt/native/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yql/yt/native/CMakeLists.linux-aarch64.txt @@ -7,11 +7,11 @@ -add_library(yql-plugin-native) -target_compile_options(yql-plugin-native PRIVATE +add_library(yql-yt-native) +target_compile_options(yql-yt-native PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(yql-plugin-native PUBLIC +target_link_libraries(yql-yt-native PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil @@ -47,18 +47,18 @@ target_link_libraries(yql-plugin-native PUBLIC yt-lib-log yt-lib-yt_download providers-yt-provider - yt-yql-plugin + library-yql-yt ) -target_sources(yql-plugin-native PRIVATE - ${CMAKE_SOURCE_DIR}/yt/yql/plugin/native/error_helpers.cpp - ${CMAKE_SOURCE_DIR}/yt/yql/plugin/native/progress_merger.cpp +target_sources(yql-yt-native PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/yt/native/error_helpers.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/yt/native/progress_merger.cpp ) -add_global_library_for(yql-plugin-native.global yql-plugin-native) -target_compile_options(yql-plugin-native.global PRIVATE +add_global_library_for(yql-yt-native.global yql-yt-native) +target_compile_options(yql-yt-native.global PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(yql-plugin-native.global PUBLIC +target_link_libraries(yql-yt-native.global PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil @@ -94,8 +94,8 @@ target_link_libraries(yql-plugin-native.global PUBLIC yt-lib-log yt-lib-yt_download providers-yt-provider - yt-yql-plugin + library-yql-yt ) -target_sources(yql-plugin-native.global PRIVATE - ${CMAKE_SOURCE_DIR}/yt/yql/plugin/native/plugin.cpp +target_sources(yql-yt-native.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/yt/native/plugin.cpp ) diff --git a/ydb/library/yql/yt/native/CMakeLists.linux-x86_64.txt b/ydb/library/yql/yt/native/CMakeLists.linux-x86_64.txt index b9ac27203cd6..2bc97adc47d9 100644 --- a/ydb/library/yql/yt/native/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yql/yt/native/CMakeLists.linux-x86_64.txt @@ -7,11 +7,11 @@ -add_library(yql-plugin-native) -target_compile_options(yql-plugin-native PRIVATE +add_library(yql-yt-native) +target_compile_options(yql-yt-native PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(yql-plugin-native PUBLIC +target_link_libraries(yql-yt-native PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil @@ -47,18 +47,18 @@ target_link_libraries(yql-plugin-native PUBLIC yt-lib-log yt-lib-yt_download providers-yt-provider - yt-yql-plugin + library-yql-yt ) -target_sources(yql-plugin-native PRIVATE - ${CMAKE_SOURCE_DIR}/yt/yql/plugin/native/error_helpers.cpp - ${CMAKE_SOURCE_DIR}/yt/yql/plugin/native/progress_merger.cpp +target_sources(yql-yt-native PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/yt/native/error_helpers.cpp + ${CMAKE_SOURCE_DIR}/ydb/library/yql/yt/native/progress_merger.cpp ) -add_global_library_for(yql-plugin-native.global yql-plugin-native) -target_compile_options(yql-plugin-native.global PRIVATE +add_global_library_for(yql-yt-native.global yql-yt-native) +target_compile_options(yql-yt-native.global PRIVATE -DUSE_CURRENT_UDF_ABI_VERSION ) -target_link_libraries(yql-plugin-native.global PUBLIC +target_link_libraries(yql-yt-native.global PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil @@ -94,8 +94,8 @@ target_link_libraries(yql-plugin-native.global PUBLIC yt-lib-log yt-lib-yt_download providers-yt-provider - yt-yql-plugin + library-yql-yt ) -target_sources(yql-plugin-native.global PRIVATE - ${CMAKE_SOURCE_DIR}/yt/yql/plugin/native/plugin.cpp +target_sources(yql-yt-native.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/library/yql/yt/native/plugin.cpp ) diff --git a/ydb/library/yql/yt/native/CMakeLists.txt b/ydb/library/yql/yt/native/CMakeLists.txt index d863ebd18067..d6c5c0bbeb44 100644 --- a/ydb/library/yql/yt/native/CMakeLists.txt +++ b/ydb/library/yql/yt/native/CMakeLists.txt @@ -10,10 +10,4 @@ if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_ include(CMakeLists.linux-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) endif() diff --git a/ydb/library/yverify_stream/CMakeLists.darwin-arm64.txt b/ydb/library/yverify_stream/CMakeLists.darwin-arm64.txt index 32f3123873bc..870ca0ebca40 100644 --- a/ydb/library/yverify_stream/CMakeLists.darwin-arm64.txt +++ b/ydb/library/yverify_stream/CMakeLists.darwin-arm64.txt @@ -12,3 +12,6 @@ target_link_libraries(ydb-library-yverify_stream INTERFACE contrib-libs-cxxsupp yutil ) +target_sources(ydb-library-yverify_stream INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/yverify_stream/yverify_stream.h +) diff --git a/ydb/library/yverify_stream/CMakeLists.darwin-x86_64.txt b/ydb/library/yverify_stream/CMakeLists.darwin-x86_64.txt index 32f3123873bc..870ca0ebca40 100644 --- a/ydb/library/yverify_stream/CMakeLists.darwin-x86_64.txt +++ b/ydb/library/yverify_stream/CMakeLists.darwin-x86_64.txt @@ -12,3 +12,6 @@ target_link_libraries(ydb-library-yverify_stream INTERFACE contrib-libs-cxxsupp yutil ) +target_sources(ydb-library-yverify_stream INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/yverify_stream/yverify_stream.h +) diff --git a/ydb/library/yverify_stream/CMakeLists.linux-aarch64.txt b/ydb/library/yverify_stream/CMakeLists.linux-aarch64.txt index 1fe4c0e9c0ab..a1e53dafd860 100644 --- a/ydb/library/yverify_stream/CMakeLists.linux-aarch64.txt +++ b/ydb/library/yverify_stream/CMakeLists.linux-aarch64.txt @@ -13,3 +13,6 @@ target_link_libraries(ydb-library-yverify_stream INTERFACE contrib-libs-cxxsupp yutil ) +target_sources(ydb-library-yverify_stream INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/yverify_stream/yverify_stream.h +) diff --git a/ydb/library/yverify_stream/CMakeLists.linux-x86_64.txt b/ydb/library/yverify_stream/CMakeLists.linux-x86_64.txt index 1fe4c0e9c0ab..a1e53dafd860 100644 --- a/ydb/library/yverify_stream/CMakeLists.linux-x86_64.txt +++ b/ydb/library/yverify_stream/CMakeLists.linux-x86_64.txt @@ -13,3 +13,6 @@ target_link_libraries(ydb-library-yverify_stream INTERFACE contrib-libs-cxxsupp yutil ) +target_sources(ydb-library-yverify_stream INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/yverify_stream/yverify_stream.h +) diff --git a/ydb/library/yverify_stream/CMakeLists.windows-x86_64.txt b/ydb/library/yverify_stream/CMakeLists.windows-x86_64.txt index 32f3123873bc..870ca0ebca40 100644 --- a/ydb/library/yverify_stream/CMakeLists.windows-x86_64.txt +++ b/ydb/library/yverify_stream/CMakeLists.windows-x86_64.txt @@ -12,3 +12,6 @@ target_link_libraries(ydb-library-yverify_stream INTERFACE contrib-libs-cxxsupp yutil ) +target_sources(ydb-library-yverify_stream INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/library/yverify_stream/yverify_stream.h +) diff --git a/ydb/public/api/client/yc_private/CMakeLists.txt b/ydb/public/api/client/yc_private/CMakeLists.txt index 7869b2eaa912..844a2b3d1e6f 100644 --- a/ydb/public/api/client/yc_private/CMakeLists.txt +++ b/ydb/public/api/client/yc_private/CMakeLists.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(accessservice) add_subdirectory(compute) add_subdirectory(iam) add_subdirectory(kms) diff --git a/ydb/public/api/client/yc_private/accessservice/CMakeLists.darwin-arm64.txt b/ydb/public/api/client/yc_private/accessservice/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..4ee4ecf64e92 --- /dev/null +++ b/ydb/public/api/client/yc_private/accessservice/CMakeLists.darwin-arm64.txt @@ -0,0 +1,93 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_grpc_cpp_bin + TOOL_grpc_cpp_dependency + contrib/tools/protoc/plugins/grpc_cpp + grpc_cpp +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) + +add_library(client-yc_private-accessservice) +set_property(TARGET client-yc_private-accessservice PROPERTY + PROTOC_EXTRA_OUTS .grpc.pb.cc .grpc.pb.h +) +target_link_libraries(client-yc_private-accessservice PUBLIC + contrib-libs-googleapis-common-protos + contrib-libs-cxxsupp + yutil + contrib-libs-grpc + contrib-libs-protobuf +) +target_proto_messages(client-yc_private-accessservice PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/accessservice/access_service.proto + ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/accessservice/resource.proto + ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/accessservice/sensitive.proto +) +target_sources(client-yc_private-accessservice PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/access_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/access_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/resource.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/resource.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/sensitive.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/sensitive.grpc.pb.h +) +target_proto_addincls(client-yc_private-accessservice + ./ + ${CMAKE_SOURCE_DIR}/ + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/googleapis-common-protos + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src +) +target_proto_outs(client-yc_private-accessservice + --cpp_out=${CMAKE_BINARY_DIR}/ + --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ +) +target_proto_plugin(client-yc_private-accessservice + grpc_cpp + grpc_cpp +) diff --git a/ydb/public/api/client/yc_private/accessservice/CMakeLists.darwin-x86_64.txt b/ydb/public/api/client/yc_private/accessservice/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..4ee4ecf64e92 --- /dev/null +++ b/ydb/public/api/client/yc_private/accessservice/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,93 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_grpc_cpp_bin + TOOL_grpc_cpp_dependency + contrib/tools/protoc/plugins/grpc_cpp + grpc_cpp +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) + +add_library(client-yc_private-accessservice) +set_property(TARGET client-yc_private-accessservice PROPERTY + PROTOC_EXTRA_OUTS .grpc.pb.cc .grpc.pb.h +) +target_link_libraries(client-yc_private-accessservice PUBLIC + contrib-libs-googleapis-common-protos + contrib-libs-cxxsupp + yutil + contrib-libs-grpc + contrib-libs-protobuf +) +target_proto_messages(client-yc_private-accessservice PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/accessservice/access_service.proto + ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/accessservice/resource.proto + ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/accessservice/sensitive.proto +) +target_sources(client-yc_private-accessservice PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/access_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/access_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/resource.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/resource.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/sensitive.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/sensitive.grpc.pb.h +) +target_proto_addincls(client-yc_private-accessservice + ./ + ${CMAKE_SOURCE_DIR}/ + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/googleapis-common-protos + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src +) +target_proto_outs(client-yc_private-accessservice + --cpp_out=${CMAKE_BINARY_DIR}/ + --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ +) +target_proto_plugin(client-yc_private-accessservice + grpc_cpp + grpc_cpp +) diff --git a/ydb/public/api/client/yc_private/accessservice/CMakeLists.linux-aarch64.txt b/ydb/public/api/client/yc_private/accessservice/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..a0f947598ea8 --- /dev/null +++ b/ydb/public/api/client/yc_private/accessservice/CMakeLists.linux-aarch64.txt @@ -0,0 +1,94 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_grpc_cpp_bin + TOOL_grpc_cpp_dependency + contrib/tools/protoc/plugins/grpc_cpp + grpc_cpp +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) + +add_library(client-yc_private-accessservice) +set_property(TARGET client-yc_private-accessservice PROPERTY + PROTOC_EXTRA_OUTS .grpc.pb.cc .grpc.pb.h +) +target_link_libraries(client-yc_private-accessservice PUBLIC + contrib-libs-googleapis-common-protos + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + contrib-libs-grpc + contrib-libs-protobuf +) +target_proto_messages(client-yc_private-accessservice PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/accessservice/access_service.proto + ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/accessservice/resource.proto + ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/accessservice/sensitive.proto +) +target_sources(client-yc_private-accessservice PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/access_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/access_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/resource.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/resource.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/sensitive.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/sensitive.grpc.pb.h +) +target_proto_addincls(client-yc_private-accessservice + ./ + ${CMAKE_SOURCE_DIR}/ + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/googleapis-common-protos + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src +) +target_proto_outs(client-yc_private-accessservice + --cpp_out=${CMAKE_BINARY_DIR}/ + --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ +) +target_proto_plugin(client-yc_private-accessservice + grpc_cpp + grpc_cpp +) diff --git a/ydb/public/api/client/yc_private/accessservice/CMakeLists.linux-x86_64.txt b/ydb/public/api/client/yc_private/accessservice/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..a0f947598ea8 --- /dev/null +++ b/ydb/public/api/client/yc_private/accessservice/CMakeLists.linux-x86_64.txt @@ -0,0 +1,94 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_grpc_cpp_bin + TOOL_grpc_cpp_dependency + contrib/tools/protoc/plugins/grpc_cpp + grpc_cpp +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) + +add_library(client-yc_private-accessservice) +set_property(TARGET client-yc_private-accessservice PROPERTY + PROTOC_EXTRA_OUTS .grpc.pb.cc .grpc.pb.h +) +target_link_libraries(client-yc_private-accessservice PUBLIC + contrib-libs-googleapis-common-protos + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + contrib-libs-grpc + contrib-libs-protobuf +) +target_proto_messages(client-yc_private-accessservice PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/accessservice/access_service.proto + ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/accessservice/resource.proto + ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/accessservice/sensitive.proto +) +target_sources(client-yc_private-accessservice PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/access_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/access_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/resource.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/resource.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/sensitive.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/sensitive.grpc.pb.h +) +target_proto_addincls(client-yc_private-accessservice + ./ + ${CMAKE_SOURCE_DIR}/ + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/googleapis-common-protos + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src +) +target_proto_outs(client-yc_private-accessservice + --cpp_out=${CMAKE_BINARY_DIR}/ + --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ +) +target_proto_plugin(client-yc_private-accessservice + grpc_cpp + grpc_cpp +) diff --git a/ydb/public/api/client/yc_private/accessservice/CMakeLists.txt b/ydb/public/api/client/yc_private/accessservice/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/public/api/client/yc_private/accessservice/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/public/api/client/yc_private/accessservice/CMakeLists.windows-x86_64.txt b/ydb/public/api/client/yc_private/accessservice/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..4ee4ecf64e92 --- /dev/null +++ b/ydb/public/api/client/yc_private/accessservice/CMakeLists.windows-x86_64.txt @@ -0,0 +1,93 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_grpc_cpp_bin + TOOL_grpc_cpp_dependency + contrib/tools/protoc/plugins/grpc_cpp + grpc_cpp +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) + +add_library(client-yc_private-accessservice) +set_property(TARGET client-yc_private-accessservice PROPERTY + PROTOC_EXTRA_OUTS .grpc.pb.cc .grpc.pb.h +) +target_link_libraries(client-yc_private-accessservice PUBLIC + contrib-libs-googleapis-common-protos + contrib-libs-cxxsupp + yutil + contrib-libs-grpc + contrib-libs-protobuf +) +target_proto_messages(client-yc_private-accessservice PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/accessservice/access_service.proto + ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/accessservice/resource.proto + ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/accessservice/sensitive.proto +) +target_sources(client-yc_private-accessservice PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/access_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/access_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/resource.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/resource.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/sensitive.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/accessservice/sensitive.grpc.pb.h +) +target_proto_addincls(client-yc_private-accessservice + ./ + ${CMAKE_SOURCE_DIR}/ + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/googleapis-common-protos + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src +) +target_proto_outs(client-yc_private-accessservice + --cpp_out=${CMAKE_BINARY_DIR}/ + --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ +) +target_proto_plugin(client-yc_private-accessservice + grpc_cpp + grpc_cpp +) diff --git a/ydb/public/api/client/yc_private/compute/inner/CMakeLists.darwin-arm64.txt b/ydb/public/api/client/yc_private/compute/inner/CMakeLists.darwin-arm64.txt index 9f7e92b4da2d..c06027184ba9 100644 --- a/ydb/public/api/client/yc_private/compute/inner/CMakeLists.darwin-arm64.txt +++ b/ydb/public/api/client/yc_private/compute/inner/CMakeLists.darwin-arm64.txt @@ -38,6 +38,10 @@ target_link_libraries(yc_private-compute-inner PUBLIC target_proto_messages(yc_private-compute-inner PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/compute/inner/disk_service.proto ) +target_sources(yc_private-compute-inner PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/compute/inner/disk_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/compute/inner/disk_service.grpc.pb.h +) target_proto_addincls(yc_private-compute-inner ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/compute/inner/CMakeLists.darwin-x86_64.txt b/ydb/public/api/client/yc_private/compute/inner/CMakeLists.darwin-x86_64.txt index 9f7e92b4da2d..c06027184ba9 100644 --- a/ydb/public/api/client/yc_private/compute/inner/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/api/client/yc_private/compute/inner/CMakeLists.darwin-x86_64.txt @@ -38,6 +38,10 @@ target_link_libraries(yc_private-compute-inner PUBLIC target_proto_messages(yc_private-compute-inner PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/compute/inner/disk_service.proto ) +target_sources(yc_private-compute-inner PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/compute/inner/disk_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/compute/inner/disk_service.grpc.pb.h +) target_proto_addincls(yc_private-compute-inner ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/compute/inner/CMakeLists.linux-aarch64.txt b/ydb/public/api/client/yc_private/compute/inner/CMakeLists.linux-aarch64.txt index 487041d279cc..d93f739bb54c 100644 --- a/ydb/public/api/client/yc_private/compute/inner/CMakeLists.linux-aarch64.txt +++ b/ydb/public/api/client/yc_private/compute/inner/CMakeLists.linux-aarch64.txt @@ -39,6 +39,10 @@ target_link_libraries(yc_private-compute-inner PUBLIC target_proto_messages(yc_private-compute-inner PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/compute/inner/disk_service.proto ) +target_sources(yc_private-compute-inner PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/compute/inner/disk_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/compute/inner/disk_service.grpc.pb.h +) target_proto_addincls(yc_private-compute-inner ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/compute/inner/CMakeLists.linux-x86_64.txt b/ydb/public/api/client/yc_private/compute/inner/CMakeLists.linux-x86_64.txt index 487041d279cc..d93f739bb54c 100644 --- a/ydb/public/api/client/yc_private/compute/inner/CMakeLists.linux-x86_64.txt +++ b/ydb/public/api/client/yc_private/compute/inner/CMakeLists.linux-x86_64.txt @@ -39,6 +39,10 @@ target_link_libraries(yc_private-compute-inner PUBLIC target_proto_messages(yc_private-compute-inner PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/compute/inner/disk_service.proto ) +target_sources(yc_private-compute-inner PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/compute/inner/disk_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/compute/inner/disk_service.grpc.pb.h +) target_proto_addincls(yc_private-compute-inner ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/compute/inner/CMakeLists.windows-x86_64.txt b/ydb/public/api/client/yc_private/compute/inner/CMakeLists.windows-x86_64.txt index 9f7e92b4da2d..c06027184ba9 100644 --- a/ydb/public/api/client/yc_private/compute/inner/CMakeLists.windows-x86_64.txt +++ b/ydb/public/api/client/yc_private/compute/inner/CMakeLists.windows-x86_64.txt @@ -38,6 +38,10 @@ target_link_libraries(yc_private-compute-inner PUBLIC target_proto_messages(yc_private-compute-inner PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/compute/inner/disk_service.proto ) +target_sources(yc_private-compute-inner PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/compute/inner/disk_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/compute/inner/disk_service.grpc.pb.h +) target_proto_addincls(yc_private-compute-inner ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/iam/CMakeLists.darwin-arm64.txt b/ydb/public/api/client/yc_private/iam/CMakeLists.darwin-arm64.txt index 218cc74d277b..ad19916c15b1 100644 --- a/ydb/public/api/client/yc_private/iam/CMakeLists.darwin-arm64.txt +++ b/ydb/public/api/client/yc_private/iam/CMakeLists.darwin-arm64.txt @@ -157,6 +157,28 @@ target_proto_messages(client-yc_private-iam PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/iam/user_account.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/iam/yandex_passport_cookie.proto ) +target_sources(client-yc_private-iam PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token_service_subject.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token_service_subject.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/oauth_request.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/oauth_request.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/reference.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/reference.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/service_account_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/service_account_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/service_account.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/service_account.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/user_account_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/user_account_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/user_account.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/user_account.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/yandex_passport_cookie.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/yandex_passport_cookie.grpc.pb.h +) target_proto_addincls(client-yc_private-iam ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/iam/CMakeLists.darwin-x86_64.txt b/ydb/public/api/client/yc_private/iam/CMakeLists.darwin-x86_64.txt index 218cc74d277b..ad19916c15b1 100644 --- a/ydb/public/api/client/yc_private/iam/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/api/client/yc_private/iam/CMakeLists.darwin-x86_64.txt @@ -157,6 +157,28 @@ target_proto_messages(client-yc_private-iam PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/iam/user_account.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/iam/yandex_passport_cookie.proto ) +target_sources(client-yc_private-iam PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token_service_subject.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token_service_subject.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/oauth_request.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/oauth_request.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/reference.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/reference.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/service_account_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/service_account_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/service_account.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/service_account.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/user_account_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/user_account_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/user_account.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/user_account.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/yandex_passport_cookie.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/yandex_passport_cookie.grpc.pb.h +) target_proto_addincls(client-yc_private-iam ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/iam/CMakeLists.linux-aarch64.txt b/ydb/public/api/client/yc_private/iam/CMakeLists.linux-aarch64.txt index 498f2017e86f..a8333416dda4 100644 --- a/ydb/public/api/client/yc_private/iam/CMakeLists.linux-aarch64.txt +++ b/ydb/public/api/client/yc_private/iam/CMakeLists.linux-aarch64.txt @@ -158,6 +158,28 @@ target_proto_messages(client-yc_private-iam PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/iam/user_account.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/iam/yandex_passport_cookie.proto ) +target_sources(client-yc_private-iam PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token_service_subject.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token_service_subject.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/oauth_request.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/oauth_request.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/reference.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/reference.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/service_account_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/service_account_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/service_account.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/service_account.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/user_account_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/user_account_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/user_account.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/user_account.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/yandex_passport_cookie.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/yandex_passport_cookie.grpc.pb.h +) target_proto_addincls(client-yc_private-iam ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/iam/CMakeLists.linux-x86_64.txt b/ydb/public/api/client/yc_private/iam/CMakeLists.linux-x86_64.txt index 498f2017e86f..a8333416dda4 100644 --- a/ydb/public/api/client/yc_private/iam/CMakeLists.linux-x86_64.txt +++ b/ydb/public/api/client/yc_private/iam/CMakeLists.linux-x86_64.txt @@ -158,6 +158,28 @@ target_proto_messages(client-yc_private-iam PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/iam/user_account.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/iam/yandex_passport_cookie.proto ) +target_sources(client-yc_private-iam PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token_service_subject.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token_service_subject.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/oauth_request.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/oauth_request.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/reference.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/reference.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/service_account_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/service_account_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/service_account.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/service_account.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/user_account_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/user_account_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/user_account.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/user_account.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/yandex_passport_cookie.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/yandex_passport_cookie.grpc.pb.h +) target_proto_addincls(client-yc_private-iam ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/iam/CMakeLists.windows-x86_64.txt b/ydb/public/api/client/yc_private/iam/CMakeLists.windows-x86_64.txt index 218cc74d277b..ad19916c15b1 100644 --- a/ydb/public/api/client/yc_private/iam/CMakeLists.windows-x86_64.txt +++ b/ydb/public/api/client/yc_private/iam/CMakeLists.windows-x86_64.txt @@ -157,6 +157,28 @@ target_proto_messages(client-yc_private-iam PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/iam/user_account.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/iam/yandex_passport_cookie.proto ) +target_sources(client-yc_private-iam PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token_service_subject.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token_service_subject.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/iam_token.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/oauth_request.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/oauth_request.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/reference.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/reference.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/service_account_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/service_account_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/service_account.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/service_account.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/user_account_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/user_account_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/user_account.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/user_account.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/yandex_passport_cookie.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/iam/yandex_passport_cookie.grpc.pb.h +) target_proto_addincls(client-yc_private-iam ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/kms/CMakeLists.darwin-arm64.txt b/ydb/public/api/client/yc_private/kms/CMakeLists.darwin-arm64.txt index d358f81b1137..de8ef2f2ee00 100644 --- a/ydb/public/api/client/yc_private/kms/CMakeLists.darwin-arm64.txt +++ b/ydb/public/api/client/yc_private/kms/CMakeLists.darwin-arm64.txt @@ -55,6 +55,12 @@ target_proto_messages(client-yc_private-kms PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/kms/symmetric_crypto_service.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/kms/symmetric_key.proto ) +target_sources(client-yc_private-kms PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/symmetric_crypto_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/symmetric_crypto_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/symmetric_key.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/symmetric_key.grpc.pb.h +) target_proto_addincls(client-yc_private-kms ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/kms/CMakeLists.darwin-x86_64.txt b/ydb/public/api/client/yc_private/kms/CMakeLists.darwin-x86_64.txt index d358f81b1137..de8ef2f2ee00 100644 --- a/ydb/public/api/client/yc_private/kms/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/api/client/yc_private/kms/CMakeLists.darwin-x86_64.txt @@ -55,6 +55,12 @@ target_proto_messages(client-yc_private-kms PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/kms/symmetric_crypto_service.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/kms/symmetric_key.proto ) +target_sources(client-yc_private-kms PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/symmetric_crypto_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/symmetric_crypto_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/symmetric_key.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/symmetric_key.grpc.pb.h +) target_proto_addincls(client-yc_private-kms ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/kms/CMakeLists.linux-aarch64.txt b/ydb/public/api/client/yc_private/kms/CMakeLists.linux-aarch64.txt index cc5fd5548e3b..ad319ee84e4a 100644 --- a/ydb/public/api/client/yc_private/kms/CMakeLists.linux-aarch64.txt +++ b/ydb/public/api/client/yc_private/kms/CMakeLists.linux-aarch64.txt @@ -56,6 +56,12 @@ target_proto_messages(client-yc_private-kms PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/kms/symmetric_crypto_service.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/kms/symmetric_key.proto ) +target_sources(client-yc_private-kms PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/symmetric_crypto_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/symmetric_crypto_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/symmetric_key.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/symmetric_key.grpc.pb.h +) target_proto_addincls(client-yc_private-kms ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/kms/CMakeLists.linux-x86_64.txt b/ydb/public/api/client/yc_private/kms/CMakeLists.linux-x86_64.txt index cc5fd5548e3b..ad319ee84e4a 100644 --- a/ydb/public/api/client/yc_private/kms/CMakeLists.linux-x86_64.txt +++ b/ydb/public/api/client/yc_private/kms/CMakeLists.linux-x86_64.txt @@ -56,6 +56,12 @@ target_proto_messages(client-yc_private-kms PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/kms/symmetric_crypto_service.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/kms/symmetric_key.proto ) +target_sources(client-yc_private-kms PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/symmetric_crypto_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/symmetric_crypto_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/symmetric_key.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/symmetric_key.grpc.pb.h +) target_proto_addincls(client-yc_private-kms ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/kms/CMakeLists.windows-x86_64.txt b/ydb/public/api/client/yc_private/kms/CMakeLists.windows-x86_64.txt index d358f81b1137..de8ef2f2ee00 100644 --- a/ydb/public/api/client/yc_private/kms/CMakeLists.windows-x86_64.txt +++ b/ydb/public/api/client/yc_private/kms/CMakeLists.windows-x86_64.txt @@ -55,6 +55,12 @@ target_proto_messages(client-yc_private-kms PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/kms/symmetric_crypto_service.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/kms/symmetric_key.proto ) +target_sources(client-yc_private-kms PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/symmetric_crypto_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/symmetric_crypto_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/symmetric_key.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/symmetric_key.grpc.pb.h +) target_proto_addincls(client-yc_private-kms ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/kms/asymmetricencryption/CMakeLists.darwin-arm64.txt b/ydb/public/api/client/yc_private/kms/asymmetricencryption/CMakeLists.darwin-arm64.txt index 1c930dcaa7fa..f1bb622fd4ab 100644 --- a/ydb/public/api/client/yc_private/kms/asymmetricencryption/CMakeLists.darwin-arm64.txt +++ b/ydb/public/api/client/yc_private/kms/asymmetricencryption/CMakeLists.darwin-arm64.txt @@ -38,6 +38,10 @@ target_link_libraries(yc_private-kms-asymmetricencryption PUBLIC target_proto_messages(yc_private-kms-asymmetricencryption PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/kms/asymmetricencryption/asymmetric_encryption_key.proto ) +target_sources(yc_private-kms-asymmetricencryption PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/asymmetricencryption/asymmetric_encryption_key.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/asymmetricencryption/asymmetric_encryption_key.grpc.pb.h +) target_proto_addincls(yc_private-kms-asymmetricencryption ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/kms/asymmetricencryption/CMakeLists.darwin-x86_64.txt b/ydb/public/api/client/yc_private/kms/asymmetricencryption/CMakeLists.darwin-x86_64.txt index 1c930dcaa7fa..f1bb622fd4ab 100644 --- a/ydb/public/api/client/yc_private/kms/asymmetricencryption/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/api/client/yc_private/kms/asymmetricencryption/CMakeLists.darwin-x86_64.txt @@ -38,6 +38,10 @@ target_link_libraries(yc_private-kms-asymmetricencryption PUBLIC target_proto_messages(yc_private-kms-asymmetricencryption PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/kms/asymmetricencryption/asymmetric_encryption_key.proto ) +target_sources(yc_private-kms-asymmetricencryption PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/asymmetricencryption/asymmetric_encryption_key.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/asymmetricencryption/asymmetric_encryption_key.grpc.pb.h +) target_proto_addincls(yc_private-kms-asymmetricencryption ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/kms/asymmetricencryption/CMakeLists.linux-aarch64.txt b/ydb/public/api/client/yc_private/kms/asymmetricencryption/CMakeLists.linux-aarch64.txt index eaed0d19a4db..ecce1618fbb6 100644 --- a/ydb/public/api/client/yc_private/kms/asymmetricencryption/CMakeLists.linux-aarch64.txt +++ b/ydb/public/api/client/yc_private/kms/asymmetricencryption/CMakeLists.linux-aarch64.txt @@ -39,6 +39,10 @@ target_link_libraries(yc_private-kms-asymmetricencryption PUBLIC target_proto_messages(yc_private-kms-asymmetricencryption PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/kms/asymmetricencryption/asymmetric_encryption_key.proto ) +target_sources(yc_private-kms-asymmetricencryption PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/asymmetricencryption/asymmetric_encryption_key.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/asymmetricencryption/asymmetric_encryption_key.grpc.pb.h +) target_proto_addincls(yc_private-kms-asymmetricencryption ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/kms/asymmetricencryption/CMakeLists.linux-x86_64.txt b/ydb/public/api/client/yc_private/kms/asymmetricencryption/CMakeLists.linux-x86_64.txt index eaed0d19a4db..ecce1618fbb6 100644 --- a/ydb/public/api/client/yc_private/kms/asymmetricencryption/CMakeLists.linux-x86_64.txt +++ b/ydb/public/api/client/yc_private/kms/asymmetricencryption/CMakeLists.linux-x86_64.txt @@ -39,6 +39,10 @@ target_link_libraries(yc_private-kms-asymmetricencryption PUBLIC target_proto_messages(yc_private-kms-asymmetricencryption PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/kms/asymmetricencryption/asymmetric_encryption_key.proto ) +target_sources(yc_private-kms-asymmetricencryption PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/asymmetricencryption/asymmetric_encryption_key.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/asymmetricencryption/asymmetric_encryption_key.grpc.pb.h +) target_proto_addincls(yc_private-kms-asymmetricencryption ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/kms/asymmetricencryption/CMakeLists.windows-x86_64.txt b/ydb/public/api/client/yc_private/kms/asymmetricencryption/CMakeLists.windows-x86_64.txt index 1c930dcaa7fa..f1bb622fd4ab 100644 --- a/ydb/public/api/client/yc_private/kms/asymmetricencryption/CMakeLists.windows-x86_64.txt +++ b/ydb/public/api/client/yc_private/kms/asymmetricencryption/CMakeLists.windows-x86_64.txt @@ -38,6 +38,10 @@ target_link_libraries(yc_private-kms-asymmetricencryption PUBLIC target_proto_messages(yc_private-kms-asymmetricencryption PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/kms/asymmetricencryption/asymmetric_encryption_key.proto ) +target_sources(yc_private-kms-asymmetricencryption PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/asymmetricencryption/asymmetric_encryption_key.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/asymmetricencryption/asymmetric_encryption_key.grpc.pb.h +) target_proto_addincls(yc_private-kms-asymmetricencryption ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/kms/asymmetricsignature/CMakeLists.darwin-arm64.txt b/ydb/public/api/client/yc_private/kms/asymmetricsignature/CMakeLists.darwin-arm64.txt index 2d51592240b3..ef15b0f1c792 100644 --- a/ydb/public/api/client/yc_private/kms/asymmetricsignature/CMakeLists.darwin-arm64.txt +++ b/ydb/public/api/client/yc_private/kms/asymmetricsignature/CMakeLists.darwin-arm64.txt @@ -38,6 +38,10 @@ target_link_libraries(yc_private-kms-asymmetricsignature PUBLIC target_proto_messages(yc_private-kms-asymmetricsignature PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/kms/asymmetricsignature/asymmetric_signature_key.proto ) +target_sources(yc_private-kms-asymmetricsignature PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/asymmetricsignature/asymmetric_signature_key.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/asymmetricsignature/asymmetric_signature_key.grpc.pb.h +) target_proto_addincls(yc_private-kms-asymmetricsignature ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/kms/asymmetricsignature/CMakeLists.darwin-x86_64.txt b/ydb/public/api/client/yc_private/kms/asymmetricsignature/CMakeLists.darwin-x86_64.txt index 2d51592240b3..ef15b0f1c792 100644 --- a/ydb/public/api/client/yc_private/kms/asymmetricsignature/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/api/client/yc_private/kms/asymmetricsignature/CMakeLists.darwin-x86_64.txt @@ -38,6 +38,10 @@ target_link_libraries(yc_private-kms-asymmetricsignature PUBLIC target_proto_messages(yc_private-kms-asymmetricsignature PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/kms/asymmetricsignature/asymmetric_signature_key.proto ) +target_sources(yc_private-kms-asymmetricsignature PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/asymmetricsignature/asymmetric_signature_key.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/asymmetricsignature/asymmetric_signature_key.grpc.pb.h +) target_proto_addincls(yc_private-kms-asymmetricsignature ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/kms/asymmetricsignature/CMakeLists.linux-aarch64.txt b/ydb/public/api/client/yc_private/kms/asymmetricsignature/CMakeLists.linux-aarch64.txt index d32b93b44e4b..60b23eb688b0 100644 --- a/ydb/public/api/client/yc_private/kms/asymmetricsignature/CMakeLists.linux-aarch64.txt +++ b/ydb/public/api/client/yc_private/kms/asymmetricsignature/CMakeLists.linux-aarch64.txt @@ -39,6 +39,10 @@ target_link_libraries(yc_private-kms-asymmetricsignature PUBLIC target_proto_messages(yc_private-kms-asymmetricsignature PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/kms/asymmetricsignature/asymmetric_signature_key.proto ) +target_sources(yc_private-kms-asymmetricsignature PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/asymmetricsignature/asymmetric_signature_key.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/asymmetricsignature/asymmetric_signature_key.grpc.pb.h +) target_proto_addincls(yc_private-kms-asymmetricsignature ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/kms/asymmetricsignature/CMakeLists.linux-x86_64.txt b/ydb/public/api/client/yc_private/kms/asymmetricsignature/CMakeLists.linux-x86_64.txt index d32b93b44e4b..60b23eb688b0 100644 --- a/ydb/public/api/client/yc_private/kms/asymmetricsignature/CMakeLists.linux-x86_64.txt +++ b/ydb/public/api/client/yc_private/kms/asymmetricsignature/CMakeLists.linux-x86_64.txt @@ -39,6 +39,10 @@ target_link_libraries(yc_private-kms-asymmetricsignature PUBLIC target_proto_messages(yc_private-kms-asymmetricsignature PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/kms/asymmetricsignature/asymmetric_signature_key.proto ) +target_sources(yc_private-kms-asymmetricsignature PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/asymmetricsignature/asymmetric_signature_key.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/asymmetricsignature/asymmetric_signature_key.grpc.pb.h +) target_proto_addincls(yc_private-kms-asymmetricsignature ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/kms/asymmetricsignature/CMakeLists.windows-x86_64.txt b/ydb/public/api/client/yc_private/kms/asymmetricsignature/CMakeLists.windows-x86_64.txt index 2d51592240b3..ef15b0f1c792 100644 --- a/ydb/public/api/client/yc_private/kms/asymmetricsignature/CMakeLists.windows-x86_64.txt +++ b/ydb/public/api/client/yc_private/kms/asymmetricsignature/CMakeLists.windows-x86_64.txt @@ -38,6 +38,10 @@ target_link_libraries(yc_private-kms-asymmetricsignature PUBLIC target_proto_messages(yc_private-kms-asymmetricsignature PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/kms/asymmetricsignature/asymmetric_signature_key.proto ) +target_sources(yc_private-kms-asymmetricsignature PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/asymmetricsignature/asymmetric_signature_key.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/kms/asymmetricsignature/asymmetric_signature_key.grpc.pb.h +) target_proto_addincls(yc_private-kms-asymmetricsignature ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/operation/CMakeLists.darwin-arm64.txt b/ydb/public/api/client/yc_private/operation/CMakeLists.darwin-arm64.txt index 97cc8932f73a..9d9bab04c306 100644 --- a/ydb/public/api/client/yc_private/operation/CMakeLists.darwin-arm64.txt +++ b/ydb/public/api/client/yc_private/operation/CMakeLists.darwin-arm64.txt @@ -39,6 +39,10 @@ target_link_libraries(client-yc_private-operation PUBLIC target_proto_messages(client-yc_private-operation PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/operation/operation.proto ) +target_sources(client-yc_private-operation PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/operation/operation.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/operation/operation.grpc.pb.h +) target_proto_addincls(client-yc_private-operation ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/operation/CMakeLists.darwin-x86_64.txt b/ydb/public/api/client/yc_private/operation/CMakeLists.darwin-x86_64.txt index 97cc8932f73a..9d9bab04c306 100644 --- a/ydb/public/api/client/yc_private/operation/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/api/client/yc_private/operation/CMakeLists.darwin-x86_64.txt @@ -39,6 +39,10 @@ target_link_libraries(client-yc_private-operation PUBLIC target_proto_messages(client-yc_private-operation PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/operation/operation.proto ) +target_sources(client-yc_private-operation PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/operation/operation.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/operation/operation.grpc.pb.h +) target_proto_addincls(client-yc_private-operation ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/operation/CMakeLists.linux-aarch64.txt b/ydb/public/api/client/yc_private/operation/CMakeLists.linux-aarch64.txt index 19e60d143fd2..bcc0989f7dd5 100644 --- a/ydb/public/api/client/yc_private/operation/CMakeLists.linux-aarch64.txt +++ b/ydb/public/api/client/yc_private/operation/CMakeLists.linux-aarch64.txt @@ -40,6 +40,10 @@ target_link_libraries(client-yc_private-operation PUBLIC target_proto_messages(client-yc_private-operation PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/operation/operation.proto ) +target_sources(client-yc_private-operation PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/operation/operation.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/operation/operation.grpc.pb.h +) target_proto_addincls(client-yc_private-operation ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/operation/CMakeLists.linux-x86_64.txt b/ydb/public/api/client/yc_private/operation/CMakeLists.linux-x86_64.txt index 19e60d143fd2..bcc0989f7dd5 100644 --- a/ydb/public/api/client/yc_private/operation/CMakeLists.linux-x86_64.txt +++ b/ydb/public/api/client/yc_private/operation/CMakeLists.linux-x86_64.txt @@ -40,6 +40,10 @@ target_link_libraries(client-yc_private-operation PUBLIC target_proto_messages(client-yc_private-operation PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/operation/operation.proto ) +target_sources(client-yc_private-operation PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/operation/operation.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/operation/operation.grpc.pb.h +) target_proto_addincls(client-yc_private-operation ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/operation/CMakeLists.windows-x86_64.txt b/ydb/public/api/client/yc_private/operation/CMakeLists.windows-x86_64.txt index 97cc8932f73a..9d9bab04c306 100644 --- a/ydb/public/api/client/yc_private/operation/CMakeLists.windows-x86_64.txt +++ b/ydb/public/api/client/yc_private/operation/CMakeLists.windows-x86_64.txt @@ -39,6 +39,10 @@ target_link_libraries(client-yc_private-operation PUBLIC target_proto_messages(client-yc_private-operation PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/operation/operation.proto ) +target_sources(client-yc_private-operation PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/operation/operation.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/operation/operation.grpc.pb.h +) target_proto_addincls(client-yc_private-operation ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/resourcemanager/CMakeLists.darwin-arm64.txt b/ydb/public/api/client/yc_private/resourcemanager/CMakeLists.darwin-arm64.txt index 267a6c51527f..6c354be68ca0 100644 --- a/ydb/public/api/client/yc_private/resourcemanager/CMakeLists.darwin-arm64.txt +++ b/ydb/public/api/client/yc_private/resourcemanager/CMakeLists.darwin-arm64.txt @@ -67,6 +67,14 @@ target_proto_messages(client-yc_private-resourcemanager PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/resourcemanager/transitional/folder_service.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder_service.proto ) +target_sources(client-yc_private-resourcemanager PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/transitional/folder_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/transitional/folder_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder_service.grpc.pb.h +) target_proto_addincls(client-yc_private-resourcemanager ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/resourcemanager/CMakeLists.darwin-x86_64.txt b/ydb/public/api/client/yc_private/resourcemanager/CMakeLists.darwin-x86_64.txt index 267a6c51527f..6c354be68ca0 100644 --- a/ydb/public/api/client/yc_private/resourcemanager/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/api/client/yc_private/resourcemanager/CMakeLists.darwin-x86_64.txt @@ -67,6 +67,14 @@ target_proto_messages(client-yc_private-resourcemanager PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/resourcemanager/transitional/folder_service.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder_service.proto ) +target_sources(client-yc_private-resourcemanager PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/transitional/folder_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/transitional/folder_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder_service.grpc.pb.h +) target_proto_addincls(client-yc_private-resourcemanager ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/resourcemanager/CMakeLists.linux-aarch64.txt b/ydb/public/api/client/yc_private/resourcemanager/CMakeLists.linux-aarch64.txt index 1c78669b473b..f83e0541b941 100644 --- a/ydb/public/api/client/yc_private/resourcemanager/CMakeLists.linux-aarch64.txt +++ b/ydb/public/api/client/yc_private/resourcemanager/CMakeLists.linux-aarch64.txt @@ -68,6 +68,14 @@ target_proto_messages(client-yc_private-resourcemanager PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/resourcemanager/transitional/folder_service.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder_service.proto ) +target_sources(client-yc_private-resourcemanager PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/transitional/folder_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/transitional/folder_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder_service.grpc.pb.h +) target_proto_addincls(client-yc_private-resourcemanager ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/resourcemanager/CMakeLists.linux-x86_64.txt b/ydb/public/api/client/yc_private/resourcemanager/CMakeLists.linux-x86_64.txt index 1c78669b473b..f83e0541b941 100644 --- a/ydb/public/api/client/yc_private/resourcemanager/CMakeLists.linux-x86_64.txt +++ b/ydb/public/api/client/yc_private/resourcemanager/CMakeLists.linux-x86_64.txt @@ -68,6 +68,14 @@ target_proto_messages(client-yc_private-resourcemanager PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/resourcemanager/transitional/folder_service.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder_service.proto ) +target_sources(client-yc_private-resourcemanager PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/transitional/folder_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/transitional/folder_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder_service.grpc.pb.h +) target_proto_addincls(client-yc_private-resourcemanager ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/resourcemanager/CMakeLists.windows-x86_64.txt b/ydb/public/api/client/yc_private/resourcemanager/CMakeLists.windows-x86_64.txt index 267a6c51527f..6c354be68ca0 100644 --- a/ydb/public/api/client/yc_private/resourcemanager/CMakeLists.windows-x86_64.txt +++ b/ydb/public/api/client/yc_private/resourcemanager/CMakeLists.windows-x86_64.txt @@ -67,6 +67,14 @@ target_proto_messages(client-yc_private-resourcemanager PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/resourcemanager/transitional/folder_service.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder_service.proto ) +target_sources(client-yc_private-resourcemanager PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/transitional/folder_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/transitional/folder_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/resourcemanager/folder_service.grpc.pb.h +) target_proto_addincls(client-yc_private-resourcemanager ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/servicecontrol/CMakeLists.darwin-arm64.txt b/ydb/public/api/client/yc_private/servicecontrol/CMakeLists.darwin-arm64.txt index 0a8651e29d9f..e988965acb69 100644 --- a/ydb/public/api/client/yc_private/servicecontrol/CMakeLists.darwin-arm64.txt +++ b/ydb/public/api/client/yc_private/servicecontrol/CMakeLists.darwin-arm64.txt @@ -52,6 +52,12 @@ target_proto_messages(client-yc_private-servicecontrol PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/servicecontrol/access_service.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/servicecontrol/resource.proto ) +target_sources(client-yc_private-servicecontrol PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/servicecontrol/access_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/servicecontrol/access_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/servicecontrol/resource.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/servicecontrol/resource.grpc.pb.h +) target_proto_addincls(client-yc_private-servicecontrol ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/servicecontrol/CMakeLists.darwin-x86_64.txt b/ydb/public/api/client/yc_private/servicecontrol/CMakeLists.darwin-x86_64.txt index 0a8651e29d9f..e988965acb69 100644 --- a/ydb/public/api/client/yc_private/servicecontrol/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/api/client/yc_private/servicecontrol/CMakeLists.darwin-x86_64.txt @@ -52,6 +52,12 @@ target_proto_messages(client-yc_private-servicecontrol PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/servicecontrol/access_service.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/servicecontrol/resource.proto ) +target_sources(client-yc_private-servicecontrol PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/servicecontrol/access_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/servicecontrol/access_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/servicecontrol/resource.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/servicecontrol/resource.grpc.pb.h +) target_proto_addincls(client-yc_private-servicecontrol ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/servicecontrol/CMakeLists.linux-aarch64.txt b/ydb/public/api/client/yc_private/servicecontrol/CMakeLists.linux-aarch64.txt index ed9cff8ba65a..0f5d610c2507 100644 --- a/ydb/public/api/client/yc_private/servicecontrol/CMakeLists.linux-aarch64.txt +++ b/ydb/public/api/client/yc_private/servicecontrol/CMakeLists.linux-aarch64.txt @@ -53,6 +53,12 @@ target_proto_messages(client-yc_private-servicecontrol PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/servicecontrol/access_service.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/servicecontrol/resource.proto ) +target_sources(client-yc_private-servicecontrol PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/servicecontrol/access_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/servicecontrol/access_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/servicecontrol/resource.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/servicecontrol/resource.grpc.pb.h +) target_proto_addincls(client-yc_private-servicecontrol ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/servicecontrol/CMakeLists.linux-x86_64.txt b/ydb/public/api/client/yc_private/servicecontrol/CMakeLists.linux-x86_64.txt index ed9cff8ba65a..0f5d610c2507 100644 --- a/ydb/public/api/client/yc_private/servicecontrol/CMakeLists.linux-x86_64.txt +++ b/ydb/public/api/client/yc_private/servicecontrol/CMakeLists.linux-x86_64.txt @@ -53,6 +53,12 @@ target_proto_messages(client-yc_private-servicecontrol PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/servicecontrol/access_service.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/servicecontrol/resource.proto ) +target_sources(client-yc_private-servicecontrol PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/servicecontrol/access_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/servicecontrol/access_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/servicecontrol/resource.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/servicecontrol/resource.grpc.pb.h +) target_proto_addincls(client-yc_private-servicecontrol ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_private/servicecontrol/CMakeLists.windows-x86_64.txt b/ydb/public/api/client/yc_private/servicecontrol/CMakeLists.windows-x86_64.txt index 0a8651e29d9f..e988965acb69 100644 --- a/ydb/public/api/client/yc_private/servicecontrol/CMakeLists.windows-x86_64.txt +++ b/ydb/public/api/client/yc_private/servicecontrol/CMakeLists.windows-x86_64.txt @@ -52,6 +52,12 @@ target_proto_messages(client-yc_private-servicecontrol PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/servicecontrol/access_service.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_private/servicecontrol/resource.proto ) +target_sources(client-yc_private-servicecontrol PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/servicecontrol/access_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/servicecontrol/access_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/servicecontrol/resource.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_private/servicecontrol/resource.grpc.pb.h +) target_proto_addincls(client-yc_private-servicecontrol ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_public/common/CMakeLists.darwin-arm64.txt b/ydb/public/api/client/yc_public/common/CMakeLists.darwin-arm64.txt index f33957c22e07..e135331434bf 100644 --- a/ydb/public/api/client/yc_public/common/CMakeLists.darwin-arm64.txt +++ b/ydb/public/api/client/yc_public/common/CMakeLists.darwin-arm64.txt @@ -39,6 +39,10 @@ target_link_libraries(client-yc_public-common PUBLIC target_proto_messages(client-yc_public-common PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/common/validation.proto ) +target_sources(client-yc_public-common PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/common/validation.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/common/validation.grpc.pb.h +) target_proto_addincls(client-yc_public-common ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_public/common/CMakeLists.darwin-x86_64.txt b/ydb/public/api/client/yc_public/common/CMakeLists.darwin-x86_64.txt index f33957c22e07..e135331434bf 100644 --- a/ydb/public/api/client/yc_public/common/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/api/client/yc_public/common/CMakeLists.darwin-x86_64.txt @@ -39,6 +39,10 @@ target_link_libraries(client-yc_public-common PUBLIC target_proto_messages(client-yc_public-common PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/common/validation.proto ) +target_sources(client-yc_public-common PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/common/validation.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/common/validation.grpc.pb.h +) target_proto_addincls(client-yc_public-common ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_public/common/CMakeLists.linux-aarch64.txt b/ydb/public/api/client/yc_public/common/CMakeLists.linux-aarch64.txt index c883515f4383..3a55b247f941 100644 --- a/ydb/public/api/client/yc_public/common/CMakeLists.linux-aarch64.txt +++ b/ydb/public/api/client/yc_public/common/CMakeLists.linux-aarch64.txt @@ -40,6 +40,10 @@ target_link_libraries(client-yc_public-common PUBLIC target_proto_messages(client-yc_public-common PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/common/validation.proto ) +target_sources(client-yc_public-common PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/common/validation.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/common/validation.grpc.pb.h +) target_proto_addincls(client-yc_public-common ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_public/common/CMakeLists.linux-x86_64.txt b/ydb/public/api/client/yc_public/common/CMakeLists.linux-x86_64.txt index c883515f4383..3a55b247f941 100644 --- a/ydb/public/api/client/yc_public/common/CMakeLists.linux-x86_64.txt +++ b/ydb/public/api/client/yc_public/common/CMakeLists.linux-x86_64.txt @@ -40,6 +40,10 @@ target_link_libraries(client-yc_public-common PUBLIC target_proto_messages(client-yc_public-common PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/common/validation.proto ) +target_sources(client-yc_public-common PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/common/validation.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/common/validation.grpc.pb.h +) target_proto_addincls(client-yc_public-common ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_public/common/CMakeLists.windows-x86_64.txt b/ydb/public/api/client/yc_public/common/CMakeLists.windows-x86_64.txt index f33957c22e07..e135331434bf 100644 --- a/ydb/public/api/client/yc_public/common/CMakeLists.windows-x86_64.txt +++ b/ydb/public/api/client/yc_public/common/CMakeLists.windows-x86_64.txt @@ -39,6 +39,10 @@ target_link_libraries(client-yc_public-common PUBLIC target_proto_messages(client-yc_public-common PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/common/validation.proto ) +target_sources(client-yc_public-common PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/common/validation.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/common/validation.grpc.pb.h +) target_proto_addincls(client-yc_public-common ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_public/events/CMakeLists.darwin-arm64.txt b/ydb/public/api/client/yc_public/events/CMakeLists.darwin-arm64.txt index 554d97242b11..969363e46970 100644 --- a/ydb/public/api/client/yc_public/events/CMakeLists.darwin-arm64.txt +++ b/ydb/public/api/client/yc_public/events/CMakeLists.darwin-arm64.txt @@ -66,6 +66,14 @@ target_proto_messages(client-yc_public-events PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/events/common.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/events/yq.proto ) +target_sources(client-yc_public-events PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/options.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/options.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/common.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/common.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/yq.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/yq.grpc.pb.h +) target_proto_addincls(client-yc_public-events ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_public/events/CMakeLists.darwin-x86_64.txt b/ydb/public/api/client/yc_public/events/CMakeLists.darwin-x86_64.txt index 554d97242b11..969363e46970 100644 --- a/ydb/public/api/client/yc_public/events/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/api/client/yc_public/events/CMakeLists.darwin-x86_64.txt @@ -66,6 +66,14 @@ target_proto_messages(client-yc_public-events PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/events/common.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/events/yq.proto ) +target_sources(client-yc_public-events PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/options.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/options.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/common.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/common.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/yq.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/yq.grpc.pb.h +) target_proto_addincls(client-yc_public-events ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_public/events/CMakeLists.linux-aarch64.txt b/ydb/public/api/client/yc_public/events/CMakeLists.linux-aarch64.txt index 96d965d41af4..7769ac3279e1 100644 --- a/ydb/public/api/client/yc_public/events/CMakeLists.linux-aarch64.txt +++ b/ydb/public/api/client/yc_public/events/CMakeLists.linux-aarch64.txt @@ -67,6 +67,14 @@ target_proto_messages(client-yc_public-events PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/events/common.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/events/yq.proto ) +target_sources(client-yc_public-events PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/options.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/options.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/common.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/common.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/yq.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/yq.grpc.pb.h +) target_proto_addincls(client-yc_public-events ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_public/events/CMakeLists.linux-x86_64.txt b/ydb/public/api/client/yc_public/events/CMakeLists.linux-x86_64.txt index 96d965d41af4..7769ac3279e1 100644 --- a/ydb/public/api/client/yc_public/events/CMakeLists.linux-x86_64.txt +++ b/ydb/public/api/client/yc_public/events/CMakeLists.linux-x86_64.txt @@ -67,6 +67,14 @@ target_proto_messages(client-yc_public-events PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/events/common.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/events/yq.proto ) +target_sources(client-yc_public-events PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/options.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/options.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/common.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/common.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/yq.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/yq.grpc.pb.h +) target_proto_addincls(client-yc_public-events ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_public/events/CMakeLists.windows-x86_64.txt b/ydb/public/api/client/yc_public/events/CMakeLists.windows-x86_64.txt index 554d97242b11..969363e46970 100644 --- a/ydb/public/api/client/yc_public/events/CMakeLists.windows-x86_64.txt +++ b/ydb/public/api/client/yc_public/events/CMakeLists.windows-x86_64.txt @@ -66,6 +66,14 @@ target_proto_messages(client-yc_public-events PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/events/common.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/events/yq.proto ) +target_sources(client-yc_public-events PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/options.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/options.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/common.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/common.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/yq.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/events/yq.grpc.pb.h +) target_proto_addincls(client-yc_public-events ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_public/iam/CMakeLists.darwin-arm64.txt b/ydb/public/api/client/yc_public/iam/CMakeLists.darwin-arm64.txt index 1b286b49c6c4..4b441f29b40f 100644 --- a/ydb/public/api/client/yc_public/iam/CMakeLists.darwin-arm64.txt +++ b/ydb/public/api/client/yc_public/iam/CMakeLists.darwin-arm64.txt @@ -40,6 +40,10 @@ target_link_libraries(client-yc_public-iam PUBLIC target_proto_messages(client-yc_public-iam PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/iam/iam_token_service.proto ) +target_sources(client-yc_public-iam PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/iam/iam_token_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/iam/iam_token_service.grpc.pb.h +) target_proto_addincls(client-yc_public-iam ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_public/iam/CMakeLists.darwin-x86_64.txt b/ydb/public/api/client/yc_public/iam/CMakeLists.darwin-x86_64.txt index 1b286b49c6c4..4b441f29b40f 100644 --- a/ydb/public/api/client/yc_public/iam/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/api/client/yc_public/iam/CMakeLists.darwin-x86_64.txt @@ -40,6 +40,10 @@ target_link_libraries(client-yc_public-iam PUBLIC target_proto_messages(client-yc_public-iam PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/iam/iam_token_service.proto ) +target_sources(client-yc_public-iam PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/iam/iam_token_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/iam/iam_token_service.grpc.pb.h +) target_proto_addincls(client-yc_public-iam ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_public/iam/CMakeLists.linux-aarch64.txt b/ydb/public/api/client/yc_public/iam/CMakeLists.linux-aarch64.txt index f6794279095b..44726e846693 100644 --- a/ydb/public/api/client/yc_public/iam/CMakeLists.linux-aarch64.txt +++ b/ydb/public/api/client/yc_public/iam/CMakeLists.linux-aarch64.txt @@ -41,6 +41,10 @@ target_link_libraries(client-yc_public-iam PUBLIC target_proto_messages(client-yc_public-iam PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/iam/iam_token_service.proto ) +target_sources(client-yc_public-iam PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/iam/iam_token_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/iam/iam_token_service.grpc.pb.h +) target_proto_addincls(client-yc_public-iam ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_public/iam/CMakeLists.linux-x86_64.txt b/ydb/public/api/client/yc_public/iam/CMakeLists.linux-x86_64.txt index f6794279095b..44726e846693 100644 --- a/ydb/public/api/client/yc_public/iam/CMakeLists.linux-x86_64.txt +++ b/ydb/public/api/client/yc_public/iam/CMakeLists.linux-x86_64.txt @@ -41,6 +41,10 @@ target_link_libraries(client-yc_public-iam PUBLIC target_proto_messages(client-yc_public-iam PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/iam/iam_token_service.proto ) +target_sources(client-yc_public-iam PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/iam/iam_token_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/iam/iam_token_service.grpc.pb.h +) target_proto_addincls(client-yc_public-iam ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_public/iam/CMakeLists.windows-x86_64.txt b/ydb/public/api/client/yc_public/iam/CMakeLists.windows-x86_64.txt index 1b286b49c6c4..4b441f29b40f 100644 --- a/ydb/public/api/client/yc_public/iam/CMakeLists.windows-x86_64.txt +++ b/ydb/public/api/client/yc_public/iam/CMakeLists.windows-x86_64.txt @@ -40,6 +40,10 @@ target_link_libraries(client-yc_public-iam PUBLIC target_proto_messages(client-yc_public-iam PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/iam/iam_token_service.proto ) +target_sources(client-yc_public-iam PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/iam/iam_token_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/iam/iam_token_service.grpc.pb.h +) target_proto_addincls(client-yc_public-iam ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_public/logging/CMakeLists.darwin-arm64.txt b/ydb/public/api/client/yc_public/logging/CMakeLists.darwin-arm64.txt index 6ff708119f18..3e88e2d01029 100644 --- a/ydb/public/api/client/yc_public/logging/CMakeLists.darwin-arm64.txt +++ b/ydb/public/api/client/yc_public/logging/CMakeLists.darwin-arm64.txt @@ -66,6 +66,14 @@ target_proto_messages(client-yc_public-logging PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/logging/log_ingestion_service.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/logging/log_resource.proto ) +target_sources(client-yc_public-logging PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_entry.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_entry.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_ingestion_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_ingestion_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_resource.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_resource.grpc.pb.h +) target_proto_addincls(client-yc_public-logging ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_public/logging/CMakeLists.darwin-x86_64.txt b/ydb/public/api/client/yc_public/logging/CMakeLists.darwin-x86_64.txt index 6ff708119f18..3e88e2d01029 100644 --- a/ydb/public/api/client/yc_public/logging/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/api/client/yc_public/logging/CMakeLists.darwin-x86_64.txt @@ -66,6 +66,14 @@ target_proto_messages(client-yc_public-logging PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/logging/log_ingestion_service.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/logging/log_resource.proto ) +target_sources(client-yc_public-logging PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_entry.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_entry.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_ingestion_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_ingestion_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_resource.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_resource.grpc.pb.h +) target_proto_addincls(client-yc_public-logging ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_public/logging/CMakeLists.linux-aarch64.txt b/ydb/public/api/client/yc_public/logging/CMakeLists.linux-aarch64.txt index 8e1ae13a9d6e..bb356d3a2d31 100644 --- a/ydb/public/api/client/yc_public/logging/CMakeLists.linux-aarch64.txt +++ b/ydb/public/api/client/yc_public/logging/CMakeLists.linux-aarch64.txt @@ -67,6 +67,14 @@ target_proto_messages(client-yc_public-logging PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/logging/log_ingestion_service.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/logging/log_resource.proto ) +target_sources(client-yc_public-logging PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_entry.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_entry.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_ingestion_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_ingestion_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_resource.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_resource.grpc.pb.h +) target_proto_addincls(client-yc_public-logging ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_public/logging/CMakeLists.linux-x86_64.txt b/ydb/public/api/client/yc_public/logging/CMakeLists.linux-x86_64.txt index 8e1ae13a9d6e..bb356d3a2d31 100644 --- a/ydb/public/api/client/yc_public/logging/CMakeLists.linux-x86_64.txt +++ b/ydb/public/api/client/yc_public/logging/CMakeLists.linux-x86_64.txt @@ -67,6 +67,14 @@ target_proto_messages(client-yc_public-logging PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/logging/log_ingestion_service.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/logging/log_resource.proto ) +target_sources(client-yc_public-logging PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_entry.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_entry.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_ingestion_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_ingestion_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_resource.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_resource.grpc.pb.h +) target_proto_addincls(client-yc_public-logging ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/client/yc_public/logging/CMakeLists.windows-x86_64.txt b/ydb/public/api/client/yc_public/logging/CMakeLists.windows-x86_64.txt index 6ff708119f18..3e88e2d01029 100644 --- a/ydb/public/api/client/yc_public/logging/CMakeLists.windows-x86_64.txt +++ b/ydb/public/api/client/yc_public/logging/CMakeLists.windows-x86_64.txt @@ -66,6 +66,14 @@ target_proto_messages(client-yc_public-logging PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/logging/log_ingestion_service.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/client/yc_public/logging/log_resource.proto ) +target_sources(client-yc_public-logging PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_entry.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_entry.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_ingestion_service.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_ingestion_service.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_resource.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/client/yc_public/logging/log_resource.grpc.pb.h +) target_proto_addincls(client-yc_public-logging ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/grpc/CMakeLists.darwin-arm64.txt b/ydb/public/api/grpc/CMakeLists.darwin-arm64.txt index 2c51f9ed46ee..90daf131ae3a 100644 --- a/ydb/public/api/grpc/CMakeLists.darwin-arm64.txt +++ b/ydb/public/api/grpc/CMakeLists.darwin-arm64.txt @@ -235,6 +235,40 @@ target_proto_messages(api-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/grpc/ydb_topic_v1.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/grpc/ydb_keyvalue_v1.proto ) +target_sources(api-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_federation_discovery_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_federation_discovery_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_auth_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_auth_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_cms_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_cms_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_coordination_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_coordination_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_discovery_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_discovery_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_export_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_export_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_import_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_import_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_monitoring_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_monitoring_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_operation_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_operation_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_query_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_query_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_rate_limiter_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_rate_limiter_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_scheme_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_scheme_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_scripting_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_scripting_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_table_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_table_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_topic_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_topic_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_keyvalue_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_keyvalue_v1.grpc.pb.h +) target_proto_addincls(api-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/grpc/CMakeLists.darwin-x86_64.txt b/ydb/public/api/grpc/CMakeLists.darwin-x86_64.txt index 2c51f9ed46ee..90daf131ae3a 100644 --- a/ydb/public/api/grpc/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/api/grpc/CMakeLists.darwin-x86_64.txt @@ -235,6 +235,40 @@ target_proto_messages(api-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/grpc/ydb_topic_v1.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/grpc/ydb_keyvalue_v1.proto ) +target_sources(api-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_federation_discovery_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_federation_discovery_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_auth_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_auth_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_cms_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_cms_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_coordination_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_coordination_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_discovery_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_discovery_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_export_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_export_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_import_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_import_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_monitoring_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_monitoring_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_operation_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_operation_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_query_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_query_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_rate_limiter_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_rate_limiter_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_scheme_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_scheme_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_scripting_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_scripting_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_table_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_table_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_topic_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_topic_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_keyvalue_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_keyvalue_v1.grpc.pb.h +) target_proto_addincls(api-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/grpc/CMakeLists.linux-aarch64.txt b/ydb/public/api/grpc/CMakeLists.linux-aarch64.txt index cee7a6b962e7..bf961ce4fbd6 100644 --- a/ydb/public/api/grpc/CMakeLists.linux-aarch64.txt +++ b/ydb/public/api/grpc/CMakeLists.linux-aarch64.txt @@ -236,6 +236,40 @@ target_proto_messages(api-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/grpc/ydb_topic_v1.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/grpc/ydb_keyvalue_v1.proto ) +target_sources(api-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_federation_discovery_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_federation_discovery_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_auth_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_auth_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_cms_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_cms_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_coordination_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_coordination_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_discovery_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_discovery_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_export_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_export_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_import_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_import_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_monitoring_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_monitoring_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_operation_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_operation_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_query_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_query_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_rate_limiter_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_rate_limiter_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_scheme_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_scheme_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_scripting_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_scripting_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_table_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_table_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_topic_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_topic_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_keyvalue_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_keyvalue_v1.grpc.pb.h +) target_proto_addincls(api-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/grpc/CMakeLists.linux-x86_64.txt b/ydb/public/api/grpc/CMakeLists.linux-x86_64.txt index cee7a6b962e7..bf961ce4fbd6 100644 --- a/ydb/public/api/grpc/CMakeLists.linux-x86_64.txt +++ b/ydb/public/api/grpc/CMakeLists.linux-x86_64.txt @@ -236,6 +236,40 @@ target_proto_messages(api-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/grpc/ydb_topic_v1.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/grpc/ydb_keyvalue_v1.proto ) +target_sources(api-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_federation_discovery_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_federation_discovery_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_auth_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_auth_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_cms_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_cms_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_coordination_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_coordination_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_discovery_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_discovery_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_export_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_export_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_import_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_import_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_monitoring_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_monitoring_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_operation_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_operation_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_query_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_query_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_rate_limiter_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_rate_limiter_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_scheme_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_scheme_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_scripting_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_scripting_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_table_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_table_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_topic_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_topic_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_keyvalue_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_keyvalue_v1.grpc.pb.h +) target_proto_addincls(api-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/grpc/CMakeLists.windows-x86_64.txt b/ydb/public/api/grpc/CMakeLists.windows-x86_64.txt index 2c51f9ed46ee..90daf131ae3a 100644 --- a/ydb/public/api/grpc/CMakeLists.windows-x86_64.txt +++ b/ydb/public/api/grpc/CMakeLists.windows-x86_64.txt @@ -235,6 +235,40 @@ target_proto_messages(api-grpc PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/grpc/ydb_topic_v1.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/grpc/ydb_keyvalue_v1.proto ) +target_sources(api-grpc PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_federation_discovery_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_federation_discovery_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_auth_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_auth_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_cms_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_cms_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_coordination_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_coordination_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_discovery_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_discovery_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_export_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_export_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_import_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_import_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_monitoring_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_monitoring_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_operation_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_operation_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_query_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_query_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_rate_limiter_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_rate_limiter_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_scheme_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_scheme_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_scripting_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_scripting_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_table_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_table_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_topic_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_topic_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_keyvalue_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/ydb_keyvalue_v1.grpc.pb.h +) target_proto_addincls(api-grpc ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/grpc/draft/CMakeLists.darwin-arm64.txt b/ydb/public/api/grpc/draft/CMakeLists.darwin-arm64.txt index ec91e2feae26..fae6890103ba 100644 --- a/ydb/public/api/grpc/draft/CMakeLists.darwin-arm64.txt +++ b/ydb/public/api/grpc/draft/CMakeLists.darwin-arm64.txt @@ -108,18 +108,6 @@ get_built_tool_path( contrib/tools/protoc/plugins/cpp_styleguide cpp_styleguide ) -get_built_tool_path( - TOOL_protoc_bin - TOOL_protoc_dependency - contrib/tools/protoc/bin - protoc -) -get_built_tool_path( - TOOL_cpp_styleguide_bin - TOOL_cpp_styleguide_dependency - contrib/tools/protoc/plugins/cpp_styleguide - cpp_styleguide -) add_library(api-grpc-draft) set_property(TARGET api-grpc-draft PROPERTY @@ -142,6 +130,24 @@ target_proto_messages(api-grpc-draft PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/grpc/draft/ydb_logstore_v1.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/grpc/draft/ydb_dynamic_config_v1.proto ) +target_sources(api-grpc-draft PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/dummy.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/dummy.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/fq_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/fq_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_clickhouse_internal_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_clickhouse_internal_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_persqueue_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_persqueue_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_datastreams_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_datastreams_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_maintenance_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_maintenance_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_logstore_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_logstore_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_dynamic_config_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_dynamic_config_v1.grpc.pb.h +) target_proto_addincls(api-grpc-draft ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/grpc/draft/CMakeLists.darwin-x86_64.txt b/ydb/public/api/grpc/draft/CMakeLists.darwin-x86_64.txt index ec91e2feae26..fae6890103ba 100644 --- a/ydb/public/api/grpc/draft/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/api/grpc/draft/CMakeLists.darwin-x86_64.txt @@ -108,18 +108,6 @@ get_built_tool_path( contrib/tools/protoc/plugins/cpp_styleguide cpp_styleguide ) -get_built_tool_path( - TOOL_protoc_bin - TOOL_protoc_dependency - contrib/tools/protoc/bin - protoc -) -get_built_tool_path( - TOOL_cpp_styleguide_bin - TOOL_cpp_styleguide_dependency - contrib/tools/protoc/plugins/cpp_styleguide - cpp_styleguide -) add_library(api-grpc-draft) set_property(TARGET api-grpc-draft PROPERTY @@ -142,6 +130,24 @@ target_proto_messages(api-grpc-draft PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/grpc/draft/ydb_logstore_v1.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/grpc/draft/ydb_dynamic_config_v1.proto ) +target_sources(api-grpc-draft PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/dummy.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/dummy.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/fq_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/fq_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_clickhouse_internal_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_clickhouse_internal_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_persqueue_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_persqueue_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_datastreams_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_datastreams_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_maintenance_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_maintenance_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_logstore_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_logstore_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_dynamic_config_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_dynamic_config_v1.grpc.pb.h +) target_proto_addincls(api-grpc-draft ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/grpc/draft/CMakeLists.linux-aarch64.txt b/ydb/public/api/grpc/draft/CMakeLists.linux-aarch64.txt index bf26eb685a8e..fb49e4844753 100644 --- a/ydb/public/api/grpc/draft/CMakeLists.linux-aarch64.txt +++ b/ydb/public/api/grpc/draft/CMakeLists.linux-aarch64.txt @@ -108,18 +108,6 @@ get_built_tool_path( contrib/tools/protoc/plugins/cpp_styleguide cpp_styleguide ) -get_built_tool_path( - TOOL_protoc_bin - TOOL_protoc_dependency - contrib/tools/protoc/bin - protoc -) -get_built_tool_path( - TOOL_cpp_styleguide_bin - TOOL_cpp_styleguide_dependency - contrib/tools/protoc/plugins/cpp_styleguide - cpp_styleguide -) add_library(api-grpc-draft) set_property(TARGET api-grpc-draft PROPERTY @@ -143,6 +131,24 @@ target_proto_messages(api-grpc-draft PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/grpc/draft/ydb_logstore_v1.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/grpc/draft/ydb_dynamic_config_v1.proto ) +target_sources(api-grpc-draft PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/dummy.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/dummy.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/fq_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/fq_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_clickhouse_internal_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_clickhouse_internal_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_persqueue_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_persqueue_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_datastreams_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_datastreams_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_maintenance_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_maintenance_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_logstore_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_logstore_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_dynamic_config_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_dynamic_config_v1.grpc.pb.h +) target_proto_addincls(api-grpc-draft ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/grpc/draft/CMakeLists.linux-x86_64.txt b/ydb/public/api/grpc/draft/CMakeLists.linux-x86_64.txt index bf26eb685a8e..fb49e4844753 100644 --- a/ydb/public/api/grpc/draft/CMakeLists.linux-x86_64.txt +++ b/ydb/public/api/grpc/draft/CMakeLists.linux-x86_64.txt @@ -108,18 +108,6 @@ get_built_tool_path( contrib/tools/protoc/plugins/cpp_styleguide cpp_styleguide ) -get_built_tool_path( - TOOL_protoc_bin - TOOL_protoc_dependency - contrib/tools/protoc/bin - protoc -) -get_built_tool_path( - TOOL_cpp_styleguide_bin - TOOL_cpp_styleguide_dependency - contrib/tools/protoc/plugins/cpp_styleguide - cpp_styleguide -) add_library(api-grpc-draft) set_property(TARGET api-grpc-draft PROPERTY @@ -143,6 +131,24 @@ target_proto_messages(api-grpc-draft PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/grpc/draft/ydb_logstore_v1.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/grpc/draft/ydb_dynamic_config_v1.proto ) +target_sources(api-grpc-draft PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/dummy.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/dummy.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/fq_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/fq_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_clickhouse_internal_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_clickhouse_internal_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_persqueue_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_persqueue_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_datastreams_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_datastreams_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_maintenance_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_maintenance_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_logstore_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_logstore_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_dynamic_config_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_dynamic_config_v1.grpc.pb.h +) target_proto_addincls(api-grpc-draft ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/grpc/draft/CMakeLists.windows-x86_64.txt b/ydb/public/api/grpc/draft/CMakeLists.windows-x86_64.txt index ec91e2feae26..fae6890103ba 100644 --- a/ydb/public/api/grpc/draft/CMakeLists.windows-x86_64.txt +++ b/ydb/public/api/grpc/draft/CMakeLists.windows-x86_64.txt @@ -108,18 +108,6 @@ get_built_tool_path( contrib/tools/protoc/plugins/cpp_styleguide cpp_styleguide ) -get_built_tool_path( - TOOL_protoc_bin - TOOL_protoc_dependency - contrib/tools/protoc/bin - protoc -) -get_built_tool_path( - TOOL_cpp_styleguide_bin - TOOL_cpp_styleguide_dependency - contrib/tools/protoc/plugins/cpp_styleguide - cpp_styleguide -) add_library(api-grpc-draft) set_property(TARGET api-grpc-draft PROPERTY @@ -142,6 +130,24 @@ target_proto_messages(api-grpc-draft PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/grpc/draft/ydb_logstore_v1.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/grpc/draft/ydb_dynamic_config_v1.proto ) +target_sources(api-grpc-draft PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/dummy.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/dummy.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/fq_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/fq_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_clickhouse_internal_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_clickhouse_internal_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_persqueue_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_persqueue_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_datastreams_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_datastreams_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_maintenance_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_maintenance_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_logstore_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_logstore_v1.grpc.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_dynamic_config_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/grpc/draft/ydb_dynamic_config_v1.grpc.pb.h +) target_proto_addincls(api-grpc-draft ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/protos/CMakeLists.darwin-arm64.txt b/ydb/public/api/protos/CMakeLists.darwin-arm64.txt index 472587120819..aae6327b1e3c 100644 --- a/ydb/public/api/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/public/api/protos/CMakeLists.darwin-arm64.txt @@ -410,18 +410,6 @@ get_built_tool_path( contrib/tools/protoc/plugins/cpp_styleguide cpp_styleguide ) -get_built_tool_path( - TOOL_protoc_bin - TOOL_protoc_dependency - contrib/tools/protoc/bin - protoc -) -get_built_tool_path( - TOOL_cpp_styleguide_bin - TOOL_cpp_styleguide_dependency - contrib/tools/protoc/plugins/cpp_styleguide - cpp_styleguide -) get_built_tool_path( TOOL_enum_parser_bin TOOL_enum_parser_dependency @@ -490,6 +478,41 @@ target_proto_messages(api-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/protos/ydb_value.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/protos/ydb_keyvalue.proto ) +target_sources(api-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/datastreams.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/fq.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/persqueue_common.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/persqueue_error_codes.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/ydb_maintenance.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/ydb_logstore.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/ydb_dynamic_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_federation_discovery.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/persqueue_error_codes_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_auth.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_persqueue_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_persqueue_cluster_discovery.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_clickhouse_internal.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_cms.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_common.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_coordination.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_discovery.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_export.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_formats.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_import.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_issue_message.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_monitoring.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_operation.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_query_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_query.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_rate_limiter.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_scheme.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_scripting.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_status_codes.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_table.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_topic.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_value.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_keyvalue.pb.h +) generate_enum_serilization(api-protos ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/persqueue_common.pb.h INCLUDE_HEADERS diff --git a/ydb/public/api/protos/CMakeLists.darwin-x86_64.txt b/ydb/public/api/protos/CMakeLists.darwin-x86_64.txt index 472587120819..aae6327b1e3c 100644 --- a/ydb/public/api/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/api/protos/CMakeLists.darwin-x86_64.txt @@ -410,18 +410,6 @@ get_built_tool_path( contrib/tools/protoc/plugins/cpp_styleguide cpp_styleguide ) -get_built_tool_path( - TOOL_protoc_bin - TOOL_protoc_dependency - contrib/tools/protoc/bin - protoc -) -get_built_tool_path( - TOOL_cpp_styleguide_bin - TOOL_cpp_styleguide_dependency - contrib/tools/protoc/plugins/cpp_styleguide - cpp_styleguide -) get_built_tool_path( TOOL_enum_parser_bin TOOL_enum_parser_dependency @@ -490,6 +478,41 @@ target_proto_messages(api-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/protos/ydb_value.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/protos/ydb_keyvalue.proto ) +target_sources(api-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/datastreams.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/fq.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/persqueue_common.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/persqueue_error_codes.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/ydb_maintenance.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/ydb_logstore.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/ydb_dynamic_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_federation_discovery.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/persqueue_error_codes_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_auth.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_persqueue_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_persqueue_cluster_discovery.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_clickhouse_internal.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_cms.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_common.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_coordination.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_discovery.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_export.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_formats.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_import.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_issue_message.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_monitoring.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_operation.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_query_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_query.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_rate_limiter.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_scheme.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_scripting.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_status_codes.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_table.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_topic.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_value.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_keyvalue.pb.h +) generate_enum_serilization(api-protos ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/persqueue_common.pb.h INCLUDE_HEADERS diff --git a/ydb/public/api/protos/CMakeLists.linux-aarch64.txt b/ydb/public/api/protos/CMakeLists.linux-aarch64.txt index ff7dd71ab01c..de639fffb530 100644 --- a/ydb/public/api/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/public/api/protos/CMakeLists.linux-aarch64.txt @@ -410,18 +410,6 @@ get_built_tool_path( contrib/tools/protoc/plugins/cpp_styleguide cpp_styleguide ) -get_built_tool_path( - TOOL_protoc_bin - TOOL_protoc_dependency - contrib/tools/protoc/bin - protoc -) -get_built_tool_path( - TOOL_cpp_styleguide_bin - TOOL_cpp_styleguide_dependency - contrib/tools/protoc/plugins/cpp_styleguide - cpp_styleguide -) get_built_tool_path( TOOL_enum_parser_bin TOOL_enum_parser_dependency @@ -491,6 +479,41 @@ target_proto_messages(api-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/protos/ydb_value.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/protos/ydb_keyvalue.proto ) +target_sources(api-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/datastreams.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/fq.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/persqueue_common.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/persqueue_error_codes.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/ydb_maintenance.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/ydb_logstore.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/ydb_dynamic_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_federation_discovery.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/persqueue_error_codes_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_auth.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_persqueue_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_persqueue_cluster_discovery.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_clickhouse_internal.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_cms.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_common.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_coordination.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_discovery.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_export.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_formats.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_import.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_issue_message.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_monitoring.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_operation.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_query_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_query.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_rate_limiter.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_scheme.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_scripting.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_status_codes.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_table.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_topic.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_value.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_keyvalue.pb.h +) generate_enum_serilization(api-protos ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/persqueue_common.pb.h INCLUDE_HEADERS diff --git a/ydb/public/api/protos/CMakeLists.linux-x86_64.txt b/ydb/public/api/protos/CMakeLists.linux-x86_64.txt index ff7dd71ab01c..de639fffb530 100644 --- a/ydb/public/api/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/public/api/protos/CMakeLists.linux-x86_64.txt @@ -410,18 +410,6 @@ get_built_tool_path( contrib/tools/protoc/plugins/cpp_styleguide cpp_styleguide ) -get_built_tool_path( - TOOL_protoc_bin - TOOL_protoc_dependency - contrib/tools/protoc/bin - protoc -) -get_built_tool_path( - TOOL_cpp_styleguide_bin - TOOL_cpp_styleguide_dependency - contrib/tools/protoc/plugins/cpp_styleguide - cpp_styleguide -) get_built_tool_path( TOOL_enum_parser_bin TOOL_enum_parser_dependency @@ -491,6 +479,41 @@ target_proto_messages(api-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/protos/ydb_value.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/protos/ydb_keyvalue.proto ) +target_sources(api-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/datastreams.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/fq.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/persqueue_common.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/persqueue_error_codes.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/ydb_maintenance.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/ydb_logstore.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/ydb_dynamic_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_federation_discovery.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/persqueue_error_codes_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_auth.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_persqueue_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_persqueue_cluster_discovery.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_clickhouse_internal.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_cms.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_common.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_coordination.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_discovery.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_export.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_formats.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_import.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_issue_message.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_monitoring.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_operation.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_query_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_query.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_rate_limiter.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_scheme.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_scripting.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_status_codes.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_table.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_topic.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_value.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_keyvalue.pb.h +) generate_enum_serilization(api-protos ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/persqueue_common.pb.h INCLUDE_HEADERS diff --git a/ydb/public/api/protos/CMakeLists.windows-x86_64.txt b/ydb/public/api/protos/CMakeLists.windows-x86_64.txt index 472587120819..aae6327b1e3c 100644 --- a/ydb/public/api/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/public/api/protos/CMakeLists.windows-x86_64.txt @@ -410,18 +410,6 @@ get_built_tool_path( contrib/tools/protoc/plugins/cpp_styleguide cpp_styleguide ) -get_built_tool_path( - TOOL_protoc_bin - TOOL_protoc_dependency - contrib/tools/protoc/bin - protoc -) -get_built_tool_path( - TOOL_cpp_styleguide_bin - TOOL_cpp_styleguide_dependency - contrib/tools/protoc/plugins/cpp_styleguide - cpp_styleguide -) get_built_tool_path( TOOL_enum_parser_bin TOOL_enum_parser_dependency @@ -490,6 +478,41 @@ target_proto_messages(api-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/protos/ydb_value.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/protos/ydb_keyvalue.proto ) +target_sources(api-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/datastreams.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/fq.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/persqueue_common.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/persqueue_error_codes.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/ydb_maintenance.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/ydb_logstore.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/ydb_dynamic_config.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_federation_discovery.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/persqueue_error_codes_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_auth.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_persqueue_v1.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_persqueue_cluster_discovery.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_clickhouse_internal.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_cms.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_common.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_coordination.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_discovery.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_export.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_formats.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_import.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_issue_message.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_monitoring.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_operation.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_query_stats.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_query.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_rate_limiter.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_scheme.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_scripting.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_status_codes.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_table.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_topic.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_value.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/ydb_keyvalue.pb.h +) generate_enum_serilization(api-protos ${CMAKE_BINARY_DIR}/ydb/public/api/protos/draft/persqueue_common.pb.h INCLUDE_HEADERS diff --git a/ydb/public/api/protos/annotations/CMakeLists.darwin-arm64.txt b/ydb/public/api/protos/annotations/CMakeLists.darwin-arm64.txt index 4c41d677bdbf..19f200a7520a 100644 --- a/ydb/public/api/protos/annotations/CMakeLists.darwin-arm64.txt +++ b/ydb/public/api/protos/annotations/CMakeLists.darwin-arm64.txt @@ -41,6 +41,10 @@ target_proto_messages(api-protos-annotations PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/protos/annotations/sensitive.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/protos/annotations/validation.proto ) +target_sources(api-protos-annotations PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/annotations/sensitive.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/annotations/validation.pb.h +) target_proto_addincls(api-protos-annotations ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/protos/annotations/CMakeLists.darwin-x86_64.txt b/ydb/public/api/protos/annotations/CMakeLists.darwin-x86_64.txt index 4c41d677bdbf..19f200a7520a 100644 --- a/ydb/public/api/protos/annotations/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/api/protos/annotations/CMakeLists.darwin-x86_64.txt @@ -41,6 +41,10 @@ target_proto_messages(api-protos-annotations PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/protos/annotations/sensitive.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/protos/annotations/validation.proto ) +target_sources(api-protos-annotations PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/annotations/sensitive.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/annotations/validation.pb.h +) target_proto_addincls(api-protos-annotations ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/protos/annotations/CMakeLists.linux-aarch64.txt b/ydb/public/api/protos/annotations/CMakeLists.linux-aarch64.txt index 559ce387ba5d..e932ba6318d1 100644 --- a/ydb/public/api/protos/annotations/CMakeLists.linux-aarch64.txt +++ b/ydb/public/api/protos/annotations/CMakeLists.linux-aarch64.txt @@ -42,6 +42,10 @@ target_proto_messages(api-protos-annotations PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/protos/annotations/sensitive.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/protos/annotations/validation.proto ) +target_sources(api-protos-annotations PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/annotations/sensitive.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/annotations/validation.pb.h +) target_proto_addincls(api-protos-annotations ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/protos/annotations/CMakeLists.linux-x86_64.txt b/ydb/public/api/protos/annotations/CMakeLists.linux-x86_64.txt index 559ce387ba5d..e932ba6318d1 100644 --- a/ydb/public/api/protos/annotations/CMakeLists.linux-x86_64.txt +++ b/ydb/public/api/protos/annotations/CMakeLists.linux-x86_64.txt @@ -42,6 +42,10 @@ target_proto_messages(api-protos-annotations PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/protos/annotations/sensitive.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/protos/annotations/validation.proto ) +target_sources(api-protos-annotations PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/annotations/sensitive.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/annotations/validation.pb.h +) target_proto_addincls(api-protos-annotations ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/api/protos/annotations/CMakeLists.windows-x86_64.txt b/ydb/public/api/protos/annotations/CMakeLists.windows-x86_64.txt index 4c41d677bdbf..19f200a7520a 100644 --- a/ydb/public/api/protos/annotations/CMakeLists.windows-x86_64.txt +++ b/ydb/public/api/protos/annotations/CMakeLists.windows-x86_64.txt @@ -41,6 +41,10 @@ target_proto_messages(api-protos-annotations PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/api/protos/annotations/sensitive.proto ${CMAKE_SOURCE_DIR}/ydb/public/api/protos/annotations/validation.proto ) +target_sources(api-protos-annotations PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/annotations/sensitive.pb.h + ${CMAKE_BINARY_DIR}/ydb/public/api/protos/annotations/validation.pb.h +) target_proto_addincls(api-protos-annotations ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/lib/base/CMakeLists.darwin-arm64.txt b/ydb/public/lib/base/CMakeLists.darwin-arm64.txt index d721624bf8ef..e5cde95faf36 100644 --- a/ydb/public/lib/base/CMakeLists.darwin-arm64.txt +++ b/ydb/public/lib/base/CMakeLists.darwin-arm64.txt @@ -18,5 +18,8 @@ target_link_libraries(public-lib-base PUBLIC ydb-core-protos ) target_sources(public-lib-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/base/defs.h + ${CMAKE_SOURCE_DIR}/ydb/public/lib/base/msgbus_status.h + ${CMAKE_SOURCE_DIR}/ydb/public/lib/base/msgbus.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/base/msgbus.cpp ) diff --git a/ydb/public/lib/base/CMakeLists.darwin-x86_64.txt b/ydb/public/lib/base/CMakeLists.darwin-x86_64.txt index d721624bf8ef..e5cde95faf36 100644 --- a/ydb/public/lib/base/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/lib/base/CMakeLists.darwin-x86_64.txt @@ -18,5 +18,8 @@ target_link_libraries(public-lib-base PUBLIC ydb-core-protos ) target_sources(public-lib-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/base/defs.h + ${CMAKE_SOURCE_DIR}/ydb/public/lib/base/msgbus_status.h + ${CMAKE_SOURCE_DIR}/ydb/public/lib/base/msgbus.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/base/msgbus.cpp ) diff --git a/ydb/public/lib/base/CMakeLists.linux-aarch64.txt b/ydb/public/lib/base/CMakeLists.linux-aarch64.txt index da7ca2cd24af..1e329d7c7bec 100644 --- a/ydb/public/lib/base/CMakeLists.linux-aarch64.txt +++ b/ydb/public/lib/base/CMakeLists.linux-aarch64.txt @@ -19,5 +19,8 @@ target_link_libraries(public-lib-base PUBLIC ydb-core-protos ) target_sources(public-lib-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/base/defs.h + ${CMAKE_SOURCE_DIR}/ydb/public/lib/base/msgbus_status.h + ${CMAKE_SOURCE_DIR}/ydb/public/lib/base/msgbus.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/base/msgbus.cpp ) diff --git a/ydb/public/lib/base/CMakeLists.linux-x86_64.txt b/ydb/public/lib/base/CMakeLists.linux-x86_64.txt index da7ca2cd24af..1e329d7c7bec 100644 --- a/ydb/public/lib/base/CMakeLists.linux-x86_64.txt +++ b/ydb/public/lib/base/CMakeLists.linux-x86_64.txt @@ -19,5 +19,8 @@ target_link_libraries(public-lib-base PUBLIC ydb-core-protos ) target_sources(public-lib-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/base/defs.h + ${CMAKE_SOURCE_DIR}/ydb/public/lib/base/msgbus_status.h + ${CMAKE_SOURCE_DIR}/ydb/public/lib/base/msgbus.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/base/msgbus.cpp ) diff --git a/ydb/public/lib/base/CMakeLists.windows-x86_64.txt b/ydb/public/lib/base/CMakeLists.windows-x86_64.txt index d721624bf8ef..e5cde95faf36 100644 --- a/ydb/public/lib/base/CMakeLists.windows-x86_64.txt +++ b/ydb/public/lib/base/CMakeLists.windows-x86_64.txt @@ -18,5 +18,8 @@ target_link_libraries(public-lib-base PUBLIC ydb-core-protos ) target_sources(public-lib-base PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/base/defs.h + ${CMAKE_SOURCE_DIR}/ydb/public/lib/base/msgbus_status.h + ${CMAKE_SOURCE_DIR}/ydb/public/lib/base/msgbus.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/base/msgbus.cpp ) diff --git a/ydb/public/lib/deprecated/client/CMakeLists.darwin-arm64.txt b/ydb/public/lib/deprecated/client/CMakeLists.darwin-arm64.txt index d3b179d754a3..f26c1ad5b0d0 100644 --- a/ydb/public/lib/deprecated/client/CMakeLists.darwin-arm64.txt +++ b/ydb/public/lib/deprecated/client/CMakeLists.darwin-arm64.txt @@ -16,7 +16,8 @@ target_link_libraries(lib-deprecated-client PUBLIC public-lib-base ) target_sources(lib-deprecated-client PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/msgbus_client.h + ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/msgbus_client_config.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/msgbus_client.cpp - ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/msgbus_player.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/grpc_client.cpp ) diff --git a/ydb/public/lib/deprecated/client/CMakeLists.darwin-x86_64.txt b/ydb/public/lib/deprecated/client/CMakeLists.darwin-x86_64.txt index d3b179d754a3..f26c1ad5b0d0 100644 --- a/ydb/public/lib/deprecated/client/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/lib/deprecated/client/CMakeLists.darwin-x86_64.txt @@ -16,7 +16,8 @@ target_link_libraries(lib-deprecated-client PUBLIC public-lib-base ) target_sources(lib-deprecated-client PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/msgbus_client.h + ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/msgbus_client_config.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/msgbus_client.cpp - ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/msgbus_player.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/grpc_client.cpp ) diff --git a/ydb/public/lib/deprecated/client/CMakeLists.linux-aarch64.txt b/ydb/public/lib/deprecated/client/CMakeLists.linux-aarch64.txt index f0b5b6da861c..ee11525e30df 100644 --- a/ydb/public/lib/deprecated/client/CMakeLists.linux-aarch64.txt +++ b/ydb/public/lib/deprecated/client/CMakeLists.linux-aarch64.txt @@ -17,7 +17,8 @@ target_link_libraries(lib-deprecated-client PUBLIC public-lib-base ) target_sources(lib-deprecated-client PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/msgbus_client.h + ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/msgbus_client_config.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/msgbus_client.cpp - ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/msgbus_player.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/grpc_client.cpp ) diff --git a/ydb/public/lib/deprecated/client/CMakeLists.linux-x86_64.txt b/ydb/public/lib/deprecated/client/CMakeLists.linux-x86_64.txt index f0b5b6da861c..ee11525e30df 100644 --- a/ydb/public/lib/deprecated/client/CMakeLists.linux-x86_64.txt +++ b/ydb/public/lib/deprecated/client/CMakeLists.linux-x86_64.txt @@ -17,7 +17,8 @@ target_link_libraries(lib-deprecated-client PUBLIC public-lib-base ) target_sources(lib-deprecated-client PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/msgbus_client.h + ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/msgbus_client_config.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/msgbus_client.cpp - ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/msgbus_player.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/grpc_client.cpp ) diff --git a/ydb/public/lib/deprecated/client/CMakeLists.windows-x86_64.txt b/ydb/public/lib/deprecated/client/CMakeLists.windows-x86_64.txt index d3b179d754a3..f26c1ad5b0d0 100644 --- a/ydb/public/lib/deprecated/client/CMakeLists.windows-x86_64.txt +++ b/ydb/public/lib/deprecated/client/CMakeLists.windows-x86_64.txt @@ -16,7 +16,8 @@ target_link_libraries(lib-deprecated-client PUBLIC public-lib-base ) target_sources(lib-deprecated-client PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/msgbus_client.h + ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/msgbus_client_config.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/msgbus_client.cpp - ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/msgbus_player.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/client/grpc_client.cpp ) diff --git a/ydb/public/lib/deprecated/kicli/CMakeLists.darwin-arm64.txt b/ydb/public/lib/deprecated/kicli/CMakeLists.darwin-arm64.txt index 875785e53f17..6b2bece8356d 100644 --- a/ydb/public/lib/deprecated/kicli/CMakeLists.darwin-arm64.txt +++ b/ydb/public/lib/deprecated/kicli/CMakeLists.darwin-arm64.txt @@ -28,6 +28,7 @@ target_link_libraries(lib-deprecated-kicli PUBLIC yql-public-issue ) target_sources(lib-deprecated-kicli PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/kicli.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/configurator.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/dynamic_node.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/error.cpp diff --git a/ydb/public/lib/deprecated/kicli/CMakeLists.darwin-x86_64.txt b/ydb/public/lib/deprecated/kicli/CMakeLists.darwin-x86_64.txt index 875785e53f17..6b2bece8356d 100644 --- a/ydb/public/lib/deprecated/kicli/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/lib/deprecated/kicli/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,7 @@ target_link_libraries(lib-deprecated-kicli PUBLIC yql-public-issue ) target_sources(lib-deprecated-kicli PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/kicli.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/configurator.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/dynamic_node.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/error.cpp diff --git a/ydb/public/lib/deprecated/kicli/CMakeLists.linux-aarch64.txt b/ydb/public/lib/deprecated/kicli/CMakeLists.linux-aarch64.txt index a3a0449ffffc..3e350e2b96c5 100644 --- a/ydb/public/lib/deprecated/kicli/CMakeLists.linux-aarch64.txt +++ b/ydb/public/lib/deprecated/kicli/CMakeLists.linux-aarch64.txt @@ -29,6 +29,7 @@ target_link_libraries(lib-deprecated-kicli PUBLIC yql-public-issue ) target_sources(lib-deprecated-kicli PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/kicli.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/configurator.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/dynamic_node.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/error.cpp diff --git a/ydb/public/lib/deprecated/kicli/CMakeLists.linux-x86_64.txt b/ydb/public/lib/deprecated/kicli/CMakeLists.linux-x86_64.txt index a3a0449ffffc..3e350e2b96c5 100644 --- a/ydb/public/lib/deprecated/kicli/CMakeLists.linux-x86_64.txt +++ b/ydb/public/lib/deprecated/kicli/CMakeLists.linux-x86_64.txt @@ -29,6 +29,7 @@ target_link_libraries(lib-deprecated-kicli PUBLIC yql-public-issue ) target_sources(lib-deprecated-kicli PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/kicli.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/configurator.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/dynamic_node.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/error.cpp diff --git a/ydb/public/lib/deprecated/kicli/CMakeLists.windows-x86_64.txt b/ydb/public/lib/deprecated/kicli/CMakeLists.windows-x86_64.txt index 875785e53f17..6b2bece8356d 100644 --- a/ydb/public/lib/deprecated/kicli/CMakeLists.windows-x86_64.txt +++ b/ydb/public/lib/deprecated/kicli/CMakeLists.windows-x86_64.txt @@ -28,6 +28,7 @@ target_link_libraries(lib-deprecated-kicli PUBLIC yql-public-issue ) target_sources(lib-deprecated-kicli PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/kicli.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/configurator.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/dynamic_node.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/error.cpp diff --git a/ydb/public/lib/deprecated/kicli/ut/CMakeLists.darwin-arm64.txt b/ydb/public/lib/deprecated/kicli/ut/CMakeLists.darwin-arm64.txt index 5618b3cd0462..88976e0b9299 100644 --- a/ydb/public/lib/deprecated/kicli/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/public/lib/deprecated/kicli/ut/CMakeLists.darwin-arm64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-public-lib-deprecated-kicli-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-lib-deprecated-kicli-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/cpp_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/deprecated/kicli/ut/CMakeLists.darwin-x86_64.txt b/ydb/public/lib/deprecated/kicli/ut/CMakeLists.darwin-x86_64.txt index 87f47b6c4605..6ef05f88cda1 100644 --- a/ydb/public/lib/deprecated/kicli/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/lib/deprecated/kicli/ut/CMakeLists.darwin-x86_64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-public-lib-deprecated-kicli-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-lib-deprecated-kicli-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/cpp_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/deprecated/kicli/ut/CMakeLists.linux-aarch64.txt b/ydb/public/lib/deprecated/kicli/ut/CMakeLists.linux-aarch64.txt index 05d14b80658f..e00caeca259e 100644 --- a/ydb/public/lib/deprecated/kicli/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/public/lib/deprecated/kicli/ut/CMakeLists.linux-aarch64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-public-lib-deprecated-kicli-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-lib-deprecated-kicli-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/cpp_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/deprecated/kicli/ut/CMakeLists.linux-x86_64.txt b/ydb/public/lib/deprecated/kicli/ut/CMakeLists.linux-x86_64.txt index e37ffae6edbc..b7382dd9c60f 100644 --- a/ydb/public/lib/deprecated/kicli/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/public/lib/deprecated/kicli/ut/CMakeLists.linux-x86_64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-public-lib-deprecated-kicli-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-lib-deprecated-kicli-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/deprecated/kicli/cpp_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/deprecated/kicli/ut/CMakeLists.windows-x86_64.txt b/ydb/public/lib/deprecated/kicli/ut/CMakeLists.windows-x86_64.txt index c0d41371f0af..06d98414e310 100644 --- a/ydb/public/lib/deprecated/kicli/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/public/lib/deprecated/kicli/ut/CMakeLists.windows-x86_64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/idx_test/ut/CMakeLists.darwin-arm64.txt b/ydb/public/lib/idx_test/ut/CMakeLists.darwin-arm64.txt index 3eab6d6fa468..e30b9632aa75 100644 --- a/ydb/public/lib/idx_test/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/public/lib/idx_test/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-public-lib-idx_test-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-lib-idx_test-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/idx_test/ut/idx_test_data_provider_ut.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/idx_test/ut/CMakeLists.darwin-x86_64.txt b/ydb/public/lib/idx_test/ut/CMakeLists.darwin-x86_64.txt index ec517de8b95a..083430ec549e 100644 --- a/ydb/public/lib/idx_test/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/lib/idx_test/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-public-lib-idx_test-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-lib-idx_test-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/idx_test/ut/idx_test_data_provider_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/idx_test/ut/CMakeLists.linux-aarch64.txt b/ydb/public/lib/idx_test/ut/CMakeLists.linux-aarch64.txt index 134f617db177..fb516f707692 100644 --- a/ydb/public/lib/idx_test/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/public/lib/idx_test/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-public-lib-idx_test-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-lib-idx_test-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/idx_test/ut/idx_test_data_provider_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/idx_test/ut/CMakeLists.linux-x86_64.txt b/ydb/public/lib/idx_test/ut/CMakeLists.linux-x86_64.txt index 041a5f24f7e4..529c094aebb0 100644 --- a/ydb/public/lib/idx_test/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/public/lib/idx_test/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-public-lib-idx_test-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-lib-idx_test-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/idx_test/ut/idx_test_data_provider_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/idx_test/ut/CMakeLists.windows-x86_64.txt b/ydb/public/lib/idx_test/ut/CMakeLists.windows-x86_64.txt index e691ab819cfd..620912b583bd 100644 --- a/ydb/public/lib/idx_test/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/public/lib/idx_test/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/json_value/ut/CMakeLists.darwin-arm64.txt b/ydb/public/lib/json_value/ut/CMakeLists.darwin-arm64.txt index 12d78895c8c5..32d0463fa250 100644 --- a/ydb/public/lib/json_value/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/public/lib/json_value/ut/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-public-lib-json_value-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-lib-json_value-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/json_value/ydb_json_value_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/json_value/ut/CMakeLists.darwin-x86_64.txt b/ydb/public/lib/json_value/ut/CMakeLists.darwin-x86_64.txt index 49dddabd4d40..1fd6b0d97e31 100644 --- a/ydb/public/lib/json_value/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/lib/json_value/ut/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(ydb-public-lib-json_value-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-lib-json_value-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/json_value/ydb_json_value_ut.cpp @@ -57,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/json_value/ut/CMakeLists.linux-aarch64.txt b/ydb/public/lib/json_value/ut/CMakeLists.linux-aarch64.txt index dbb9b04ed126..4c3a429177ae 100644 --- a/ydb/public/lib/json_value/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/public/lib/json_value/ut/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-public-lib-json_value-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-lib-json_value-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/json_value/ydb_json_value_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/json_value/ut/CMakeLists.linux-x86_64.txt b/ydb/public/lib/json_value/ut/CMakeLists.linux-x86_64.txt index 4bf278ad0f7a..8a6967e48f28 100644 --- a/ydb/public/lib/json_value/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/public/lib/json_value/ut/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(ydb-public-lib-json_value-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-lib-json_value-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/json_value/ydb_json_value_ut.cpp @@ -61,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/json_value/ut/CMakeLists.windows-x86_64.txt b/ydb/public/lib/json_value/ut/CMakeLists.windows-x86_64.txt index 493d8cf2eaa2..3acd3defed96 100644 --- a/ydb/public/lib/json_value/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/public/lib/json_value/ut/CMakeLists.windows-x86_64.txt @@ -50,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/jwt/CMakeLists.darwin-arm64.txt b/ydb/public/lib/jwt/CMakeLists.darwin-arm64.txt index a8da4b49f7b5..fcaef2fe78bb 100644 --- a/ydb/public/lib/jwt/CMakeLists.darwin-arm64.txt +++ b/ydb/public/lib/jwt/CMakeLists.darwin-arm64.txt @@ -16,5 +16,6 @@ target_link_libraries(public-lib-jwt PUBLIC impl-ydb_internal-common ) target_sources(public-lib-jwt PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/jwt/jwt.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/jwt/jwt.cpp ) diff --git a/ydb/public/lib/jwt/CMakeLists.darwin-x86_64.txt b/ydb/public/lib/jwt/CMakeLists.darwin-x86_64.txt index a8da4b49f7b5..fcaef2fe78bb 100644 --- a/ydb/public/lib/jwt/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/lib/jwt/CMakeLists.darwin-x86_64.txt @@ -16,5 +16,6 @@ target_link_libraries(public-lib-jwt PUBLIC impl-ydb_internal-common ) target_sources(public-lib-jwt PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/jwt/jwt.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/jwt/jwt.cpp ) diff --git a/ydb/public/lib/jwt/CMakeLists.linux-aarch64.txt b/ydb/public/lib/jwt/CMakeLists.linux-aarch64.txt index 276c34d4fb00..baab181cd036 100644 --- a/ydb/public/lib/jwt/CMakeLists.linux-aarch64.txt +++ b/ydb/public/lib/jwt/CMakeLists.linux-aarch64.txt @@ -17,5 +17,6 @@ target_link_libraries(public-lib-jwt PUBLIC impl-ydb_internal-common ) target_sources(public-lib-jwt PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/jwt/jwt.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/jwt/jwt.cpp ) diff --git a/ydb/public/lib/jwt/CMakeLists.linux-x86_64.txt b/ydb/public/lib/jwt/CMakeLists.linux-x86_64.txt index 276c34d4fb00..baab181cd036 100644 --- a/ydb/public/lib/jwt/CMakeLists.linux-x86_64.txt +++ b/ydb/public/lib/jwt/CMakeLists.linux-x86_64.txt @@ -17,5 +17,6 @@ target_link_libraries(public-lib-jwt PUBLIC impl-ydb_internal-common ) target_sources(public-lib-jwt PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/jwt/jwt.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/jwt/jwt.cpp ) diff --git a/ydb/public/lib/jwt/CMakeLists.windows-x86_64.txt b/ydb/public/lib/jwt/CMakeLists.windows-x86_64.txt index a8da4b49f7b5..fcaef2fe78bb 100644 --- a/ydb/public/lib/jwt/CMakeLists.windows-x86_64.txt +++ b/ydb/public/lib/jwt/CMakeLists.windows-x86_64.txt @@ -16,5 +16,6 @@ target_link_libraries(public-lib-jwt PUBLIC impl-ydb_internal-common ) target_sources(public-lib-jwt PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/jwt/jwt.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/jwt/jwt.cpp ) diff --git a/ydb/public/lib/operation_id/protos/CMakeLists.darwin-arm64.txt b/ydb/public/lib/operation_id/protos/CMakeLists.darwin-arm64.txt index a800067d564c..aa5f6751595f 100644 --- a/ydb/public/lib/operation_id/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/public/lib/operation_id/protos/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(lib-operation_id-protos PUBLIC target_proto_messages(lib-operation_id-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/operation_id/protos/operation_id.proto ) +target_sources(lib-operation_id-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/lib/operation_id/protos/operation_id.pb.h +) target_proto_addincls(lib-operation_id-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/lib/operation_id/protos/CMakeLists.darwin-x86_64.txt b/ydb/public/lib/operation_id/protos/CMakeLists.darwin-x86_64.txt index a800067d564c..aa5f6751595f 100644 --- a/ydb/public/lib/operation_id/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/lib/operation_id/protos/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(lib-operation_id-protos PUBLIC target_proto_messages(lib-operation_id-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/operation_id/protos/operation_id.proto ) +target_sources(lib-operation_id-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/lib/operation_id/protos/operation_id.pb.h +) target_proto_addincls(lib-operation_id-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/lib/operation_id/protos/CMakeLists.linux-aarch64.txt b/ydb/public/lib/operation_id/protos/CMakeLists.linux-aarch64.txt index d316cb2ab758..d3c3ee55d144 100644 --- a/ydb/public/lib/operation_id/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/public/lib/operation_id/protos/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(lib-operation_id-protos PUBLIC target_proto_messages(lib-operation_id-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/operation_id/protos/operation_id.proto ) +target_sources(lib-operation_id-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/lib/operation_id/protos/operation_id.pb.h +) target_proto_addincls(lib-operation_id-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/lib/operation_id/protos/CMakeLists.linux-x86_64.txt b/ydb/public/lib/operation_id/protos/CMakeLists.linux-x86_64.txt index d316cb2ab758..d3c3ee55d144 100644 --- a/ydb/public/lib/operation_id/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/public/lib/operation_id/protos/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(lib-operation_id-protos PUBLIC target_proto_messages(lib-operation_id-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/operation_id/protos/operation_id.proto ) +target_sources(lib-operation_id-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/lib/operation_id/protos/operation_id.pb.h +) target_proto_addincls(lib-operation_id-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/lib/operation_id/protos/CMakeLists.windows-x86_64.txt b/ydb/public/lib/operation_id/protos/CMakeLists.windows-x86_64.txt index a800067d564c..aa5f6751595f 100644 --- a/ydb/public/lib/operation_id/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/public/lib/operation_id/protos/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(lib-operation_id-protos PUBLIC target_proto_messages(lib-operation_id-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/operation_id/protos/operation_id.proto ) +target_sources(lib-operation_id-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/lib/operation_id/protos/operation_id.pb.h +) target_proto_addincls(lib-operation_id-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/lib/operation_id/ut/CMakeLists.darwin-arm64.txt b/ydb/public/lib/operation_id/ut/CMakeLists.darwin-arm64.txt index e9699b6cb300..b2c4cf6cfaf1 100644 --- a/ydb/public/lib/operation_id/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/public/lib/operation_id/ut/CMakeLists.darwin-arm64.txt @@ -51,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/operation_id/ut/CMakeLists.darwin-x86_64.txt b/ydb/public/lib/operation_id/ut/CMakeLists.darwin-x86_64.txt index 499cf1c0918a..0c5bc9441904 100644 --- a/ydb/public/lib/operation_id/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/lib/operation_id/ut/CMakeLists.darwin-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/operation_id/ut/CMakeLists.linux-aarch64.txt b/ydb/public/lib/operation_id/ut/CMakeLists.linux-aarch64.txt index c45408716466..b41f961d0316 100644 --- a/ydb/public/lib/operation_id/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/public/lib/operation_id/ut/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-public-lib-operation_id-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-lib-operation_id-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/operation_id/operation_id_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/operation_id/ut/CMakeLists.linux-x86_64.txt b/ydb/public/lib/operation_id/ut/CMakeLists.linux-x86_64.txt index 75e1b10e6ec1..1dd45fa877a6 100644 --- a/ydb/public/lib/operation_id/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/public/lib/operation_id/ut/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-public-lib-operation_id-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-lib-operation_id-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/operation_id/operation_id_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/operation_id/ut/CMakeLists.windows-x86_64.txt b/ydb/public/lib/operation_id/ut/CMakeLists.windows-x86_64.txt index a42b3c0cf571..cf7712180187 100644 --- a/ydb/public/lib/operation_id/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/public/lib/operation_id/ut/CMakeLists.windows-x86_64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/scheme_types/CMakeLists.darwin-arm64.txt b/ydb/public/lib/scheme_types/CMakeLists.darwin-arm64.txt index 80504edf4858..942913938f2a 100644 --- a/ydb/public/lib/scheme_types/CMakeLists.darwin-arm64.txt +++ b/ydb/public/lib/scheme_types/CMakeLists.darwin-arm64.txt @@ -14,5 +14,6 @@ target_link_libraries(public-lib-scheme_types PUBLIC yql-public-types ) target_sources(public-lib-scheme_types PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/scheme_types/scheme_type_id.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/scheme_types/scheme_type_id.cpp ) diff --git a/ydb/public/lib/scheme_types/CMakeLists.darwin-x86_64.txt b/ydb/public/lib/scheme_types/CMakeLists.darwin-x86_64.txt index 80504edf4858..942913938f2a 100644 --- a/ydb/public/lib/scheme_types/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/lib/scheme_types/CMakeLists.darwin-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(public-lib-scheme_types PUBLIC yql-public-types ) target_sources(public-lib-scheme_types PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/scheme_types/scheme_type_id.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/scheme_types/scheme_type_id.cpp ) diff --git a/ydb/public/lib/scheme_types/CMakeLists.linux-aarch64.txt b/ydb/public/lib/scheme_types/CMakeLists.linux-aarch64.txt index 48f32db0226e..183b76c48983 100644 --- a/ydb/public/lib/scheme_types/CMakeLists.linux-aarch64.txt +++ b/ydb/public/lib/scheme_types/CMakeLists.linux-aarch64.txt @@ -15,5 +15,6 @@ target_link_libraries(public-lib-scheme_types PUBLIC yql-public-types ) target_sources(public-lib-scheme_types PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/scheme_types/scheme_type_id.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/scheme_types/scheme_type_id.cpp ) diff --git a/ydb/public/lib/scheme_types/CMakeLists.linux-x86_64.txt b/ydb/public/lib/scheme_types/CMakeLists.linux-x86_64.txt index 48f32db0226e..183b76c48983 100644 --- a/ydb/public/lib/scheme_types/CMakeLists.linux-x86_64.txt +++ b/ydb/public/lib/scheme_types/CMakeLists.linux-x86_64.txt @@ -15,5 +15,6 @@ target_link_libraries(public-lib-scheme_types PUBLIC yql-public-types ) target_sources(public-lib-scheme_types PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/scheme_types/scheme_type_id.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/scheme_types/scheme_type_id.cpp ) diff --git a/ydb/public/lib/scheme_types/CMakeLists.windows-x86_64.txt b/ydb/public/lib/scheme_types/CMakeLists.windows-x86_64.txt index 80504edf4858..942913938f2a 100644 --- a/ydb/public/lib/scheme_types/CMakeLists.windows-x86_64.txt +++ b/ydb/public/lib/scheme_types/CMakeLists.windows-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(public-lib-scheme_types PUBLIC yql-public-types ) target_sources(public-lib-scheme_types PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/scheme_types/scheme_type_id.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/scheme_types/scheme_type_id.cpp ) diff --git a/ydb/public/lib/validation/CMakeLists.linux-aarch64.txt b/ydb/public/lib/validation/CMakeLists.linux-aarch64.txt index 8cc45373dc94..7175cd4da4e1 100644 --- a/ydb/public/lib/validation/CMakeLists.linux-aarch64.txt +++ b/ydb/public/lib/validation/CMakeLists.linux-aarch64.txt @@ -22,9 +22,6 @@ target_link_options(validation PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(validation PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/validation/helpers.cpp diff --git a/ydb/public/lib/validation/CMakeLists.linux-x86_64.txt b/ydb/public/lib/validation/CMakeLists.linux-x86_64.txt index f6191a1c2eaf..d08f491bb09f 100644 --- a/ydb/public/lib/validation/CMakeLists.linux-x86_64.txt +++ b/ydb/public/lib/validation/CMakeLists.linux-x86_64.txt @@ -23,9 +23,6 @@ target_link_options(validation PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(validation PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/validation/helpers.cpp diff --git a/ydb/public/lib/validation/ut/CMakeLists.darwin-arm64.txt b/ydb/public/lib/validation/ut/CMakeLists.darwin-arm64.txt index 268969d25838..437791af5a76 100644 --- a/ydb/public/lib/validation/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/public/lib/validation/ut/CMakeLists.darwin-arm64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/validation/ut/CMakeLists.darwin-x86_64.txt b/ydb/public/lib/validation/ut/CMakeLists.darwin-x86_64.txt index 560a5fabf3f0..a77131c9bfc5 100644 --- a/ydb/public/lib/validation/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/lib/validation/ut/CMakeLists.darwin-x86_64.txt @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/validation/ut/CMakeLists.linux-aarch64.txt b/ydb/public/lib/validation/ut/CMakeLists.linux-aarch64.txt index 1aee1aa3c239..a8ac4e1038d8 100644 --- a/ydb/public/lib/validation/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/public/lib/validation/ut/CMakeLists.linux-aarch64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-public-lib-validation-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-lib-validation-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/validation/ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/validation/ut/CMakeLists.linux-x86_64.txt b/ydb/public/lib/validation/ut/CMakeLists.linux-x86_64.txt index 4ac352e78ccd..05b9aef7773d 100644 --- a/ydb/public/lib/validation/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/public/lib/validation/ut/CMakeLists.linux-x86_64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-public-lib-validation-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-lib-validation-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/validation/ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/validation/ut/CMakeLists.windows-x86_64.txt b/ydb/public/lib/validation/ut/CMakeLists.windows-x86_64.txt index ac4d4fcbb524..e428412faf14 100644 --- a/ydb/public/lib/validation/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/public/lib/validation/ut/CMakeLists.windows-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/validation/ut/protos/CMakeLists.darwin-arm64.txt b/ydb/public/lib/validation/ut/protos/CMakeLists.darwin-arm64.txt index 7f7553fb8036..81f4ae337573 100644 --- a/ydb/public/lib/validation/ut/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/public/lib/validation/ut/protos/CMakeLists.darwin-arm64.txt @@ -35,6 +35,9 @@ target_link_libraries(validation-ut-protos PUBLIC target_proto_messages(validation-ut-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/validation/ut/protos/validation_test.proto ) +target_sources(validation-ut-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/lib/validation/ut/protos/validation_test.pb.h +) target_proto_addincls(validation-ut-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/lib/validation/ut/protos/CMakeLists.darwin-x86_64.txt b/ydb/public/lib/validation/ut/protos/CMakeLists.darwin-x86_64.txt index 7f7553fb8036..81f4ae337573 100644 --- a/ydb/public/lib/validation/ut/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/lib/validation/ut/protos/CMakeLists.darwin-x86_64.txt @@ -35,6 +35,9 @@ target_link_libraries(validation-ut-protos PUBLIC target_proto_messages(validation-ut-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/validation/ut/protos/validation_test.proto ) +target_sources(validation-ut-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/lib/validation/ut/protos/validation_test.pb.h +) target_proto_addincls(validation-ut-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/lib/validation/ut/protos/CMakeLists.linux-aarch64.txt b/ydb/public/lib/validation/ut/protos/CMakeLists.linux-aarch64.txt index 880fa86a9bcb..c7cc0e0a9804 100644 --- a/ydb/public/lib/validation/ut/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/public/lib/validation/ut/protos/CMakeLists.linux-aarch64.txt @@ -36,6 +36,9 @@ target_link_libraries(validation-ut-protos PUBLIC target_proto_messages(validation-ut-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/validation/ut/protos/validation_test.proto ) +target_sources(validation-ut-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/lib/validation/ut/protos/validation_test.pb.h +) target_proto_addincls(validation-ut-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/lib/validation/ut/protos/CMakeLists.linux-x86_64.txt b/ydb/public/lib/validation/ut/protos/CMakeLists.linux-x86_64.txt index 880fa86a9bcb..c7cc0e0a9804 100644 --- a/ydb/public/lib/validation/ut/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/public/lib/validation/ut/protos/CMakeLists.linux-x86_64.txt @@ -36,6 +36,9 @@ target_link_libraries(validation-ut-protos PUBLIC target_proto_messages(validation-ut-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/validation/ut/protos/validation_test.proto ) +target_sources(validation-ut-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/lib/validation/ut/protos/validation_test.pb.h +) target_proto_addincls(validation-ut-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/lib/validation/ut/protos/CMakeLists.windows-x86_64.txt b/ydb/public/lib/validation/ut/protos/CMakeLists.windows-x86_64.txt index 7f7553fb8036..81f4ae337573 100644 --- a/ydb/public/lib/validation/ut/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/public/lib/validation/ut/protos/CMakeLists.windows-x86_64.txt @@ -35,6 +35,9 @@ target_link_libraries(validation-ut-protos PUBLIC target_proto_messages(validation-ut-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/validation/ut/protos/validation_test.proto ) +target_sources(validation-ut-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/public/lib/validation/ut/protos/validation_test.pb.h +) target_proto_addincls(validation-ut-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/public/lib/ydb_cli/commands/CMakeLists.darwin-arm64.txt b/ydb/public/lib/ydb_cli/commands/CMakeLists.darwin-arm64.txt index 7715907a5798..afa22114a896 100644 --- a/ydb/public/lib/ydb_cli/commands/CMakeLists.darwin-arm64.txt +++ b/ydb/public/lib/ydb_cli/commands/CMakeLists.darwin-arm64.txt @@ -19,6 +19,7 @@ add_library(clicommands) target_link_libraries(clicommands PUBLIC contrib-libs-cxxsupp yutil + contrib-libs-fmt restricted-patched-replxx cpp-histogram-hdr cpp-protobuf-json @@ -26,6 +27,7 @@ target_link_libraries(clicommands PUBLIC cpp-threading-local_executor kikimr_backup ydb-library-workload + library-yaml_config-public public-lib-operation_id public-lib-stat_visualization common @@ -54,17 +56,16 @@ target_sources(clicommands PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/interactive/line_reader.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/benchmark_utils.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench.cpp - ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/kv_workload.cpp - ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/stock_workload.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_operations_scenario.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_read_scenario.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_write_scenario.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_readwrite_scenario.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/tpch.cpp - ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/tpcc_workload.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/query_workload.cpp + ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_admin.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_sdk_core_access.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_command.cpp + ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_dynamic_config.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_profile.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_root_common.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_service_auth.cpp @@ -86,6 +87,7 @@ add_global_library_for(clicommands.global clicommands) target_link_libraries(clicommands.global PUBLIC contrib-libs-cxxsupp yutil + contrib-libs-fmt restricted-patched-replxx cpp-histogram-hdr cpp-protobuf-json @@ -93,6 +95,7 @@ target_link_libraries(clicommands.global PUBLIC cpp-threading-local_executor kikimr_backup ydb-library-workload + library-yaml_config-public public-lib-operation_id public-lib-stat_visualization common @@ -117,14 +120,15 @@ target_link_libraries(clicommands.global PUBLIC library-cpp-resource ) target_sources(clicommands.global PRIVATE - ${CMAKE_BINARY_DIR}/ydb/public/lib/ydb_cli/commands/6b4a693856d7dfaada0935e4f9b61c1b.cpp + ${CMAKE_BINARY_DIR}/ydb/public/lib/ydb_cli/commands/93bc55e26f576673786aed13327b5397.cpp ) resources(clicommands.global - ${CMAKE_BINARY_DIR}/ydb/public/lib/ydb_cli/commands/6b4a693856d7dfaada0935e4f9b61c1b.cpp + ${CMAKE_BINARY_DIR}/ydb/public/lib/ydb_cli/commands/93bc55e26f576673786aed13327b5397.cpp INPUTS ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_queries.sql ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_schema.sql ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/tpch_schema.sql + ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/tpch_queries.sql ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_canonical/q0.result ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_canonical/q1.result ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_canonical/q2.result @@ -172,6 +176,7 @@ resources(clicommands.global click_bench_queries.sql click_bench_schema.sql tpch_schema.sql + tpch_queries.sql q0.result q1.result q2.result diff --git a/ydb/public/lib/ydb_cli/commands/CMakeLists.darwin-x86_64.txt b/ydb/public/lib/ydb_cli/commands/CMakeLists.darwin-x86_64.txt index 3639c457ab9b..afa22114a896 100644 --- a/ydb/public/lib/ydb_cli/commands/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/lib/ydb_cli/commands/CMakeLists.darwin-x86_64.txt @@ -19,6 +19,7 @@ add_library(clicommands) target_link_libraries(clicommands PUBLIC contrib-libs-cxxsupp yutil + contrib-libs-fmt restricted-patched-replxx cpp-histogram-hdr cpp-protobuf-json @@ -26,6 +27,7 @@ target_link_libraries(clicommands PUBLIC cpp-threading-local_executor kikimr_backup ydb-library-workload + library-yaml_config-public public-lib-operation_id public-lib-stat_visualization common @@ -54,16 +56,16 @@ target_sources(clicommands PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/interactive/line_reader.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/benchmark_utils.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench.cpp - ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/kv_workload.cpp - ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/stock_workload.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_operations_scenario.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_read_scenario.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_write_scenario.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_readwrite_scenario.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/tpch.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/query_workload.cpp + ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_admin.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_sdk_core_access.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_command.cpp + ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_dynamic_config.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_profile.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_root_common.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_service_auth.cpp @@ -85,6 +87,7 @@ add_global_library_for(clicommands.global clicommands) target_link_libraries(clicommands.global PUBLIC contrib-libs-cxxsupp yutil + contrib-libs-fmt restricted-patched-replxx cpp-histogram-hdr cpp-protobuf-json @@ -92,6 +95,7 @@ target_link_libraries(clicommands.global PUBLIC cpp-threading-local_executor kikimr_backup ydb-library-workload + library-yaml_config-public public-lib-operation_id public-lib-stat_visualization common @@ -116,14 +120,15 @@ target_link_libraries(clicommands.global PUBLIC library-cpp-resource ) target_sources(clicommands.global PRIVATE - ${CMAKE_BINARY_DIR}/ydb/public/lib/ydb_cli/commands/6b4a693856d7dfaada0935e4f9b61c1b.cpp + ${CMAKE_BINARY_DIR}/ydb/public/lib/ydb_cli/commands/93bc55e26f576673786aed13327b5397.cpp ) resources(clicommands.global - ${CMAKE_BINARY_DIR}/ydb/public/lib/ydb_cli/commands/6b4a693856d7dfaada0935e4f9b61c1b.cpp + ${CMAKE_BINARY_DIR}/ydb/public/lib/ydb_cli/commands/93bc55e26f576673786aed13327b5397.cpp INPUTS ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_queries.sql ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_schema.sql ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/tpch_schema.sql + ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/tpch_queries.sql ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_canonical/q0.result ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_canonical/q1.result ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_canonical/q2.result @@ -171,6 +176,7 @@ resources(clicommands.global click_bench_queries.sql click_bench_schema.sql tpch_schema.sql + tpch_queries.sql q0.result q1.result q2.result diff --git a/ydb/public/lib/ydb_cli/commands/CMakeLists.linux-aarch64.txt b/ydb/public/lib/ydb_cli/commands/CMakeLists.linux-aarch64.txt index 7f9290ee765b..1618854322c6 100644 --- a/ydb/public/lib/ydb_cli/commands/CMakeLists.linux-aarch64.txt +++ b/ydb/public/lib/ydb_cli/commands/CMakeLists.linux-aarch64.txt @@ -20,6 +20,7 @@ target_link_libraries(clicommands PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + contrib-libs-fmt restricted-patched-replxx cpp-histogram-hdr cpp-protobuf-json @@ -27,6 +28,7 @@ target_link_libraries(clicommands PUBLIC cpp-threading-local_executor kikimr_backup ydb-library-workload + library-yaml_config-public public-lib-operation_id public-lib-stat_visualization common @@ -55,16 +57,16 @@ target_sources(clicommands PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/interactive/line_reader.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/benchmark_utils.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench.cpp - ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/kv_workload.cpp - ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/stock_workload.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_operations_scenario.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_read_scenario.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_write_scenario.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_readwrite_scenario.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/tpch.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/query_workload.cpp + ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_admin.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_sdk_core_access.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_command.cpp + ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_dynamic_config.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_profile.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_root_common.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_service_auth.cpp @@ -87,6 +89,7 @@ target_link_libraries(clicommands.global PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + contrib-libs-fmt restricted-patched-replxx cpp-histogram-hdr cpp-protobuf-json @@ -94,6 +97,7 @@ target_link_libraries(clicommands.global PUBLIC cpp-threading-local_executor kikimr_backup ydb-library-workload + library-yaml_config-public public-lib-operation_id public-lib-stat_visualization common @@ -118,14 +122,15 @@ target_link_libraries(clicommands.global PUBLIC library-cpp-resource ) target_sources(clicommands.global PRIVATE - ${CMAKE_BINARY_DIR}/ydb/public/lib/ydb_cli/commands/6b4a693856d7dfaada0935e4f9b61c1b.cpp + ${CMAKE_BINARY_DIR}/ydb/public/lib/ydb_cli/commands/93bc55e26f576673786aed13327b5397.cpp ) resources(clicommands.global - ${CMAKE_BINARY_DIR}/ydb/public/lib/ydb_cli/commands/6b4a693856d7dfaada0935e4f9b61c1b.cpp + ${CMAKE_BINARY_DIR}/ydb/public/lib/ydb_cli/commands/93bc55e26f576673786aed13327b5397.cpp INPUTS ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_queries.sql ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_schema.sql ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/tpch_schema.sql + ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/tpch_queries.sql ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_canonical/q0.result ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_canonical/q1.result ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_canonical/q2.result @@ -173,6 +178,7 @@ resources(clicommands.global click_bench_queries.sql click_bench_schema.sql tpch_schema.sql + tpch_queries.sql q0.result q1.result q2.result diff --git a/ydb/public/lib/ydb_cli/commands/CMakeLists.linux-x86_64.txt b/ydb/public/lib/ydb_cli/commands/CMakeLists.linux-x86_64.txt index 7f9290ee765b..1618854322c6 100644 --- a/ydb/public/lib/ydb_cli/commands/CMakeLists.linux-x86_64.txt +++ b/ydb/public/lib/ydb_cli/commands/CMakeLists.linux-x86_64.txt @@ -20,6 +20,7 @@ target_link_libraries(clicommands PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + contrib-libs-fmt restricted-patched-replxx cpp-histogram-hdr cpp-protobuf-json @@ -27,6 +28,7 @@ target_link_libraries(clicommands PUBLIC cpp-threading-local_executor kikimr_backup ydb-library-workload + library-yaml_config-public public-lib-operation_id public-lib-stat_visualization common @@ -55,16 +57,16 @@ target_sources(clicommands PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/interactive/line_reader.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/benchmark_utils.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench.cpp - ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/kv_workload.cpp - ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/stock_workload.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_operations_scenario.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_read_scenario.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_write_scenario.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_readwrite_scenario.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/tpch.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/query_workload.cpp + ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_admin.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_sdk_core_access.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_command.cpp + ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_dynamic_config.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_profile.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_root_common.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_service_auth.cpp @@ -87,6 +89,7 @@ target_link_libraries(clicommands.global PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + contrib-libs-fmt restricted-patched-replxx cpp-histogram-hdr cpp-protobuf-json @@ -94,6 +97,7 @@ target_link_libraries(clicommands.global PUBLIC cpp-threading-local_executor kikimr_backup ydb-library-workload + library-yaml_config-public public-lib-operation_id public-lib-stat_visualization common @@ -118,14 +122,15 @@ target_link_libraries(clicommands.global PUBLIC library-cpp-resource ) target_sources(clicommands.global PRIVATE - ${CMAKE_BINARY_DIR}/ydb/public/lib/ydb_cli/commands/6b4a693856d7dfaada0935e4f9b61c1b.cpp + ${CMAKE_BINARY_DIR}/ydb/public/lib/ydb_cli/commands/93bc55e26f576673786aed13327b5397.cpp ) resources(clicommands.global - ${CMAKE_BINARY_DIR}/ydb/public/lib/ydb_cli/commands/6b4a693856d7dfaada0935e4f9b61c1b.cpp + ${CMAKE_BINARY_DIR}/ydb/public/lib/ydb_cli/commands/93bc55e26f576673786aed13327b5397.cpp INPUTS ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_queries.sql ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_schema.sql ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/tpch_schema.sql + ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/tpch_queries.sql ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_canonical/q0.result ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_canonical/q1.result ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_canonical/q2.result @@ -173,6 +178,7 @@ resources(clicommands.global click_bench_queries.sql click_bench_schema.sql tpch_schema.sql + tpch_queries.sql q0.result q1.result q2.result diff --git a/ydb/public/lib/ydb_cli/commands/CMakeLists.windows-x86_64.txt b/ydb/public/lib/ydb_cli/commands/CMakeLists.windows-x86_64.txt index 3639c457ab9b..afa22114a896 100644 --- a/ydb/public/lib/ydb_cli/commands/CMakeLists.windows-x86_64.txt +++ b/ydb/public/lib/ydb_cli/commands/CMakeLists.windows-x86_64.txt @@ -19,6 +19,7 @@ add_library(clicommands) target_link_libraries(clicommands PUBLIC contrib-libs-cxxsupp yutil + contrib-libs-fmt restricted-patched-replxx cpp-histogram-hdr cpp-protobuf-json @@ -26,6 +27,7 @@ target_link_libraries(clicommands PUBLIC cpp-threading-local_executor kikimr_backup ydb-library-workload + library-yaml_config-public public-lib-operation_id public-lib-stat_visualization common @@ -54,16 +56,16 @@ target_sources(clicommands PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/interactive/line_reader.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/benchmark_utils.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench.cpp - ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/kv_workload.cpp - ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/stock_workload.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_operations_scenario.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_read_scenario.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_write_scenario.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_readwrite_scenario.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/tpch.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/query_workload.cpp + ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_admin.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_sdk_core_access.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_command.cpp + ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_dynamic_config.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_profile.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_root_common.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/ydb_service_auth.cpp @@ -85,6 +87,7 @@ add_global_library_for(clicommands.global clicommands) target_link_libraries(clicommands.global PUBLIC contrib-libs-cxxsupp yutil + contrib-libs-fmt restricted-patched-replxx cpp-histogram-hdr cpp-protobuf-json @@ -92,6 +95,7 @@ target_link_libraries(clicommands.global PUBLIC cpp-threading-local_executor kikimr_backup ydb-library-workload + library-yaml_config-public public-lib-operation_id public-lib-stat_visualization common @@ -116,14 +120,15 @@ target_link_libraries(clicommands.global PUBLIC library-cpp-resource ) target_sources(clicommands.global PRIVATE - ${CMAKE_BINARY_DIR}/ydb/public/lib/ydb_cli/commands/6b4a693856d7dfaada0935e4f9b61c1b.cpp + ${CMAKE_BINARY_DIR}/ydb/public/lib/ydb_cli/commands/93bc55e26f576673786aed13327b5397.cpp ) resources(clicommands.global - ${CMAKE_BINARY_DIR}/ydb/public/lib/ydb_cli/commands/6b4a693856d7dfaada0935e4f9b61c1b.cpp + ${CMAKE_BINARY_DIR}/ydb/public/lib/ydb_cli/commands/93bc55e26f576673786aed13327b5397.cpp INPUTS ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_queries.sql ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_schema.sql ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/tpch_schema.sql + ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/tpch_queries.sql ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_canonical/q0.result ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_canonical/q1.result ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/click_bench_canonical/q2.result @@ -171,6 +176,7 @@ resources(clicommands.global click_bench_queries.sql click_bench_schema.sql tpch_schema.sql + tpch_queries.sql q0.result q1.result q2.result diff --git a/ydb/public/lib/ydb_cli/commands/topic_workload/ut/CMakeLists.darwin-arm64.txt b/ydb/public/lib/ydb_cli/commands/topic_workload/ut/CMakeLists.darwin-arm64.txt index ce905a532ac4..12c0cb11b430 100644 --- a/ydb/public/lib/ydb_cli/commands/topic_workload/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/public/lib/ydb_cli/commands/topic_workload/ut/CMakeLists.darwin-arm64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-public-lib-ydb_cli-commands-topic_workload-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-lib-ydb_cli-commands-topic_workload-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_workload/topic_workload_params_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/ydb_cli/commands/topic_workload/ut/CMakeLists.darwin-x86_64.txt b/ydb/public/lib/ydb_cli/commands/topic_workload/ut/CMakeLists.darwin-x86_64.txt index 7f8275fc0d19..04ae7b643e42 100644 --- a/ydb/public/lib/ydb_cli/commands/topic_workload/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/lib/ydb_cli/commands/topic_workload/ut/CMakeLists.darwin-x86_64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-public-lib-ydb_cli-commands-topic_workload-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-lib-ydb_cli-commands-topic_workload-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_workload/topic_workload_params_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/ydb_cli/commands/topic_workload/ut/CMakeLists.linux-aarch64.txt b/ydb/public/lib/ydb_cli/commands/topic_workload/ut/CMakeLists.linux-aarch64.txt index d4763a78e3ba..55be209fe256 100644 --- a/ydb/public/lib/ydb_cli/commands/topic_workload/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/public/lib/ydb_cli/commands/topic_workload/ut/CMakeLists.linux-aarch64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-public-lib-ydb_cli-commands-topic_workload-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-lib-ydb_cli-commands-topic_workload-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_workload/topic_workload_params_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/ydb_cli/commands/topic_workload/ut/CMakeLists.linux-x86_64.txt b/ydb/public/lib/ydb_cli/commands/topic_workload/ut/CMakeLists.linux-x86_64.txt index a9e9e79c61e9..abd6818c21fd 100644 --- a/ydb/public/lib/ydb_cli/commands/topic_workload/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/public/lib/ydb_cli/commands/topic_workload/ut/CMakeLists.linux-x86_64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-public-lib-ydb_cli-commands-topic_workload-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-lib-ydb_cli-commands-topic_workload-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/commands/topic_workload/topic_workload_params_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/ydb_cli/commands/topic_workload/ut/CMakeLists.windows-x86_64.txt b/ydb/public/lib/ydb_cli/commands/topic_workload/ut/CMakeLists.windows-x86_64.txt index 26b646c82224..20a5d7410d1d 100644 --- a/ydb/public/lib/ydb_cli/commands/topic_workload/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/public/lib/ydb_cli/commands/topic_workload/ut/CMakeLists.windows-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/ydb_cli/common/CMakeLists.darwin-arm64.txt b/ydb/public/lib/ydb_cli/common/CMakeLists.darwin-arm64.txt index c684a660f2de..739483ec8c94 100644 --- a/ydb/public/lib/ydb_cli/common/CMakeLists.darwin-arm64.txt +++ b/ydb/public/lib/ydb_cli/common/CMakeLists.darwin-arm64.txt @@ -24,6 +24,7 @@ add_library(common) target_link_libraries(common PUBLIC contrib-libs-cxxsupp yutil + libs-aws-sdk-cpp-aws-cpp-sdk-s3 library-cpp-config library-cpp-getopt cpp-json-writer @@ -39,6 +40,7 @@ target_link_libraries(common PUBLIC cpp-client-ydb_topic cpp-client-ydb_types client-ydb_types-credentials + ydb-library-arrow_parquet tools-enum_parser-enum_serialization_runtime ) target_sources(common PRIVATE diff --git a/ydb/public/lib/ydb_cli/common/CMakeLists.darwin-x86_64.txt b/ydb/public/lib/ydb_cli/common/CMakeLists.darwin-x86_64.txt index c684a660f2de..739483ec8c94 100644 --- a/ydb/public/lib/ydb_cli/common/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/lib/ydb_cli/common/CMakeLists.darwin-x86_64.txt @@ -24,6 +24,7 @@ add_library(common) target_link_libraries(common PUBLIC contrib-libs-cxxsupp yutil + libs-aws-sdk-cpp-aws-cpp-sdk-s3 library-cpp-config library-cpp-getopt cpp-json-writer @@ -39,6 +40,7 @@ target_link_libraries(common PUBLIC cpp-client-ydb_topic cpp-client-ydb_types client-ydb_types-credentials + ydb-library-arrow_parquet tools-enum_parser-enum_serialization_runtime ) target_sources(common PRIVATE diff --git a/ydb/public/lib/ydb_cli/common/CMakeLists.linux-aarch64.txt b/ydb/public/lib/ydb_cli/common/CMakeLists.linux-aarch64.txt index 740a58d60cbc..c04d06e63f9b 100644 --- a/ydb/public/lib/ydb_cli/common/CMakeLists.linux-aarch64.txt +++ b/ydb/public/lib/ydb_cli/common/CMakeLists.linux-aarch64.txt @@ -25,6 +25,7 @@ target_link_libraries(common PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + libs-aws-sdk-cpp-aws-cpp-sdk-s3 library-cpp-config library-cpp-getopt cpp-json-writer @@ -40,6 +41,7 @@ target_link_libraries(common PUBLIC cpp-client-ydb_topic cpp-client-ydb_types client-ydb_types-credentials + ydb-library-arrow_parquet tools-enum_parser-enum_serialization_runtime ) target_sources(common PRIVATE diff --git a/ydb/public/lib/ydb_cli/common/CMakeLists.linux-x86_64.txt b/ydb/public/lib/ydb_cli/common/CMakeLists.linux-x86_64.txt index 740a58d60cbc..c04d06e63f9b 100644 --- a/ydb/public/lib/ydb_cli/common/CMakeLists.linux-x86_64.txt +++ b/ydb/public/lib/ydb_cli/common/CMakeLists.linux-x86_64.txt @@ -25,6 +25,7 @@ target_link_libraries(common PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + libs-aws-sdk-cpp-aws-cpp-sdk-s3 library-cpp-config library-cpp-getopt cpp-json-writer @@ -40,6 +41,7 @@ target_link_libraries(common PUBLIC cpp-client-ydb_topic cpp-client-ydb_types client-ydb_types-credentials + ydb-library-arrow_parquet tools-enum_parser-enum_serialization_runtime ) target_sources(common PRIVATE diff --git a/ydb/public/lib/ydb_cli/common/CMakeLists.windows-x86_64.txt b/ydb/public/lib/ydb_cli/common/CMakeLists.windows-x86_64.txt index c684a660f2de..739483ec8c94 100644 --- a/ydb/public/lib/ydb_cli/common/CMakeLists.windows-x86_64.txt +++ b/ydb/public/lib/ydb_cli/common/CMakeLists.windows-x86_64.txt @@ -24,6 +24,7 @@ add_library(common) target_link_libraries(common PUBLIC contrib-libs-cxxsupp yutil + libs-aws-sdk-cpp-aws-cpp-sdk-s3 library-cpp-config library-cpp-getopt cpp-json-writer @@ -39,6 +40,7 @@ target_link_libraries(common PUBLIC cpp-client-ydb_topic cpp-client-ydb_types client-ydb_types-credentials + ydb-library-arrow_parquet tools-enum_parser-enum_serialization_runtime ) target_sources(common PRIVATE diff --git a/ydb/public/lib/ydb_cli/common/ut/CMakeLists.darwin-arm64.txt b/ydb/public/lib/ydb_cli/common/ut/CMakeLists.darwin-arm64.txt index 18ba45ebb3ef..4fc28b42bbaf 100644 --- a/ydb/public/lib/ydb_cli/common/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/public/lib/ydb_cli/common/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-public-lib-ydb_cli-common-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-lib-ydb_cli-common-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/common/normalize_path_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/ydb_cli/common/ut/CMakeLists.darwin-x86_64.txt b/ydb/public/lib/ydb_cli/common/ut/CMakeLists.darwin-x86_64.txt index 329a4c7e3fa1..d261603a3727 100644 --- a/ydb/public/lib/ydb_cli/common/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/lib/ydb_cli/common/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-public-lib-ydb_cli-common-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-lib-ydb_cli-common-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/common/normalize_path_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/ydb_cli/common/ut/CMakeLists.linux-aarch64.txt b/ydb/public/lib/ydb_cli/common/ut/CMakeLists.linux-aarch64.txt index 129ee56e45a1..b9070bddd466 100644 --- a/ydb/public/lib/ydb_cli/common/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/public/lib/ydb_cli/common/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-public-lib-ydb_cli-common-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-lib-ydb_cli-common-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/common/normalize_path_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/ydb_cli/common/ut/CMakeLists.linux-x86_64.txt b/ydb/public/lib/ydb_cli/common/ut/CMakeLists.linux-x86_64.txt index 6763952b32fc..1ba992335148 100644 --- a/ydb/public/lib/ydb_cli/common/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/public/lib/ydb_cli/common/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-public-lib-ydb_cli-common-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-lib-ydb_cli-common-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/common/normalize_path_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/ydb_cli/common/ut/CMakeLists.windows-x86_64.txt b/ydb/public/lib/ydb_cli/common/ut/CMakeLists.windows-x86_64.txt index 982a141b099c..28be79da1efc 100644 --- a/ydb/public/lib/ydb_cli/common/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/public/lib/ydb_cli/common/ut/CMakeLists.windows-x86_64.txt @@ -48,6 +48,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/ydb_cli/topic/ut/CMakeLists.darwin-arm64.txt b/ydb/public/lib/ydb_cli/topic/ut/CMakeLists.darwin-arm64.txt index 52f2c7e9c291..97529436ef95 100644 --- a/ydb/public/lib/ydb_cli/topic/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/public/lib/ydb_cli/topic/ut/CMakeLists.darwin-arm64.txt @@ -34,10 +34,9 @@ target_link_options(ydb-public-lib-ydb_cli-topic-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-lib-ydb_cli-topic-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/topic/topic_write.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/topic/topic_write.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/topic/topic_write_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/topic/topic_read_ut.cpp @@ -67,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/ydb_cli/topic/ut/CMakeLists.darwin-x86_64.txt b/ydb/public/lib/ydb_cli/topic/ut/CMakeLists.darwin-x86_64.txt index 8747791be6f8..5591d6ea18a8 100644 --- a/ydb/public/lib/ydb_cli/topic/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/lib/ydb_cli/topic/ut/CMakeLists.darwin-x86_64.txt @@ -35,10 +35,9 @@ target_link_options(ydb-public-lib-ydb_cli-topic-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-lib-ydb_cli-topic-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/topic/topic_write.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/topic/topic_write.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/topic/topic_write_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/topic/topic_read_ut.cpp @@ -68,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/ydb_cli/topic/ut/CMakeLists.linux-aarch64.txt b/ydb/public/lib/ydb_cli/topic/ut/CMakeLists.linux-aarch64.txt index 4cb79809b827..9c9c93d3255b 100644 --- a/ydb/public/lib/ydb_cli/topic/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/public/lib/ydb_cli/topic/ut/CMakeLists.linux-aarch64.txt @@ -37,11 +37,9 @@ target_link_options(ydb-public-lib-ydb_cli-topic-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-lib-ydb_cli-topic-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/topic/topic_write.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/topic/topic_write.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/topic/topic_write_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/topic/topic_read_ut.cpp @@ -71,6 +69,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/ydb_cli/topic/ut/CMakeLists.linux-x86_64.txt b/ydb/public/lib/ydb_cli/topic/ut/CMakeLists.linux-x86_64.txt index 3b132c9fb458..12b1c739d83b 100644 --- a/ydb/public/lib/ydb_cli/topic/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/public/lib/ydb_cli/topic/ut/CMakeLists.linux-x86_64.txt @@ -38,11 +38,9 @@ target_link_options(ydb-public-lib-ydb_cli-topic-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-lib-ydb_cli-topic-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/topic/topic_write.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/topic/topic_write.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/topic/topic_write_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/topic/topic_read_ut.cpp @@ -72,6 +70,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/lib/ydb_cli/topic/ut/CMakeLists.windows-x86_64.txt b/ydb/public/lib/ydb_cli/topic/ut/CMakeLists.windows-x86_64.txt index f2b29d20758c..1fdd21424901 100644 --- a/ydb/public/lib/ydb_cli/topic/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/public/lib/ydb_cli/topic/ut/CMakeLists.windows-x86_64.txt @@ -32,6 +32,7 @@ target_link_libraries(ydb-public-lib-ydb_cli-topic-ut PUBLIC ydb_persqueue_core-ut-ut_utils ) target_sources(ydb-public-lib-ydb_cli-topic-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/topic/topic_write.h ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/topic/topic_write.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/topic/topic_write_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/public/lib/ydb_cli/topic/topic_read_ut.cpp @@ -61,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/draft/ut/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/draft/ut/CMakeLists.darwin-arm64.txt index 8d6480229603..8a44042157b5 100644 --- a/ydb/public/sdk/cpp/client/draft/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/draft/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-public-sdk-cpp-client-draft-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-sdk-cpp-client-draft-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/draft/ydb_scripting_response_headers_ut.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/draft/ut/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/draft/ut/CMakeLists.darwin-x86_64.txt index eca60737ff47..3582ab3ee68b 100644 --- a/ydb/public/sdk/cpp/client/draft/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/draft/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-public-sdk-cpp-client-draft-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-sdk-cpp-client-draft-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/draft/ydb_scripting_response_headers_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/draft/ut/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/draft/ut/CMakeLists.linux-aarch64.txt index 049facf2bc34..29491eb62b45 100644 --- a/ydb/public/sdk/cpp/client/draft/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/draft/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-public-sdk-cpp-client-draft-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-sdk-cpp-client-draft-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/draft/ydb_scripting_response_headers_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/draft/ut/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/draft/ut/CMakeLists.linux-x86_64.txt index 24da5572fff3..ca76c1ddd9c5 100644 --- a/ydb/public/sdk/cpp/client/draft/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/draft/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-public-sdk-cpp-client-draft-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-sdk-cpp-client-draft-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/draft/ydb_scripting_response_headers_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/draft/ut/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/draft/ut/CMakeLists.windows-x86_64.txt index 7f70ecd4a5ed..bf43d512ea06 100644 --- a/ydb/public/sdk/cpp/client/draft/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/draft/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/extensions/discovery_mutator/ut/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/extensions/discovery_mutator/ut/CMakeLists.darwin-arm64.txt index 772c1373c88e..1059de59581e 100644 --- a/ydb/public/sdk/cpp/client/extensions/discovery_mutator/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/extensions/discovery_mutator/ut/CMakeLists.darwin-arm64.txt @@ -22,8 +22,6 @@ target_link_options(client-extensions-discovery_mutator-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(client-extensions-discovery_mutator-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/extensions/discovery_mutator/discovery_mutator_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/extensions/discovery_mutator/ut/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/extensions/discovery_mutator/ut/CMakeLists.darwin-x86_64.txt index 0bdb739b6c6f..34488bb24228 100644 --- a/ydb/public/sdk/cpp/client/extensions/discovery_mutator/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/extensions/discovery_mutator/ut/CMakeLists.darwin-x86_64.txt @@ -23,8 +23,6 @@ target_link_options(client-extensions-discovery_mutator-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(client-extensions-discovery_mutator-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/extensions/discovery_mutator/discovery_mutator_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/extensions/discovery_mutator/ut/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/extensions/discovery_mutator/ut/CMakeLists.linux-aarch64.txt index 90a75827f594..dbe91f811d40 100644 --- a/ydb/public/sdk/cpp/client/extensions/discovery_mutator/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/extensions/discovery_mutator/ut/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(client-extensions-discovery_mutator-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(client-extensions-discovery_mutator-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/extensions/discovery_mutator/discovery_mutator_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/extensions/discovery_mutator/ut/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/extensions/discovery_mutator/ut/CMakeLists.linux-x86_64.txt index 4f6fb263bf55..3b4ea43f52cb 100644 --- a/ydb/public/sdk/cpp/client/extensions/discovery_mutator/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/extensions/discovery_mutator/ut/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(client-extensions-discovery_mutator-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(client-extensions-discovery_mutator-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/extensions/discovery_mutator/discovery_mutator_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/extensions/discovery_mutator/ut/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/extensions/discovery_mutator/ut/CMakeLists.windows-x86_64.txt index bab4b5096422..76382ba917e0 100644 --- a/ydb/public/sdk/cpp/client/extensions/discovery_mutator/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/extensions/discovery_mutator/ut/CMakeLists.windows-x86_64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/iam/impl/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/iam/impl/CMakeLists.darwin-arm64.txt index bc0b4bf5c433..0ee0a92733e7 100644 --- a/ydb/public/sdk/cpp/client/iam/impl/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/iam/impl/CMakeLists.darwin-arm64.txt @@ -19,3 +19,6 @@ target_link_libraries(client-iam-impl INTERFACE client-ydb_types-credentials client-iam-common ) +target_sources(client-iam-impl INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/iam/impl/iam_impl.h +) diff --git a/ydb/public/sdk/cpp/client/iam/impl/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/iam/impl/CMakeLists.darwin-x86_64.txt index bc0b4bf5c433..0ee0a92733e7 100644 --- a/ydb/public/sdk/cpp/client/iam/impl/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/iam/impl/CMakeLists.darwin-x86_64.txt @@ -19,3 +19,6 @@ target_link_libraries(client-iam-impl INTERFACE client-ydb_types-credentials client-iam-common ) +target_sources(client-iam-impl INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/iam/impl/iam_impl.h +) diff --git a/ydb/public/sdk/cpp/client/iam/impl/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/iam/impl/CMakeLists.linux-aarch64.txt index 814d7a7be534..844006fe79b6 100644 --- a/ydb/public/sdk/cpp/client/iam/impl/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/iam/impl/CMakeLists.linux-aarch64.txt @@ -20,3 +20,6 @@ target_link_libraries(client-iam-impl INTERFACE client-ydb_types-credentials client-iam-common ) +target_sources(client-iam-impl INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/iam/impl/iam_impl.h +) diff --git a/ydb/public/sdk/cpp/client/iam/impl/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/iam/impl/CMakeLists.linux-x86_64.txt index 814d7a7be534..844006fe79b6 100644 --- a/ydb/public/sdk/cpp/client/iam/impl/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/iam/impl/CMakeLists.linux-x86_64.txt @@ -20,3 +20,6 @@ target_link_libraries(client-iam-impl INTERFACE client-ydb_types-credentials client-iam-common ) +target_sources(client-iam-impl INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/iam/impl/iam_impl.h +) diff --git a/ydb/public/sdk/cpp/client/iam/impl/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/iam/impl/CMakeLists.windows-x86_64.txt index bc0b4bf5c433..0ee0a92733e7 100644 --- a/ydb/public/sdk/cpp/client/iam/impl/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/iam/impl/CMakeLists.windows-x86_64.txt @@ -19,3 +19,6 @@ target_link_libraries(client-iam-impl INTERFACE client-ydb_types-credentials client-iam-common ) +target_sources(client-iam-impl INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/iam/impl/iam_impl.h +) diff --git a/ydb/public/sdk/cpp/client/impl/ydb_endpoints/ut/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/impl/ydb_endpoints/ut/CMakeLists.darwin-arm64.txt index 445bbca32119..2eb49ba2aaf1 100644 --- a/ydb/public/sdk/cpp/client/impl/ydb_endpoints/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/impl/ydb_endpoints/ut/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-public-sdk-cpp-client-impl-ydb_endpoints-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-sdk-cpp-client-impl-ydb_endpoints-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/impl/ydb_endpoints/endpoints_ut.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/impl/ydb_endpoints/ut/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/impl/ydb_endpoints/ut/CMakeLists.darwin-x86_64.txt index 58188feff55e..dcbb5eb21ecc 100644 --- a/ydb/public/sdk/cpp/client/impl/ydb_endpoints/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/impl/ydb_endpoints/ut/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-public-sdk-cpp-client-impl-ydb_endpoints-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-sdk-cpp-client-impl-ydb_endpoints-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/impl/ydb_endpoints/endpoints_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/impl/ydb_endpoints/ut/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/impl/ydb_endpoints/ut/CMakeLists.linux-aarch64.txt index f13f739002a9..e0e609ab4409 100644 --- a/ydb/public/sdk/cpp/client/impl/ydb_endpoints/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/impl/ydb_endpoints/ut/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-public-sdk-cpp-client-impl-ydb_endpoints-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-sdk-cpp-client-impl-ydb_endpoints-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/impl/ydb_endpoints/endpoints_ut.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/impl/ydb_endpoints/ut/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/impl/ydb_endpoints/ut/CMakeLists.linux-x86_64.txt index 358dacf72ac7..b4c8fb365201 100644 --- a/ydb/public/sdk/cpp/client/impl/ydb_endpoints/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/impl/ydb_endpoints/ut/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-public-sdk-cpp-client-impl-ydb_endpoints-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-sdk-cpp-client-impl-ydb_endpoints-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/impl/ydb_endpoints/endpoints_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/impl/ydb_endpoints/ut/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/impl/ydb_endpoints/ut/CMakeLists.windows-x86_64.txt index cffc724457f9..d8b58887cb68 100644 --- a/ydb/public/sdk/cpp/client/impl/ydb_endpoints/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/impl/ydb_endpoints/ut/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_coordination/ut/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/ydb_coordination/ut/CMakeLists.darwin-arm64.txt index 89b0e5b07e3d..c191c9b75ae9 100644 --- a/ydb/public/sdk/cpp/client/ydb_coordination/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/ydb_coordination/ut/CMakeLists.darwin-arm64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_coordination-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-sdk-cpp-client-ydb_coordination-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_coordination/coordination_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_coordination/ut/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_coordination/ut/CMakeLists.darwin-x86_64.txt index d865373e038d..f6f999b24f45 100644 --- a/ydb/public/sdk/cpp/client/ydb_coordination/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_coordination/ut/CMakeLists.darwin-x86_64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_coordination-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-sdk-cpp-client-ydb_coordination-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_coordination/coordination_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_coordination/ut/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/ydb_coordination/ut/CMakeLists.linux-aarch64.txt index db03fcdbaa20..89c76626027f 100644 --- a/ydb/public/sdk/cpp/client/ydb_coordination/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/ydb_coordination/ut/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_coordination-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-sdk-cpp-client-ydb_coordination-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_coordination/coordination_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_coordination/ut/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_coordination/ut/CMakeLists.linux-x86_64.txt index af48ec55d738..b5896e0d64a8 100644 --- a/ydb/public/sdk/cpp/client/ydb_coordination/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_coordination/ut/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_coordination-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-sdk-cpp-client-ydb_coordination-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_coordination/coordination_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_coordination/ut/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_coordination/ut/CMakeLists.windows-x86_64.txt index 83ec97a9d1b3..c45556acc817 100644 --- a/ydb/public/sdk/cpp/client/ydb_coordination/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_coordination/ut/CMakeLists.windows-x86_64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_driver/ut/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/ydb_driver/ut/CMakeLists.darwin-arm64.txt index 6a048be57784..01e853455fb1 100644 --- a/ydb/public/sdk/cpp/client/ydb_driver/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/ydb_driver/ut/CMakeLists.darwin-arm64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_driver-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-sdk-cpp-client-ydb_driver-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_driver/driver_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_driver/ut/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_driver/ut/CMakeLists.darwin-x86_64.txt index 09afdbc8d77e..a29ceafa3f1b 100644 --- a/ydb/public/sdk/cpp/client/ydb_driver/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_driver/ut/CMakeLists.darwin-x86_64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_driver-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-sdk-cpp-client-ydb_driver-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_driver/driver_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_driver/ut/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/ydb_driver/ut/CMakeLists.linux-aarch64.txt index 115ee06e0701..930c8f38de4c 100644 --- a/ydb/public/sdk/cpp/client/ydb_driver/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/ydb_driver/ut/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_driver-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-sdk-cpp-client-ydb_driver-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_driver/driver_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_driver/ut/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_driver/ut/CMakeLists.linux-x86_64.txt index 771e268470c7..169098910560 100644 --- a/ydb/public/sdk/cpp/client/ydb_driver/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_driver/ut/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_driver-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-sdk-cpp-client-ydb_driver-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_driver/driver_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_driver/ut/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_driver/ut/CMakeLists.windows-x86_64.txt index a63492287078..715d7d8f4bc0 100644 --- a/ydb/public/sdk/cpp/client/ydb_driver/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_driver/ut/CMakeLists.windows-x86_64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_federated_topic/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/ydb_federated_topic/CMakeLists.darwin-arm64.txt index dce7f916340f..6947ac5b5d50 100644 --- a/ydb/public/sdk/cpp/client/ydb_federated_topic/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/ydb_federated_topic/CMakeLists.darwin-arm64.txt @@ -23,6 +23,9 @@ target_link_libraries(cpp-client-ydb_federated_topic PUBLIC cpp-client-ydb_topic client-ydb_federated_topic-impl ) +target_sources(cpp-client-ydb_federated_topic PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/federated_topic.h +) generate_enum_serilization(cpp-client-ydb_federated_topic ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/federated_topic.h INCLUDE_HEADERS diff --git a/ydb/public/sdk/cpp/client/ydb_federated_topic/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_federated_topic/CMakeLists.darwin-x86_64.txt index dce7f916340f..6947ac5b5d50 100644 --- a/ydb/public/sdk/cpp/client/ydb_federated_topic/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_federated_topic/CMakeLists.darwin-x86_64.txt @@ -23,6 +23,9 @@ target_link_libraries(cpp-client-ydb_federated_topic PUBLIC cpp-client-ydb_topic client-ydb_federated_topic-impl ) +target_sources(cpp-client-ydb_federated_topic PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/federated_topic.h +) generate_enum_serilization(cpp-client-ydb_federated_topic ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/federated_topic.h INCLUDE_HEADERS diff --git a/ydb/public/sdk/cpp/client/ydb_federated_topic/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/ydb_federated_topic/CMakeLists.linux-aarch64.txt index 3e5d5f67b04d..6d31b42488fd 100644 --- a/ydb/public/sdk/cpp/client/ydb_federated_topic/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/ydb_federated_topic/CMakeLists.linux-aarch64.txt @@ -24,6 +24,9 @@ target_link_libraries(cpp-client-ydb_federated_topic PUBLIC cpp-client-ydb_topic client-ydb_federated_topic-impl ) +target_sources(cpp-client-ydb_federated_topic PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/federated_topic.h +) generate_enum_serilization(cpp-client-ydb_federated_topic ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/federated_topic.h INCLUDE_HEADERS diff --git a/ydb/public/sdk/cpp/client/ydb_federated_topic/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_federated_topic/CMakeLists.linux-x86_64.txt index 3e5d5f67b04d..6d31b42488fd 100644 --- a/ydb/public/sdk/cpp/client/ydb_federated_topic/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_federated_topic/CMakeLists.linux-x86_64.txt @@ -24,6 +24,9 @@ target_link_libraries(cpp-client-ydb_federated_topic PUBLIC cpp-client-ydb_topic client-ydb_federated_topic-impl ) +target_sources(cpp-client-ydb_federated_topic PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/federated_topic.h +) generate_enum_serilization(cpp-client-ydb_federated_topic ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/federated_topic.h INCLUDE_HEADERS diff --git a/ydb/public/sdk/cpp/client/ydb_federated_topic/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_federated_topic/CMakeLists.windows-x86_64.txt index dce7f916340f..6947ac5b5d50 100644 --- a/ydb/public/sdk/cpp/client/ydb_federated_topic/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_federated_topic/CMakeLists.windows-x86_64.txt @@ -23,6 +23,9 @@ target_link_libraries(cpp-client-ydb_federated_topic PUBLIC cpp-client-ydb_topic client-ydb_federated_topic-impl ) +target_sources(cpp-client-ydb_federated_topic PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/federated_topic.h +) generate_enum_serilization(cpp-client-ydb_federated_topic ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/federated_topic.h INCLUDE_HEADERS diff --git a/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/CMakeLists.darwin-arm64.txt index bea5a60f1e4a..4fdc550e9cf3 100644 --- a/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/CMakeLists.darwin-arm64.txt @@ -25,6 +25,10 @@ target_link_libraries(client-ydb_federated_topic-impl PUBLIC cpp-client-ydb_proto ) target_sources(client-ydb_federated_topic-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_read_session.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_write_session.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_topic_impl.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federation_observer.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_read_session.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_read_session_event.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_write_session.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/CMakeLists.darwin-x86_64.txt index bea5a60f1e4a..4fdc550e9cf3 100644 --- a/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/CMakeLists.darwin-x86_64.txt @@ -25,6 +25,10 @@ target_link_libraries(client-ydb_federated_topic-impl PUBLIC cpp-client-ydb_proto ) target_sources(client-ydb_federated_topic-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_read_session.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_write_session.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_topic_impl.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federation_observer.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_read_session.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_read_session_event.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_write_session.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/CMakeLists.linux-aarch64.txt index efd677ea08d8..455929fdcd4c 100644 --- a/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/CMakeLists.linux-aarch64.txt @@ -26,6 +26,10 @@ target_link_libraries(client-ydb_federated_topic-impl PUBLIC cpp-client-ydb_proto ) target_sources(client-ydb_federated_topic-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_read_session.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_write_session.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_topic_impl.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federation_observer.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_read_session.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_read_session_event.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_write_session.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/CMakeLists.linux-x86_64.txt index efd677ea08d8..455929fdcd4c 100644 --- a/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/CMakeLists.linux-x86_64.txt @@ -26,6 +26,10 @@ target_link_libraries(client-ydb_federated_topic-impl PUBLIC cpp-client-ydb_proto ) target_sources(client-ydb_federated_topic-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_read_session.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_write_session.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_topic_impl.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federation_observer.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_read_session.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_read_session_event.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_write_session.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/CMakeLists.windows-x86_64.txt index bea5a60f1e4a..4fdc550e9cf3 100644 --- a/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/CMakeLists.windows-x86_64.txt @@ -25,6 +25,10 @@ target_link_libraries(client-ydb_federated_topic-impl PUBLIC cpp-client-ydb_proto ) target_sources(client-ydb_federated_topic-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_read_session.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_write_session.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_topic_impl.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federation_observer.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_read_session.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_read_session_event.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/impl/federated_write_session.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/CMakeLists.darwin-arm64.txt index d090bfafab60..b741639d4562 100644 --- a/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/CMakeLists.darwin-arm64.txt @@ -36,8 +36,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_federated_topic-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-sdk-cpp-client-ydb_federated_topic-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/basic_usage_ut.cpp @@ -67,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/CMakeLists.darwin-x86_64.txt index 8ae3258bf296..770e555e4285 100644 --- a/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/CMakeLists.darwin-x86_64.txt @@ -37,8 +37,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_federated_topic-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-sdk-cpp-client-ydb_federated_topic-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/basic_usage_ut.cpp @@ -68,6 +66,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/CMakeLists.linux-aarch64.txt index f5d7b13900c3..60df93e056dd 100644 --- a/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/CMakeLists.linux-aarch64.txt @@ -39,9 +39,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_federated_topic-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-sdk-cpp-client-ydb_federated_topic-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/basic_usage_ut.cpp @@ -71,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/CMakeLists.linux-x86_64.txt index a70159ebcd07..5cdbf2a0461f 100644 --- a/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/CMakeLists.linux-x86_64.txt @@ -40,9 +40,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_federated_topic-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-sdk-cpp-client-ydb_federated_topic-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/basic_usage_ut.cpp @@ -72,6 +69,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/CMakeLists.windows-x86_64.txt index 4d6c28c3cda7..0df01dfcce48 100644 --- a/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_federated_topic/ut/CMakeLists.windows-x86_64.txt @@ -61,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_params/ut/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/ydb_params/ut/CMakeLists.darwin-arm64.txt index 0ab860b6e757..e1d1f956e626 100644 --- a/ydb/public/sdk/cpp/client/ydb_params/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/ydb_params/ut/CMakeLists.darwin-arm64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_params-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-sdk-cpp-client-ydb_params-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_params/params_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_params/ut/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_params/ut/CMakeLists.darwin-x86_64.txt index 632443160874..7d2ad67056bf 100644 --- a/ydb/public/sdk/cpp/client/ydb_params/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_params/ut/CMakeLists.darwin-x86_64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_params-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-sdk-cpp-client-ydb_params-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_params/params_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_params/ut/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/ydb_params/ut/CMakeLists.linux-aarch64.txt index bf4476c73d4f..0db1581d3154 100644 --- a/ydb/public/sdk/cpp/client/ydb_params/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/ydb_params/ut/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_params-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-sdk-cpp-client-ydb_params-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_params/params_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_params/ut/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_params/ut/CMakeLists.linux-x86_64.txt index 1c3738dc401f..f00f4a6a0df5 100644 --- a/ydb/public/sdk/cpp/client/ydb_params/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_params/ut/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_params-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-sdk-cpp-client-ydb_params-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_params/params_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_params/ut/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_params/ut/CMakeLists.windows-x86_64.txt index d4eeadcc3588..03c9fa6e57ba 100644 --- a/ydb/public/sdk/cpp/client/ydb_params/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_params/ut/CMakeLists.windows-x86_64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/CMakeLists.darwin-arm64.txt index fab78335eeb3..af62d2989a1e 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(cpp-client-ydb_persqueue_core PUBLIC api-grpc-draft api-protos ) +target_sources(cpp-client-ydb_persqueue_core PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/persqueue.h +) generate_enum_serilization(cpp-client-ydb_persqueue_core ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/persqueue.h INCLUDE_HEADERS diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/CMakeLists.darwin-x86_64.txt index fab78335eeb3..af62d2989a1e 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(cpp-client-ydb_persqueue_core PUBLIC api-grpc-draft api-protos ) +target_sources(cpp-client-ydb_persqueue_core PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/persqueue.h +) generate_enum_serilization(cpp-client-ydb_persqueue_core ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/persqueue.h INCLUDE_HEADERS diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/CMakeLists.linux-aarch64.txt index 6ac95f3166a3..e64bd84e8ebe 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(cpp-client-ydb_persqueue_core PUBLIC api-grpc-draft api-protos ) +target_sources(cpp-client-ydb_persqueue_core PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/persqueue.h +) generate_enum_serilization(cpp-client-ydb_persqueue_core ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/persqueue.h INCLUDE_HEADERS diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/CMakeLists.linux-x86_64.txt index 6ac95f3166a3..e64bd84e8ebe 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(cpp-client-ydb_persqueue_core PUBLIC api-grpc-draft api-protos ) +target_sources(cpp-client-ydb_persqueue_core PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/persqueue.h +) generate_enum_serilization(cpp-client-ydb_persqueue_core ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/persqueue.h INCLUDE_HEADERS diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/CMakeLists.windows-x86_64.txt index fab78335eeb3..af62d2989a1e 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(cpp-client-ydb_persqueue_core PUBLIC api-grpc-draft api-protos ) +target_sources(cpp-client-ydb_persqueue_core PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/persqueue.h +) generate_enum_serilization(cpp-client-ydb_persqueue_core ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/persqueue.h INCLUDE_HEADERS diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/CMakeLists.darwin-arm64.txt index f205192103ba..827dc0713994 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/CMakeLists.darwin-arm64.txt @@ -23,6 +23,7 @@ target_link_libraries(client-ydb_persqueue_core-impl PUBLIC cpp-client-ydb_driver ) target_sources(client-ydb_persqueue_core-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session_messages.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/common.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/write_session.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/CMakeLists.darwin-x86_64.txt index f205192103ba..827dc0713994 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/CMakeLists.darwin-x86_64.txt @@ -23,6 +23,7 @@ target_link_libraries(client-ydb_persqueue_core-impl PUBLIC cpp-client-ydb_driver ) target_sources(client-ydb_persqueue_core-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session_messages.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/common.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/write_session.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/CMakeLists.linux-aarch64.txt index 031aae283b54..559674a9d2d6 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/CMakeLists.linux-aarch64.txt @@ -24,6 +24,7 @@ target_link_libraries(client-ydb_persqueue_core-impl PUBLIC cpp-client-ydb_driver ) target_sources(client-ydb_persqueue_core-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session_messages.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/common.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/write_session.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/CMakeLists.linux-x86_64.txt index 031aae283b54..559674a9d2d6 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/CMakeLists.linux-x86_64.txt @@ -24,6 +24,7 @@ target_link_libraries(client-ydb_persqueue_core-impl PUBLIC cpp-client-ydb_driver ) target_sources(client-ydb_persqueue_core-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session_messages.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/common.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/write_session.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/CMakeLists.windows-x86_64.txt index f205192103ba..827dc0713994 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/CMakeLists.windows-x86_64.txt @@ -23,6 +23,7 @@ target_link_libraries(client-ydb_persqueue_core-impl PUBLIC cpp-client-ydb_driver ) target_sources(client-ydb_persqueue_core-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session_messages.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/common.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/write_session.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/CMakeLists.darwin-arm64.txt index 1d1d9438a9f2..26add22793cb 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_persqueue_core-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-sdk-cpp-client-ydb_persqueue_core-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/common_ut.cpp @@ -70,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/CMakeLists.darwin-x86_64.txt index 434fe6ea0299..fbbe5d9c4ca5 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_persqueue_core-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-sdk-cpp-client-ydb_persqueue_core-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/common_ut.cpp @@ -71,6 +69,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/CMakeLists.linux-aarch64.txt index 0583c9c77440..5995d2b891cc 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_persqueue_core-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-sdk-cpp-client-ydb_persqueue_core-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/common_ut.cpp @@ -74,6 +71,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/CMakeLists.linux-x86_64.txt index 55e744f380e2..18473ea5103f 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_persqueue_core-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-sdk-cpp-client-ydb_persqueue_core-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/common_ut.cpp @@ -75,6 +72,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/CMakeLists.windows-x86_64.txt index 48af9e1f445e..1afdef6e5717 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/CMakeLists.windows-x86_64.txt @@ -64,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/CMakeLists.darwin-arm64.txt index 664861b823e1..76f2d93ff0c8 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/CMakeLists.darwin-arm64.txt @@ -25,6 +25,10 @@ target_link_libraries(ydb_persqueue_core-ut-ut_utils PUBLIC cpp-client-ydb_table ) target_sources(ydb_persqueue_core-ut-ut_utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/sdk_test_setup.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/test_utils.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/test_server.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/ut_utils.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/data_plane_helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/test_server.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/ut_utils.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/CMakeLists.darwin-x86_64.txt index 664861b823e1..76f2d93ff0c8 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/CMakeLists.darwin-x86_64.txt @@ -25,6 +25,10 @@ target_link_libraries(ydb_persqueue_core-ut-ut_utils PUBLIC cpp-client-ydb_table ) target_sources(ydb_persqueue_core-ut-ut_utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/sdk_test_setup.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/test_utils.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/test_server.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/ut_utils.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/data_plane_helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/test_server.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/ut_utils.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/CMakeLists.linux-aarch64.txt index 13f0828a1ed4..be0815ce5277 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/CMakeLists.linux-aarch64.txt @@ -26,6 +26,10 @@ target_link_libraries(ydb_persqueue_core-ut-ut_utils PUBLIC cpp-client-ydb_table ) target_sources(ydb_persqueue_core-ut-ut_utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/sdk_test_setup.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/test_utils.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/test_server.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/ut_utils.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/data_plane_helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/test_server.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/ut_utils.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/CMakeLists.linux-x86_64.txt index 13f0828a1ed4..be0815ce5277 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/CMakeLists.linux-x86_64.txt @@ -26,6 +26,10 @@ target_link_libraries(ydb_persqueue_core-ut-ut_utils PUBLIC cpp-client-ydb_table ) target_sources(ydb_persqueue_core-ut-ut_utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/sdk_test_setup.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/test_utils.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/test_server.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/ut_utils.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/data_plane_helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/test_server.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/ut_utils.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/CMakeLists.windows-x86_64.txt index 664861b823e1..76f2d93ff0c8 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/CMakeLists.windows-x86_64.txt @@ -25,6 +25,10 @@ target_link_libraries(ydb_persqueue_core-ut-ut_utils PUBLIC cpp-client-ydb_table ) target_sources(ydb_persqueue_core-ut-ut_utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/sdk_test_setup.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/test_utils.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/test_server.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/ut_utils.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/data_plane_helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/test_server.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/ut_utils/ut_utils.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/with_offset_ranges_mode_ut/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/with_offset_ranges_mode_ut/CMakeLists.darwin-arm64.txt index 9a0f943795c8..6b3f85609563 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/with_offset_ranges_mode_ut/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/with_offset_ranges_mode_ut/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(with_offset_ranges_mode_ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(with_offset_ranges_mode_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/common_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/with_offset_ranges_mode_ut/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/with_offset_ranges_mode_ut/CMakeLists.darwin-x86_64.txt index 9d2af3535911..175462a8dfad 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/with_offset_ranges_mode_ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/with_offset_ranges_mode_ut/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(with_offset_ranges_mode_ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(with_offset_ranges_mode_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/common_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/with_offset_ranges_mode_ut/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/with_offset_ranges_mode_ut/CMakeLists.linux-aarch64.txt index b43f232adec9..b2734e933bc4 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/with_offset_ranges_mode_ut/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/with_offset_ranges_mode_ut/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(with_offset_ranges_mode_ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(with_offset_ranges_mode_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/common_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/with_offset_ranges_mode_ut/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/with_offset_ranges_mode_ut/CMakeLists.linux-x86_64.txt index 5db34406b64f..35d110e7d689 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/with_offset_ranges_mode_ut/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/with_offset_ranges_mode_ut/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(with_offset_ranges_mode_ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(with_offset_ranges_mode_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/common_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/with_offset_ranges_mode_ut/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/with_offset_ranges_mode_ut/CMakeLists.windows-x86_64.txt index 9cc17131a2dc..4659c9ef7c5e 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/with_offset_ranges_mode_ut/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/with_offset_ranges_mode_ut/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_public/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_public/CMakeLists.darwin-arm64.txt index 4d63969baad8..a422885d93aa 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_public/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_public/CMakeLists.darwin-arm64.txt @@ -15,3 +15,6 @@ target_link_libraries(cpp-client-ydb_persqueue_public INTERFACE cpp-client-ydb_persqueue_core client-ydb_persqueue_public-codecs ) +target_sources(cpp-client-ydb_persqueue_public INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_public/persqueue.h +) diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_public/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_public/CMakeLists.darwin-x86_64.txt index 4d63969baad8..a422885d93aa 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_public/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_public/CMakeLists.darwin-x86_64.txt @@ -15,3 +15,6 @@ target_link_libraries(cpp-client-ydb_persqueue_public INTERFACE cpp-client-ydb_persqueue_core client-ydb_persqueue_public-codecs ) +target_sources(cpp-client-ydb_persqueue_public INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_public/persqueue.h +) diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_public/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_public/CMakeLists.linux-aarch64.txt index 66a951e2cfd4..730e4884084b 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_public/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_public/CMakeLists.linux-aarch64.txt @@ -16,3 +16,6 @@ target_link_libraries(cpp-client-ydb_persqueue_public INTERFACE cpp-client-ydb_persqueue_core client-ydb_persqueue_public-codecs ) +target_sources(cpp-client-ydb_persqueue_public INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_public/persqueue.h +) diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_public/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_public/CMakeLists.linux-x86_64.txt index 66a951e2cfd4..730e4884084b 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_public/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_public/CMakeLists.linux-x86_64.txt @@ -16,3 +16,6 @@ target_link_libraries(cpp-client-ydb_persqueue_public INTERFACE cpp-client-ydb_persqueue_core client-ydb_persqueue_public-codecs ) +target_sources(cpp-client-ydb_persqueue_public INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_public/persqueue.h +) diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_public/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_public/CMakeLists.windows-x86_64.txt index 4d63969baad8..a422885d93aa 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_public/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_public/CMakeLists.windows-x86_64.txt @@ -15,3 +15,6 @@ target_link_libraries(cpp-client-ydb_persqueue_public INTERFACE cpp-client-ydb_persqueue_core client-ydb_persqueue_public-codecs ) +target_sources(cpp-client-ydb_persqueue_public INTERFACE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_public/persqueue.h +) diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/CMakeLists.darwin-arm64.txt index 06fc4a13ebda..e3cbf4df0b18 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/CMakeLists.darwin-arm64.txt @@ -18,5 +18,6 @@ target_link_libraries(client-ydb_persqueue_public-codecs PUBLIC api-protos ) target_sources(client-ydb_persqueue_public-codecs PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/codecs.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/codecs.cpp ) diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/CMakeLists.darwin-x86_64.txt index 06fc4a13ebda..e3cbf4df0b18 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/CMakeLists.darwin-x86_64.txt @@ -18,5 +18,6 @@ target_link_libraries(client-ydb_persqueue_public-codecs PUBLIC api-protos ) target_sources(client-ydb_persqueue_public-codecs PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/codecs.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/codecs.cpp ) diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/CMakeLists.linux-aarch64.txt index 47a2fe8b31a8..c43a84040fa9 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/CMakeLists.linux-aarch64.txt @@ -19,5 +19,6 @@ target_link_libraries(client-ydb_persqueue_public-codecs PUBLIC api-protos ) target_sources(client-ydb_persqueue_public-codecs PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/codecs.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/codecs.cpp ) diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/CMakeLists.linux-x86_64.txt index 47a2fe8b31a8..c43a84040fa9 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/CMakeLists.linux-x86_64.txt @@ -19,5 +19,6 @@ target_link_libraries(client-ydb_persqueue_public-codecs PUBLIC api-protos ) target_sources(client-ydb_persqueue_public-codecs PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/codecs.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/codecs.cpp ) diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/CMakeLists.windows-x86_64.txt index 06fc4a13ebda..e3cbf4df0b18 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/CMakeLists.windows-x86_64.txt @@ -18,5 +18,6 @@ target_link_libraries(client-ydb_persqueue_public-codecs PUBLIC api-protos ) target_sources(client-ydb_persqueue_public-codecs PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/codecs.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_persqueue_public/codecs/codecs.cpp ) diff --git a/ydb/public/sdk/cpp/client/ydb_query/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/ydb_query/CMakeLists.darwin-arm64.txt index 6b201d4ea70e..b1a50c6510e9 100644 --- a/ydb/public/sdk/cpp/client/ydb_query/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/ydb_query/CMakeLists.darwin-arm64.txt @@ -23,6 +23,10 @@ target_link_libraries(cpp-client-ydb_query PUBLIC client-ydb_types-operation ) target_sources(cpp-client-ydb_query PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/client.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/query.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/stats.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/tx.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/client.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/query.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/stats.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_query/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_query/CMakeLists.darwin-x86_64.txt index 6b201d4ea70e..b1a50c6510e9 100644 --- a/ydb/public/sdk/cpp/client/ydb_query/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_query/CMakeLists.darwin-x86_64.txt @@ -23,6 +23,10 @@ target_link_libraries(cpp-client-ydb_query PUBLIC client-ydb_types-operation ) target_sources(cpp-client-ydb_query PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/client.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/query.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/stats.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/tx.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/client.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/query.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/stats.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_query/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/ydb_query/CMakeLists.linux-aarch64.txt index c9cf47ea1542..8862f9542a1e 100644 --- a/ydb/public/sdk/cpp/client/ydb_query/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/ydb_query/CMakeLists.linux-aarch64.txt @@ -24,6 +24,10 @@ target_link_libraries(cpp-client-ydb_query PUBLIC client-ydb_types-operation ) target_sources(cpp-client-ydb_query PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/client.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/query.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/stats.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/tx.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/client.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/query.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/stats.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_query/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_query/CMakeLists.linux-x86_64.txt index c9cf47ea1542..8862f9542a1e 100644 --- a/ydb/public/sdk/cpp/client/ydb_query/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_query/CMakeLists.linux-x86_64.txt @@ -24,6 +24,10 @@ target_link_libraries(cpp-client-ydb_query PUBLIC client-ydb_types-operation ) target_sources(cpp-client-ydb_query PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/client.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/query.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/stats.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/tx.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/client.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/query.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/stats.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_query/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_query/CMakeLists.windows-x86_64.txt index 6b201d4ea70e..b1a50c6510e9 100644 --- a/ydb/public/sdk/cpp/client/ydb_query/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_query/CMakeLists.windows-x86_64.txt @@ -23,6 +23,10 @@ target_link_libraries(cpp-client-ydb_query PUBLIC client-ydb_types-operation ) target_sources(cpp-client-ydb_query PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/client.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/query.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/stats.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/tx.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/client.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/query.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/stats.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_query/impl/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/ydb_query/impl/CMakeLists.darwin-arm64.txt index 5636e882602a..c0b5c5a17a31 100644 --- a/ydb/public/sdk/cpp/client/ydb_query/impl/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/ydb_query/impl/CMakeLists.darwin-arm64.txt @@ -17,6 +17,7 @@ target_link_libraries(client-ydb_query-impl PUBLIC cpp-client-ydb_proto ) target_sources(client-ydb_query-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/impl/exec_query.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/impl/exec_query.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/impl/client_session.cpp ) diff --git a/ydb/public/sdk/cpp/client/ydb_query/impl/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_query/impl/CMakeLists.darwin-x86_64.txt index 5636e882602a..c0b5c5a17a31 100644 --- a/ydb/public/sdk/cpp/client/ydb_query/impl/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_query/impl/CMakeLists.darwin-x86_64.txt @@ -17,6 +17,7 @@ target_link_libraries(client-ydb_query-impl PUBLIC cpp-client-ydb_proto ) target_sources(client-ydb_query-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/impl/exec_query.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/impl/exec_query.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/impl/client_session.cpp ) diff --git a/ydb/public/sdk/cpp/client/ydb_query/impl/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/ydb_query/impl/CMakeLists.linux-aarch64.txt index 09ad124d137d..dc2eeff183d7 100644 --- a/ydb/public/sdk/cpp/client/ydb_query/impl/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/ydb_query/impl/CMakeLists.linux-aarch64.txt @@ -18,6 +18,7 @@ target_link_libraries(client-ydb_query-impl PUBLIC cpp-client-ydb_proto ) target_sources(client-ydb_query-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/impl/exec_query.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/impl/exec_query.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/impl/client_session.cpp ) diff --git a/ydb/public/sdk/cpp/client/ydb_query/impl/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_query/impl/CMakeLists.linux-x86_64.txt index 09ad124d137d..dc2eeff183d7 100644 --- a/ydb/public/sdk/cpp/client/ydb_query/impl/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_query/impl/CMakeLists.linux-x86_64.txt @@ -18,6 +18,7 @@ target_link_libraries(client-ydb_query-impl PUBLIC cpp-client-ydb_proto ) target_sources(client-ydb_query-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/impl/exec_query.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/impl/exec_query.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/impl/client_session.cpp ) diff --git a/ydb/public/sdk/cpp/client/ydb_query/impl/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_query/impl/CMakeLists.windows-x86_64.txt index 5636e882602a..c0b5c5a17a31 100644 --- a/ydb/public/sdk/cpp/client/ydb_query/impl/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_query/impl/CMakeLists.windows-x86_64.txt @@ -17,6 +17,7 @@ target_link_libraries(client-ydb_query-impl PUBLIC cpp-client-ydb_proto ) target_sources(client-ydb_query-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/impl/exec_query.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/impl/exec_query.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_query/impl/client_session.cpp ) diff --git a/ydb/public/sdk/cpp/client/ydb_result/ut/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/ydb_result/ut/CMakeLists.darwin-arm64.txt index 6a790873dbe4..82198ca6427e 100644 --- a/ydb/public/sdk/cpp/client/ydb_result/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/ydb_result/ut/CMakeLists.darwin-arm64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_result-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-sdk-cpp-client-ydb_result-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_result/result_ut.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_result/ut/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_result/ut/CMakeLists.darwin-x86_64.txt index ef9d161b74c7..ab43b0be8edf 100644 --- a/ydb/public/sdk/cpp/client/ydb_result/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_result/ut/CMakeLists.darwin-x86_64.txt @@ -23,8 +23,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_result-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-sdk-cpp-client-ydb_result-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_result/result_ut.cpp @@ -54,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_result/ut/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/ydb_result/ut/CMakeLists.linux-aarch64.txt index e769fb3708ac..6cacd2145b10 100644 --- a/ydb/public/sdk/cpp/client/ydb_result/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/ydb_result/ut/CMakeLists.linux-aarch64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_result-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-sdk-cpp-client-ydb_result-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_result/result_ut.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_result/ut/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_result/ut/CMakeLists.linux-x86_64.txt index a6a550611f43..6e3712c8a3e4 100644 --- a/ydb/public/sdk/cpp/client/ydb_result/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_result/ut/CMakeLists.linux-x86_64.txt @@ -26,9 +26,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_result-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-sdk-cpp-client-ydb_result-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_result/result_ut.cpp @@ -58,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_result/ut/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_result/ut/CMakeLists.windows-x86_64.txt index 1e70bf161c75..96804584b979 100644 --- a/ydb/public/sdk/cpp/client/ydb_result/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_result/ut/CMakeLists.windows-x86_64.txt @@ -47,6 +47,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_topic/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/ydb_topic/CMakeLists.darwin-arm64.txt index afd2882e3971..d692f73f6931 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/CMakeLists.darwin-arm64.txt @@ -32,6 +32,7 @@ target_link_libraries(cpp-client-ydb_topic PUBLIC cpp-client-ydb_table ) target_sources(cpp-client-ydb_topic PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/topic.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/proto_accessor.cpp ) generate_enum_serilization(cpp-client-ydb_topic diff --git a/ydb/public/sdk/cpp/client/ydb_topic/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_topic/CMakeLists.darwin-x86_64.txt index afd2882e3971..d692f73f6931 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/CMakeLists.darwin-x86_64.txt @@ -32,6 +32,7 @@ target_link_libraries(cpp-client-ydb_topic PUBLIC cpp-client-ydb_table ) target_sources(cpp-client-ydb_topic PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/topic.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/proto_accessor.cpp ) generate_enum_serilization(cpp-client-ydb_topic diff --git a/ydb/public/sdk/cpp/client/ydb_topic/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/ydb_topic/CMakeLists.linux-aarch64.txt index e62148bcc980..ca8a0b07477c 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/CMakeLists.linux-aarch64.txt @@ -33,6 +33,7 @@ target_link_libraries(cpp-client-ydb_topic PUBLIC cpp-client-ydb_table ) target_sources(cpp-client-ydb_topic PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/topic.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/proto_accessor.cpp ) generate_enum_serilization(cpp-client-ydb_topic diff --git a/ydb/public/sdk/cpp/client/ydb_topic/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_topic/CMakeLists.linux-x86_64.txt index e62148bcc980..ca8a0b07477c 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/CMakeLists.linux-x86_64.txt @@ -33,6 +33,7 @@ target_link_libraries(cpp-client-ydb_topic PUBLIC cpp-client-ydb_table ) target_sources(cpp-client-ydb_topic PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/topic.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/proto_accessor.cpp ) generate_enum_serilization(cpp-client-ydb_topic diff --git a/ydb/public/sdk/cpp/client/ydb_topic/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_topic/CMakeLists.windows-x86_64.txt index afd2882e3971..d692f73f6931 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/CMakeLists.windows-x86_64.txt @@ -32,6 +32,7 @@ target_link_libraries(cpp-client-ydb_topic PUBLIC cpp-client-ydb_table ) target_sources(cpp-client-ydb_topic PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/topic.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/proto_accessor.cpp ) generate_enum_serilization(cpp-client-ydb_topic diff --git a/ydb/public/sdk/cpp/client/ydb_topic/codecs/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/ydb_topic/codecs/CMakeLists.darwin-arm64.txt index a417b3b9cd1e..cbf8e0519f88 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/codecs/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/codecs/CMakeLists.darwin-arm64.txt @@ -18,5 +18,6 @@ target_link_libraries(client-ydb_topic-codecs PUBLIC api-protos ) target_sources(client-ydb_topic-codecs PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/codecs/codecs.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/codecs/codecs.cpp ) diff --git a/ydb/public/sdk/cpp/client/ydb_topic/codecs/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_topic/codecs/CMakeLists.darwin-x86_64.txt index a417b3b9cd1e..cbf8e0519f88 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/codecs/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/codecs/CMakeLists.darwin-x86_64.txt @@ -18,5 +18,6 @@ target_link_libraries(client-ydb_topic-codecs PUBLIC api-protos ) target_sources(client-ydb_topic-codecs PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/codecs/codecs.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/codecs/codecs.cpp ) diff --git a/ydb/public/sdk/cpp/client/ydb_topic/codecs/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/ydb_topic/codecs/CMakeLists.linux-aarch64.txt index fe17569b4f5f..452ab4c2bffe 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/codecs/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/codecs/CMakeLists.linux-aarch64.txt @@ -19,5 +19,6 @@ target_link_libraries(client-ydb_topic-codecs PUBLIC api-protos ) target_sources(client-ydb_topic-codecs PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/codecs/codecs.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/codecs/codecs.cpp ) diff --git a/ydb/public/sdk/cpp/client/ydb_topic/codecs/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_topic/codecs/CMakeLists.linux-x86_64.txt index fe17569b4f5f..452ab4c2bffe 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/codecs/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/codecs/CMakeLists.linux-x86_64.txt @@ -19,5 +19,6 @@ target_link_libraries(client-ydb_topic-codecs PUBLIC api-protos ) target_sources(client-ydb_topic-codecs PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/codecs/codecs.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/codecs/codecs.cpp ) diff --git a/ydb/public/sdk/cpp/client/ydb_topic/codecs/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_topic/codecs/CMakeLists.windows-x86_64.txt index a417b3b9cd1e..cbf8e0519f88 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/codecs/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/codecs/CMakeLists.windows-x86_64.txt @@ -18,5 +18,6 @@ target_link_libraries(client-ydb_topic-codecs PUBLIC api-protos ) target_sources(client-ydb_topic-codecs PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/codecs/codecs.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/codecs/codecs.cpp ) diff --git a/ydb/public/sdk/cpp/client/ydb_topic/impl/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/ydb_topic/impl/CMakeLists.darwin-arm64.txt index 5d27cbf75206..e07cf9af2a86 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/impl/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/impl/CMakeLists.darwin-arm64.txt @@ -25,6 +25,11 @@ target_link_libraries(client-ydb_topic-impl PUBLIC cpp-client-ydb_proto ) target_sources(client-ydb_topic-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/executor.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/read_session.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/write_session.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/write_session_impl.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/topic_impl.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/executor.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/read_session_event.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/counters.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_topic/impl/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_topic/impl/CMakeLists.darwin-x86_64.txt index 5d27cbf75206..e07cf9af2a86 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/impl/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/impl/CMakeLists.darwin-x86_64.txt @@ -25,6 +25,11 @@ target_link_libraries(client-ydb_topic-impl PUBLIC cpp-client-ydb_proto ) target_sources(client-ydb_topic-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/executor.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/read_session.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/write_session.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/write_session_impl.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/topic_impl.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/executor.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/read_session_event.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/counters.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_topic/impl/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/ydb_topic/impl/CMakeLists.linux-aarch64.txt index 97dfcfbcca04..50eb072b75ab 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/impl/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/impl/CMakeLists.linux-aarch64.txt @@ -26,6 +26,11 @@ target_link_libraries(client-ydb_topic-impl PUBLIC cpp-client-ydb_proto ) target_sources(client-ydb_topic-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/executor.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/read_session.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/write_session.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/write_session_impl.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/topic_impl.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/executor.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/read_session_event.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/counters.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_topic/impl/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_topic/impl/CMakeLists.linux-x86_64.txt index 97dfcfbcca04..50eb072b75ab 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/impl/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/impl/CMakeLists.linux-x86_64.txt @@ -26,6 +26,11 @@ target_link_libraries(client-ydb_topic-impl PUBLIC cpp-client-ydb_proto ) target_sources(client-ydb_topic-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/executor.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/read_session.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/write_session.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/write_session_impl.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/topic_impl.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/executor.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/read_session_event.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/counters.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_topic/impl/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_topic/impl/CMakeLists.windows-x86_64.txt index 5d27cbf75206..e07cf9af2a86 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/impl/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/impl/CMakeLists.windows-x86_64.txt @@ -25,6 +25,11 @@ target_link_libraries(client-ydb_topic-impl PUBLIC cpp-client-ydb_proto ) target_sources(client-ydb_topic-impl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/executor.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/read_session.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/write_session.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/write_session_impl.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/topic_impl.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/executor.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/read_session_event.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/impl/counters.cpp diff --git a/ydb/public/sdk/cpp/client/ydb_topic/ut/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/ydb_topic/ut/CMakeLists.darwin-arm64.txt index 8aa8c654766a..67faa14f5c65 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/ut/CMakeLists.darwin-arm64.txt @@ -36,8 +36,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_topic-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-sdk-cpp-client-ydb_topic-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/basic_usage_ut.cpp @@ -70,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_topic/ut/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_topic/ut/CMakeLists.darwin-x86_64.txt index aab41b843efd..5019e120bf37 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/ut/CMakeLists.darwin-x86_64.txt @@ -37,8 +37,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_topic-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-sdk-cpp-client-ydb_topic-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/basic_usage_ut.cpp @@ -71,6 +69,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_topic/ut/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/ydb_topic/ut/CMakeLists.linux-aarch64.txt index e9b30bcfbd99..417b1263f51d 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/ut/CMakeLists.linux-aarch64.txt @@ -39,9 +39,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_topic-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-sdk-cpp-client-ydb_topic-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/basic_usage_ut.cpp @@ -74,6 +71,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_topic/ut/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_topic/ut/CMakeLists.linux-x86_64.txt index 45c90bfdb512..0bc937fe4c68 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/ut/CMakeLists.linux-x86_64.txt @@ -40,9 +40,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_topic-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-sdk-cpp-client-ydb_topic-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/basic_usage_ut.cpp @@ -75,6 +72,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_topic/ut/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_topic/ut/CMakeLists.windows-x86_64.txt index c41eb4e0dd3f..f692b5e12bb3 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/ut/CMakeLists.windows-x86_64.txt @@ -64,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/CMakeLists.darwin-arm64.txt index d73cda6e6205..0d897bea74df 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/CMakeLists.darwin-arm64.txt @@ -24,6 +24,8 @@ target_link_libraries(ydb_topic-ut-ut_utils PUBLIC cpp-client-ydb_table ) target_sources(ydb_topic-ut-ut_utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/managed_executor.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/topic_sdk_test_setup.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/managed_executor.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/topic_sdk_test_setup.cpp ) diff --git a/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/CMakeLists.darwin-x86_64.txt index d73cda6e6205..0d897bea74df 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/CMakeLists.darwin-x86_64.txt @@ -24,6 +24,8 @@ target_link_libraries(ydb_topic-ut-ut_utils PUBLIC cpp-client-ydb_table ) target_sources(ydb_topic-ut-ut_utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/managed_executor.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/topic_sdk_test_setup.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/managed_executor.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/topic_sdk_test_setup.cpp ) diff --git a/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/CMakeLists.linux-aarch64.txt index 2867a0d1f07f..c483c4fbe42a 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/CMakeLists.linux-aarch64.txt @@ -25,6 +25,8 @@ target_link_libraries(ydb_topic-ut-ut_utils PUBLIC cpp-client-ydb_table ) target_sources(ydb_topic-ut-ut_utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/managed_executor.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/topic_sdk_test_setup.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/managed_executor.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/topic_sdk_test_setup.cpp ) diff --git a/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/CMakeLists.linux-x86_64.txt index 2867a0d1f07f..c483c4fbe42a 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/CMakeLists.linux-x86_64.txt @@ -25,6 +25,8 @@ target_link_libraries(ydb_topic-ut-ut_utils PUBLIC cpp-client-ydb_table ) target_sources(ydb_topic-ut-ut_utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/managed_executor.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/topic_sdk_test_setup.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/managed_executor.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/topic_sdk_test_setup.cpp ) diff --git a/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/CMakeLists.windows-x86_64.txt index d73cda6e6205..0d897bea74df 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/CMakeLists.windows-x86_64.txt @@ -24,6 +24,8 @@ target_link_libraries(ydb_topic-ut-ut_utils PUBLIC cpp-client-ydb_table ) target_sources(ydb_topic-ut-ut_utils PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/managed_executor.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/topic_sdk_test_setup.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/managed_executor.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_topic/ut/ut_utils/topic_sdk_test_setup.cpp ) diff --git a/ydb/public/sdk/cpp/client/ydb_value/ut/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/client/ydb_value/ut/CMakeLists.darwin-arm64.txt index 4e7838507f1a..058e1e348779 100644 --- a/ydb/public/sdk/cpp/client/ydb_value/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/client/ydb_value/ut/CMakeLists.darwin-arm64.txt @@ -24,8 +24,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_value-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-sdk-cpp-client-ydb_value-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_value/value_ut.cpp @@ -55,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_value/ut/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_value/ut/CMakeLists.darwin-x86_64.txt index 76df06562e33..8103800770d4 100644 --- a/ydb/public/sdk/cpp/client/ydb_value/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_value/ut/CMakeLists.darwin-x86_64.txt @@ -25,8 +25,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_value-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-public-sdk-cpp-client-ydb_value-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_value/value_ut.cpp @@ -56,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_value/ut/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/client/ydb_value/ut/CMakeLists.linux-aarch64.txt index c5cd47be4677..db8edb33d26f 100644 --- a/ydb/public/sdk/cpp/client/ydb_value/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/client/ydb_value/ut/CMakeLists.linux-aarch64.txt @@ -27,9 +27,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_value-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-sdk-cpp-client-ydb_value-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_value/value_ut.cpp @@ -59,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_value/ut/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_value/ut/CMakeLists.linux-x86_64.txt index 987364b15964..9732e3fb15ad 100644 --- a/ydb/public/sdk/cpp/client/ydb_value/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_value/ut/CMakeLists.linux-x86_64.txt @@ -28,9 +28,6 @@ target_link_options(ydb-public-sdk-cpp-client-ydb_value-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-public-sdk-cpp-client-ydb_value-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/client/ydb_value/value_ut.cpp @@ -60,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/client/ydb_value/ut/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/client/ydb_value/ut/CMakeLists.windows-x86_64.txt index 5069ac779b1c..64b6e7545c08 100644 --- a/ydb/public/sdk/cpp/client/ydb_value/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/client/ydb_value/ut/CMakeLists.windows-x86_64.txt @@ -49,6 +49,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/public/sdk/cpp/examples/basic_example/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/examples/basic_example/CMakeLists.darwin-arm64.txt index b5869ecb9486..4d51e8645197 100644 --- a/ydb/public/sdk/cpp/examples/basic_example/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/examples/basic_example/CMakeLists.darwin-arm64.txt @@ -18,8 +18,6 @@ target_link_options(basic_example PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(basic_example PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/basic_example/main.cpp diff --git a/ydb/public/sdk/cpp/examples/basic_example/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/examples/basic_example/CMakeLists.darwin-x86_64.txt index 89569d4649d4..4f39f7e95707 100644 --- a/ydb/public/sdk/cpp/examples/basic_example/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/examples/basic_example/CMakeLists.darwin-x86_64.txt @@ -19,8 +19,6 @@ target_link_options(basic_example PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(basic_example PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/basic_example/main.cpp diff --git a/ydb/public/sdk/cpp/examples/basic_example/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/examples/basic_example/CMakeLists.linux-aarch64.txt index d856b27c723a..7d290264c462 100644 --- a/ydb/public/sdk/cpp/examples/basic_example/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/examples/basic_example/CMakeLists.linux-aarch64.txt @@ -21,9 +21,6 @@ target_link_options(basic_example PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(basic_example PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/basic_example/main.cpp diff --git a/ydb/public/sdk/cpp/examples/basic_example/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/examples/basic_example/CMakeLists.linux-x86_64.txt index e89b9d97e201..ab45b6389166 100644 --- a/ydb/public/sdk/cpp/examples/basic_example/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/examples/basic_example/CMakeLists.linux-x86_64.txt @@ -22,9 +22,6 @@ target_link_options(basic_example PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(basic_example PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/basic_example/main.cpp diff --git a/ydb/public/sdk/cpp/examples/bulk_upsert_simple/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/examples/bulk_upsert_simple/CMakeLists.darwin-arm64.txt index 2ae13931a484..81e785fdadd5 100644 --- a/ydb/public/sdk/cpp/examples/bulk_upsert_simple/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/examples/bulk_upsert_simple/CMakeLists.darwin-arm64.txt @@ -18,8 +18,6 @@ target_link_options(bulk_upsert_simple PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(bulk_upsert_simple PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/bulk_upsert_simple/main.cpp diff --git a/ydb/public/sdk/cpp/examples/bulk_upsert_simple/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/examples/bulk_upsert_simple/CMakeLists.darwin-x86_64.txt index f4173284097f..a569f6110e65 100644 --- a/ydb/public/sdk/cpp/examples/bulk_upsert_simple/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/examples/bulk_upsert_simple/CMakeLists.darwin-x86_64.txt @@ -19,8 +19,6 @@ target_link_options(bulk_upsert_simple PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(bulk_upsert_simple PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/bulk_upsert_simple/main.cpp diff --git a/ydb/public/sdk/cpp/examples/bulk_upsert_simple/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/examples/bulk_upsert_simple/CMakeLists.linux-aarch64.txt index 593b8a074563..ba49663a69ae 100644 --- a/ydb/public/sdk/cpp/examples/bulk_upsert_simple/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/examples/bulk_upsert_simple/CMakeLists.linux-aarch64.txt @@ -21,9 +21,6 @@ target_link_options(bulk_upsert_simple PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(bulk_upsert_simple PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/bulk_upsert_simple/main.cpp diff --git a/ydb/public/sdk/cpp/examples/bulk_upsert_simple/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/examples/bulk_upsert_simple/CMakeLists.linux-x86_64.txt index 78f142f7e80f..1d25f8196716 100644 --- a/ydb/public/sdk/cpp/examples/bulk_upsert_simple/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/examples/bulk_upsert_simple/CMakeLists.linux-x86_64.txt @@ -22,9 +22,6 @@ target_link_options(bulk_upsert_simple PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(bulk_upsert_simple PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/bulk_upsert_simple/main.cpp diff --git a/ydb/public/sdk/cpp/examples/pagination/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/examples/pagination/CMakeLists.darwin-arm64.txt index b62e3ed2541e..8c9fabfe7968 100644 --- a/ydb/public/sdk/cpp/examples/pagination/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/examples/pagination/CMakeLists.darwin-arm64.txt @@ -18,8 +18,6 @@ target_link_options(pagination PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(pagination PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/pagination/main.cpp diff --git a/ydb/public/sdk/cpp/examples/pagination/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/examples/pagination/CMakeLists.darwin-x86_64.txt index 5fdaf70b411d..d29e9e000796 100644 --- a/ydb/public/sdk/cpp/examples/pagination/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/examples/pagination/CMakeLists.darwin-x86_64.txt @@ -19,8 +19,6 @@ target_link_options(pagination PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(pagination PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/pagination/main.cpp diff --git a/ydb/public/sdk/cpp/examples/pagination/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/examples/pagination/CMakeLists.linux-aarch64.txt index 68a6336fbc81..acdfe1844abd 100644 --- a/ydb/public/sdk/cpp/examples/pagination/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/examples/pagination/CMakeLists.linux-aarch64.txt @@ -21,9 +21,6 @@ target_link_options(pagination PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(pagination PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/pagination/main.cpp diff --git a/ydb/public/sdk/cpp/examples/pagination/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/examples/pagination/CMakeLists.linux-x86_64.txt index 83ab5af0f12e..d0c4d4105436 100644 --- a/ydb/public/sdk/cpp/examples/pagination/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/examples/pagination/CMakeLists.linux-x86_64.txt @@ -22,9 +22,6 @@ target_link_options(pagination PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(pagination PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/pagination/main.cpp diff --git a/ydb/public/sdk/cpp/examples/secondary_index/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/examples/secondary_index/CMakeLists.darwin-arm64.txt index 0c015c3a07be..acba86538403 100644 --- a/ydb/public/sdk/cpp/examples/secondary_index/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/examples/secondary_index/CMakeLists.darwin-arm64.txt @@ -18,8 +18,6 @@ target_link_options(secondary_index PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(secondary_index PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/secondary_index/main.cpp diff --git a/ydb/public/sdk/cpp/examples/secondary_index/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/examples/secondary_index/CMakeLists.darwin-x86_64.txt index a73049d49482..3c15f8d2ed02 100644 --- a/ydb/public/sdk/cpp/examples/secondary_index/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/examples/secondary_index/CMakeLists.darwin-x86_64.txt @@ -19,8 +19,6 @@ target_link_options(secondary_index PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(secondary_index PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/secondary_index/main.cpp diff --git a/ydb/public/sdk/cpp/examples/secondary_index/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/examples/secondary_index/CMakeLists.linux-aarch64.txt index 2ccc24de8756..48e6642eef9e 100644 --- a/ydb/public/sdk/cpp/examples/secondary_index/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/examples/secondary_index/CMakeLists.linux-aarch64.txt @@ -21,9 +21,6 @@ target_link_options(secondary_index PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(secondary_index PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/secondary_index/main.cpp diff --git a/ydb/public/sdk/cpp/examples/secondary_index/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/examples/secondary_index/CMakeLists.linux-x86_64.txt index a7ef16f59f12..40fb58223bad 100644 --- a/ydb/public/sdk/cpp/examples/secondary_index/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/examples/secondary_index/CMakeLists.linux-x86_64.txt @@ -22,9 +22,6 @@ target_link_options(secondary_index PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(secondary_index PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/secondary_index/main.cpp diff --git a/ydb/public/sdk/cpp/examples/secondary_index_builtin/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/examples/secondary_index_builtin/CMakeLists.darwin-arm64.txt index 03e5f962efaa..dd757b7fcb07 100644 --- a/ydb/public/sdk/cpp/examples/secondary_index_builtin/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/examples/secondary_index_builtin/CMakeLists.darwin-arm64.txt @@ -18,8 +18,6 @@ target_link_options(secondary_index_builtin PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(secondary_index_builtin PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/secondary_index_builtin/main.cpp diff --git a/ydb/public/sdk/cpp/examples/secondary_index_builtin/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/examples/secondary_index_builtin/CMakeLists.darwin-x86_64.txt index 61eb482ec38e..ee676f9d97be 100644 --- a/ydb/public/sdk/cpp/examples/secondary_index_builtin/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/examples/secondary_index_builtin/CMakeLists.darwin-x86_64.txt @@ -19,8 +19,6 @@ target_link_options(secondary_index_builtin PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(secondary_index_builtin PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/secondary_index_builtin/main.cpp diff --git a/ydb/public/sdk/cpp/examples/secondary_index_builtin/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/examples/secondary_index_builtin/CMakeLists.linux-aarch64.txt index 2add0ab64d22..24cda8772252 100644 --- a/ydb/public/sdk/cpp/examples/secondary_index_builtin/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/examples/secondary_index_builtin/CMakeLists.linux-aarch64.txt @@ -21,9 +21,6 @@ target_link_options(secondary_index_builtin PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(secondary_index_builtin PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/secondary_index_builtin/main.cpp diff --git a/ydb/public/sdk/cpp/examples/secondary_index_builtin/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/examples/secondary_index_builtin/CMakeLists.linux-x86_64.txt index 98ade20a7edb..7c031caed7bf 100644 --- a/ydb/public/sdk/cpp/examples/secondary_index_builtin/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/examples/secondary_index_builtin/CMakeLists.linux-x86_64.txt @@ -22,9 +22,6 @@ target_link_options(secondary_index_builtin PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(secondary_index_builtin PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/secondary_index_builtin/main.cpp diff --git a/ydb/public/sdk/cpp/examples/topic_reader/eventloop/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/examples/topic_reader/eventloop/CMakeLists.darwin-arm64.txt index e4f45d964769..98c92ca2118a 100644 --- a/ydb/public/sdk/cpp/examples/topic_reader/eventloop/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/examples/topic_reader/eventloop/CMakeLists.darwin-arm64.txt @@ -18,8 +18,6 @@ target_link_options(persqueue_reader_eventloop PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(persqueue_reader_eventloop PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/topic_reader/eventloop/main.cpp diff --git a/ydb/public/sdk/cpp/examples/topic_reader/eventloop/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/examples/topic_reader/eventloop/CMakeLists.darwin-x86_64.txt index 1cb19aab356b..541b8c5940b8 100644 --- a/ydb/public/sdk/cpp/examples/topic_reader/eventloop/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/examples/topic_reader/eventloop/CMakeLists.darwin-x86_64.txt @@ -19,8 +19,6 @@ target_link_options(persqueue_reader_eventloop PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(persqueue_reader_eventloop PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/topic_reader/eventloop/main.cpp diff --git a/ydb/public/sdk/cpp/examples/topic_reader/eventloop/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/examples/topic_reader/eventloop/CMakeLists.linux-aarch64.txt index 7536798294f9..2febe9872a60 100644 --- a/ydb/public/sdk/cpp/examples/topic_reader/eventloop/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/examples/topic_reader/eventloop/CMakeLists.linux-aarch64.txt @@ -21,9 +21,6 @@ target_link_options(persqueue_reader_eventloop PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(persqueue_reader_eventloop PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/topic_reader/eventloop/main.cpp diff --git a/ydb/public/sdk/cpp/examples/topic_reader/eventloop/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/examples/topic_reader/eventloop/CMakeLists.linux-x86_64.txt index cfa4b2204288..d62a558bec7c 100644 --- a/ydb/public/sdk/cpp/examples/topic_reader/eventloop/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/examples/topic_reader/eventloop/CMakeLists.linux-x86_64.txt @@ -22,9 +22,6 @@ target_link_options(persqueue_reader_eventloop PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(persqueue_reader_eventloop PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/topic_reader/eventloop/main.cpp diff --git a/ydb/public/sdk/cpp/examples/topic_reader/simple/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/examples/topic_reader/simple/CMakeLists.darwin-arm64.txt index 30ad21dbfb4d..33d31580c0b2 100644 --- a/ydb/public/sdk/cpp/examples/topic_reader/simple/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/examples/topic_reader/simple/CMakeLists.darwin-arm64.txt @@ -18,8 +18,6 @@ target_link_options(simple_persqueue_reader PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(simple_persqueue_reader PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/topic_reader/simple/main.cpp diff --git a/ydb/public/sdk/cpp/examples/topic_reader/simple/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/examples/topic_reader/simple/CMakeLists.darwin-x86_64.txt index c6f296ec5229..56315c49d9be 100644 --- a/ydb/public/sdk/cpp/examples/topic_reader/simple/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/examples/topic_reader/simple/CMakeLists.darwin-x86_64.txt @@ -19,8 +19,6 @@ target_link_options(simple_persqueue_reader PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(simple_persqueue_reader PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/topic_reader/simple/main.cpp diff --git a/ydb/public/sdk/cpp/examples/topic_reader/simple/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/examples/topic_reader/simple/CMakeLists.linux-aarch64.txt index 269f2b1544fb..22d538602a4d 100644 --- a/ydb/public/sdk/cpp/examples/topic_reader/simple/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/examples/topic_reader/simple/CMakeLists.linux-aarch64.txt @@ -21,9 +21,6 @@ target_link_options(simple_persqueue_reader PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(simple_persqueue_reader PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/topic_reader/simple/main.cpp diff --git a/ydb/public/sdk/cpp/examples/topic_reader/simple/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/examples/topic_reader/simple/CMakeLists.linux-x86_64.txt index 7816fb06207c..5386ed8ae485 100644 --- a/ydb/public/sdk/cpp/examples/topic_reader/simple/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/examples/topic_reader/simple/CMakeLists.linux-x86_64.txt @@ -22,9 +22,6 @@ target_link_options(simple_persqueue_reader PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(simple_persqueue_reader PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/topic_reader/simple/main.cpp diff --git a/ydb/public/sdk/cpp/examples/topic_reader/transaction/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/examples/topic_reader/transaction/CMakeLists.darwin-arm64.txt index 3b54f483577f..5d6ebf2b2180 100644 --- a/ydb/public/sdk/cpp/examples/topic_reader/transaction/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/examples/topic_reader/transaction/CMakeLists.darwin-arm64.txt @@ -18,8 +18,6 @@ target_link_options(read_from_topic_in_transaction PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(read_from_topic_in_transaction PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/topic_reader/transaction/application.cpp diff --git a/ydb/public/sdk/cpp/examples/topic_reader/transaction/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/examples/topic_reader/transaction/CMakeLists.darwin-x86_64.txt index 6a330398e25a..b8ae1c081831 100644 --- a/ydb/public/sdk/cpp/examples/topic_reader/transaction/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/examples/topic_reader/transaction/CMakeLists.darwin-x86_64.txt @@ -19,8 +19,6 @@ target_link_options(read_from_topic_in_transaction PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(read_from_topic_in_transaction PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/topic_reader/transaction/application.cpp diff --git a/ydb/public/sdk/cpp/examples/topic_reader/transaction/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/examples/topic_reader/transaction/CMakeLists.linux-aarch64.txt index 0528f1dc1910..deb766c26c42 100644 --- a/ydb/public/sdk/cpp/examples/topic_reader/transaction/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/examples/topic_reader/transaction/CMakeLists.linux-aarch64.txt @@ -21,9 +21,6 @@ target_link_options(read_from_topic_in_transaction PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(read_from_topic_in_transaction PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/topic_reader/transaction/application.cpp diff --git a/ydb/public/sdk/cpp/examples/topic_reader/transaction/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/examples/topic_reader/transaction/CMakeLists.linux-x86_64.txt index 6c4059200e9d..0ab278eb75f2 100644 --- a/ydb/public/sdk/cpp/examples/topic_reader/transaction/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/examples/topic_reader/transaction/CMakeLists.linux-x86_64.txt @@ -22,9 +22,6 @@ target_link_options(read_from_topic_in_transaction PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(read_from_topic_in_transaction PRIVATE ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/topic_reader/transaction/application.cpp diff --git a/ydb/public/sdk/cpp/examples/ttl/CMakeLists.darwin-arm64.txt b/ydb/public/sdk/cpp/examples/ttl/CMakeLists.darwin-arm64.txt index 68a3862c5d30..1fb64fb929e0 100644 --- a/ydb/public/sdk/cpp/examples/ttl/CMakeLists.darwin-arm64.txt +++ b/ydb/public/sdk/cpp/examples/ttl/CMakeLists.darwin-arm64.txt @@ -18,10 +18,10 @@ target_link_options(ttl PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ttl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/ttl/ttl.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/ttl/util.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/ttl/main.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/ttl/ttl.cpp ) diff --git a/ydb/public/sdk/cpp/examples/ttl/CMakeLists.darwin-x86_64.txt b/ydb/public/sdk/cpp/examples/ttl/CMakeLists.darwin-x86_64.txt index 02cab908996a..85cef17f9116 100644 --- a/ydb/public/sdk/cpp/examples/ttl/CMakeLists.darwin-x86_64.txt +++ b/ydb/public/sdk/cpp/examples/ttl/CMakeLists.darwin-x86_64.txt @@ -19,10 +19,10 @@ target_link_options(ttl PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ttl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/ttl/ttl.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/ttl/util.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/ttl/main.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/ttl/ttl.cpp ) diff --git a/ydb/public/sdk/cpp/examples/ttl/CMakeLists.linux-aarch64.txt b/ydb/public/sdk/cpp/examples/ttl/CMakeLists.linux-aarch64.txt index b727597c53e7..56895ad97f22 100644 --- a/ydb/public/sdk/cpp/examples/ttl/CMakeLists.linux-aarch64.txt +++ b/ydb/public/sdk/cpp/examples/ttl/CMakeLists.linux-aarch64.txt @@ -21,11 +21,10 @@ target_link_options(ttl PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ttl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/ttl/ttl.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/ttl/util.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/ttl/main.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/ttl/ttl.cpp ) diff --git a/ydb/public/sdk/cpp/examples/ttl/CMakeLists.linux-x86_64.txt b/ydb/public/sdk/cpp/examples/ttl/CMakeLists.linux-x86_64.txt index a26fc0369c0c..48e578c76d59 100644 --- a/ydb/public/sdk/cpp/examples/ttl/CMakeLists.linux-x86_64.txt +++ b/ydb/public/sdk/cpp/examples/ttl/CMakeLists.linux-x86_64.txt @@ -22,11 +22,10 @@ target_link_options(ttl PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ttl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/ttl/ttl.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/ttl/util.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/ttl/main.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/ttl/ttl.cpp ) diff --git a/ydb/public/sdk/cpp/examples/ttl/CMakeLists.windows-x86_64.txt b/ydb/public/sdk/cpp/examples/ttl/CMakeLists.windows-x86_64.txt index fd29a09b7086..d4adeeca3008 100644 --- a/ydb/public/sdk/cpp/examples/ttl/CMakeLists.windows-x86_64.txt +++ b/ydb/public/sdk/cpp/examples/ttl/CMakeLists.windows-x86_64.txt @@ -16,6 +16,8 @@ target_link_libraries(ttl PUBLIC cpp-client-ydb_table ) target_sources(ttl PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/ttl/ttl.h + ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/ttl/util.h ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/ttl/main.cpp ${CMAKE_SOURCE_DIR}/ydb/public/sdk/cpp/examples/ttl/ttl.cpp ) diff --git a/ydb/services/bg_tasks/protos/CMakeLists.darwin-arm64.txt b/ydb/services/bg_tasks/protos/CMakeLists.darwin-arm64.txt index cec47cc18b87..3de59d8e0159 100644 --- a/ydb/services/bg_tasks/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/services/bg_tasks/protos/CMakeLists.darwin-arm64.txt @@ -28,6 +28,9 @@ target_link_libraries(services-bg_tasks-protos PUBLIC target_proto_messages(services-bg_tasks-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/bg_tasks/protos/container.proto ) +target_sources(services-bg_tasks-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/services/bg_tasks/protos/container.pb.h +) target_proto_addincls(services-bg_tasks-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/services/bg_tasks/protos/CMakeLists.darwin-x86_64.txt b/ydb/services/bg_tasks/protos/CMakeLists.darwin-x86_64.txt index cec47cc18b87..3de59d8e0159 100644 --- a/ydb/services/bg_tasks/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/bg_tasks/protos/CMakeLists.darwin-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(services-bg_tasks-protos PUBLIC target_proto_messages(services-bg_tasks-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/bg_tasks/protos/container.proto ) +target_sources(services-bg_tasks-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/services/bg_tasks/protos/container.pb.h +) target_proto_addincls(services-bg_tasks-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/services/bg_tasks/protos/CMakeLists.linux-aarch64.txt b/ydb/services/bg_tasks/protos/CMakeLists.linux-aarch64.txt index 792e0c2f9af3..0299694910b9 100644 --- a/ydb/services/bg_tasks/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/services/bg_tasks/protos/CMakeLists.linux-aarch64.txt @@ -29,6 +29,9 @@ target_link_libraries(services-bg_tasks-protos PUBLIC target_proto_messages(services-bg_tasks-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/bg_tasks/protos/container.proto ) +target_sources(services-bg_tasks-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/services/bg_tasks/protos/container.pb.h +) target_proto_addincls(services-bg_tasks-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/services/bg_tasks/protos/CMakeLists.linux-x86_64.txt b/ydb/services/bg_tasks/protos/CMakeLists.linux-x86_64.txt index 792e0c2f9af3..0299694910b9 100644 --- a/ydb/services/bg_tasks/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/services/bg_tasks/protos/CMakeLists.linux-x86_64.txt @@ -29,6 +29,9 @@ target_link_libraries(services-bg_tasks-protos PUBLIC target_proto_messages(services-bg_tasks-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/bg_tasks/protos/container.proto ) +target_sources(services-bg_tasks-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/services/bg_tasks/protos/container.pb.h +) target_proto_addincls(services-bg_tasks-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/services/bg_tasks/protos/CMakeLists.windows-x86_64.txt b/ydb/services/bg_tasks/protos/CMakeLists.windows-x86_64.txt index cec47cc18b87..3de59d8e0159 100644 --- a/ydb/services/bg_tasks/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/services/bg_tasks/protos/CMakeLists.windows-x86_64.txt @@ -28,6 +28,9 @@ target_link_libraries(services-bg_tasks-protos PUBLIC target_proto_messages(services-bg_tasks-protos PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/bg_tasks/protos/container.proto ) +target_sources(services-bg_tasks-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/services/bg_tasks/protos/container.pb.h +) target_proto_addincls(services-bg_tasks-protos ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/services/bg_tasks/ut/CMakeLists.darwin-arm64.txt b/ydb/services/bg_tasks/ut/CMakeLists.darwin-arm64.txt index e9d8655ab976..2e98f066b30c 100644 --- a/ydb/services/bg_tasks/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/services/bg_tasks/ut/CMakeLists.darwin-arm64.txt @@ -34,8 +34,6 @@ target_link_options(ydb-services-bg_tasks-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-bg_tasks-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/bg_tasks/ut/ut_tasks.cpp @@ -66,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/bg_tasks/ut/CMakeLists.darwin-x86_64.txt b/ydb/services/bg_tasks/ut/CMakeLists.darwin-x86_64.txt index 20b1a8316af6..68d1ffcfd8d0 100644 --- a/ydb/services/bg_tasks/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/bg_tasks/ut/CMakeLists.darwin-x86_64.txt @@ -35,8 +35,6 @@ target_link_options(ydb-services-bg_tasks-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-bg_tasks-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/bg_tasks/ut/ut_tasks.cpp @@ -67,6 +65,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/bg_tasks/ut/CMakeLists.linux-aarch64.txt b/ydb/services/bg_tasks/ut/CMakeLists.linux-aarch64.txt index 6493715f3b08..a58fd0b48cb3 100644 --- a/ydb/services/bg_tasks/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/services/bg_tasks/ut/CMakeLists.linux-aarch64.txt @@ -37,9 +37,6 @@ target_link_options(ydb-services-bg_tasks-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-bg_tasks-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/bg_tasks/ut/ut_tasks.cpp @@ -70,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/bg_tasks/ut/CMakeLists.linux-x86_64.txt b/ydb/services/bg_tasks/ut/CMakeLists.linux-x86_64.txt index 1ca0e89eda76..73f39558e0b0 100644 --- a/ydb/services/bg_tasks/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/services/bg_tasks/ut/CMakeLists.linux-x86_64.txt @@ -38,9 +38,6 @@ target_link_options(ydb-services-bg_tasks-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-bg_tasks-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/bg_tasks/ut/ut_tasks.cpp @@ -71,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/bg_tasks/ut/CMakeLists.windows-x86_64.txt b/ydb/services/bg_tasks/ut/CMakeLists.windows-x86_64.txt index 663c306f11d3..c1e46521de09 100644 --- a/ydb/services/bg_tasks/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/services/bg_tasks/ut/CMakeLists.windows-x86_64.txt @@ -60,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/cms/ut/CMakeLists.darwin-arm64.txt b/ydb/services/cms/ut/CMakeLists.darwin-arm64.txt index 8e9c2ac79da3..76b68438a45a 100644 --- a/ydb/services/cms/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/services/cms/ut/CMakeLists.darwin-arm64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-services-cms-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-cms-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/cms/cms_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/cms/ut/CMakeLists.darwin-x86_64.txt b/ydb/services/cms/ut/CMakeLists.darwin-x86_64.txt index b73e8c4c8219..26bcc9b437dd 100644 --- a/ydb/services/cms/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/cms/ut/CMakeLists.darwin-x86_64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-services-cms-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-cms-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/cms/cms_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/cms/ut/CMakeLists.linux-aarch64.txt b/ydb/services/cms/ut/CMakeLists.linux-aarch64.txt index 8c7338a6384a..f3bd94b4a6ac 100644 --- a/ydb/services/cms/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/services/cms/ut/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-services-cms-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-cms-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/cms/cms_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/cms/ut/CMakeLists.linux-x86_64.txt b/ydb/services/cms/ut/CMakeLists.linux-x86_64.txt index b513ccf11e56..4cc910aed53c 100644 --- a/ydb/services/cms/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/services/cms/ut/CMakeLists.linux-x86_64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-services-cms-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-cms-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/cms/cms_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/cms/ut/CMakeLists.windows-x86_64.txt b/ydb/services/cms/ut/CMakeLists.windows-x86_64.txt index 5b5f84fa287b..1f456496a21a 100644 --- a/ydb/services/cms/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/services/cms/ut/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/datastreams/ut/CMakeLists.darwin-arm64.txt b/ydb/services/datastreams/ut/CMakeLists.darwin-arm64.txt index b58c71af6096..b328114e13b0 100644 --- a/ydb/services/datastreams/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/services/datastreams/ut/CMakeLists.darwin-arm64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-services-datastreams-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-datastreams-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/datastreams/datastreams_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/datastreams/ut/CMakeLists.darwin-x86_64.txt b/ydb/services/datastreams/ut/CMakeLists.darwin-x86_64.txt index 70577ca58128..0062b8816fbd 100644 --- a/ydb/services/datastreams/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/datastreams/ut/CMakeLists.darwin-x86_64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-services-datastreams-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-datastreams-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/datastreams/datastreams_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/datastreams/ut/CMakeLists.linux-aarch64.txt b/ydb/services/datastreams/ut/CMakeLists.linux-aarch64.txt index 558f630fbc4e..623fca029888 100644 --- a/ydb/services/datastreams/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/services/datastreams/ut/CMakeLists.linux-aarch64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-services-datastreams-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-datastreams-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/datastreams/datastreams_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/datastreams/ut/CMakeLists.linux-x86_64.txt b/ydb/services/datastreams/ut/CMakeLists.linux-x86_64.txt index 976ef31c35db..f66301eded97 100644 --- a/ydb/services/datastreams/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/services/datastreams/ut/CMakeLists.linux-x86_64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-services-datastreams-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-datastreams-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/datastreams/datastreams_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/datastreams/ut/CMakeLists.windows-x86_64.txt b/ydb/services/datastreams/ut/CMakeLists.windows-x86_64.txt index 7f03282416a3..f4c3157d31ef 100644 --- a/ydb/services/datastreams/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/services/datastreams/ut/CMakeLists.windows-x86_64.txt @@ -54,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/deprecated/persqueue_v0/api/grpc/CMakeLists.darwin-arm64.txt b/ydb/services/deprecated/persqueue_v0/api/grpc/CMakeLists.darwin-arm64.txt index 77bda3ed067d..d3afe70beb50 100644 --- a/ydb/services/deprecated/persqueue_v0/api/grpc/CMakeLists.darwin-arm64.txt +++ b/ydb/services/deprecated/persqueue_v0/api/grpc/CMakeLists.darwin-arm64.txt @@ -40,6 +40,10 @@ target_link_libraries(api-grpc-persqueue-deprecated PUBLIC target_proto_messages(api-grpc-persqueue-deprecated PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/deprecated/persqueue_v0/api/grpc/persqueue.proto ) +target_sources(api-grpc-persqueue-deprecated PRIVATE + ${CMAKE_BINARY_DIR}/ydb/services/deprecated/persqueue_v0/api/grpc/persqueue.pb.h + ${CMAKE_BINARY_DIR}/ydb/services/deprecated/persqueue_v0/api/grpc/persqueue.grpc.pb.h +) target_proto_addincls(api-grpc-persqueue-deprecated ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/services/deprecated/persqueue_v0/api/grpc/CMakeLists.darwin-x86_64.txt b/ydb/services/deprecated/persqueue_v0/api/grpc/CMakeLists.darwin-x86_64.txt index 77bda3ed067d..d3afe70beb50 100644 --- a/ydb/services/deprecated/persqueue_v0/api/grpc/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/deprecated/persqueue_v0/api/grpc/CMakeLists.darwin-x86_64.txt @@ -40,6 +40,10 @@ target_link_libraries(api-grpc-persqueue-deprecated PUBLIC target_proto_messages(api-grpc-persqueue-deprecated PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/deprecated/persqueue_v0/api/grpc/persqueue.proto ) +target_sources(api-grpc-persqueue-deprecated PRIVATE + ${CMAKE_BINARY_DIR}/ydb/services/deprecated/persqueue_v0/api/grpc/persqueue.pb.h + ${CMAKE_BINARY_DIR}/ydb/services/deprecated/persqueue_v0/api/grpc/persqueue.grpc.pb.h +) target_proto_addincls(api-grpc-persqueue-deprecated ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/services/deprecated/persqueue_v0/api/grpc/CMakeLists.linux-aarch64.txt b/ydb/services/deprecated/persqueue_v0/api/grpc/CMakeLists.linux-aarch64.txt index 42026a7c4dc9..8ff2150ae7f4 100644 --- a/ydb/services/deprecated/persqueue_v0/api/grpc/CMakeLists.linux-aarch64.txt +++ b/ydb/services/deprecated/persqueue_v0/api/grpc/CMakeLists.linux-aarch64.txt @@ -41,6 +41,10 @@ target_link_libraries(api-grpc-persqueue-deprecated PUBLIC target_proto_messages(api-grpc-persqueue-deprecated PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/deprecated/persqueue_v0/api/grpc/persqueue.proto ) +target_sources(api-grpc-persqueue-deprecated PRIVATE + ${CMAKE_BINARY_DIR}/ydb/services/deprecated/persqueue_v0/api/grpc/persqueue.pb.h + ${CMAKE_BINARY_DIR}/ydb/services/deprecated/persqueue_v0/api/grpc/persqueue.grpc.pb.h +) target_proto_addincls(api-grpc-persqueue-deprecated ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/services/deprecated/persqueue_v0/api/grpc/CMakeLists.linux-x86_64.txt b/ydb/services/deprecated/persqueue_v0/api/grpc/CMakeLists.linux-x86_64.txt index 42026a7c4dc9..8ff2150ae7f4 100644 --- a/ydb/services/deprecated/persqueue_v0/api/grpc/CMakeLists.linux-x86_64.txt +++ b/ydb/services/deprecated/persqueue_v0/api/grpc/CMakeLists.linux-x86_64.txt @@ -41,6 +41,10 @@ target_link_libraries(api-grpc-persqueue-deprecated PUBLIC target_proto_messages(api-grpc-persqueue-deprecated PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/deprecated/persqueue_v0/api/grpc/persqueue.proto ) +target_sources(api-grpc-persqueue-deprecated PRIVATE + ${CMAKE_BINARY_DIR}/ydb/services/deprecated/persqueue_v0/api/grpc/persqueue.pb.h + ${CMAKE_BINARY_DIR}/ydb/services/deprecated/persqueue_v0/api/grpc/persqueue.grpc.pb.h +) target_proto_addincls(api-grpc-persqueue-deprecated ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/services/deprecated/persqueue_v0/api/grpc/CMakeLists.windows-x86_64.txt b/ydb/services/deprecated/persqueue_v0/api/grpc/CMakeLists.windows-x86_64.txt index 77bda3ed067d..d3afe70beb50 100644 --- a/ydb/services/deprecated/persqueue_v0/api/grpc/CMakeLists.windows-x86_64.txt +++ b/ydb/services/deprecated/persqueue_v0/api/grpc/CMakeLists.windows-x86_64.txt @@ -40,6 +40,10 @@ target_link_libraries(api-grpc-persqueue-deprecated PUBLIC target_proto_messages(api-grpc-persqueue-deprecated PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/deprecated/persqueue_v0/api/grpc/persqueue.proto ) +target_sources(api-grpc-persqueue-deprecated PRIVATE + ${CMAKE_BINARY_DIR}/ydb/services/deprecated/persqueue_v0/api/grpc/persqueue.pb.h + ${CMAKE_BINARY_DIR}/ydb/services/deprecated/persqueue_v0/api/grpc/persqueue.grpc.pb.h +) target_proto_addincls(api-grpc-persqueue-deprecated ./ ${CMAKE_SOURCE_DIR}/ diff --git a/ydb/services/deprecated/persqueue_v0/api/protos/CMakeLists.darwin-arm64.txt b/ydb/services/deprecated/persqueue_v0/api/protos/CMakeLists.darwin-arm64.txt index 14b1c5308aa0..7c9c91f69279 100644 --- a/ydb/services/deprecated/persqueue_v0/api/protos/CMakeLists.darwin-arm64.txt +++ b/ydb/services/deprecated/persqueue_v0/api/protos/CMakeLists.darwin-arm64.txt @@ -36,6 +36,9 @@ target_link_libraries(api-protos-persqueue-deprecated PUBLIC target_proto_messages(api-protos-persqueue-deprecated PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/deprecated/persqueue_v0/api/protos/persqueue.proto ) +target_sources(api-protos-persqueue-deprecated PRIVATE + ${CMAKE_BINARY_DIR}/ydb/services/deprecated/persqueue_v0/api/protos/persqueue.pb.h +) generate_enum_serilization(api-protos-persqueue-deprecated ${CMAKE_BINARY_DIR}/ydb/services/deprecated/persqueue_v0/api/protos/persqueue.pb.h INCLUDE_HEADERS diff --git a/ydb/services/deprecated/persqueue_v0/api/protos/CMakeLists.darwin-x86_64.txt b/ydb/services/deprecated/persqueue_v0/api/protos/CMakeLists.darwin-x86_64.txt index 14b1c5308aa0..7c9c91f69279 100644 --- a/ydb/services/deprecated/persqueue_v0/api/protos/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/deprecated/persqueue_v0/api/protos/CMakeLists.darwin-x86_64.txt @@ -36,6 +36,9 @@ target_link_libraries(api-protos-persqueue-deprecated PUBLIC target_proto_messages(api-protos-persqueue-deprecated PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/deprecated/persqueue_v0/api/protos/persqueue.proto ) +target_sources(api-protos-persqueue-deprecated PRIVATE + ${CMAKE_BINARY_DIR}/ydb/services/deprecated/persqueue_v0/api/protos/persqueue.pb.h +) generate_enum_serilization(api-protos-persqueue-deprecated ${CMAKE_BINARY_DIR}/ydb/services/deprecated/persqueue_v0/api/protos/persqueue.pb.h INCLUDE_HEADERS diff --git a/ydb/services/deprecated/persqueue_v0/api/protos/CMakeLists.linux-aarch64.txt b/ydb/services/deprecated/persqueue_v0/api/protos/CMakeLists.linux-aarch64.txt index 2f0a5f943c17..11f7f00c6afd 100644 --- a/ydb/services/deprecated/persqueue_v0/api/protos/CMakeLists.linux-aarch64.txt +++ b/ydb/services/deprecated/persqueue_v0/api/protos/CMakeLists.linux-aarch64.txt @@ -37,6 +37,9 @@ target_link_libraries(api-protos-persqueue-deprecated PUBLIC target_proto_messages(api-protos-persqueue-deprecated PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/deprecated/persqueue_v0/api/protos/persqueue.proto ) +target_sources(api-protos-persqueue-deprecated PRIVATE + ${CMAKE_BINARY_DIR}/ydb/services/deprecated/persqueue_v0/api/protos/persqueue.pb.h +) generate_enum_serilization(api-protos-persqueue-deprecated ${CMAKE_BINARY_DIR}/ydb/services/deprecated/persqueue_v0/api/protos/persqueue.pb.h INCLUDE_HEADERS diff --git a/ydb/services/deprecated/persqueue_v0/api/protos/CMakeLists.linux-x86_64.txt b/ydb/services/deprecated/persqueue_v0/api/protos/CMakeLists.linux-x86_64.txt index 2f0a5f943c17..11f7f00c6afd 100644 --- a/ydb/services/deprecated/persqueue_v0/api/protos/CMakeLists.linux-x86_64.txt +++ b/ydb/services/deprecated/persqueue_v0/api/protos/CMakeLists.linux-x86_64.txt @@ -37,6 +37,9 @@ target_link_libraries(api-protos-persqueue-deprecated PUBLIC target_proto_messages(api-protos-persqueue-deprecated PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/deprecated/persqueue_v0/api/protos/persqueue.proto ) +target_sources(api-protos-persqueue-deprecated PRIVATE + ${CMAKE_BINARY_DIR}/ydb/services/deprecated/persqueue_v0/api/protos/persqueue.pb.h +) generate_enum_serilization(api-protos-persqueue-deprecated ${CMAKE_BINARY_DIR}/ydb/services/deprecated/persqueue_v0/api/protos/persqueue.pb.h INCLUDE_HEADERS diff --git a/ydb/services/deprecated/persqueue_v0/api/protos/CMakeLists.windows-x86_64.txt b/ydb/services/deprecated/persqueue_v0/api/protos/CMakeLists.windows-x86_64.txt index 14b1c5308aa0..7c9c91f69279 100644 --- a/ydb/services/deprecated/persqueue_v0/api/protos/CMakeLists.windows-x86_64.txt +++ b/ydb/services/deprecated/persqueue_v0/api/protos/CMakeLists.windows-x86_64.txt @@ -36,6 +36,9 @@ target_link_libraries(api-protos-persqueue-deprecated PUBLIC target_proto_messages(api-protos-persqueue-deprecated PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/deprecated/persqueue_v0/api/protos/persqueue.proto ) +target_sources(api-protos-persqueue-deprecated PRIVATE + ${CMAKE_BINARY_DIR}/ydb/services/deprecated/persqueue_v0/api/protos/persqueue.pb.h +) generate_enum_serilization(api-protos-persqueue-deprecated ${CMAKE_BINARY_DIR}/ydb/services/deprecated/persqueue_v0/api/protos/persqueue.pb.h INCLUDE_HEADERS diff --git a/ydb/services/dynamic_config/ut/CMakeLists.darwin-arm64.txt b/ydb/services/dynamic_config/ut/CMakeLists.darwin-arm64.txt index 9607c8ac2c7c..5509459d9783 100644 --- a/ydb/services/dynamic_config/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/services/dynamic_config/ut/CMakeLists.darwin-arm64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-services-dynamic_config-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-dynamic_config-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/dynamic_config/dynamic_config_ut.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/dynamic_config/ut/CMakeLists.darwin-x86_64.txt b/ydb/services/dynamic_config/ut/CMakeLists.darwin-x86_64.txt index 1d79fbf9cb64..2686e46820b5 100644 --- a/ydb/services/dynamic_config/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/dynamic_config/ut/CMakeLists.darwin-x86_64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-services-dynamic_config-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-dynamic_config-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/dynamic_config/dynamic_config_ut.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/dynamic_config/ut/CMakeLists.linux-aarch64.txt b/ydb/services/dynamic_config/ut/CMakeLists.linux-aarch64.txt index 513f5676935f..d8c860290766 100644 --- a/ydb/services/dynamic_config/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/services/dynamic_config/ut/CMakeLists.linux-aarch64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-services-dynamic_config-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-dynamic_config-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/dynamic_config/dynamic_config_ut.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/dynamic_config/ut/CMakeLists.linux-x86_64.txt b/ydb/services/dynamic_config/ut/CMakeLists.linux-x86_64.txt index 4ba27e34ac08..5b67c321addb 100644 --- a/ydb/services/dynamic_config/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/services/dynamic_config/ut/CMakeLists.linux-x86_64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-services-dynamic_config-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-dynamic_config-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/dynamic_config/dynamic_config_ut.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/dynamic_config/ut/CMakeLists.windows-x86_64.txt b/ydb/services/dynamic_config/ut/CMakeLists.windows-x86_64.txt index 4d659ef0ee8a..92457d90db72 100644 --- a/ydb/services/dynamic_config/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/services/dynamic_config/ut/CMakeLists.windows-x86_64.txt @@ -55,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS SMALL + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ext_index/ut/CMakeLists.darwin-arm64.txt b/ydb/services/ext_index/ut/CMakeLists.darwin-arm64.txt index 40d9d663806f..785bf612c6da 100644 --- a/ydb/services/ext_index/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/services/ext_index/ut/CMakeLists.darwin-arm64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-services-ext_index-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-ext_index-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ext_index/ut/ut_ext_index.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ext_index/ut/CMakeLists.darwin-x86_64.txt b/ydb/services/ext_index/ut/CMakeLists.darwin-x86_64.txt index 36a8f09a5f20..fc10026321ff 100644 --- a/ydb/services/ext_index/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/ext_index/ut/CMakeLists.darwin-x86_64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-services-ext_index-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-ext_index-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ext_index/ut/ut_ext_index.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ext_index/ut/CMakeLists.linux-aarch64.txt b/ydb/services/ext_index/ut/CMakeLists.linux-aarch64.txt index 20b9fc391416..8c14c37e8770 100644 --- a/ydb/services/ext_index/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/services/ext_index/ut/CMakeLists.linux-aarch64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-services-ext_index-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-ext_index-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ext_index/ut/ut_ext_index.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ext_index/ut/CMakeLists.linux-x86_64.txt b/ydb/services/ext_index/ut/CMakeLists.linux-x86_64.txt index 29d4ebd4c09b..4ab045d7e1e9 100644 --- a/ydb/services/ext_index/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/services/ext_index/ut/CMakeLists.linux-x86_64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-services-ext_index-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-ext_index-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ext_index/ut/ut_ext_index.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ext_index/ut/CMakeLists.windows-x86_64.txt b/ydb/services/ext_index/ut/CMakeLists.windows-x86_64.txt index d3eb8a649d9f..c1916c1d5573 100644 --- a/ydb/services/ext_index/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/services/ext_index/ut/CMakeLists.windows-x86_64.txt @@ -55,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/fq/ut_integration/CMakeLists.darwin-arm64.txt b/ydb/services/fq/ut_integration/CMakeLists.darwin-arm64.txt index 8b6d337e3a92..97fc55a62d51 100644 --- a/ydb/services/fq/ut_integration/CMakeLists.darwin-arm64.txt +++ b/ydb/services/fq/ut_integration/CMakeLists.darwin-arm64.txt @@ -38,8 +38,6 @@ target_link_options(ydb-services-fq-ut_integration PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-fq-ut_integration PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/fq/ut_integration/ut_utils.cpp @@ -70,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/fq/ut_integration/CMakeLists.darwin-x86_64.txt b/ydb/services/fq/ut_integration/CMakeLists.darwin-x86_64.txt index a052b0fc6362..fe8af71a93a6 100644 --- a/ydb/services/fq/ut_integration/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/fq/ut_integration/CMakeLists.darwin-x86_64.txt @@ -39,8 +39,6 @@ target_link_options(ydb-services-fq-ut_integration PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-fq-ut_integration PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/fq/ut_integration/ut_utils.cpp @@ -71,6 +69,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/fq/ut_integration/CMakeLists.linux-aarch64.txt b/ydb/services/fq/ut_integration/CMakeLists.linux-aarch64.txt index 5095497fd40e..c9b85517bfdc 100644 --- a/ydb/services/fq/ut_integration/CMakeLists.linux-aarch64.txt +++ b/ydb/services/fq/ut_integration/CMakeLists.linux-aarch64.txt @@ -41,9 +41,6 @@ target_link_options(ydb-services-fq-ut_integration PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-fq-ut_integration PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/fq/ut_integration/ut_utils.cpp @@ -74,6 +71,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/fq/ut_integration/CMakeLists.linux-x86_64.txt b/ydb/services/fq/ut_integration/CMakeLists.linux-x86_64.txt index 508130078e31..e7647ca94c96 100644 --- a/ydb/services/fq/ut_integration/CMakeLists.linux-x86_64.txt +++ b/ydb/services/fq/ut_integration/CMakeLists.linux-x86_64.txt @@ -42,9 +42,6 @@ target_link_options(ydb-services-fq-ut_integration PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-fq-ut_integration PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/fq/ut_integration/ut_utils.cpp @@ -75,6 +72,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/fq/ut_integration/CMakeLists.windows-x86_64.txt b/ydb/services/fq/ut_integration/CMakeLists.windows-x86_64.txt index b0de82833859..18162c9ea017 100644 --- a/ydb/services/fq/ut_integration/CMakeLists.windows-x86_64.txt +++ b/ydb/services/fq/ut_integration/CMakeLists.windows-x86_64.txt @@ -64,6 +64,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/keyvalue/ut/CMakeLists.darwin-arm64.txt b/ydb/services/keyvalue/ut/CMakeLists.darwin-arm64.txt index d771aa8ae2c5..d045fcbf4ecc 100644 --- a/ydb/services/keyvalue/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/services/keyvalue/ut/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-services-keyvalue-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-keyvalue-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/keyvalue/grpc_service_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/keyvalue/ut/CMakeLists.darwin-x86_64.txt b/ydb/services/keyvalue/ut/CMakeLists.darwin-x86_64.txt index 2fbf1f4e2dc9..0b42fb83b488 100644 --- a/ydb/services/keyvalue/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/keyvalue/ut/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-services-keyvalue-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-keyvalue-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/keyvalue/grpc_service_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/keyvalue/ut/CMakeLists.linux-aarch64.txt b/ydb/services/keyvalue/ut/CMakeLists.linux-aarch64.txt index 0d0ad06718bc..6b3d1e530fb7 100644 --- a/ydb/services/keyvalue/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/services/keyvalue/ut/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-services-keyvalue-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-keyvalue-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/keyvalue/grpc_service_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/keyvalue/ut/CMakeLists.linux-x86_64.txt b/ydb/services/keyvalue/ut/CMakeLists.linux-x86_64.txt index baa6125f0233..dde30fbee67e 100644 --- a/ydb/services/keyvalue/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/services/keyvalue/ut/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-services-keyvalue-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-keyvalue-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/keyvalue/grpc_service_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/keyvalue/ut/CMakeLists.windows-x86_64.txt b/ydb/services/keyvalue/ut/CMakeLists.windows-x86_64.txt index 6bfcb33387cd..4667f35409ee 100644 --- a/ydb/services/keyvalue/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/services/keyvalue/ut/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/metadata/abstract/CMakeLists.darwin-arm64.txt b/ydb/services/metadata/abstract/CMakeLists.darwin-arm64.txt index a92a16c44b21..2bbf80e97ff1 100644 --- a/ydb/services/metadata/abstract/CMakeLists.darwin-arm64.txt +++ b/ydb/services/metadata/abstract/CMakeLists.darwin-arm64.txt @@ -18,12 +18,12 @@ target_link_libraries(services-metadata-abstract PUBLIC contrib-libs-cxxsupp yutil tools-enum_parser-enum_serialization_runtime + ydb-core-base ydb-library-accessor library-actors-core - services-metadata-request - api-protos - ydb-core-base yql-core-expr_nodes + api-protos + services-metadata-request ) target_sources(services-metadata-abstract PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/metadata/abstract/common.cpp diff --git a/ydb/services/metadata/abstract/CMakeLists.darwin-x86_64.txt b/ydb/services/metadata/abstract/CMakeLists.darwin-x86_64.txt index a92a16c44b21..2bbf80e97ff1 100644 --- a/ydb/services/metadata/abstract/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/metadata/abstract/CMakeLists.darwin-x86_64.txt @@ -18,12 +18,12 @@ target_link_libraries(services-metadata-abstract PUBLIC contrib-libs-cxxsupp yutil tools-enum_parser-enum_serialization_runtime + ydb-core-base ydb-library-accessor library-actors-core - services-metadata-request - api-protos - ydb-core-base yql-core-expr_nodes + api-protos + services-metadata-request ) target_sources(services-metadata-abstract PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/metadata/abstract/common.cpp diff --git a/ydb/services/metadata/abstract/CMakeLists.linux-aarch64.txt b/ydb/services/metadata/abstract/CMakeLists.linux-aarch64.txt index f6c2750c1167..a1f47a7ca217 100644 --- a/ydb/services/metadata/abstract/CMakeLists.linux-aarch64.txt +++ b/ydb/services/metadata/abstract/CMakeLists.linux-aarch64.txt @@ -19,12 +19,12 @@ target_link_libraries(services-metadata-abstract PUBLIC contrib-libs-cxxsupp yutil tools-enum_parser-enum_serialization_runtime + ydb-core-base ydb-library-accessor library-actors-core - services-metadata-request - api-protos - ydb-core-base yql-core-expr_nodes + api-protos + services-metadata-request ) target_sources(services-metadata-abstract PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/metadata/abstract/common.cpp diff --git a/ydb/services/metadata/abstract/CMakeLists.linux-x86_64.txt b/ydb/services/metadata/abstract/CMakeLists.linux-x86_64.txt index f6c2750c1167..a1f47a7ca217 100644 --- a/ydb/services/metadata/abstract/CMakeLists.linux-x86_64.txt +++ b/ydb/services/metadata/abstract/CMakeLists.linux-x86_64.txt @@ -19,12 +19,12 @@ target_link_libraries(services-metadata-abstract PUBLIC contrib-libs-cxxsupp yutil tools-enum_parser-enum_serialization_runtime + ydb-core-base ydb-library-accessor library-actors-core - services-metadata-request - api-protos - ydb-core-base yql-core-expr_nodes + api-protos + services-metadata-request ) target_sources(services-metadata-abstract PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/metadata/abstract/common.cpp diff --git a/ydb/services/metadata/abstract/CMakeLists.windows-x86_64.txt b/ydb/services/metadata/abstract/CMakeLists.windows-x86_64.txt index a92a16c44b21..2bbf80e97ff1 100644 --- a/ydb/services/metadata/abstract/CMakeLists.windows-x86_64.txt +++ b/ydb/services/metadata/abstract/CMakeLists.windows-x86_64.txt @@ -18,12 +18,12 @@ target_link_libraries(services-metadata-abstract PUBLIC contrib-libs-cxxsupp yutil tools-enum_parser-enum_serialization_runtime + ydb-core-base ydb-library-accessor library-actors-core - services-metadata-request - api-protos - ydb-core-base yql-core-expr_nodes + api-protos + services-metadata-request ) target_sources(services-metadata-abstract PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/metadata/abstract/common.cpp diff --git a/ydb/services/metadata/initializer/ut/CMakeLists.darwin-arm64.txt b/ydb/services/metadata/initializer/ut/CMakeLists.darwin-arm64.txt index 86beef95ab66..6329a3ddc15a 100644 --- a/ydb/services/metadata/initializer/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/services/metadata/initializer/ut/CMakeLists.darwin-arm64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-services-metadata-initializer-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-metadata-initializer-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/metadata/initializer/ut/ut_init.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/metadata/initializer/ut/CMakeLists.darwin-x86_64.txt b/ydb/services/metadata/initializer/ut/CMakeLists.darwin-x86_64.txt index 374d2aa1319a..5e727b5eea09 100644 --- a/ydb/services/metadata/initializer/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/metadata/initializer/ut/CMakeLists.darwin-x86_64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-services-metadata-initializer-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-metadata-initializer-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/metadata/initializer/ut/ut_init.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/metadata/initializer/ut/CMakeLists.linux-aarch64.txt b/ydb/services/metadata/initializer/ut/CMakeLists.linux-aarch64.txt index eb5005bbc5ec..f1b6117ed562 100644 --- a/ydb/services/metadata/initializer/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/services/metadata/initializer/ut/CMakeLists.linux-aarch64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-services-metadata-initializer-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-metadata-initializer-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/metadata/initializer/ut/ut_init.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/metadata/initializer/ut/CMakeLists.linux-x86_64.txt b/ydb/services/metadata/initializer/ut/CMakeLists.linux-x86_64.txt index 78e3e9e8af01..dbb8bdc11496 100644 --- a/ydb/services/metadata/initializer/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/services/metadata/initializer/ut/CMakeLists.linux-x86_64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-services-metadata-initializer-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-metadata-initializer-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/metadata/initializer/ut/ut_init.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/metadata/initializer/ut/CMakeLists.windows-x86_64.txt b/ydb/services/metadata/initializer/ut/CMakeLists.windows-x86_64.txt index 5f1043636665..85b27bb07392 100644 --- a/ydb/services/metadata/initializer/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/services/metadata/initializer/ut/CMakeLists.windows-x86_64.txt @@ -55,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/metadata/secret/ut/CMakeLists.darwin-arm64.txt b/ydb/services/metadata/secret/ut/CMakeLists.darwin-arm64.txt index 5d6532c769a5..6d07d68a07d2 100644 --- a/ydb/services/metadata/secret/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/services/metadata/secret/ut/CMakeLists.darwin-arm64.txt @@ -30,8 +30,6 @@ target_link_options(ydb-services-metadata-secret-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-metadata-secret-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/metadata/secret/ut/ut_secret.cpp @@ -61,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/metadata/secret/ut/CMakeLists.darwin-x86_64.txt b/ydb/services/metadata/secret/ut/CMakeLists.darwin-x86_64.txt index e9868b72bc88..8f52cf21208b 100644 --- a/ydb/services/metadata/secret/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/metadata/secret/ut/CMakeLists.darwin-x86_64.txt @@ -31,8 +31,6 @@ target_link_options(ydb-services-metadata-secret-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-metadata-secret-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/metadata/secret/ut/ut_secret.cpp @@ -62,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/metadata/secret/ut/CMakeLists.linux-aarch64.txt b/ydb/services/metadata/secret/ut/CMakeLists.linux-aarch64.txt index b63bc5235642..b7bbc9454f00 100644 --- a/ydb/services/metadata/secret/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/services/metadata/secret/ut/CMakeLists.linux-aarch64.txt @@ -33,9 +33,6 @@ target_link_options(ydb-services-metadata-secret-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-metadata-secret-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/metadata/secret/ut/ut_secret.cpp @@ -65,6 +62,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/metadata/secret/ut/CMakeLists.linux-x86_64.txt b/ydb/services/metadata/secret/ut/CMakeLists.linux-x86_64.txt index 35a8805f851f..24e6ee0604f5 100644 --- a/ydb/services/metadata/secret/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/services/metadata/secret/ut/CMakeLists.linux-x86_64.txt @@ -34,9 +34,6 @@ target_link_options(ydb-services-metadata-secret-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-metadata-secret-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/metadata/secret/ut/ut_secret.cpp @@ -66,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/metadata/secret/ut/CMakeLists.windows-x86_64.txt b/ydb/services/metadata/secret/ut/CMakeLists.windows-x86_64.txt index 0ecbc36747d4..c8874301212c 100644 --- a/ydb/services/metadata/secret/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/services/metadata/secret/ut/CMakeLists.windows-x86_64.txt @@ -55,6 +55,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/persqueue_cluster_discovery/ut/CMakeLists.darwin-arm64.txt b/ydb/services/persqueue_cluster_discovery/ut/CMakeLists.darwin-arm64.txt index 5e02ac6c1055..578c9502e705 100644 --- a/ydb/services/persqueue_cluster_discovery/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/services/persqueue_cluster_discovery/ut/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-services-persqueue_cluster_discovery-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-persqueue_cluster_discovery-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_cluster_discovery/cluster_discovery_service_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/persqueue_cluster_discovery/ut/CMakeLists.darwin-x86_64.txt b/ydb/services/persqueue_cluster_discovery/ut/CMakeLists.darwin-x86_64.txt index 8ff6d639e339..95f38e38234a 100644 --- a/ydb/services/persqueue_cluster_discovery/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/persqueue_cluster_discovery/ut/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-services-persqueue_cluster_discovery-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-persqueue_cluster_discovery-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_cluster_discovery/cluster_discovery_service_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/persqueue_cluster_discovery/ut/CMakeLists.linux-aarch64.txt b/ydb/services/persqueue_cluster_discovery/ut/CMakeLists.linux-aarch64.txt index ee9a8cd7fd15..3a6c036801ef 100644 --- a/ydb/services/persqueue_cluster_discovery/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/services/persqueue_cluster_discovery/ut/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-services-persqueue_cluster_discovery-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-persqueue_cluster_discovery-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_cluster_discovery/cluster_discovery_service_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/persqueue_cluster_discovery/ut/CMakeLists.linux-x86_64.txt b/ydb/services/persqueue_cluster_discovery/ut/CMakeLists.linux-x86_64.txt index e2c31e7894bd..1dedaeba9b13 100644 --- a/ydb/services/persqueue_cluster_discovery/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/services/persqueue_cluster_discovery/ut/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-services-persqueue_cluster_discovery-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-persqueue_cluster_discovery-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_cluster_discovery/cluster_discovery_service_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/persqueue_cluster_discovery/ut/CMakeLists.windows-x86_64.txt b/ydb/services/persqueue_cluster_discovery/ut/CMakeLists.windows-x86_64.txt index c75b9885c6a2..58168b9bad24 100644 --- a/ydb/services/persqueue_cluster_discovery/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/services/persqueue_cluster_discovery/ut/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/persqueue_v1/CMakeLists.darwin-arm64.txt b/ydb/services/persqueue_v1/CMakeLists.darwin-arm64.txt index 2d2cb692c4f7..b526f77ab96b 100644 --- a/ydb/services/persqueue_v1/CMakeLists.darwin-arm64.txt +++ b/ydb/services/persqueue_v1/CMakeLists.darwin-arm64.txt @@ -35,6 +35,10 @@ target_link_libraries(ydb-services-persqueue_v1 PUBLIC services-persqueue_v1-actors ) target_sources(ydb-services-persqueue_v1 PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_read.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_schema.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_write.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue.h ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_read.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_schema.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_write.cpp diff --git a/ydb/services/persqueue_v1/CMakeLists.darwin-x86_64.txt b/ydb/services/persqueue_v1/CMakeLists.darwin-x86_64.txt index 2d2cb692c4f7..b526f77ab96b 100644 --- a/ydb/services/persqueue_v1/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/persqueue_v1/CMakeLists.darwin-x86_64.txt @@ -35,6 +35,10 @@ target_link_libraries(ydb-services-persqueue_v1 PUBLIC services-persqueue_v1-actors ) target_sources(ydb-services-persqueue_v1 PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_read.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_schema.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_write.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue.h ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_read.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_schema.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_write.cpp diff --git a/ydb/services/persqueue_v1/CMakeLists.linux-aarch64.txt b/ydb/services/persqueue_v1/CMakeLists.linux-aarch64.txt index 7496a8ad1140..c2f507c1fd76 100644 --- a/ydb/services/persqueue_v1/CMakeLists.linux-aarch64.txt +++ b/ydb/services/persqueue_v1/CMakeLists.linux-aarch64.txt @@ -36,6 +36,10 @@ target_link_libraries(ydb-services-persqueue_v1 PUBLIC services-persqueue_v1-actors ) target_sources(ydb-services-persqueue_v1 PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_read.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_schema.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_write.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue.h ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_read.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_schema.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_write.cpp diff --git a/ydb/services/persqueue_v1/CMakeLists.linux-x86_64.txt b/ydb/services/persqueue_v1/CMakeLists.linux-x86_64.txt index 7496a8ad1140..c2f507c1fd76 100644 --- a/ydb/services/persqueue_v1/CMakeLists.linux-x86_64.txt +++ b/ydb/services/persqueue_v1/CMakeLists.linux-x86_64.txt @@ -36,6 +36,10 @@ target_link_libraries(ydb-services-persqueue_v1 PUBLIC services-persqueue_v1-actors ) target_sources(ydb-services-persqueue_v1 PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_read.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_schema.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_write.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue.h ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_read.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_schema.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_write.cpp diff --git a/ydb/services/persqueue_v1/CMakeLists.windows-x86_64.txt b/ydb/services/persqueue_v1/CMakeLists.windows-x86_64.txt index 2d2cb692c4f7..b526f77ab96b 100644 --- a/ydb/services/persqueue_v1/CMakeLists.windows-x86_64.txt +++ b/ydb/services/persqueue_v1/CMakeLists.windows-x86_64.txt @@ -35,6 +35,10 @@ target_link_libraries(ydb-services-persqueue_v1 PUBLIC services-persqueue_v1-actors ) target_sources(ydb-services-persqueue_v1 PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_read.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_schema.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_write.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue.h ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_read.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_schema.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/grpc_pq_write.cpp diff --git a/ydb/services/persqueue_v1/actors/CMakeLists.darwin-arm64.txt b/ydb/services/persqueue_v1/actors/CMakeLists.darwin-arm64.txt index d2f25bf3c91a..9f91599be3bc 100644 --- a/ydb/services/persqueue_v1/actors/CMakeLists.darwin-arm64.txt +++ b/ydb/services/persqueue_v1/actors/CMakeLists.darwin-arm64.txt @@ -31,6 +31,21 @@ target_link_libraries(services-persqueue_v1-actors PUBLIC ydb-services-metadata ) target_sources(services-persqueue_v1-actors PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/codecs.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/commit_offset_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/events.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/persqueue_utils.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/helpers.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/partition_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/partition_id.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/read_init_auth_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/read_info_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/read_session_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/direct_read_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/write_session_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/schema_actors.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/partition_writer.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/partition_writer_cache_actor.h ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/codecs.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/commit_offset_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/persqueue_utils.cpp diff --git a/ydb/services/persqueue_v1/actors/CMakeLists.darwin-x86_64.txt b/ydb/services/persqueue_v1/actors/CMakeLists.darwin-x86_64.txt index d2f25bf3c91a..9f91599be3bc 100644 --- a/ydb/services/persqueue_v1/actors/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/persqueue_v1/actors/CMakeLists.darwin-x86_64.txt @@ -31,6 +31,21 @@ target_link_libraries(services-persqueue_v1-actors PUBLIC ydb-services-metadata ) target_sources(services-persqueue_v1-actors PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/codecs.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/commit_offset_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/events.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/persqueue_utils.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/helpers.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/partition_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/partition_id.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/read_init_auth_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/read_info_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/read_session_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/direct_read_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/write_session_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/schema_actors.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/partition_writer.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/partition_writer_cache_actor.h ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/codecs.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/commit_offset_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/persqueue_utils.cpp diff --git a/ydb/services/persqueue_v1/actors/CMakeLists.linux-aarch64.txt b/ydb/services/persqueue_v1/actors/CMakeLists.linux-aarch64.txt index 326faf12eb84..2c117a55bace 100644 --- a/ydb/services/persqueue_v1/actors/CMakeLists.linux-aarch64.txt +++ b/ydb/services/persqueue_v1/actors/CMakeLists.linux-aarch64.txt @@ -32,6 +32,21 @@ target_link_libraries(services-persqueue_v1-actors PUBLIC ydb-services-metadata ) target_sources(services-persqueue_v1-actors PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/codecs.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/commit_offset_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/events.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/persqueue_utils.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/helpers.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/partition_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/partition_id.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/read_init_auth_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/read_info_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/read_session_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/direct_read_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/write_session_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/schema_actors.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/partition_writer.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/partition_writer_cache_actor.h ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/codecs.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/commit_offset_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/persqueue_utils.cpp diff --git a/ydb/services/persqueue_v1/actors/CMakeLists.linux-x86_64.txt b/ydb/services/persqueue_v1/actors/CMakeLists.linux-x86_64.txt index 326faf12eb84..2c117a55bace 100644 --- a/ydb/services/persqueue_v1/actors/CMakeLists.linux-x86_64.txt +++ b/ydb/services/persqueue_v1/actors/CMakeLists.linux-x86_64.txt @@ -32,6 +32,21 @@ target_link_libraries(services-persqueue_v1-actors PUBLIC ydb-services-metadata ) target_sources(services-persqueue_v1-actors PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/codecs.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/commit_offset_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/events.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/persqueue_utils.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/helpers.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/partition_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/partition_id.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/read_init_auth_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/read_info_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/read_session_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/direct_read_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/write_session_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/schema_actors.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/partition_writer.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/partition_writer_cache_actor.h ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/codecs.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/commit_offset_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/persqueue_utils.cpp diff --git a/ydb/services/persqueue_v1/actors/CMakeLists.windows-x86_64.txt b/ydb/services/persqueue_v1/actors/CMakeLists.windows-x86_64.txt index d2f25bf3c91a..9f91599be3bc 100644 --- a/ydb/services/persqueue_v1/actors/CMakeLists.windows-x86_64.txt +++ b/ydb/services/persqueue_v1/actors/CMakeLists.windows-x86_64.txt @@ -31,6 +31,21 @@ target_link_libraries(services-persqueue_v1-actors PUBLIC ydb-services-metadata ) target_sources(services-persqueue_v1-actors PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/codecs.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/commit_offset_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/events.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/persqueue_utils.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/helpers.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/partition_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/partition_id.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/read_init_auth_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/read_info_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/read_session_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/direct_read_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/write_session_actor.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/schema_actors.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/partition_writer.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/partition_writer_cache_actor.h ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/codecs.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/commit_offset_actor.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/actors/persqueue_utils.cpp diff --git a/ydb/services/persqueue_v1/ut/CMakeLists.darwin-arm64.txt b/ydb/services/persqueue_v1/ut/CMakeLists.darwin-arm64.txt index b754157dc255..a816d36bd06f 100644 --- a/ydb/services/persqueue_v1/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/services/persqueue_v1/ut/CMakeLists.darwin-arm64.txt @@ -39,10 +39,13 @@ target_link_options(ydb-services-persqueue_v1-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-persqueue_v1-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/test_utils.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/pq_data_writer.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/api_test_setup.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/rate_limiter_test_setup.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/functions_executor_wrapper.h ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_common_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_compat_ut.cpp @@ -82,6 +85,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/persqueue_v1/ut/CMakeLists.darwin-x86_64.txt b/ydb/services/persqueue_v1/ut/CMakeLists.darwin-x86_64.txt index b9ff3fbb0345..9bc64da3463b 100644 --- a/ydb/services/persqueue_v1/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/persqueue_v1/ut/CMakeLists.darwin-x86_64.txt @@ -40,10 +40,13 @@ target_link_options(ydb-services-persqueue_v1-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-persqueue_v1-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/test_utils.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/pq_data_writer.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/api_test_setup.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/rate_limiter_test_setup.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/functions_executor_wrapper.h ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_common_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_compat_ut.cpp @@ -83,6 +86,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/persqueue_v1/ut/CMakeLists.linux-aarch64.txt b/ydb/services/persqueue_v1/ut/CMakeLists.linux-aarch64.txt index d135c0c3dce9..5b8972d23d51 100644 --- a/ydb/services/persqueue_v1/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/services/persqueue_v1/ut/CMakeLists.linux-aarch64.txt @@ -42,11 +42,13 @@ target_link_options(ydb-services-persqueue_v1-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-persqueue_v1-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/test_utils.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/pq_data_writer.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/api_test_setup.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/rate_limiter_test_setup.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/functions_executor_wrapper.h ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_common_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_compat_ut.cpp @@ -86,6 +88,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/persqueue_v1/ut/CMakeLists.linux-x86_64.txt b/ydb/services/persqueue_v1/ut/CMakeLists.linux-x86_64.txt index fff4a470c7bc..5e20901bdfeb 100644 --- a/ydb/services/persqueue_v1/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/services/persqueue_v1/ut/CMakeLists.linux-x86_64.txt @@ -43,11 +43,13 @@ target_link_options(ydb-services-persqueue_v1-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-persqueue_v1-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/test_utils.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/pq_data_writer.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/api_test_setup.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/rate_limiter_test_setup.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/functions_executor_wrapper.h ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_common_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_compat_ut.cpp @@ -87,6 +89,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/persqueue_v1/ut/CMakeLists.windows-x86_64.txt b/ydb/services/persqueue_v1/ut/CMakeLists.windows-x86_64.txt index 1700f10ce74c..f11d54c656a8 100644 --- a/ydb/services/persqueue_v1/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/services/persqueue_v1/ut/CMakeLists.windows-x86_64.txt @@ -37,6 +37,11 @@ target_link_libraries(ydb-services-persqueue_v1-ut PUBLIC cpp-client-ydb_proto ) target_sources(ydb-services-persqueue_v1-ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/test_utils.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/pq_data_writer.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/api_test_setup.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/rate_limiter_test_setup.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/functions_executor_wrapper.h ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_common_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_compat_ut.cpp @@ -76,6 +81,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/persqueue_v1/ut/describes_ut/CMakeLists.darwin-arm64.txt b/ydb/services/persqueue_v1/ut/describes_ut/CMakeLists.darwin-arm64.txt index b1df578d1d5b..a549f0d52727 100644 --- a/ydb/services/persqueue_v1/ut/describes_ut/CMakeLists.darwin-arm64.txt +++ b/ydb/services/persqueue_v1/ut/describes_ut/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-services-persqueue_v1-ut-describes_ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-persqueue_v1-ut-describes_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/describes_ut/ic_cache_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/persqueue_v1/ut/describes_ut/CMakeLists.darwin-x86_64.txt b/ydb/services/persqueue_v1/ut/describes_ut/CMakeLists.darwin-x86_64.txt index 2933016185f5..7c7fdf5b6c2e 100644 --- a/ydb/services/persqueue_v1/ut/describes_ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/persqueue_v1/ut/describes_ut/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-services-persqueue_v1-ut-describes_ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-persqueue_v1-ut-describes_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/describes_ut/ic_cache_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/persqueue_v1/ut/describes_ut/CMakeLists.linux-aarch64.txt b/ydb/services/persqueue_v1/ut/describes_ut/CMakeLists.linux-aarch64.txt index 733eac0df596..a6e05f44e65a 100644 --- a/ydb/services/persqueue_v1/ut/describes_ut/CMakeLists.linux-aarch64.txt +++ b/ydb/services/persqueue_v1/ut/describes_ut/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-services-persqueue_v1-ut-describes_ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-persqueue_v1-ut-describes_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/describes_ut/ic_cache_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/persqueue_v1/ut/describes_ut/CMakeLists.linux-x86_64.txt b/ydb/services/persqueue_v1/ut/describes_ut/CMakeLists.linux-x86_64.txt index fb655893e2f5..f8c12d245ecd 100644 --- a/ydb/services/persqueue_v1/ut/describes_ut/CMakeLists.linux-x86_64.txt +++ b/ydb/services/persqueue_v1/ut/describes_ut/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-services-persqueue_v1-ut-describes_ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-persqueue_v1-ut-describes_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/describes_ut/ic_cache_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/persqueue_v1/ut/describes_ut/CMakeLists.windows-x86_64.txt b/ydb/services/persqueue_v1/ut/describes_ut/CMakeLists.windows-x86_64.txt index 311d4cc3736e..2bef11564437 100644 --- a/ydb/services/persqueue_v1/ut/describes_ut/CMakeLists.windows-x86_64.txt +++ b/ydb/services/persqueue_v1/ut/describes_ut/CMakeLists.windows-x86_64.txt @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/persqueue_v1/ut/new_schemecache_ut/CMakeLists.darwin-arm64.txt b/ydb/services/persqueue_v1/ut/new_schemecache_ut/CMakeLists.darwin-arm64.txt index 11ff4c2f3869..012ca992dcdc 100644 --- a/ydb/services/persqueue_v1/ut/new_schemecache_ut/CMakeLists.darwin-arm64.txt +++ b/ydb/services/persqueue_v1/ut/new_schemecache_ut/CMakeLists.darwin-arm64.txt @@ -32,10 +32,12 @@ target_link_options(ydb-services-persqueue_v1-ut-new_schemecache_ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-persqueue_v1-ut-new_schemecache_ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/api_test_setup.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/test_utils.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/pq_data_writer.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/rate_limiter_test_setup.h ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_new_schemecache_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_common_new_schemecache_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/rate_limiter_test_setup.cpp @@ -65,6 +67,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/persqueue_v1/ut/new_schemecache_ut/CMakeLists.darwin-x86_64.txt b/ydb/services/persqueue_v1/ut/new_schemecache_ut/CMakeLists.darwin-x86_64.txt index 1c8bcbe935cd..001c948c2fd9 100644 --- a/ydb/services/persqueue_v1/ut/new_schemecache_ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/persqueue_v1/ut/new_schemecache_ut/CMakeLists.darwin-x86_64.txt @@ -33,10 +33,12 @@ target_link_options(ydb-services-persqueue_v1-ut-new_schemecache_ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-persqueue_v1-ut-new_schemecache_ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/api_test_setup.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/test_utils.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/pq_data_writer.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/rate_limiter_test_setup.h ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_new_schemecache_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_common_new_schemecache_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/rate_limiter_test_setup.cpp @@ -66,6 +68,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/persqueue_v1/ut/new_schemecache_ut/CMakeLists.linux-aarch64.txt b/ydb/services/persqueue_v1/ut/new_schemecache_ut/CMakeLists.linux-aarch64.txt index 757deb67a474..c5bb87bb09d2 100644 --- a/ydb/services/persqueue_v1/ut/new_schemecache_ut/CMakeLists.linux-aarch64.txt +++ b/ydb/services/persqueue_v1/ut/new_schemecache_ut/CMakeLists.linux-aarch64.txt @@ -35,11 +35,12 @@ target_link_options(ydb-services-persqueue_v1-ut-new_schemecache_ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-persqueue_v1-ut-new_schemecache_ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/api_test_setup.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/test_utils.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/pq_data_writer.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/rate_limiter_test_setup.h ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_new_schemecache_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_common_new_schemecache_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/rate_limiter_test_setup.cpp @@ -69,6 +70,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/persqueue_v1/ut/new_schemecache_ut/CMakeLists.linux-x86_64.txt b/ydb/services/persqueue_v1/ut/new_schemecache_ut/CMakeLists.linux-x86_64.txt index e100ca68582b..9bea86d1498d 100644 --- a/ydb/services/persqueue_v1/ut/new_schemecache_ut/CMakeLists.linux-x86_64.txt +++ b/ydb/services/persqueue_v1/ut/new_schemecache_ut/CMakeLists.linux-x86_64.txt @@ -36,11 +36,12 @@ target_link_options(ydb-services-persqueue_v1-ut-new_schemecache_ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-persqueue_v1-ut-new_schemecache_ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/api_test_setup.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/test_utils.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/pq_data_writer.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/rate_limiter_test_setup.h ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_new_schemecache_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_common_new_schemecache_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/rate_limiter_test_setup.cpp @@ -70,6 +71,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/persqueue_v1/ut/new_schemecache_ut/CMakeLists.windows-x86_64.txt b/ydb/services/persqueue_v1/ut/new_schemecache_ut/CMakeLists.windows-x86_64.txt index a3ac31b15650..5ca6f4da7b95 100644 --- a/ydb/services/persqueue_v1/ut/new_schemecache_ut/CMakeLists.windows-x86_64.txt +++ b/ydb/services/persqueue_v1/ut/new_schemecache_ut/CMakeLists.windows-x86_64.txt @@ -30,6 +30,10 @@ target_link_libraries(ydb-services-persqueue_v1-ut-new_schemecache_ut PUBLIC cpp-client-ydb_table ) target_sources(ydb-services-persqueue_v1-ut-new_schemecache_ut PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/api_test_setup.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/test_utils.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/pq_data_writer.h + ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/rate_limiter_test_setup.h ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_new_schemecache_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/persqueue_common_new_schemecache_ut.cpp ${CMAKE_SOURCE_DIR}/ydb/services/persqueue_v1/ut/rate_limiter_test_setup.cpp @@ -59,6 +63,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/rate_limiter/ut/CMakeLists.darwin-arm64.txt b/ydb/services/rate_limiter/ut/CMakeLists.darwin-arm64.txt index 79f118743ee4..53add87125b1 100644 --- a/ydb/services/rate_limiter/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/services/rate_limiter/ut/CMakeLists.darwin-arm64.txt @@ -27,8 +27,6 @@ target_link_options(ydb-services-rate_limiter-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-rate_limiter-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/rate_limiter/rate_limiter_ut.cpp @@ -58,6 +56,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/rate_limiter/ut/CMakeLists.darwin-x86_64.txt b/ydb/services/rate_limiter/ut/CMakeLists.darwin-x86_64.txt index 9a3d44a52a82..f5ae2cbbed5f 100644 --- a/ydb/services/rate_limiter/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/rate_limiter/ut/CMakeLists.darwin-x86_64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-services-rate_limiter-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-rate_limiter-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/rate_limiter/rate_limiter_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/rate_limiter/ut/CMakeLists.linux-aarch64.txt b/ydb/services/rate_limiter/ut/CMakeLists.linux-aarch64.txt index 95da2e42366f..eeaf0701c7c6 100644 --- a/ydb/services/rate_limiter/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/services/rate_limiter/ut/CMakeLists.linux-aarch64.txt @@ -30,9 +30,6 @@ target_link_options(ydb-services-rate_limiter-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-rate_limiter-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/rate_limiter/rate_limiter_ut.cpp @@ -62,6 +59,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/rate_limiter/ut/CMakeLists.linux-x86_64.txt b/ydb/services/rate_limiter/ut/CMakeLists.linux-x86_64.txt index 7d1b6ed889a4..bdb2a80d748f 100644 --- a/ydb/services/rate_limiter/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/services/rate_limiter/ut/CMakeLists.linux-x86_64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-services-rate_limiter-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-rate_limiter-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/rate_limiter/rate_limiter_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/rate_limiter/ut/CMakeLists.windows-x86_64.txt b/ydb/services/rate_limiter/ut/CMakeLists.windows-x86_64.txt index 79316e6be594..8bb4d4fba474 100644 --- a/ydb/services/rate_limiter/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/services/rate_limiter/ut/CMakeLists.windows-x86_64.txt @@ -52,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/sdk_credprovider_ut/CMakeLists.darwin-arm64.txt b/ydb/services/ydb/sdk_credprovider_ut/CMakeLists.darwin-arm64.txt index af988ad518c6..04ec384ffb5f 100644 --- a/ydb/services/ydb/sdk_credprovider_ut/CMakeLists.darwin-arm64.txt +++ b/ydb/services/ydb/sdk_credprovider_ut/CMakeLists.darwin-arm64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-services-ydb-sdk_credprovider_ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-ydb-sdk_credprovider_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ydb/sdk_credprovider_ut/dummy_provider_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/sdk_credprovider_ut/CMakeLists.darwin-x86_64.txt b/ydb/services/ydb/sdk_credprovider_ut/CMakeLists.darwin-x86_64.txt index 4bfcbee03f50..35eda7c817ba 100644 --- a/ydb/services/ydb/sdk_credprovider_ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/ydb/sdk_credprovider_ut/CMakeLists.darwin-x86_64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-services-ydb-sdk_credprovider_ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-ydb-sdk_credprovider_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ydb/sdk_credprovider_ut/dummy_provider_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/sdk_credprovider_ut/CMakeLists.linux-aarch64.txt b/ydb/services/ydb/sdk_credprovider_ut/CMakeLists.linux-aarch64.txt index 5238ae2f4871..c7fae7184197 100644 --- a/ydb/services/ydb/sdk_credprovider_ut/CMakeLists.linux-aarch64.txt +++ b/ydb/services/ydb/sdk_credprovider_ut/CMakeLists.linux-aarch64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-services-ydb-sdk_credprovider_ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-ydb-sdk_credprovider_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ydb/sdk_credprovider_ut/dummy_provider_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/sdk_credprovider_ut/CMakeLists.linux-x86_64.txt b/ydb/services/ydb/sdk_credprovider_ut/CMakeLists.linux-x86_64.txt index e7545a63d0c7..d11c29dea56c 100644 --- a/ydb/services/ydb/sdk_credprovider_ut/CMakeLists.linux-x86_64.txt +++ b/ydb/services/ydb/sdk_credprovider_ut/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-services-ydb-sdk_credprovider_ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-ydb-sdk_credprovider_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ydb/sdk_credprovider_ut/dummy_provider_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/sdk_credprovider_ut/CMakeLists.windows-x86_64.txt b/ydb/services/ydb/sdk_credprovider_ut/CMakeLists.windows-x86_64.txt index 021af2c3405b..1f1dfdc76781 100644 --- a/ydb/services/ydb/sdk_credprovider_ut/CMakeLists.windows-x86_64.txt +++ b/ydb/services/ydb/sdk_credprovider_ut/CMakeLists.windows-x86_64.txt @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/sdk_sessions_pool_ut/CMakeLists.darwin-arm64.txt b/ydb/services/ydb/sdk_sessions_pool_ut/CMakeLists.darwin-arm64.txt index 677c5707fe26..e8e3e9b5c626 100644 --- a/ydb/services/ydb/sdk_sessions_pool_ut/CMakeLists.darwin-arm64.txt +++ b/ydb/services/ydb/sdk_sessions_pool_ut/CMakeLists.darwin-arm64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-services-ydb-sdk_sessions_pool_ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-ydb-sdk_sessions_pool_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ydb/sdk_sessions_pool_ut/sdk_sessions_pool_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/sdk_sessions_pool_ut/CMakeLists.darwin-x86_64.txt b/ydb/services/ydb/sdk_sessions_pool_ut/CMakeLists.darwin-x86_64.txt index c21a5760fe5f..a5a872d3f554 100644 --- a/ydb/services/ydb/sdk_sessions_pool_ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/ydb/sdk_sessions_pool_ut/CMakeLists.darwin-x86_64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-services-ydb-sdk_sessions_pool_ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-ydb-sdk_sessions_pool_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ydb/sdk_sessions_pool_ut/sdk_sessions_pool_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/sdk_sessions_pool_ut/CMakeLists.linux-aarch64.txt b/ydb/services/ydb/sdk_sessions_pool_ut/CMakeLists.linux-aarch64.txt index 8c018dfdc04e..0c5712e73632 100644 --- a/ydb/services/ydb/sdk_sessions_pool_ut/CMakeLists.linux-aarch64.txt +++ b/ydb/services/ydb/sdk_sessions_pool_ut/CMakeLists.linux-aarch64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-services-ydb-sdk_sessions_pool_ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-ydb-sdk_sessions_pool_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ydb/sdk_sessions_pool_ut/sdk_sessions_pool_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/sdk_sessions_pool_ut/CMakeLists.linux-x86_64.txt b/ydb/services/ydb/sdk_sessions_pool_ut/CMakeLists.linux-x86_64.txt index 326761139bb9..fac5c5e90d7a 100644 --- a/ydb/services/ydb/sdk_sessions_pool_ut/CMakeLists.linux-x86_64.txt +++ b/ydb/services/ydb/sdk_sessions_pool_ut/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-services-ydb-sdk_sessions_pool_ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-ydb-sdk_sessions_pool_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ydb/sdk_sessions_pool_ut/sdk_sessions_pool_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/sdk_sessions_pool_ut/CMakeLists.windows-x86_64.txt b/ydb/services/ydb/sdk_sessions_pool_ut/CMakeLists.windows-x86_64.txt index 90af9c563bb0..588ee64a36d9 100644 --- a/ydb/services/ydb/sdk_sessions_pool_ut/CMakeLists.windows-x86_64.txt +++ b/ydb/services/ydb/sdk_sessions_pool_ut/CMakeLists.windows-x86_64.txt @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/sdk_sessions_ut/CMakeLists.darwin-arm64.txt b/ydb/services/ydb/sdk_sessions_ut/CMakeLists.darwin-arm64.txt index 6367e11d9496..a840a1ba0fa6 100644 --- a/ydb/services/ydb/sdk_sessions_ut/CMakeLists.darwin-arm64.txt +++ b/ydb/services/ydb/sdk_sessions_ut/CMakeLists.darwin-arm64.txt @@ -28,8 +28,6 @@ target_link_options(ydb-services-ydb-sdk_sessions_ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-ydb-sdk_sessions_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ydb/sdk_sessions_ut/sdk_sessions_ut.cpp @@ -59,6 +57,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/sdk_sessions_ut/CMakeLists.darwin-x86_64.txt b/ydb/services/ydb/sdk_sessions_ut/CMakeLists.darwin-x86_64.txt index 4c3d43dc90d7..40e03cce3f91 100644 --- a/ydb/services/ydb/sdk_sessions_ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/ydb/sdk_sessions_ut/CMakeLists.darwin-x86_64.txt @@ -29,8 +29,6 @@ target_link_options(ydb-services-ydb-sdk_sessions_ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-ydb-sdk_sessions_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ydb/sdk_sessions_ut/sdk_sessions_ut.cpp @@ -60,6 +58,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/sdk_sessions_ut/CMakeLists.linux-aarch64.txt b/ydb/services/ydb/sdk_sessions_ut/CMakeLists.linux-aarch64.txt index 1d55248e4472..f52cc03266c6 100644 --- a/ydb/services/ydb/sdk_sessions_ut/CMakeLists.linux-aarch64.txt +++ b/ydb/services/ydb/sdk_sessions_ut/CMakeLists.linux-aarch64.txt @@ -31,9 +31,6 @@ target_link_options(ydb-services-ydb-sdk_sessions_ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-ydb-sdk_sessions_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ydb/sdk_sessions_ut/sdk_sessions_ut.cpp @@ -63,6 +60,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/sdk_sessions_ut/CMakeLists.linux-x86_64.txt b/ydb/services/ydb/sdk_sessions_ut/CMakeLists.linux-x86_64.txt index 2cd247ba4345..a448c4f7fb36 100644 --- a/ydb/services/ydb/sdk_sessions_ut/CMakeLists.linux-x86_64.txt +++ b/ydb/services/ydb/sdk_sessions_ut/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(ydb-services-ydb-sdk_sessions_ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-ydb-sdk_sessions_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ydb/sdk_sessions_ut/sdk_sessions_ut.cpp @@ -64,6 +61,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/sdk_sessions_ut/CMakeLists.windows-x86_64.txt b/ydb/services/ydb/sdk_sessions_ut/CMakeLists.windows-x86_64.txt index a36c6e100b89..638891ff2ce2 100644 --- a/ydb/services/ydb/sdk_sessions_ut/CMakeLists.windows-x86_64.txt +++ b/ydb/services/ydb/sdk_sessions_ut/CMakeLists.windows-x86_64.txt @@ -53,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/table_split_ut/CMakeLists.darwin-arm64.txt b/ydb/services/ydb/table_split_ut/CMakeLists.darwin-arm64.txt index e25821cf8c84..e033142627cc 100644 --- a/ydb/services/ydb/table_split_ut/CMakeLists.darwin-arm64.txt +++ b/ydb/services/ydb/table_split_ut/CMakeLists.darwin-arm64.txt @@ -45,8 +45,6 @@ target_link_options(ydb-services-ydb-table_split_ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-ydb-table_split_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ydb/ydb_table_split_ut.cpp @@ -76,6 +74,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/table_split_ut/CMakeLists.darwin-x86_64.txt b/ydb/services/ydb/table_split_ut/CMakeLists.darwin-x86_64.txt index 23711239fc69..21774f56807f 100644 --- a/ydb/services/ydb/table_split_ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/ydb/table_split_ut/CMakeLists.darwin-x86_64.txt @@ -46,8 +46,6 @@ target_link_options(ydb-services-ydb-table_split_ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-ydb-table_split_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ydb/ydb_table_split_ut.cpp @@ -77,6 +75,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/table_split_ut/CMakeLists.linux-aarch64.txt b/ydb/services/ydb/table_split_ut/CMakeLists.linux-aarch64.txt index 927b4e7fa544..af6f8f6b5cc5 100644 --- a/ydb/services/ydb/table_split_ut/CMakeLists.linux-aarch64.txt +++ b/ydb/services/ydb/table_split_ut/CMakeLists.linux-aarch64.txt @@ -48,9 +48,6 @@ target_link_options(ydb-services-ydb-table_split_ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-ydb-table_split_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ydb/ydb_table_split_ut.cpp @@ -80,6 +77,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/table_split_ut/CMakeLists.linux-x86_64.txt b/ydb/services/ydb/table_split_ut/CMakeLists.linux-x86_64.txt index 0d8ac5e1e3de..9899c49c8763 100644 --- a/ydb/services/ydb/table_split_ut/CMakeLists.linux-x86_64.txt +++ b/ydb/services/ydb/table_split_ut/CMakeLists.linux-x86_64.txt @@ -49,9 +49,6 @@ target_link_options(ydb-services-ydb-table_split_ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-ydb-table_split_ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ydb/ydb_table_split_ut.cpp @@ -81,6 +78,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/table_split_ut/CMakeLists.windows-x86_64.txt b/ydb/services/ydb/table_split_ut/CMakeLists.windows-x86_64.txt index 6e2957020d16..c4084f0e8cde 100644 --- a/ydb/services/ydb/table_split_ut/CMakeLists.windows-x86_64.txt +++ b/ydb/services/ydb/table_split_ut/CMakeLists.windows-x86_64.txt @@ -70,6 +70,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/ut/CMakeLists.darwin-arm64.txt b/ydb/services/ydb/ut/CMakeLists.darwin-arm64.txt index ec2af8ae754d..996a277ff295 100644 --- a/ydb/services/ydb/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/services/ydb/ut/CMakeLists.darwin-arm64.txt @@ -48,8 +48,6 @@ target_link_options(ydb-services-ydb-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-ydb-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ydb/ydb_bulk_upsert_ut.cpp @@ -94,6 +92,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/ut/CMakeLists.darwin-x86_64.txt b/ydb/services/ydb/ut/CMakeLists.darwin-x86_64.txt index 236ce002b2ac..ee0f7056de80 100644 --- a/ydb/services/ydb/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/ydb/ut/CMakeLists.darwin-x86_64.txt @@ -49,8 +49,6 @@ target_link_options(ydb-services-ydb-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-services-ydb-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ydb/ydb_bulk_upsert_ut.cpp @@ -95,6 +93,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/ut/CMakeLists.linux-aarch64.txt b/ydb/services/ydb/ut/CMakeLists.linux-aarch64.txt index 22602791c90c..e8e1cffc5681 100644 --- a/ydb/services/ydb/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/services/ydb/ut/CMakeLists.linux-aarch64.txt @@ -51,9 +51,6 @@ target_link_options(ydb-services-ydb-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-ydb-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ydb/ydb_bulk_upsert_ut.cpp @@ -98,6 +95,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/ut/CMakeLists.linux-x86_64.txt b/ydb/services/ydb/ut/CMakeLists.linux-x86_64.txt index 500d6550c29a..2b0e06238dd2 100644 --- a/ydb/services/ydb/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/services/ydb/ut/CMakeLists.linux-x86_64.txt @@ -52,9 +52,6 @@ target_link_options(ydb-services-ydb-ut PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-services-ydb-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/ydb/ydb_bulk_upsert_ut.cpp @@ -99,6 +96,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/services/ydb/ut/CMakeLists.windows-x86_64.txt b/ydb/services/ydb/ut/CMakeLists.windows-x86_64.txt index 99cd79461a8f..4040949678c6 100644 --- a/ydb/services/ydb/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/services/ydb/ut/CMakeLists.windows-x86_64.txt @@ -88,6 +88,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/tests/functional/kqp/kqp_indexes/CMakeLists.darwin-arm64.txt b/ydb/tests/functional/kqp/kqp_indexes/CMakeLists.darwin-arm64.txt index dd2dc2d62444..ae9a63207384 100644 --- a/ydb/tests/functional/kqp/kqp_indexes/CMakeLists.darwin-arm64.txt +++ b/ydb/tests/functional/kqp/kqp_indexes/CMakeLists.darwin-arm64.txt @@ -20,8 +20,6 @@ target_link_options(ydb-tests-functional-kqp-kqp_indexes PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-tests-functional-kqp-kqp_indexes PRIVATE ${CMAKE_SOURCE_DIR}/ydb/tests/functional/kqp/kqp_indexes/main.cpp @@ -51,6 +49,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/tests/functional/kqp/kqp_indexes/CMakeLists.darwin-x86_64.txt b/ydb/tests/functional/kqp/kqp_indexes/CMakeLists.darwin-x86_64.txt index 8767ebd7362a..0f71e365d2e4 100644 --- a/ydb/tests/functional/kqp/kqp_indexes/CMakeLists.darwin-x86_64.txt +++ b/ydb/tests/functional/kqp/kqp_indexes/CMakeLists.darwin-x86_64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-tests-functional-kqp-kqp_indexes PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-tests-functional-kqp-kqp_indexes PRIVATE ${CMAKE_SOURCE_DIR}/ydb/tests/functional/kqp/kqp_indexes/main.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/tests/functional/kqp/kqp_indexes/CMakeLists.linux-aarch64.txt b/ydb/tests/functional/kqp/kqp_indexes/CMakeLists.linux-aarch64.txt index 34359df0fb81..16609b5ac024 100644 --- a/ydb/tests/functional/kqp/kqp_indexes/CMakeLists.linux-aarch64.txt +++ b/ydb/tests/functional/kqp/kqp_indexes/CMakeLists.linux-aarch64.txt @@ -23,9 +23,6 @@ target_link_options(ydb-tests-functional-kqp-kqp_indexes PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-tests-functional-kqp-kqp_indexes PRIVATE ${CMAKE_SOURCE_DIR}/ydb/tests/functional/kqp/kqp_indexes/main.cpp @@ -55,6 +52,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/tests/functional/kqp/kqp_indexes/CMakeLists.linux-x86_64.txt b/ydb/tests/functional/kqp/kqp_indexes/CMakeLists.linux-x86_64.txt index d5fd5a97a6be..37da42290865 100644 --- a/ydb/tests/functional/kqp/kqp_indexes/CMakeLists.linux-x86_64.txt +++ b/ydb/tests/functional/kqp/kqp_indexes/CMakeLists.linux-x86_64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-tests-functional-kqp-kqp_indexes PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-tests-functional-kqp-kqp_indexes PRIVATE ${CMAKE_SOURCE_DIR}/ydb/tests/functional/kqp/kqp_indexes/main.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/tests/functional/kqp/kqp_indexes/CMakeLists.windows-x86_64.txt b/ydb/tests/functional/kqp/kqp_indexes/CMakeLists.windows-x86_64.txt index 9143d82474cd..39b11aeddd7d 100644 --- a/ydb/tests/functional/kqp/kqp_indexes/CMakeLists.windows-x86_64.txt +++ b/ydb/tests/functional/kqp/kqp_indexes/CMakeLists.windows-x86_64.txt @@ -45,6 +45,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/tests/functional/kqp/kqp_query_session/CMakeLists.darwin-arm64.txt b/ydb/tests/functional/kqp/kqp_query_session/CMakeLists.darwin-arm64.txt index 325c63dc74e4..5f6bcbc5f7e1 100644 --- a/ydb/tests/functional/kqp/kqp_query_session/CMakeLists.darwin-arm64.txt +++ b/ydb/tests/functional/kqp/kqp_query_session/CMakeLists.darwin-arm64.txt @@ -21,8 +21,6 @@ target_link_options(ydb-tests-functional-kqp-kqp_query_session PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-tests-functional-kqp-kqp_query_session PRIVATE ${CMAKE_SOURCE_DIR}/ydb/tests/functional/kqp/kqp_query_session/main.cpp @@ -52,6 +50,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/tests/functional/kqp/kqp_query_session/CMakeLists.darwin-x86_64.txt b/ydb/tests/functional/kqp/kqp_query_session/CMakeLists.darwin-x86_64.txt index 6b738edf7e65..cef9887510b1 100644 --- a/ydb/tests/functional/kqp/kqp_query_session/CMakeLists.darwin-x86_64.txt +++ b/ydb/tests/functional/kqp/kqp_query_session/CMakeLists.darwin-x86_64.txt @@ -22,8 +22,6 @@ target_link_options(ydb-tests-functional-kqp-kqp_query_session PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(ydb-tests-functional-kqp-kqp_query_session PRIVATE ${CMAKE_SOURCE_DIR}/ydb/tests/functional/kqp/kqp_query_session/main.cpp @@ -53,6 +51,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/tests/functional/kqp/kqp_query_session/CMakeLists.linux-aarch64.txt b/ydb/tests/functional/kqp/kqp_query_session/CMakeLists.linux-aarch64.txt index 5698f4e5bf0a..5f8e51aa6858 100644 --- a/ydb/tests/functional/kqp/kqp_query_session/CMakeLists.linux-aarch64.txt +++ b/ydb/tests/functional/kqp/kqp_query_session/CMakeLists.linux-aarch64.txt @@ -24,9 +24,6 @@ target_link_options(ydb-tests-functional-kqp-kqp_query_session PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-tests-functional-kqp-kqp_query_session PRIVATE ${CMAKE_SOURCE_DIR}/ydb/tests/functional/kqp/kqp_query_session/main.cpp @@ -56,6 +53,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/tests/functional/kqp/kqp_query_session/CMakeLists.linux-x86_64.txt b/ydb/tests/functional/kqp/kqp_query_session/CMakeLists.linux-x86_64.txt index 07e554c14bfb..34defa601285 100644 --- a/ydb/tests/functional/kqp/kqp_query_session/CMakeLists.linux-x86_64.txt +++ b/ydb/tests/functional/kqp/kqp_query_session/CMakeLists.linux-x86_64.txt @@ -25,9 +25,6 @@ target_link_options(ydb-tests-functional-kqp-kqp_query_session PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(ydb-tests-functional-kqp-kqp_query_session PRIVATE ${CMAKE_SOURCE_DIR}/ydb/tests/functional/kqp/kqp_query_session/main.cpp @@ -57,6 +54,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/tests/functional/kqp/kqp_query_session/CMakeLists.windows-x86_64.txt b/ydb/tests/functional/kqp/kqp_query_session/CMakeLists.windows-x86_64.txt index c99d3c10746f..b34287aeacfc 100644 --- a/ydb/tests/functional/kqp/kqp_query_session/CMakeLists.windows-x86_64.txt +++ b/ydb/tests/functional/kqp/kqp_query_session/CMakeLists.windows-x86_64.txt @@ -46,6 +46,7 @@ set_yunittest_property( PROPERTY LABELS MEDIUM + $FILTER_ONLY_TEST_TAGS ) set_yunittest_property( TEST diff --git a/ydb/tests/tools/idx_test/CMakeLists.darwin-arm64.txt b/ydb/tests/tools/idx_test/CMakeLists.darwin-arm64.txt index 2768da3f4549..ed374566102d 100644 --- a/ydb/tests/tools/idx_test/CMakeLists.darwin-arm64.txt +++ b/ydb/tests/tools/idx_test/CMakeLists.darwin-arm64.txt @@ -28,8 +28,6 @@ target_link_options(idx_test PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(idx_test PRIVATE ${CMAKE_SOURCE_DIR}/ydb/tests/tools/idx_test/main.cpp diff --git a/ydb/tests/tools/idx_test/CMakeLists.darwin-x86_64.txt b/ydb/tests/tools/idx_test/CMakeLists.darwin-x86_64.txt index 85f13fe714fe..6131bddf7d97 100644 --- a/ydb/tests/tools/idx_test/CMakeLists.darwin-x86_64.txt +++ b/ydb/tests/tools/idx_test/CMakeLists.darwin-x86_64.txt @@ -29,8 +29,6 @@ target_link_options(idx_test PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(idx_test PRIVATE ${CMAKE_SOURCE_DIR}/ydb/tests/tools/idx_test/main.cpp diff --git a/ydb/tests/tools/idx_test/CMakeLists.linux-aarch64.txt b/ydb/tests/tools/idx_test/CMakeLists.linux-aarch64.txt index 166ecb0c6e3d..1837dc6302e1 100644 --- a/ydb/tests/tools/idx_test/CMakeLists.linux-aarch64.txt +++ b/ydb/tests/tools/idx_test/CMakeLists.linux-aarch64.txt @@ -31,9 +31,6 @@ target_link_options(idx_test PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(idx_test PRIVATE ${CMAKE_SOURCE_DIR}/ydb/tests/tools/idx_test/main.cpp diff --git a/ydb/tests/tools/idx_test/CMakeLists.linux-x86_64.txt b/ydb/tests/tools/idx_test/CMakeLists.linux-x86_64.txt index 2bd7d6d6b696..5b1dbb68f629 100644 --- a/ydb/tests/tools/idx_test/CMakeLists.linux-x86_64.txt +++ b/ydb/tests/tools/idx_test/CMakeLists.linux-x86_64.txt @@ -32,9 +32,6 @@ target_link_options(idx_test PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(idx_test PRIVATE ${CMAKE_SOURCE_DIR}/ydb/tests/tools/idx_test/main.cpp diff --git a/ydb/tests/tools/kqprun/CMakeLists.darwin-arm64.txt b/ydb/tests/tools/kqprun/CMakeLists.darwin-arm64.txt index 5a353d6292bb..50dbef5f1d2a 100644 --- a/ydb/tests/tools/kqprun/CMakeLists.darwin-arm64.txt +++ b/ydb/tests/tools/kqprun/CMakeLists.darwin-arm64.txt @@ -25,8 +25,6 @@ target_link_options(kqprun PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(kqprun PRIVATE ${CMAKE_SOURCE_DIR}/ydb/tests/tools/kqprun/kqprun.cpp diff --git a/ydb/tests/tools/kqprun/CMakeLists.darwin-x86_64.txt b/ydb/tests/tools/kqprun/CMakeLists.darwin-x86_64.txt index a7019ec48e46..d389b0fbbde7 100644 --- a/ydb/tests/tools/kqprun/CMakeLists.darwin-x86_64.txt +++ b/ydb/tests/tools/kqprun/CMakeLists.darwin-x86_64.txt @@ -26,8 +26,6 @@ target_link_options(kqprun PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(kqprun PRIVATE ${CMAKE_SOURCE_DIR}/ydb/tests/tools/kqprun/kqprun.cpp diff --git a/ydb/tests/tools/kqprun/CMakeLists.linux-aarch64.txt b/ydb/tests/tools/kqprun/CMakeLists.linux-aarch64.txt index b3c1be0871ae..34f64dc93b21 100644 --- a/ydb/tests/tools/kqprun/CMakeLists.linux-aarch64.txt +++ b/ydb/tests/tools/kqprun/CMakeLists.linux-aarch64.txt @@ -28,9 +28,6 @@ target_link_options(kqprun PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(kqprun PRIVATE ${CMAKE_SOURCE_DIR}/ydb/tests/tools/kqprun/kqprun.cpp diff --git a/ydb/tests/tools/kqprun/CMakeLists.linux-x86_64.txt b/ydb/tests/tools/kqprun/CMakeLists.linux-x86_64.txt index b86593352c46..9d1d186123fb 100644 --- a/ydb/tests/tools/kqprun/CMakeLists.linux-x86_64.txt +++ b/ydb/tests/tools/kqprun/CMakeLists.linux-x86_64.txt @@ -29,9 +29,6 @@ target_link_options(kqprun PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(kqprun PRIVATE ${CMAKE_SOURCE_DIR}/ydb/tests/tools/kqprun/kqprun.cpp diff --git a/ydb/tests/tools/pq_read/CMakeLists.darwin-arm64.txt b/ydb/tests/tools/pq_read/CMakeLists.darwin-arm64.txt index ed466635b767..c946b1704d09 100644 --- a/ydb/tests/tools/pq_read/CMakeLists.darwin-arm64.txt +++ b/ydb/tests/tools/pq_read/CMakeLists.darwin-arm64.txt @@ -20,8 +20,6 @@ target_link_options(pq_read PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(pq_read PRIVATE ${CMAKE_SOURCE_DIR}/ydb/tests/tools/pq_read/main.cpp diff --git a/ydb/tests/tools/pq_read/CMakeLists.darwin-x86_64.txt b/ydb/tests/tools/pq_read/CMakeLists.darwin-x86_64.txt index a1834fd6f092..21b5802e571b 100644 --- a/ydb/tests/tools/pq_read/CMakeLists.darwin-x86_64.txt +++ b/ydb/tests/tools/pq_read/CMakeLists.darwin-x86_64.txt @@ -21,8 +21,6 @@ target_link_options(pq_read PRIVATE -Wl,-platform_version,macos,11.0,11.0 -fPIC -fPIC - -framework - CoreFoundation ) target_sources(pq_read PRIVATE ${CMAKE_SOURCE_DIR}/ydb/tests/tools/pq_read/main.cpp diff --git a/ydb/tests/tools/pq_read/CMakeLists.linux-aarch64.txt b/ydb/tests/tools/pq_read/CMakeLists.linux-aarch64.txt index 7427ce0f1c21..cc829d8a0c2d 100644 --- a/ydb/tests/tools/pq_read/CMakeLists.linux-aarch64.txt +++ b/ydb/tests/tools/pq_read/CMakeLists.linux-aarch64.txt @@ -23,9 +23,6 @@ target_link_options(pq_read PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(pq_read PRIVATE ${CMAKE_SOURCE_DIR}/ydb/tests/tools/pq_read/main.cpp diff --git a/ydb/tests/tools/pq_read/CMakeLists.linux-x86_64.txt b/ydb/tests/tools/pq_read/CMakeLists.linux-x86_64.txt index a4436cdee8d4..fbbb7127d013 100644 --- a/ydb/tests/tools/pq_read/CMakeLists.linux-x86_64.txt +++ b/ydb/tests/tools/pq_read/CMakeLists.linux-x86_64.txt @@ -24,9 +24,6 @@ target_link_options(pq_read PRIVATE -Wl,--no-as-needed -fPIC -fPIC - -lpthread - -lrt - -ldl ) target_sources(pq_read PRIVATE ${CMAKE_SOURCE_DIR}/ydb/tests/tools/pq_read/main.cpp diff --git a/ydb/tools/CMakeLists.txt b/ydb/tools/CMakeLists.txt new file mode 100644 index 000000000000..8f630fbba278 --- /dev/null +++ b/ydb/tools/CMakeLists.txt @@ -0,0 +1,10 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(blobsan) +add_subdirectory(tsserver) diff --git a/ydb/tools/blobsan/CMakeLists.darwin-arm64.txt b/ydb/tools/blobsan/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..7fab2b2fd372 --- /dev/null +++ b/ydb/tools/blobsan/CMakeLists.darwin-arm64.txt @@ -0,0 +1,31 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(blobsan) +target_link_libraries(blobsan PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-pop_count + cpp-streams-bzip2 + ydb-core-blobstorage + core-blobstorage-groupinfo + blobstorage-vdisk-query +) +target_link_options(blobsan PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(blobsan PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/tools/blobsan/main.cpp +) +target_allocator(blobsan + system_allocator +) +vcs_info(blobsan) diff --git a/ydb/tools/blobsan/CMakeLists.darwin-x86_64.txt b/ydb/tools/blobsan/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..7d979d0bffc2 --- /dev/null +++ b/ydb/tools/blobsan/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,32 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(blobsan) +target_link_libraries(blobsan PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + library-cpp-pop_count + cpp-streams-bzip2 + ydb-core-blobstorage + core-blobstorage-groupinfo + blobstorage-vdisk-query +) +target_link_options(blobsan PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(blobsan PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/tools/blobsan/main.cpp +) +target_allocator(blobsan + system_allocator +) +vcs_info(blobsan) diff --git a/ydb/tools/blobsan/CMakeLists.linux-aarch64.txt b/ydb/tools/blobsan/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..0b86cfd68151 --- /dev/null +++ b/ydb/tools/blobsan/CMakeLists.linux-aarch64.txt @@ -0,0 +1,34 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(blobsan) +target_link_libraries(blobsan PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-pop_count + cpp-streams-bzip2 + ydb-core-blobstorage + core-blobstorage-groupinfo + blobstorage-vdisk-query +) +target_link_options(blobsan PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(blobsan PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/tools/blobsan/main.cpp +) +target_allocator(blobsan + cpp-malloc-jemalloc +) +vcs_info(blobsan) diff --git a/ydb/tools/blobsan/CMakeLists.linux-x86_64.txt b/ydb/tools/blobsan/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..13ffba6fad4b --- /dev/null +++ b/ydb/tools/blobsan/CMakeLists.linux-x86_64.txt @@ -0,0 +1,36 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(blobsan) +target_link_libraries(blobsan PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + library-cpp-pop_count + cpp-streams-bzip2 + ydb-core-blobstorage + core-blobstorage-groupinfo + blobstorage-vdisk-query +) +target_link_options(blobsan PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(blobsan PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/tools/blobsan/main.cpp +) +target_allocator(blobsan + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(blobsan) diff --git a/ydb/tools/blobsan/CMakeLists.txt b/ydb/tools/blobsan/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/tools/blobsan/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/tools/blobsan/CMakeLists.windows-x86_64.txt b/ydb/tools/blobsan/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..47e3ef1c3045 --- /dev/null +++ b/ydb/tools/blobsan/CMakeLists.windows-x86_64.txt @@ -0,0 +1,27 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(blobsan) +target_link_libraries(blobsan PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + library-cpp-pop_count + cpp-streams-bzip2 + ydb-core-blobstorage + core-blobstorage-groupinfo + blobstorage-vdisk-query +) +target_sources(blobsan PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/tools/blobsan/main.cpp +) +target_allocator(blobsan + system_allocator +) +vcs_info(blobsan) diff --git a/ydb/tools/tsserver/CMakeLists.darwin-arm64.txt b/ydb/tools/tsserver/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..4e333f3ec4de --- /dev/null +++ b/ydb/tools/tsserver/CMakeLists.darwin-arm64.txt @@ -0,0 +1,28 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(tsserver) +target_link_libraries(tsserver PUBLIC + contrib-libs-cxxsupp + yutil + library-actors-interconnect + ydb-core-protos +) +target_link_options(tsserver PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(tsserver PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/tools/tsserver/main.cpp +) +target_allocator(tsserver + system_allocator +) +vcs_info(tsserver) diff --git a/ydb/tools/tsserver/CMakeLists.darwin-x86_64.txt b/ydb/tools/tsserver/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..aaea022802a1 --- /dev/null +++ b/ydb/tools/tsserver/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,29 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(tsserver) +target_link_libraries(tsserver PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + library-actors-interconnect + ydb-core-protos +) +target_link_options(tsserver PRIVATE + -Wl,-platform_version,macos,11.0,11.0 + -fPIC + -fPIC +) +target_sources(tsserver PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/tools/tsserver/main.cpp +) +target_allocator(tsserver + system_allocator +) +vcs_info(tsserver) diff --git a/ydb/tools/tsserver/CMakeLists.linux-aarch64.txt b/ydb/tools/tsserver/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..4cbc886b9552 --- /dev/null +++ b/ydb/tools/tsserver/CMakeLists.linux-aarch64.txt @@ -0,0 +1,31 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(tsserver) +target_link_libraries(tsserver PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-actors-interconnect + ydb-core-protos +) +target_link_options(tsserver PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(tsserver PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/tools/tsserver/main.cpp +) +target_allocator(tsserver + cpp-malloc-jemalloc +) +vcs_info(tsserver) diff --git a/ydb/tools/tsserver/CMakeLists.linux-x86_64.txt b/ydb/tools/tsserver/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..d1da28350c3b --- /dev/null +++ b/ydb/tools/tsserver/CMakeLists.linux-x86_64.txt @@ -0,0 +1,33 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(tsserver) +target_link_libraries(tsserver PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + library-actors-interconnect + ydb-core-protos +) +target_link_options(tsserver PRIVATE + -ldl + -lrt + -Wl,--no-as-needed + -fPIC + -fPIC +) +target_sources(tsserver PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/tools/tsserver/main.cpp +) +target_allocator(tsserver + cpp-malloc-tcmalloc + libs-tcmalloc-no_percpu_cache +) +vcs_info(tsserver) diff --git a/ydb/tools/tsserver/CMakeLists.txt b/ydb/tools/tsserver/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/tools/tsserver/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/tools/tsserver/CMakeLists.windows-x86_64.txt b/ydb/tools/tsserver/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..8eaa76723cf5 --- /dev/null +++ b/ydb/tools/tsserver/CMakeLists.windows-x86_64.txt @@ -0,0 +1,24 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_executable(tsserver) +target_link_libraries(tsserver PUBLIC + contrib-libs-cxxsupp + yutil + library-cpp-cpuid_check + library-actors-interconnect + ydb-core-protos +) +target_sources(tsserver PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/tools/tsserver/main.cpp +) +target_allocator(tsserver + system_allocator +) +vcs_info(tsserver) diff --git a/yt/CMakeLists.txt b/yt/CMakeLists.txt index f7ed775592ef..8e57f8c28a14 100644 --- a/yt/CMakeLists.txt +++ b/yt/CMakeLists.txt @@ -7,6 +7,5 @@ add_subdirectory(cpp) -add_subdirectory(yql) add_subdirectory(yt) add_subdirectory(yt_proto) diff --git a/yt/cpp/mapreduce/client/CMakeLists.linux-aarch64.txt b/yt/cpp/mapreduce/client/CMakeLists.linux-aarch64.txt index 69b08c73ce97..5658f8832893 100644 --- a/yt/cpp/mapreduce/client/CMakeLists.linux-aarch64.txt +++ b/yt/cpp/mapreduce/client/CMakeLists.linux-aarch64.txt @@ -33,7 +33,8 @@ target_link_libraries(cpp-mapreduce-client PUBLIC cpp-mapreduce-io mapreduce-library-table_schema cpp-mapreduce-raw_client - yt_proto-yt-core + yt-yt-core + yt-core-http tools-enum_parser-enum_serialization_runtime ) target_sources(cpp-mapreduce-client PRIVATE diff --git a/yt/cpp/mapreduce/library/table_schema/CMakeLists.darwin-arm64.txt b/yt/cpp/mapreduce/library/table_schema/CMakeLists.darwin-arm64.txt index 92eec36f23b4..d4eae0300f3a 100644 --- a/yt/cpp/mapreduce/library/table_schema/CMakeLists.darwin-arm64.txt +++ b/yt/cpp/mapreduce/library/table_schema/CMakeLists.darwin-arm64.txt @@ -17,5 +17,6 @@ target_link_libraries(mapreduce-library-table_schema PUBLIC cpp-mapreduce-interface ) target_sources(mapreduce-library-table_schema PRIVATE + ${CMAKE_SOURCE_DIR}/yt/cpp/mapreduce/library/table_schema/protobuf.h ${CMAKE_SOURCE_DIR}/yt/cpp/mapreduce/library/table_schema/protobuf.cpp ) diff --git a/yt/cpp/mapreduce/library/table_schema/CMakeLists.darwin-x86_64.txt b/yt/cpp/mapreduce/library/table_schema/CMakeLists.darwin-x86_64.txt index 92eec36f23b4..d4eae0300f3a 100644 --- a/yt/cpp/mapreduce/library/table_schema/CMakeLists.darwin-x86_64.txt +++ b/yt/cpp/mapreduce/library/table_schema/CMakeLists.darwin-x86_64.txt @@ -17,5 +17,6 @@ target_link_libraries(mapreduce-library-table_schema PUBLIC cpp-mapreduce-interface ) target_sources(mapreduce-library-table_schema PRIVATE + ${CMAKE_SOURCE_DIR}/yt/cpp/mapreduce/library/table_schema/protobuf.h ${CMAKE_SOURCE_DIR}/yt/cpp/mapreduce/library/table_schema/protobuf.cpp ) diff --git a/yt/cpp/mapreduce/library/table_schema/CMakeLists.linux-aarch64.txt b/yt/cpp/mapreduce/library/table_schema/CMakeLists.linux-aarch64.txt index 0bb5208c97b7..9ee6030b3ae9 100644 --- a/yt/cpp/mapreduce/library/table_schema/CMakeLists.linux-aarch64.txt +++ b/yt/cpp/mapreduce/library/table_schema/CMakeLists.linux-aarch64.txt @@ -18,5 +18,6 @@ target_link_libraries(mapreduce-library-table_schema PUBLIC cpp-mapreduce-interface ) target_sources(mapreduce-library-table_schema PRIVATE + ${CMAKE_SOURCE_DIR}/yt/cpp/mapreduce/library/table_schema/protobuf.h ${CMAKE_SOURCE_DIR}/yt/cpp/mapreduce/library/table_schema/protobuf.cpp ) diff --git a/yt/cpp/mapreduce/library/table_schema/CMakeLists.linux-x86_64.txt b/yt/cpp/mapreduce/library/table_schema/CMakeLists.linux-x86_64.txt index 0bb5208c97b7..9ee6030b3ae9 100644 --- a/yt/cpp/mapreduce/library/table_schema/CMakeLists.linux-x86_64.txt +++ b/yt/cpp/mapreduce/library/table_schema/CMakeLists.linux-x86_64.txt @@ -18,5 +18,6 @@ target_link_libraries(mapreduce-library-table_schema PUBLIC cpp-mapreduce-interface ) target_sources(mapreduce-library-table_schema PRIVATE + ${CMAKE_SOURCE_DIR}/yt/cpp/mapreduce/library/table_schema/protobuf.h ${CMAKE_SOURCE_DIR}/yt/cpp/mapreduce/library/table_schema/protobuf.cpp ) diff --git a/yt/cpp/mapreduce/library/table_schema/CMakeLists.windows-x86_64.txt b/yt/cpp/mapreduce/library/table_schema/CMakeLists.windows-x86_64.txt index f8288b61f4c9..54d5e9495bae 100644 --- a/yt/cpp/mapreduce/library/table_schema/CMakeLists.windows-x86_64.txt +++ b/yt/cpp/mapreduce/library/table_schema/CMakeLists.windows-x86_64.txt @@ -14,5 +14,6 @@ target_link_libraries(mapreduce-library-table_schema PUBLIC cpp-mapreduce-interface ) target_sources(mapreduce-library-table_schema PRIVATE + ${CMAKE_SOURCE_DIR}/yt/cpp/mapreduce/library/table_schema/protobuf.h ${CMAKE_SOURCE_DIR}/yt/cpp/mapreduce/library/table_schema/protobuf.cpp ) diff --git a/yt/yt/build/CMakeLists.darwin-arm64.txt b/yt/yt/build/CMakeLists.darwin-arm64.txt index 8ab1b502578a..8672f87cd1db 100644 --- a/yt/yt/build/CMakeLists.darwin-arm64.txt +++ b/yt/yt/build/CMakeLists.darwin-arm64.txt @@ -56,11 +56,11 @@ set( ) set( YT_VERSION_MAJOR - 23 + 24 ) set( YT_VERSION_MINOR - 3 + 1 ) set( YT_VERSION_PATCH @@ -83,6 +83,8 @@ target_link_libraries(yt-yt-build PUBLIC yutil ) target_sources(yt-yt-build PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/build/config.h + ${CMAKE_SOURCE_DIR}/yt/yt/build/build.h ${CMAKE_SOURCE_DIR}/yt/yt/build/ya_version.cpp ${CMAKE_BINARY_DIR}/yt/yt/build/build.cpp ) diff --git a/yt/yt/build/CMakeLists.darwin-x86_64.txt b/yt/yt/build/CMakeLists.darwin-x86_64.txt index 8ab1b502578a..8672f87cd1db 100644 --- a/yt/yt/build/CMakeLists.darwin-x86_64.txt +++ b/yt/yt/build/CMakeLists.darwin-x86_64.txt @@ -56,11 +56,11 @@ set( ) set( YT_VERSION_MAJOR - 23 + 24 ) set( YT_VERSION_MINOR - 3 + 1 ) set( YT_VERSION_PATCH @@ -83,6 +83,8 @@ target_link_libraries(yt-yt-build PUBLIC yutil ) target_sources(yt-yt-build PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/build/config.h + ${CMAKE_SOURCE_DIR}/yt/yt/build/build.h ${CMAKE_SOURCE_DIR}/yt/yt/build/ya_version.cpp ${CMAKE_BINARY_DIR}/yt/yt/build/build.cpp ) diff --git a/yt/yt/build/CMakeLists.linux-aarch64.txt b/yt/yt/build/CMakeLists.linux-aarch64.txt index ab1fb3ded158..70b88ce1089d 100644 --- a/yt/yt/build/CMakeLists.linux-aarch64.txt +++ b/yt/yt/build/CMakeLists.linux-aarch64.txt @@ -56,11 +56,11 @@ set( ) set( YT_VERSION_MAJOR - 23 + 24 ) set( YT_VERSION_MINOR - 3 + 1 ) set( YT_VERSION_PATCH @@ -84,6 +84,8 @@ target_link_libraries(yt-yt-build PUBLIC yutil ) target_sources(yt-yt-build PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/build/config.h + ${CMAKE_SOURCE_DIR}/yt/yt/build/build.h ${CMAKE_SOURCE_DIR}/yt/yt/build/ya_version.cpp ${CMAKE_BINARY_DIR}/yt/yt/build/build.cpp ) diff --git a/yt/yt/build/CMakeLists.linux-x86_64.txt b/yt/yt/build/CMakeLists.linux-x86_64.txt index ab1fb3ded158..70b88ce1089d 100644 --- a/yt/yt/build/CMakeLists.linux-x86_64.txt +++ b/yt/yt/build/CMakeLists.linux-x86_64.txt @@ -56,11 +56,11 @@ set( ) set( YT_VERSION_MAJOR - 23 + 24 ) set( YT_VERSION_MINOR - 3 + 1 ) set( YT_VERSION_PATCH @@ -84,6 +84,8 @@ target_link_libraries(yt-yt-build PUBLIC yutil ) target_sources(yt-yt-build PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/build/config.h + ${CMAKE_SOURCE_DIR}/yt/yt/build/build.h ${CMAKE_SOURCE_DIR}/yt/yt/build/ya_version.cpp ${CMAKE_BINARY_DIR}/yt/yt/build/build.cpp ) diff --git a/yt/yt/build/CMakeLists.windows-x86_64.txt b/yt/yt/build/CMakeLists.windows-x86_64.txt index 196a5c4d95c5..35e5fbdda92f 100644 --- a/yt/yt/build/CMakeLists.windows-x86_64.txt +++ b/yt/yt/build/CMakeLists.windows-x86_64.txt @@ -56,11 +56,11 @@ set( ) set( YT_VERSION_MAJOR - 23 + 24 ) set( YT_VERSION_MINOR - 3 + 1 ) set( YT_VERSION_PATCH @@ -80,6 +80,8 @@ target_link_libraries(yt-yt-build PUBLIC yutil ) target_sources(yt-yt-build PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/build/config.h + ${CMAKE_SOURCE_DIR}/yt/yt/build/build.h ${CMAKE_SOURCE_DIR}/yt/yt/build/ya_version.cpp ${CMAKE_BINARY_DIR}/yt/yt/build/build.cpp ) diff --git a/yt/yt/client/CMakeLists.darwin-arm64.txt b/yt/yt/client/CMakeLists.darwin-arm64.txt index 3cfba2d716ba..734c2d2af4d7 100644 --- a/yt/yt/client/CMakeLists.darwin-arm64.txt +++ b/yt/yt/client/CMakeLists.darwin-arm64.txt @@ -50,13 +50,14 @@ target_link_libraries(yt-yt-client PUBLIC contrib-libs-pfr ) target_sources(yt-yt-client PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/client/_/api/rpc_proxy/protocol_version_variables.h ${CMAKE_SOURCE_DIR}/yt/yt/client/api/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/client.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/client_common.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/client_cache.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/delegating_client.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/api/delegating_transaction.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/etc_client.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/client/api/bundle_controller_client.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/journal_client.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/operation_client.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/security_client.cpp @@ -69,8 +70,11 @@ target_sources(yt-yt-client PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rowset.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/skynet.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/transaction.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/api/queue_transaction_mixin.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/api/dynamic_table_transaction_mixin.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/persistent_queue.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/sticky_transaction_pool.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/api/options.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/address_helpers.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/public.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/config.cpp @@ -91,6 +95,8 @@ target_sources(yt-yt-client PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/transaction_impl.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/row_stream.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/wire_row_stream.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/bundle_controller_client/bundle_controller_client.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/bundle_controller_client/bundle_controller_settings.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/election/public.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/hive/timestamp_map.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/hydra/version.cpp @@ -166,6 +172,7 @@ target_sources(yt-yt-client PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/common.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/consumer_client.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/helpers.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/partition_reader.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/queue_rowset.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/ypath/rich.cpp diff --git a/yt/yt/client/CMakeLists.darwin-x86_64.txt b/yt/yt/client/CMakeLists.darwin-x86_64.txt index 3cfba2d716ba..734c2d2af4d7 100644 --- a/yt/yt/client/CMakeLists.darwin-x86_64.txt +++ b/yt/yt/client/CMakeLists.darwin-x86_64.txt @@ -50,13 +50,14 @@ target_link_libraries(yt-yt-client PUBLIC contrib-libs-pfr ) target_sources(yt-yt-client PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/client/_/api/rpc_proxy/protocol_version_variables.h ${CMAKE_SOURCE_DIR}/yt/yt/client/api/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/client.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/client_common.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/client_cache.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/delegating_client.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/api/delegating_transaction.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/etc_client.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/client/api/bundle_controller_client.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/journal_client.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/operation_client.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/security_client.cpp @@ -69,8 +70,11 @@ target_sources(yt-yt-client PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rowset.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/skynet.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/transaction.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/api/queue_transaction_mixin.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/api/dynamic_table_transaction_mixin.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/persistent_queue.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/sticky_transaction_pool.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/api/options.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/address_helpers.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/public.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/config.cpp @@ -91,6 +95,8 @@ target_sources(yt-yt-client PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/transaction_impl.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/row_stream.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/wire_row_stream.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/bundle_controller_client/bundle_controller_client.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/bundle_controller_client/bundle_controller_settings.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/election/public.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/hive/timestamp_map.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/hydra/version.cpp @@ -166,6 +172,7 @@ target_sources(yt-yt-client PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/common.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/consumer_client.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/helpers.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/partition_reader.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/queue_rowset.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/ypath/rich.cpp diff --git a/yt/yt/client/CMakeLists.linux-aarch64.txt b/yt/yt/client/CMakeLists.linux-aarch64.txt index 5e96b7c47dd7..3d38562c3710 100644 --- a/yt/yt/client/CMakeLists.linux-aarch64.txt +++ b/yt/yt/client/CMakeLists.linux-aarch64.txt @@ -52,13 +52,14 @@ target_link_libraries(yt-yt-client PUBLIC contrib-libs-pfr ) target_sources(yt-yt-client PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/client/_/api/rpc_proxy/protocol_version_variables.h ${CMAKE_SOURCE_DIR}/yt/yt/client/api/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/client.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/client_common.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/client_cache.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/delegating_client.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/api/delegating_transaction.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/etc_client.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/client/api/bundle_controller_client.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/journal_client.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/operation_client.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/security_client.cpp @@ -71,8 +72,11 @@ target_sources(yt-yt-client PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rowset.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/skynet.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/transaction.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/api/queue_transaction_mixin.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/api/dynamic_table_transaction_mixin.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/persistent_queue.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/sticky_transaction_pool.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/api/options.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/address_helpers.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/public.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/config.cpp @@ -93,6 +97,8 @@ target_sources(yt-yt-client PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/transaction_impl.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/row_stream.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/wire_row_stream.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/bundle_controller_client/bundle_controller_client.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/bundle_controller_client/bundle_controller_settings.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/election/public.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/hive/timestamp_map.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/hydra/version.cpp @@ -168,6 +174,7 @@ target_sources(yt-yt-client PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/common.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/consumer_client.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/helpers.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/partition_reader.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/queue_rowset.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/ypath/rich.cpp diff --git a/yt/yt/client/CMakeLists.linux-x86_64.txt b/yt/yt/client/CMakeLists.linux-x86_64.txt index 5e96b7c47dd7..3d38562c3710 100644 --- a/yt/yt/client/CMakeLists.linux-x86_64.txt +++ b/yt/yt/client/CMakeLists.linux-x86_64.txt @@ -52,13 +52,14 @@ target_link_libraries(yt-yt-client PUBLIC contrib-libs-pfr ) target_sources(yt-yt-client PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/client/_/api/rpc_proxy/protocol_version_variables.h ${CMAKE_SOURCE_DIR}/yt/yt/client/api/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/client.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/client_common.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/client_cache.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/delegating_client.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/api/delegating_transaction.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/etc_client.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/client/api/bundle_controller_client.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/journal_client.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/operation_client.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/security_client.cpp @@ -71,8 +72,11 @@ target_sources(yt-yt-client PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rowset.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/skynet.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/transaction.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/api/queue_transaction_mixin.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/api/dynamic_table_transaction_mixin.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/persistent_queue.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/sticky_transaction_pool.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/api/options.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/address_helpers.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/public.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/config.cpp @@ -93,6 +97,8 @@ target_sources(yt-yt-client PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/transaction_impl.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/row_stream.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/api/rpc_proxy/wire_row_stream.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/bundle_controller_client/bundle_controller_client.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/bundle_controller_client/bundle_controller_settings.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/election/public.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/hive/timestamp_map.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/hydra/version.cpp @@ -168,6 +174,7 @@ target_sources(yt-yt-client PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/common.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/consumer_client.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/helpers.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/partition_reader.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/queue_client/queue_rowset.cpp ${CMAKE_SOURCE_DIR}/yt/yt/client/ypath/rich.cpp diff --git a/yt/yt/client/arrow/fbs/CMakeLists.linux-aarch64.txt b/yt/yt/client/arrow/fbs/CMakeLists.linux-aarch64.txt index aaa3e3963857..b0d9bf1bc6b3 100644 --- a/yt/yt/client/arrow/fbs/CMakeLists.linux-aarch64.txt +++ b/yt/yt/client/arrow/fbs/CMakeLists.linux-aarch64.txt @@ -39,6 +39,18 @@ target_link_libraries(client-arrow-fbs PUBLIC contrib-libs-flatbuffers ) target_sources(client-arrow-fbs PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Message.fbs.h + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Message.iter.fbs.h + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Schema.fbs.h + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Schema.iter.fbs.h + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Tensor.fbs.h + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Tensor.iter.fbs.h + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/SparseTensor.fbs.h + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/SparseTensor.iter.fbs.h + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Message.bfbs + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Schema.bfbs + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Tensor.bfbs + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/SparseTensor.bfbs ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Message.fbs.cpp ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Schema.fbs.cpp ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Tensor.fbs.cpp diff --git a/yt/yt/client/arrow/fbs/CMakeLists.linux-x86_64.txt b/yt/yt/client/arrow/fbs/CMakeLists.linux-x86_64.txt index aaa3e3963857..b0d9bf1bc6b3 100644 --- a/yt/yt/client/arrow/fbs/CMakeLists.linux-x86_64.txt +++ b/yt/yt/client/arrow/fbs/CMakeLists.linux-x86_64.txt @@ -39,6 +39,18 @@ target_link_libraries(client-arrow-fbs PUBLIC contrib-libs-flatbuffers ) target_sources(client-arrow-fbs PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Message.fbs.h + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Message.iter.fbs.h + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Schema.fbs.h + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Schema.iter.fbs.h + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Tensor.fbs.h + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Tensor.iter.fbs.h + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/SparseTensor.fbs.h + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/SparseTensor.iter.fbs.h + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Message.bfbs + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Schema.bfbs + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Tensor.bfbs + ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/SparseTensor.bfbs ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Message.fbs.cpp ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Schema.fbs.cpp ${CMAKE_BINARY_DIR}/yt/yt/client/arrow/fbs/Tensor.fbs.cpp diff --git a/yt/yt/core/CMakeLists.darwin-arm64.txt b/yt/yt/core/CMakeLists.darwin-arm64.txt index 192a65f02842..df96c9ad5d4e 100644 --- a/yt/yt/core/CMakeLists.darwin-arm64.txt +++ b/yt/yt/core/CMakeLists.darwin-arm64.txt @@ -9,8 +9,6 @@ add_subdirectory(http) add_subdirectory(https) add_subdirectory(misc) -add_subdirectory(rpc) -add_subdirectory(service_discovery) add_library(yt-yt-core) target_compile_options(yt-yt-core PRIVATE @@ -129,7 +127,7 @@ target_sources(yt-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/thread_pool.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/throughput_throttler.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/two_level_fair_share_thread_pool.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/recurring_executor_base.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/retrying_periodic_executor.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/scheduled_executor.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/crypto/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/crypto/crypto.cpp @@ -138,7 +136,6 @@ target_sources(yt-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/formatter.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/fluent_log.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/log_manager.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/logger_owner.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/serializable_logger.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/stream_output.cpp @@ -149,7 +146,6 @@ target_sources(yt-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/zstd_compression.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/arithmetic_formula.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/backoff_strategy.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/backoff_strategy_config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/bitmap.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/bit_packed_unsigned_vector.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/bit_packing.cpp @@ -278,6 +274,7 @@ target_sources(yt-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/string_merger.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/ypath_designated_consumer.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/depth_limiting_yson_consumer.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/list_verb_lazy_yson_consumer.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/attributes_stripper.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/ytree/attribute_consumer.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/ytree/helpers.cpp @@ -367,6 +364,7 @@ target_link_libraries(yt-yt-core.global PUBLIC ) target_sources(yt-yt-core.global PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/log.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/log_manager.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/assert.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/guid.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/ref_tracked.cpp diff --git a/yt/yt/core/CMakeLists.darwin-x86_64.txt b/yt/yt/core/CMakeLists.darwin-x86_64.txt index 0c1266e936c6..223fc5684b26 100644 --- a/yt/yt/core/CMakeLists.darwin-x86_64.txt +++ b/yt/yt/core/CMakeLists.darwin-x86_64.txt @@ -9,8 +9,6 @@ add_subdirectory(http) add_subdirectory(https) add_subdirectory(misc) -add_subdirectory(rpc) -add_subdirectory(service_discovery) add_library(yt-yt-core) target_compile_options(yt-yt-core PRIVATE @@ -130,7 +128,7 @@ target_sources(yt-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/thread_pool.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/throughput_throttler.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/two_level_fair_share_thread_pool.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/recurring_executor_base.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/retrying_periodic_executor.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/scheduled_executor.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/crypto/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/crypto/crypto.cpp @@ -139,7 +137,6 @@ target_sources(yt-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/formatter.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/fluent_log.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/log_manager.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/logger_owner.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/serializable_logger.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/stream_output.cpp @@ -150,7 +147,6 @@ target_sources(yt-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/zstd_compression.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/arithmetic_formula.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/backoff_strategy.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/backoff_strategy_config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/bitmap.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/bit_packed_unsigned_vector.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/bit_packing.cpp @@ -279,6 +275,7 @@ target_sources(yt-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/string_merger.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/ypath_designated_consumer.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/depth_limiting_yson_consumer.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/list_verb_lazy_yson_consumer.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/attributes_stripper.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/ytree/attribute_consumer.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/ytree/helpers.cpp @@ -369,6 +366,7 @@ target_link_libraries(yt-yt-core.global PUBLIC ) target_sources(yt-yt-core.global PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/log.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/log_manager.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/assert.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/guid.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/ref_tracked.cpp diff --git a/yt/yt/core/CMakeLists.linux-aarch64.txt b/yt/yt/core/CMakeLists.linux-aarch64.txt index d2a2d8b06782..c2e7deebc8cf 100644 --- a/yt/yt/core/CMakeLists.linux-aarch64.txt +++ b/yt/yt/core/CMakeLists.linux-aarch64.txt @@ -130,7 +130,7 @@ target_sources(yt-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/thread_pool.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/throughput_throttler.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/two_level_fair_share_thread_pool.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/recurring_executor_base.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/retrying_periodic_executor.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/scheduled_executor.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/crypto/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/crypto/crypto.cpp @@ -139,7 +139,6 @@ target_sources(yt-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/formatter.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/fluent_log.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/log_manager.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/logger_owner.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/serializable_logger.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/stream_output.cpp @@ -150,7 +149,6 @@ target_sources(yt-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/zstd_compression.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/arithmetic_formula.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/backoff_strategy.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/backoff_strategy_config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/bitmap.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/bit_packed_unsigned_vector.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/bit_packing.cpp @@ -279,6 +277,7 @@ target_sources(yt-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/string_merger.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/ypath_designated_consumer.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/depth_limiting_yson_consumer.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/list_verb_lazy_yson_consumer.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/attributes_stripper.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/ytree/attribute_consumer.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/ytree/helpers.cpp @@ -369,6 +368,7 @@ target_link_libraries(yt-yt-core.global PUBLIC ) target_sources(yt-yt-core.global PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/log.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/log_manager.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/assert.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/guid.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/ref_tracked.cpp diff --git a/yt/yt/core/CMakeLists.linux-x86_64.txt b/yt/yt/core/CMakeLists.linux-x86_64.txt index 66f859aadc63..b9a3d369147d 100644 --- a/yt/yt/core/CMakeLists.linux-x86_64.txt +++ b/yt/yt/core/CMakeLists.linux-x86_64.txt @@ -131,7 +131,7 @@ target_sources(yt-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/thread_pool.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/throughput_throttler.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/two_level_fair_share_thread_pool.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/recurring_executor_base.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/retrying_periodic_executor.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/scheduled_executor.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/crypto/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/crypto/crypto.cpp @@ -140,7 +140,6 @@ target_sources(yt-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/formatter.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/fluent_log.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/log_manager.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/logger_owner.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/serializable_logger.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/stream_output.cpp @@ -151,7 +150,6 @@ target_sources(yt-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/zstd_compression.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/arithmetic_formula.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/backoff_strategy.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/backoff_strategy_config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/bitmap.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/bit_packed_unsigned_vector.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/bit_packing.cpp @@ -280,6 +278,7 @@ target_sources(yt-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/string_merger.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/ypath_designated_consumer.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/depth_limiting_yson_consumer.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/list_verb_lazy_yson_consumer.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/attributes_stripper.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/ytree/attribute_consumer.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/ytree/helpers.cpp @@ -371,6 +370,7 @@ target_link_libraries(yt-yt-core.global PUBLIC ) target_sources(yt-yt-core.global PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/log.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/log_manager.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/assert.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/guid.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/ref_tracked.cpp diff --git a/yt/yt/core/CMakeLists.windows-x86_64.txt b/yt/yt/core/CMakeLists.windows-x86_64.txt index 6c965d6cbf17..0ecf60c88904 100644 --- a/yt/yt/core/CMakeLists.windows-x86_64.txt +++ b/yt/yt/core/CMakeLists.windows-x86_64.txt @@ -9,8 +9,6 @@ add_subdirectory(http) add_subdirectory(https) add_subdirectory(misc) -add_subdirectory(rpc) -add_subdirectory(service_discovery) add_library(yt-yt-core) target_compile_options(yt-yt-core PRIVATE @@ -129,7 +127,7 @@ target_sources(yt-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/thread_pool.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/throughput_throttler.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/two_level_fair_share_thread_pool.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/recurring_executor_base.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/retrying_periodic_executor.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/concurrency/scheduled_executor.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/crypto/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/crypto/crypto.cpp @@ -138,7 +136,6 @@ target_sources(yt-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/formatter.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/fluent_log.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/log_manager.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/logger_owner.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/serializable_logger.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/stream_output.cpp @@ -149,7 +146,6 @@ target_sources(yt-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/zstd_compression.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/arithmetic_formula.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/backoff_strategy.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/backoff_strategy_config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/bitmap.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/bit_packed_unsigned_vector.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/bit_packing.cpp @@ -278,6 +274,7 @@ target_sources(yt-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/string_merger.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/ypath_designated_consumer.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/depth_limiting_yson_consumer.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/list_verb_lazy_yson_consumer.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/yson/attributes_stripper.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/ytree/attribute_consumer.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/ytree/helpers.cpp @@ -367,6 +364,7 @@ target_link_libraries(yt-yt-core.global PUBLIC ) target_sources(yt-yt-core.global PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/log.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/logging/log_manager.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/assert.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/guid.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/misc/ref_tracked.cpp diff --git a/yt/yt/core/http/CMakeLists.darwin-arm64.txt b/yt/yt/core/http/CMakeLists.darwin-arm64.txt index 92bee16f81be..1e2c6230cb37 100644 --- a/yt/yt/core/http/CMakeLists.darwin-arm64.txt +++ b/yt/yt/core/http/CMakeLists.darwin-arm64.txt @@ -14,17 +14,20 @@ target_compile_options(yt-core-http PRIVATE target_link_libraries(yt-core-http PUBLIC contrib-libs-cxxsupp yutil + cpp-blockcodecs-core yt-yt-core contrib-restricted-http-parser ) target_sources(yt-core-http PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/http/client.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/http/compression.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/connection_pool.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/connection_reuse_helpers.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/http/helpers.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/http.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/retrying_client.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/server.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/stream.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/core/http/helpers.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/http/compression_opensource.cpp ) diff --git a/yt/yt/core/http/CMakeLists.darwin-x86_64.txt b/yt/yt/core/http/CMakeLists.darwin-x86_64.txt index 92bee16f81be..1e2c6230cb37 100644 --- a/yt/yt/core/http/CMakeLists.darwin-x86_64.txt +++ b/yt/yt/core/http/CMakeLists.darwin-x86_64.txt @@ -14,17 +14,20 @@ target_compile_options(yt-core-http PRIVATE target_link_libraries(yt-core-http PUBLIC contrib-libs-cxxsupp yutil + cpp-blockcodecs-core yt-yt-core contrib-restricted-http-parser ) target_sources(yt-core-http PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/http/client.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/http/compression.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/connection_pool.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/connection_reuse_helpers.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/http/helpers.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/http.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/retrying_client.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/server.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/stream.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/core/http/helpers.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/http/compression_opensource.cpp ) diff --git a/yt/yt/core/http/CMakeLists.linux-aarch64.txt b/yt/yt/core/http/CMakeLists.linux-aarch64.txt index 26808f57201e..0beecf51829d 100644 --- a/yt/yt/core/http/CMakeLists.linux-aarch64.txt +++ b/yt/yt/core/http/CMakeLists.linux-aarch64.txt @@ -15,17 +15,20 @@ target_link_libraries(yt-core-http PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + cpp-blockcodecs-core yt-yt-core contrib-restricted-http-parser ) target_sources(yt-core-http PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/http/client.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/http/compression.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/connection_pool.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/connection_reuse_helpers.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/http/helpers.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/http.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/retrying_client.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/server.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/stream.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/core/http/helpers.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/http/compression_opensource.cpp ) diff --git a/yt/yt/core/http/CMakeLists.linux-x86_64.txt b/yt/yt/core/http/CMakeLists.linux-x86_64.txt index 26808f57201e..0beecf51829d 100644 --- a/yt/yt/core/http/CMakeLists.linux-x86_64.txt +++ b/yt/yt/core/http/CMakeLists.linux-x86_64.txt @@ -15,17 +15,20 @@ target_link_libraries(yt-core-http PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + cpp-blockcodecs-core yt-yt-core contrib-restricted-http-parser ) target_sources(yt-core-http PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/http/client.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/http/compression.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/connection_pool.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/connection_reuse_helpers.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/http/helpers.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/http.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/retrying_client.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/server.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/stream.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/core/http/helpers.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/http/compression_opensource.cpp ) diff --git a/yt/yt/core/http/CMakeLists.windows-x86_64.txt b/yt/yt/core/http/CMakeLists.windows-x86_64.txt index 3a283cbd21f9..be289e0c2e51 100644 --- a/yt/yt/core/http/CMakeLists.windows-x86_64.txt +++ b/yt/yt/core/http/CMakeLists.windows-x86_64.txt @@ -11,17 +11,20 @@ add_library(yt-core-http) target_link_libraries(yt-core-http PUBLIC contrib-libs-cxxsupp yutil + cpp-blockcodecs-core yt-yt-core contrib-restricted-http-parser ) target_sources(yt-core-http PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/http/client.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/http/compression.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/connection_pool.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/connection_reuse_helpers.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/http/helpers.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/http.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/retrying_client.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/server.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/http/stream.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/core/http/helpers.cpp + ${CMAKE_SOURCE_DIR}/yt/yt/core/http/compression_opensource.cpp ) diff --git a/library/cpp/clickhouse/CMakeLists.linux-aarch64.txt b/yt/yt/core/rpc/CMakeLists.linux-aarch64.txt similarity index 94% rename from library/cpp/clickhouse/CMakeLists.linux-aarch64.txt rename to yt/yt/core/rpc/CMakeLists.linux-aarch64.txt index 7f79107ebc79..68ea682099d0 100644 --- a/library/cpp/clickhouse/CMakeLists.linux-aarch64.txt +++ b/yt/yt/core/rpc/CMakeLists.linux-aarch64.txt @@ -6,4 +6,4 @@ # original buildsystem will not be accepted. -add_subdirectory(client) +add_subdirectory(grpc) diff --git a/library/cpp/clickhouse/CMakeLists.linux-x86_64.txt b/yt/yt/core/rpc/CMakeLists.linux-x86_64.txt similarity index 94% rename from library/cpp/clickhouse/CMakeLists.linux-x86_64.txt rename to yt/yt/core/rpc/CMakeLists.linux-x86_64.txt index 7f79107ebc79..68ea682099d0 100644 --- a/library/cpp/clickhouse/CMakeLists.linux-x86_64.txt +++ b/yt/yt/core/rpc/CMakeLists.linux-x86_64.txt @@ -6,4 +6,4 @@ # original buildsystem will not be accepted. -add_subdirectory(client) +add_subdirectory(grpc) diff --git a/yt/yt/core/rpc/CMakeLists.txt b/yt/yt/core/rpc/CMakeLists.txt index 68ea682099d0..d6c5c0bbeb44 100644 --- a/yt/yt/core/rpc/CMakeLists.txt +++ b/yt/yt/core/rpc/CMakeLists.txt @@ -6,4 +6,8 @@ # original buildsystem will not be accepted. -add_subdirectory(grpc) +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +endif() diff --git a/yt/yt/core/rpc/grpc/CMakeLists.linux-aarch64.txt b/yt/yt/core/rpc/grpc/CMakeLists.linux-aarch64.txt index 5f274b5b3ea6..0a33b013e88e 100644 --- a/yt/yt/core/rpc/grpc/CMakeLists.linux-aarch64.txt +++ b/yt/yt/core/rpc/grpc/CMakeLists.linux-aarch64.txt @@ -42,6 +42,7 @@ target_proto_messages(core-rpc-grpc PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/rpc/grpc/proto/grpc.proto ) target_sources(core-rpc-grpc PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/core/rpc/grpc/proto/grpc.pb.h ${CMAKE_SOURCE_DIR}/yt/yt/core/rpc/grpc/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/rpc/grpc/public.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/rpc/grpc/dispatcher.cpp diff --git a/yt/yt/core/rpc/grpc/CMakeLists.linux-x86_64.txt b/yt/yt/core/rpc/grpc/CMakeLists.linux-x86_64.txt index 5f274b5b3ea6..0a33b013e88e 100644 --- a/yt/yt/core/rpc/grpc/CMakeLists.linux-x86_64.txt +++ b/yt/yt/core/rpc/grpc/CMakeLists.linux-x86_64.txt @@ -42,6 +42,7 @@ target_proto_messages(core-rpc-grpc PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/core/rpc/grpc/proto/grpc.proto ) target_sources(core-rpc-grpc PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/core/rpc/grpc/proto/grpc.pb.h ${CMAKE_SOURCE_DIR}/yt/yt/core/rpc/grpc/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/rpc/grpc/public.cpp ${CMAKE_SOURCE_DIR}/yt/yt/core/rpc/grpc/dispatcher.cpp diff --git a/yt/yt/core/rpc/grpc/CMakeLists.txt b/yt/yt/core/rpc/grpc/CMakeLists.txt index d863ebd18067..d6c5c0bbeb44 100644 --- a/yt/yt/core/rpc/grpc/CMakeLists.txt +++ b/yt/yt/core/rpc/grpc/CMakeLists.txt @@ -10,10 +10,4 @@ if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_ include(CMakeLists.linux-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) endif() diff --git a/yt/yt/core/service_discovery/CMakeLists.linux-aarch64.txt b/yt/yt/core/service_discovery/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..7f1d154d54ba --- /dev/null +++ b/yt/yt/core/service_discovery/CMakeLists.linux-aarch64.txt @@ -0,0 +1,9 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(yp) diff --git a/yt/yt/core/service_discovery/CMakeLists.linux-x86_64.txt b/yt/yt/core/service_discovery/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..7f1d154d54ba --- /dev/null +++ b/yt/yt/core/service_discovery/CMakeLists.linux-x86_64.txt @@ -0,0 +1,9 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +add_subdirectory(yp) diff --git a/yt/yt/core/service_discovery/CMakeLists.txt b/yt/yt/core/service_discovery/CMakeLists.txt index 7f1d154d54ba..d6c5c0bbeb44 100644 --- a/yt/yt/core/service_discovery/CMakeLists.txt +++ b/yt/yt/core/service_discovery/CMakeLists.txt @@ -6,4 +6,8 @@ # original buildsystem will not be accepted. -add_subdirectory(yp) +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +endif() diff --git a/yt/yt/core/service_discovery/yp/CMakeLists.txt b/yt/yt/core/service_discovery/yp/CMakeLists.txt index d863ebd18067..d6c5c0bbeb44 100644 --- a/yt/yt/core/service_discovery/yp/CMakeLists.txt +++ b/yt/yt/core/service_discovery/yp/CMakeLists.txt @@ -10,10 +10,4 @@ if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_ include(CMakeLists.linux-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) endif() diff --git a/yt/yt/library/CMakeLists.darwin-arm64.txt b/yt/yt/library/CMakeLists.darwin-arm64.txt index a85455d5cbc5..d26f3bae2884 100644 --- a/yt/yt/library/CMakeLists.darwin-arm64.txt +++ b/yt/yt/library/CMakeLists.darwin-arm64.txt @@ -9,10 +9,8 @@ add_subdirectory(auth) add_subdirectory(decimal) add_subdirectory(erasure) -add_subdirectory(monitoring) add_subdirectory(numeric) add_subdirectory(profiling) -add_subdirectory(program) add_subdirectory(quantile_digest) add_subdirectory(re2) add_subdirectory(syncmap) diff --git a/yt/yt/library/CMakeLists.darwin-x86_64.txt b/yt/yt/library/CMakeLists.darwin-x86_64.txt index a85455d5cbc5..d26f3bae2884 100644 --- a/yt/yt/library/CMakeLists.darwin-x86_64.txt +++ b/yt/yt/library/CMakeLists.darwin-x86_64.txt @@ -9,10 +9,8 @@ add_subdirectory(auth) add_subdirectory(decimal) add_subdirectory(erasure) -add_subdirectory(monitoring) add_subdirectory(numeric) add_subdirectory(profiling) -add_subdirectory(program) add_subdirectory(quantile_digest) add_subdirectory(re2) add_subdirectory(syncmap) diff --git a/yt/yt/library/CMakeLists.windows-x86_64.txt b/yt/yt/library/CMakeLists.windows-x86_64.txt index eaf7bb9e34c3..20f7fe76faf9 100644 --- a/yt/yt/library/CMakeLists.windows-x86_64.txt +++ b/yt/yt/library/CMakeLists.windows-x86_64.txt @@ -6,9 +6,7 @@ # original buildsystem will not be accepted. -add_subdirectory(monitoring) add_subdirectory(profiling) -add_subdirectory(program) add_subdirectory(syncmap) add_subdirectory(tracing) add_subdirectory(tvm) diff --git a/yt/yt/library/monitoring/CMakeLists.txt b/yt/yt/library/monitoring/CMakeLists.txt index d863ebd18067..d6c5c0bbeb44 100644 --- a/yt/yt/library/monitoring/CMakeLists.txt +++ b/yt/yt/library/monitoring/CMakeLists.txt @@ -10,10 +10,4 @@ if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_ include(CMakeLists.linux-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) endif() diff --git a/yt/yt/library/profiling/CMakeLists.darwin-arm64.txt b/yt/yt/library/profiling/CMakeLists.darwin-arm64.txt index 0f1318b348d4..bafd86d3101a 100644 --- a/yt/yt/library/profiling/CMakeLists.darwin-arm64.txt +++ b/yt/yt/library/profiling/CMakeLists.darwin-arm64.txt @@ -6,10 +6,7 @@ # original buildsystem will not be accepted. -add_subdirectory(perf) add_subdirectory(resource_tracker) -add_subdirectory(solomon) -add_subdirectory(tcmalloc) add_library(yt-library-profiling) target_compile_options(yt-library-profiling PRIVATE diff --git a/yt/yt/library/profiling/CMakeLists.darwin-x86_64.txt b/yt/yt/library/profiling/CMakeLists.darwin-x86_64.txt index 0f1318b348d4..bafd86d3101a 100644 --- a/yt/yt/library/profiling/CMakeLists.darwin-x86_64.txt +++ b/yt/yt/library/profiling/CMakeLists.darwin-x86_64.txt @@ -6,10 +6,7 @@ # original buildsystem will not be accepted. -add_subdirectory(perf) add_subdirectory(resource_tracker) -add_subdirectory(solomon) -add_subdirectory(tcmalloc) add_library(yt-library-profiling) target_compile_options(yt-library-profiling PRIVATE diff --git a/yt/yt/library/profiling/CMakeLists.windows-x86_64.txt b/yt/yt/library/profiling/CMakeLists.windows-x86_64.txt index 34e12beaad46..6a6f1a6dde8b 100644 --- a/yt/yt/library/profiling/CMakeLists.windows-x86_64.txt +++ b/yt/yt/library/profiling/CMakeLists.windows-x86_64.txt @@ -6,10 +6,7 @@ # original buildsystem will not be accepted. -add_subdirectory(perf) add_subdirectory(resource_tracker) -add_subdirectory(solomon) -add_subdirectory(tcmalloc) add_library(yt-library-profiling) target_link_libraries(yt-library-profiling PUBLIC diff --git a/yt/yt/library/profiling/perf/CMakeLists.txt b/yt/yt/library/profiling/perf/CMakeLists.txt index d863ebd18067..d6c5c0bbeb44 100644 --- a/yt/yt/library/profiling/perf/CMakeLists.txt +++ b/yt/yt/library/profiling/perf/CMakeLists.txt @@ -10,10 +10,4 @@ if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_ include(CMakeLists.linux-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) endif() diff --git a/yt/yt/library/profiling/solomon/CMakeLists.linux-aarch64.txt b/yt/yt/library/profiling/solomon/CMakeLists.linux-aarch64.txt index 57e8fb3c6e6a..424b763eccce 100644 --- a/yt/yt/library/profiling/solomon/CMakeLists.linux-aarch64.txt +++ b/yt/yt/library/profiling/solomon/CMakeLists.linux-aarch64.txt @@ -42,6 +42,7 @@ target_proto_messages(library-profiling-solomon PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/library/profiling/solomon/sensor_dump.proto ) target_sources(library-profiling-solomon PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/library/profiling/solomon/sensor_dump.pb.h ${CMAKE_SOURCE_DIR}/yt/yt/library/profiling/solomon/cube.cpp ${CMAKE_SOURCE_DIR}/yt/yt/library/profiling/solomon/exporter.cpp ${CMAKE_SOURCE_DIR}/yt/yt/library/profiling/solomon/percpu.cpp diff --git a/yt/yt/library/profiling/solomon/CMakeLists.linux-x86_64.txt b/yt/yt/library/profiling/solomon/CMakeLists.linux-x86_64.txt index 57e8fb3c6e6a..424b763eccce 100644 --- a/yt/yt/library/profiling/solomon/CMakeLists.linux-x86_64.txt +++ b/yt/yt/library/profiling/solomon/CMakeLists.linux-x86_64.txt @@ -42,6 +42,7 @@ target_proto_messages(library-profiling-solomon PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/library/profiling/solomon/sensor_dump.proto ) target_sources(library-profiling-solomon PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/library/profiling/solomon/sensor_dump.pb.h ${CMAKE_SOURCE_DIR}/yt/yt/library/profiling/solomon/cube.cpp ${CMAKE_SOURCE_DIR}/yt/yt/library/profiling/solomon/exporter.cpp ${CMAKE_SOURCE_DIR}/yt/yt/library/profiling/solomon/percpu.cpp diff --git a/yt/yt/library/profiling/solomon/CMakeLists.txt b/yt/yt/library/profiling/solomon/CMakeLists.txt index d863ebd18067..d6c5c0bbeb44 100644 --- a/yt/yt/library/profiling/solomon/CMakeLists.txt +++ b/yt/yt/library/profiling/solomon/CMakeLists.txt @@ -10,10 +10,4 @@ if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_ include(CMakeLists.linux-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) endif() diff --git a/yt/yt/library/profiling/tcmalloc/CMakeLists.txt b/yt/yt/library/profiling/tcmalloc/CMakeLists.txt index d863ebd18067..d6c5c0bbeb44 100644 --- a/yt/yt/library/profiling/tcmalloc/CMakeLists.txt +++ b/yt/yt/library/profiling/tcmalloc/CMakeLists.txt @@ -10,10 +10,4 @@ if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_ include(CMakeLists.linux-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) endif() diff --git a/yt/yt/library/program/CMakeLists.linux-aarch64.txt b/yt/yt/library/program/CMakeLists.linux-aarch64.txt index 7c15fb8b7dcb..7fb1fadf4026 100644 --- a/yt/yt/library/program/CMakeLists.linux-aarch64.txt +++ b/yt/yt/library/program/CMakeLists.linux-aarch64.txt @@ -26,6 +26,7 @@ target_link_libraries(yt-library-program PUBLIC cpp-yt-mlock cpp-yt-stockpile cpp-yt-string + cpp-getopt-small ) target_sources(yt-library-program PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/library/program/build_attributes.cpp diff --git a/yt/yt/library/program/CMakeLists.linux-x86_64.txt b/yt/yt/library/program/CMakeLists.linux-x86_64.txt index 7c15fb8b7dcb..7fb1fadf4026 100644 --- a/yt/yt/library/program/CMakeLists.linux-x86_64.txt +++ b/yt/yt/library/program/CMakeLists.linux-x86_64.txt @@ -26,6 +26,7 @@ target_link_libraries(yt-library-program PUBLIC cpp-yt-mlock cpp-yt-stockpile cpp-yt-string + cpp-getopt-small ) target_sources(yt-library-program PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/library/program/build_attributes.cpp diff --git a/yt/yt/library/program/CMakeLists.txt b/yt/yt/library/program/CMakeLists.txt index d863ebd18067..d6c5c0bbeb44 100644 --- a/yt/yt/library/program/CMakeLists.txt +++ b/yt/yt/library/program/CMakeLists.txt @@ -10,10 +10,4 @@ if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_ include(CMakeLists.linux-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) endif() diff --git a/yt/yt/library/quantile_digest/CMakeLists.darwin-arm64.txt b/yt/yt/library/quantile_digest/CMakeLists.darwin-arm64.txt index ceac4e685a65..11ec841ff259 100644 --- a/yt/yt/library/quantile_digest/CMakeLists.darwin-arm64.txt +++ b/yt/yt/library/quantile_digest/CMakeLists.darwin-arm64.txt @@ -35,6 +35,7 @@ target_proto_messages(yt-library-quantile_digest PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/library/quantile_digest/proto/quantile_digest.proto ) target_sources(yt-library-quantile_digest PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/library/quantile_digest/proto/quantile_digest.pb.h ${CMAKE_SOURCE_DIR}/yt/yt/library/quantile_digest/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/library/quantile_digest/quantile_digest.cpp ) diff --git a/yt/yt/library/quantile_digest/CMakeLists.darwin-x86_64.txt b/yt/yt/library/quantile_digest/CMakeLists.darwin-x86_64.txt index ceac4e685a65..11ec841ff259 100644 --- a/yt/yt/library/quantile_digest/CMakeLists.darwin-x86_64.txt +++ b/yt/yt/library/quantile_digest/CMakeLists.darwin-x86_64.txt @@ -35,6 +35,7 @@ target_proto_messages(yt-library-quantile_digest PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/library/quantile_digest/proto/quantile_digest.proto ) target_sources(yt-library-quantile_digest PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/library/quantile_digest/proto/quantile_digest.pb.h ${CMAKE_SOURCE_DIR}/yt/yt/library/quantile_digest/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/library/quantile_digest/quantile_digest.cpp ) diff --git a/yt/yt/library/quantile_digest/CMakeLists.linux-aarch64.txt b/yt/yt/library/quantile_digest/CMakeLists.linux-aarch64.txt index c0f1ecf93230..9605c37b0f5e 100644 --- a/yt/yt/library/quantile_digest/CMakeLists.linux-aarch64.txt +++ b/yt/yt/library/quantile_digest/CMakeLists.linux-aarch64.txt @@ -36,6 +36,7 @@ target_proto_messages(yt-library-quantile_digest PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/library/quantile_digest/proto/quantile_digest.proto ) target_sources(yt-library-quantile_digest PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/library/quantile_digest/proto/quantile_digest.pb.h ${CMAKE_SOURCE_DIR}/yt/yt/library/quantile_digest/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/library/quantile_digest/quantile_digest.cpp ) diff --git a/yt/yt/library/quantile_digest/CMakeLists.linux-x86_64.txt b/yt/yt/library/quantile_digest/CMakeLists.linux-x86_64.txt index c0f1ecf93230..9605c37b0f5e 100644 --- a/yt/yt/library/quantile_digest/CMakeLists.linux-x86_64.txt +++ b/yt/yt/library/quantile_digest/CMakeLists.linux-x86_64.txt @@ -36,6 +36,7 @@ target_proto_messages(yt-library-quantile_digest PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/library/quantile_digest/proto/quantile_digest.proto ) target_sources(yt-library-quantile_digest PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/library/quantile_digest/proto/quantile_digest.pb.h ${CMAKE_SOURCE_DIR}/yt/yt/library/quantile_digest/config.cpp ${CMAKE_SOURCE_DIR}/yt/yt/library/quantile_digest/quantile_digest.cpp ) diff --git a/yt/yt/library/tracing/CMakeLists.darwin-arm64.txt b/yt/yt/library/tracing/CMakeLists.darwin-arm64.txt index 68eb83d1718d..54f67f1ec567 100644 --- a/yt/yt/library/tracing/CMakeLists.darwin-arm64.txt +++ b/yt/yt/library/tracing/CMakeLists.darwin-arm64.txt @@ -6,7 +6,6 @@ # original buildsystem will not be accepted. -add_subdirectory(jaeger) add_library(yt-library-tracing) target_compile_options(yt-library-tracing PRIVATE diff --git a/yt/yt/library/tracing/CMakeLists.darwin-x86_64.txt b/yt/yt/library/tracing/CMakeLists.darwin-x86_64.txt index 68eb83d1718d..54f67f1ec567 100644 --- a/yt/yt/library/tracing/CMakeLists.darwin-x86_64.txt +++ b/yt/yt/library/tracing/CMakeLists.darwin-x86_64.txt @@ -6,7 +6,6 @@ # original buildsystem will not be accepted. -add_subdirectory(jaeger) add_library(yt-library-tracing) target_compile_options(yt-library-tracing PRIVATE diff --git a/yt/yt/library/tracing/CMakeLists.windows-x86_64.txt b/yt/yt/library/tracing/CMakeLists.windows-x86_64.txt index 0adf7dc67a19..e33cbed391f1 100644 --- a/yt/yt/library/tracing/CMakeLists.windows-x86_64.txt +++ b/yt/yt/library/tracing/CMakeLists.windows-x86_64.txt @@ -6,7 +6,6 @@ # original buildsystem will not be accepted. -add_subdirectory(jaeger) add_library(yt-library-tracing) target_link_libraries(yt-library-tracing PUBLIC diff --git a/yt/yt/library/tracing/jaeger/CMakeLists.linux-aarch64.txt b/yt/yt/library/tracing/jaeger/CMakeLists.linux-aarch64.txt index 2dfa2a2dc20f..9e30012ee44c 100644 --- a/yt/yt/library/tracing/jaeger/CMakeLists.linux-aarch64.txt +++ b/yt/yt/library/tracing/jaeger/CMakeLists.linux-aarch64.txt @@ -36,6 +36,7 @@ target_proto_messages(library-tracing-jaeger PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/library/tracing/jaeger/model.proto ) target_sources(library-tracing-jaeger PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/library/tracing/jaeger/model.pb.h ${CMAKE_SOURCE_DIR}/yt/yt/library/tracing/jaeger/sampler.cpp ) target_proto_addincls(library-tracing-jaeger diff --git a/yt/yt/library/tracing/jaeger/CMakeLists.linux-x86_64.txt b/yt/yt/library/tracing/jaeger/CMakeLists.linux-x86_64.txt index 2dfa2a2dc20f..9e30012ee44c 100644 --- a/yt/yt/library/tracing/jaeger/CMakeLists.linux-x86_64.txt +++ b/yt/yt/library/tracing/jaeger/CMakeLists.linux-x86_64.txt @@ -36,6 +36,7 @@ target_proto_messages(library-tracing-jaeger PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/library/tracing/jaeger/model.proto ) target_sources(library-tracing-jaeger PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/library/tracing/jaeger/model.pb.h ${CMAKE_SOURCE_DIR}/yt/yt/library/tracing/jaeger/sampler.cpp ) target_proto_addincls(library-tracing-jaeger diff --git a/yt/yt/library/tracing/jaeger/CMakeLists.txt b/yt/yt/library/tracing/jaeger/CMakeLists.txt index d863ebd18067..d6c5c0bbeb44 100644 --- a/yt/yt/library/tracing/jaeger/CMakeLists.txt +++ b/yt/yt/library/tracing/jaeger/CMakeLists.txt @@ -10,10 +10,4 @@ if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_ include(CMakeLists.linux-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) endif() diff --git a/yt/yt/library/tvm/CMakeLists.darwin-arm64.txt b/yt/yt/library/tvm/CMakeLists.darwin-arm64.txt index 5f6d73b807ff..f92c150fd39d 100644 --- a/yt/yt/library/tvm/CMakeLists.darwin-arm64.txt +++ b/yt/yt/library/tvm/CMakeLists.darwin-arm64.txt @@ -6,7 +6,6 @@ # original buildsystem will not be accepted. -add_subdirectory(service) add_library(yt-library-tvm) target_compile_options(yt-library-tvm PRIVATE diff --git a/yt/yt/library/tvm/CMakeLists.darwin-x86_64.txt b/yt/yt/library/tvm/CMakeLists.darwin-x86_64.txt index 5f6d73b807ff..f92c150fd39d 100644 --- a/yt/yt/library/tvm/CMakeLists.darwin-x86_64.txt +++ b/yt/yt/library/tvm/CMakeLists.darwin-x86_64.txt @@ -6,7 +6,6 @@ # original buildsystem will not be accepted. -add_subdirectory(service) add_library(yt-library-tvm) target_compile_options(yt-library-tvm PRIVATE diff --git a/yt/yt/library/tvm/CMakeLists.windows-x86_64.txt b/yt/yt/library/tvm/CMakeLists.windows-x86_64.txt index 6f1972e2a8de..5b92f509ce56 100644 --- a/yt/yt/library/tvm/CMakeLists.windows-x86_64.txt +++ b/yt/yt/library/tvm/CMakeLists.windows-x86_64.txt @@ -6,7 +6,6 @@ # original buildsystem will not be accepted. -add_subdirectory(service) add_library(yt-library-tvm) target_link_libraries(yt-library-tvm PUBLIC diff --git a/yt/yt/library/tvm/service/CMakeLists.txt b/yt/yt/library/tvm/service/CMakeLists.txt index d863ebd18067..d6c5c0bbeb44 100644 --- a/yt/yt/library/tvm/service/CMakeLists.txt +++ b/yt/yt/library/tvm/service/CMakeLists.txt @@ -10,10 +10,4 @@ if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_ include(CMakeLists.linux-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) endif() diff --git a/yt/yt/library/ytprof/CMakeLists.darwin-arm64.txt b/yt/yt/library/ytprof/CMakeLists.darwin-arm64.txt index ac3d970f128b..dbfb934baea2 100644 --- a/yt/yt/library/ytprof/CMakeLists.darwin-arm64.txt +++ b/yt/yt/library/ytprof/CMakeLists.darwin-arm64.txt @@ -7,35 +7,3 @@ add_subdirectory(api) -add_subdirectory(proto) - -add_library(yt-library-ytprof) -target_compile_options(yt-library-ytprof PRIVATE - -Wdeprecated-this-capture - -DYTPROF_BUILD_TYPE="RELEASE" -) -target_link_libraries(yt-library-ytprof PUBLIC - contrib-libs-cxxsupp - yutil - cpp-yt-memory - cpp-yt-threading - backtrace-cursors-interop - backtrace-cursors-frame_pointer - backtrace-cursors-libunwind - library-ytprof-api - library-ytprof-proto - contrib-libs-libunwind - libs-tcmalloc-malloc_extension - library-cpp-svnversion - yt-yt-core -) -target_sources(yt-library-ytprof PRIVATE - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/signal_safe_profiler.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/cpu_profiler.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/heap_profiler.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/spinlock_profiler.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/profile.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/build_info.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/external_pprof.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/symbolize_other.cpp -) diff --git a/yt/yt/library/ytprof/CMakeLists.darwin-x86_64.txt b/yt/yt/library/ytprof/CMakeLists.darwin-x86_64.txt index ac3d970f128b..dbfb934baea2 100644 --- a/yt/yt/library/ytprof/CMakeLists.darwin-x86_64.txt +++ b/yt/yt/library/ytprof/CMakeLists.darwin-x86_64.txt @@ -7,35 +7,3 @@ add_subdirectory(api) -add_subdirectory(proto) - -add_library(yt-library-ytprof) -target_compile_options(yt-library-ytprof PRIVATE - -Wdeprecated-this-capture - -DYTPROF_BUILD_TYPE="RELEASE" -) -target_link_libraries(yt-library-ytprof PUBLIC - contrib-libs-cxxsupp - yutil - cpp-yt-memory - cpp-yt-threading - backtrace-cursors-interop - backtrace-cursors-frame_pointer - backtrace-cursors-libunwind - library-ytprof-api - library-ytprof-proto - contrib-libs-libunwind - libs-tcmalloc-malloc_extension - library-cpp-svnversion - yt-yt-core -) -target_sources(yt-library-ytprof PRIVATE - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/signal_safe_profiler.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/cpu_profiler.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/heap_profiler.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/spinlock_profiler.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/profile.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/build_info.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/external_pprof.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/symbolize_other.cpp -) diff --git a/yt/yt/library/ytprof/CMakeLists.windows-x86_64.txt b/yt/yt/library/ytprof/CMakeLists.windows-x86_64.txt index ec5652c9e981..dbfb934baea2 100644 --- a/yt/yt/library/ytprof/CMakeLists.windows-x86_64.txt +++ b/yt/yt/library/ytprof/CMakeLists.windows-x86_64.txt @@ -7,34 +7,3 @@ add_subdirectory(api) -add_subdirectory(proto) - -add_library(yt-library-ytprof) -target_compile_options(yt-library-ytprof PRIVATE - -DYTPROF_BUILD_TYPE="RELEASE" -) -target_link_libraries(yt-library-ytprof PUBLIC - contrib-libs-cxxsupp - yutil - cpp-yt-memory - cpp-yt-threading - backtrace-cursors-interop - backtrace-cursors-frame_pointer - backtrace-cursors-libunwind - library-ytprof-api - library-ytprof-proto - contrib-libs-libunwind - libs-tcmalloc-malloc_extension - library-cpp-svnversion - yt-yt-core -) -target_sources(yt-library-ytprof PRIVATE - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/signal_safe_profiler.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/cpu_profiler.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/heap_profiler.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/spinlock_profiler.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/profile.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/build_info.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/external_pprof.cpp - ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/symbolize_other.cpp -) diff --git a/yt/yt/library/ytprof/proto/CMakeLists.linux-aarch64.txt b/yt/yt/library/ytprof/proto/CMakeLists.linux-aarch64.txt index d16987cc1d8d..608e375abf31 100644 --- a/yt/yt/library/ytprof/proto/CMakeLists.linux-aarch64.txt +++ b/yt/yt/library/ytprof/proto/CMakeLists.linux-aarch64.txt @@ -32,6 +32,9 @@ target_link_libraries(library-ytprof-proto PUBLIC target_proto_messages(library-ytprof-proto PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/proto/profile.proto ) +target_sources(library-ytprof-proto PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/library/ytprof/proto/profile.pb.h +) target_proto_addincls(library-ytprof-proto ./yt ${CMAKE_SOURCE_DIR}/yt diff --git a/yt/yt/library/ytprof/proto/CMakeLists.linux-x86_64.txt b/yt/yt/library/ytprof/proto/CMakeLists.linux-x86_64.txt index d16987cc1d8d..608e375abf31 100644 --- a/yt/yt/library/ytprof/proto/CMakeLists.linux-x86_64.txt +++ b/yt/yt/library/ytprof/proto/CMakeLists.linux-x86_64.txt @@ -32,6 +32,9 @@ target_link_libraries(library-ytprof-proto PUBLIC target_proto_messages(library-ytprof-proto PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt/library/ytprof/proto/profile.proto ) +target_sources(library-ytprof-proto PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt/library/ytprof/proto/profile.pb.h +) target_proto_addincls(library-ytprof-proto ./yt ${CMAKE_SOURCE_DIR}/yt diff --git a/yt/yt/library/ytprof/proto/CMakeLists.txt b/yt/yt/library/ytprof/proto/CMakeLists.txt index d863ebd18067..d6c5c0bbeb44 100644 --- a/yt/yt/library/ytprof/proto/CMakeLists.txt +++ b/yt/yt/library/ytprof/proto/CMakeLists.txt @@ -10,10 +10,4 @@ if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_ include(CMakeLists.linux-x86_64.txt) elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) include(CMakeLists.linux-aarch64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") - include(CMakeLists.darwin-x86_64.txt) -elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") - include(CMakeLists.darwin-arm64.txt) -elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) - include(CMakeLists.windows-x86_64.txt) endif() diff --git a/yt/yt_proto/yt/client/CMakeLists.darwin-arm64.txt b/yt/yt_proto/yt/client/CMakeLists.darwin-arm64.txt index bde6ffe9e08e..335bff11923a 100644 --- a/yt/yt_proto/yt/client/CMakeLists.darwin-arm64.txt +++ b/yt/yt_proto/yt/client/CMakeLists.darwin-arm64.txt @@ -246,6 +246,18 @@ get_built_tool_path( contrib/tools/protoc/plugins/cpp_styleguide cpp_styleguide ) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) add_library(yt_proto-yt-client) target_include_directories(yt_proto-yt-client PUBLIC @@ -260,6 +272,7 @@ target_link_libraries(yt_proto-yt-client PUBLIC target_proto_messages(yt_proto-yt-client PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/api/rpc_proxy/proto/api_service.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/api/rpc_proxy/proto/discovery_service.proto + ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/bundle_controller/proto/bundle_controller_service.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/cell_master/proto/cell_directory.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/chaos_client/proto/replication_card.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/chunk_client/proto/data_statistics.proto @@ -279,6 +292,29 @@ target_proto_messages(yt_proto-yt-client PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/query_client/proto/query_statistics.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/misc/proto/workload.proto ) +target_sources(yt_proto-yt-client PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/api/rpc_proxy/proto/api_service.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/api/rpc_proxy/proto/discovery_service.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/bundle_controller/proto/bundle_controller_service.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/cell_master/proto/cell_directory.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chaos_client/proto/replication_card.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chunk_client/proto/data_statistics.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chunk_client/proto/chunk_meta.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chunk_client/proto/read_limit.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chunk_client/proto/chunk_spec.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chunk_client/proto/confirm_chunk_replica_info.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/discovery_client/proto/discovery_client_service.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/hive/proto/timestamp_map.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/hive/proto/cluster_directory.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/node_tracker_client/proto/node.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/node_tracker_client/proto/node_directory.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/table_chunk_format/proto/chunk_meta.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/table_chunk_format/proto/column_meta.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/table_chunk_format/proto/wire_protocol.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/transaction_client/proto/timestamp_service.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/query_client/proto/query_statistics.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/misc/proto/workload.pb.h +) target_proto_addincls(yt_proto-yt-client ./yt ${CMAKE_SOURCE_DIR}/yt diff --git a/yt/yt_proto/yt/client/CMakeLists.darwin-x86_64.txt b/yt/yt_proto/yt/client/CMakeLists.darwin-x86_64.txt index bde6ffe9e08e..335bff11923a 100644 --- a/yt/yt_proto/yt/client/CMakeLists.darwin-x86_64.txt +++ b/yt/yt_proto/yt/client/CMakeLists.darwin-x86_64.txt @@ -246,6 +246,18 @@ get_built_tool_path( contrib/tools/protoc/plugins/cpp_styleguide cpp_styleguide ) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) add_library(yt_proto-yt-client) target_include_directories(yt_proto-yt-client PUBLIC @@ -260,6 +272,7 @@ target_link_libraries(yt_proto-yt-client PUBLIC target_proto_messages(yt_proto-yt-client PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/api/rpc_proxy/proto/api_service.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/api/rpc_proxy/proto/discovery_service.proto + ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/bundle_controller/proto/bundle_controller_service.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/cell_master/proto/cell_directory.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/chaos_client/proto/replication_card.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/chunk_client/proto/data_statistics.proto @@ -279,6 +292,29 @@ target_proto_messages(yt_proto-yt-client PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/query_client/proto/query_statistics.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/misc/proto/workload.proto ) +target_sources(yt_proto-yt-client PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/api/rpc_proxy/proto/api_service.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/api/rpc_proxy/proto/discovery_service.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/bundle_controller/proto/bundle_controller_service.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/cell_master/proto/cell_directory.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chaos_client/proto/replication_card.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chunk_client/proto/data_statistics.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chunk_client/proto/chunk_meta.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chunk_client/proto/read_limit.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chunk_client/proto/chunk_spec.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chunk_client/proto/confirm_chunk_replica_info.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/discovery_client/proto/discovery_client_service.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/hive/proto/timestamp_map.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/hive/proto/cluster_directory.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/node_tracker_client/proto/node.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/node_tracker_client/proto/node_directory.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/table_chunk_format/proto/chunk_meta.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/table_chunk_format/proto/column_meta.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/table_chunk_format/proto/wire_protocol.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/transaction_client/proto/timestamp_service.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/query_client/proto/query_statistics.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/misc/proto/workload.pb.h +) target_proto_addincls(yt_proto-yt-client ./yt ${CMAKE_SOURCE_DIR}/yt diff --git a/yt/yt_proto/yt/client/CMakeLists.linux-aarch64.txt b/yt/yt_proto/yt/client/CMakeLists.linux-aarch64.txt index b21f7290e77c..6d35671b7a58 100644 --- a/yt/yt_proto/yt/client/CMakeLists.linux-aarch64.txt +++ b/yt/yt_proto/yt/client/CMakeLists.linux-aarch64.txt @@ -246,6 +246,18 @@ get_built_tool_path( contrib/tools/protoc/plugins/cpp_styleguide cpp_styleguide ) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) add_library(yt_proto-yt-client) target_include_directories(yt_proto-yt-client PUBLIC @@ -261,6 +273,7 @@ target_link_libraries(yt_proto-yt-client PUBLIC target_proto_messages(yt_proto-yt-client PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/api/rpc_proxy/proto/api_service.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/api/rpc_proxy/proto/discovery_service.proto + ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/bundle_controller/proto/bundle_controller_service.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/cell_master/proto/cell_directory.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/chaos_client/proto/replication_card.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/chunk_client/proto/data_statistics.proto @@ -280,6 +293,29 @@ target_proto_messages(yt_proto-yt-client PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/query_client/proto/query_statistics.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/misc/proto/workload.proto ) +target_sources(yt_proto-yt-client PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/api/rpc_proxy/proto/api_service.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/api/rpc_proxy/proto/discovery_service.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/bundle_controller/proto/bundle_controller_service.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/cell_master/proto/cell_directory.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chaos_client/proto/replication_card.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chunk_client/proto/data_statistics.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chunk_client/proto/chunk_meta.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chunk_client/proto/read_limit.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chunk_client/proto/chunk_spec.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chunk_client/proto/confirm_chunk_replica_info.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/discovery_client/proto/discovery_client_service.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/hive/proto/timestamp_map.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/hive/proto/cluster_directory.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/node_tracker_client/proto/node.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/node_tracker_client/proto/node_directory.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/table_chunk_format/proto/chunk_meta.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/table_chunk_format/proto/column_meta.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/table_chunk_format/proto/wire_protocol.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/transaction_client/proto/timestamp_service.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/query_client/proto/query_statistics.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/misc/proto/workload.pb.h +) target_proto_addincls(yt_proto-yt-client ./yt ${CMAKE_SOURCE_DIR}/yt diff --git a/yt/yt_proto/yt/client/CMakeLists.linux-x86_64.txt b/yt/yt_proto/yt/client/CMakeLists.linux-x86_64.txt index b21f7290e77c..6d35671b7a58 100644 --- a/yt/yt_proto/yt/client/CMakeLists.linux-x86_64.txt +++ b/yt/yt_proto/yt/client/CMakeLists.linux-x86_64.txt @@ -246,6 +246,18 @@ get_built_tool_path( contrib/tools/protoc/plugins/cpp_styleguide cpp_styleguide ) +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) add_library(yt_proto-yt-client) target_include_directories(yt_proto-yt-client PUBLIC @@ -261,6 +273,7 @@ target_link_libraries(yt_proto-yt-client PUBLIC target_proto_messages(yt_proto-yt-client PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/api/rpc_proxy/proto/api_service.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/api/rpc_proxy/proto/discovery_service.proto + ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/bundle_controller/proto/bundle_controller_service.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/cell_master/proto/cell_directory.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/chaos_client/proto/replication_card.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/chunk_client/proto/data_statistics.proto @@ -280,6 +293,29 @@ target_proto_messages(yt_proto-yt-client PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/query_client/proto/query_statistics.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/client/misc/proto/workload.proto ) +target_sources(yt_proto-yt-client PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/api/rpc_proxy/proto/api_service.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/api/rpc_proxy/proto/discovery_service.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/bundle_controller/proto/bundle_controller_service.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/cell_master/proto/cell_directory.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chaos_client/proto/replication_card.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chunk_client/proto/data_statistics.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chunk_client/proto/chunk_meta.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chunk_client/proto/read_limit.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chunk_client/proto/chunk_spec.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/chunk_client/proto/confirm_chunk_replica_info.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/discovery_client/proto/discovery_client_service.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/hive/proto/timestamp_map.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/hive/proto/cluster_directory.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/node_tracker_client/proto/node.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/node_tracker_client/proto/node_directory.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/table_chunk_format/proto/chunk_meta.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/table_chunk_format/proto/column_meta.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/table_chunk_format/proto/wire_protocol.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/transaction_client/proto/timestamp_service.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/query_client/proto/query_statistics.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/client/misc/proto/workload.pb.h +) target_proto_addincls(yt_proto-yt-client ./yt ${CMAKE_SOURCE_DIR}/yt diff --git a/yt/yt_proto/yt/core/CMakeLists.darwin-arm64.txt b/yt/yt_proto/yt/core/CMakeLists.darwin-arm64.txt index 14da9a86faa9..f6462389be7d 100644 --- a/yt/yt_proto/yt/core/CMakeLists.darwin-arm64.txt +++ b/yt/yt_proto/yt/core/CMakeLists.darwin-arm64.txt @@ -187,6 +187,21 @@ target_proto_messages(yt_proto-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/core/ytree/proto/request_complexity_limits.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/core/ytree/proto/ypath.proto ) +target_sources(yt_proto-yt-core PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/crypto/proto/crypto.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/misc/proto/bloom_filter.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/misc/proto/error.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/misc/proto/guid.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/misc/proto/protobuf_helpers.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/tracing/proto/span.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/tracing/proto/tracing_ext.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/bus/proto/bus.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/rpc/proto/rpc.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/yson/proto/protobuf_interop.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/ytree/proto/attributes.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/ytree/proto/request_complexity_limits.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/ytree/proto/ypath.pb.h +) target_proto_addincls(yt_proto-yt-core ./yt ${CMAKE_SOURCE_DIR}/yt diff --git a/yt/yt_proto/yt/core/CMakeLists.darwin-x86_64.txt b/yt/yt_proto/yt/core/CMakeLists.darwin-x86_64.txt index 14da9a86faa9..f6462389be7d 100644 --- a/yt/yt_proto/yt/core/CMakeLists.darwin-x86_64.txt +++ b/yt/yt_proto/yt/core/CMakeLists.darwin-x86_64.txt @@ -187,6 +187,21 @@ target_proto_messages(yt_proto-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/core/ytree/proto/request_complexity_limits.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/core/ytree/proto/ypath.proto ) +target_sources(yt_proto-yt-core PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/crypto/proto/crypto.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/misc/proto/bloom_filter.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/misc/proto/error.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/misc/proto/guid.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/misc/proto/protobuf_helpers.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/tracing/proto/span.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/tracing/proto/tracing_ext.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/bus/proto/bus.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/rpc/proto/rpc.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/yson/proto/protobuf_interop.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/ytree/proto/attributes.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/ytree/proto/request_complexity_limits.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/ytree/proto/ypath.pb.h +) target_proto_addincls(yt_proto-yt-core ./yt ${CMAKE_SOURCE_DIR}/yt diff --git a/yt/yt_proto/yt/core/CMakeLists.linux-aarch64.txt b/yt/yt_proto/yt/core/CMakeLists.linux-aarch64.txt index 8d49808dff74..289d242a783c 100644 --- a/yt/yt_proto/yt/core/CMakeLists.linux-aarch64.txt +++ b/yt/yt_proto/yt/core/CMakeLists.linux-aarch64.txt @@ -188,6 +188,21 @@ target_proto_messages(yt_proto-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/core/ytree/proto/request_complexity_limits.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/core/ytree/proto/ypath.proto ) +target_sources(yt_proto-yt-core PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/crypto/proto/crypto.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/misc/proto/bloom_filter.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/misc/proto/error.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/misc/proto/guid.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/misc/proto/protobuf_helpers.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/tracing/proto/span.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/tracing/proto/tracing_ext.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/bus/proto/bus.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/rpc/proto/rpc.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/yson/proto/protobuf_interop.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/ytree/proto/attributes.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/ytree/proto/request_complexity_limits.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/ytree/proto/ypath.pb.h +) target_proto_addincls(yt_proto-yt-core ./yt ${CMAKE_SOURCE_DIR}/yt diff --git a/yt/yt_proto/yt/core/CMakeLists.linux-x86_64.txt b/yt/yt_proto/yt/core/CMakeLists.linux-x86_64.txt index 8d49808dff74..289d242a783c 100644 --- a/yt/yt_proto/yt/core/CMakeLists.linux-x86_64.txt +++ b/yt/yt_proto/yt/core/CMakeLists.linux-x86_64.txt @@ -188,6 +188,21 @@ target_proto_messages(yt_proto-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/core/ytree/proto/request_complexity_limits.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/core/ytree/proto/ypath.proto ) +target_sources(yt_proto-yt-core PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/crypto/proto/crypto.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/misc/proto/bloom_filter.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/misc/proto/error.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/misc/proto/guid.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/misc/proto/protobuf_helpers.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/tracing/proto/span.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/tracing/proto/tracing_ext.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/bus/proto/bus.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/rpc/proto/rpc.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/yson/proto/protobuf_interop.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/ytree/proto/attributes.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/ytree/proto/request_complexity_limits.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/ytree/proto/ypath.pb.h +) target_proto_addincls(yt_proto-yt-core ./yt ${CMAKE_SOURCE_DIR}/yt diff --git a/yt/yt_proto/yt/core/CMakeLists.windows-x86_64.txt b/yt/yt_proto/yt/core/CMakeLists.windows-x86_64.txt index 14da9a86faa9..f6462389be7d 100644 --- a/yt/yt_proto/yt/core/CMakeLists.windows-x86_64.txt +++ b/yt/yt_proto/yt/core/CMakeLists.windows-x86_64.txt @@ -187,6 +187,21 @@ target_proto_messages(yt_proto-yt-core PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/core/ytree/proto/request_complexity_limits.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/core/ytree/proto/ypath.proto ) +target_sources(yt_proto-yt-core PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/crypto/proto/crypto.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/misc/proto/bloom_filter.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/misc/proto/error.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/misc/proto/guid.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/misc/proto/protobuf_helpers.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/tracing/proto/span.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/tracing/proto/tracing_ext.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/bus/proto/bus.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/rpc/proto/rpc.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/yson/proto/protobuf_interop.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/ytree/proto/attributes.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/ytree/proto/request_complexity_limits.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/core/ytree/proto/ypath.pb.h +) target_proto_addincls(yt_proto-yt-core ./yt ${CMAKE_SOURCE_DIR}/yt diff --git a/yt/yt_proto/yt/formats/CMakeLists.darwin-arm64.txt b/yt/yt_proto/yt/formats/CMakeLists.darwin-arm64.txt index 031fc7a562cf..c8666d0e9393 100644 --- a/yt/yt_proto/yt/formats/CMakeLists.darwin-arm64.txt +++ b/yt/yt_proto/yt/formats/CMakeLists.darwin-arm64.txt @@ -41,6 +41,10 @@ target_proto_messages(yt_proto-yt-formats PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/formats/extension.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/formats/yamr.proto ) +target_sources(yt_proto-yt-formats PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/formats/extension.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/formats/yamr.pb.h +) target_proto_addincls(yt_proto-yt-formats ./ ${CMAKE_SOURCE_DIR}/ diff --git a/yt/yt_proto/yt/formats/CMakeLists.darwin-x86_64.txt b/yt/yt_proto/yt/formats/CMakeLists.darwin-x86_64.txt index 031fc7a562cf..c8666d0e9393 100644 --- a/yt/yt_proto/yt/formats/CMakeLists.darwin-x86_64.txt +++ b/yt/yt_proto/yt/formats/CMakeLists.darwin-x86_64.txt @@ -41,6 +41,10 @@ target_proto_messages(yt_proto-yt-formats PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/formats/extension.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/formats/yamr.proto ) +target_sources(yt_proto-yt-formats PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/formats/extension.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/formats/yamr.pb.h +) target_proto_addincls(yt_proto-yt-formats ./ ${CMAKE_SOURCE_DIR}/ diff --git a/yt/yt_proto/yt/formats/CMakeLists.linux-aarch64.txt b/yt/yt_proto/yt/formats/CMakeLists.linux-aarch64.txt index b56285969352..0b9d88e2d879 100644 --- a/yt/yt_proto/yt/formats/CMakeLists.linux-aarch64.txt +++ b/yt/yt_proto/yt/formats/CMakeLists.linux-aarch64.txt @@ -42,6 +42,10 @@ target_proto_messages(yt_proto-yt-formats PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/formats/extension.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/formats/yamr.proto ) +target_sources(yt_proto-yt-formats PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/formats/extension.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/formats/yamr.pb.h +) target_proto_addincls(yt_proto-yt-formats ./ ${CMAKE_SOURCE_DIR}/ diff --git a/yt/yt_proto/yt/formats/CMakeLists.linux-x86_64.txt b/yt/yt_proto/yt/formats/CMakeLists.linux-x86_64.txt index b56285969352..0b9d88e2d879 100644 --- a/yt/yt_proto/yt/formats/CMakeLists.linux-x86_64.txt +++ b/yt/yt_proto/yt/formats/CMakeLists.linux-x86_64.txt @@ -42,6 +42,10 @@ target_proto_messages(yt_proto-yt-formats PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/formats/extension.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/formats/yamr.proto ) +target_sources(yt_proto-yt-formats PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/formats/extension.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/formats/yamr.pb.h +) target_proto_addincls(yt_proto-yt-formats ./ ${CMAKE_SOURCE_DIR}/ diff --git a/yt/yt_proto/yt/formats/CMakeLists.windows-x86_64.txt b/yt/yt_proto/yt/formats/CMakeLists.windows-x86_64.txt index 031fc7a562cf..c8666d0e9393 100644 --- a/yt/yt_proto/yt/formats/CMakeLists.windows-x86_64.txt +++ b/yt/yt_proto/yt/formats/CMakeLists.windows-x86_64.txt @@ -41,6 +41,10 @@ target_proto_messages(yt_proto-yt-formats PRIVATE ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/formats/extension.proto ${CMAKE_SOURCE_DIR}/yt/yt_proto/yt/formats/yamr.proto ) +target_sources(yt_proto-yt-formats PRIVATE + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/formats/extension.pb.h + ${CMAKE_BINARY_DIR}/yt/yt_proto/yt/formats/yamr.pb.h +) target_proto_addincls(yt_proto-yt-formats ./ ${CMAKE_SOURCE_DIR}/ From 14c6dfb07278ce6142ff9b46239dd89248ed4b01 Mon Sep 17 00:00:00 2001 From: Aleksei Borzenkov Date: Thu, 22 Feb 2024 20:18:48 +0300 Subject: [PATCH 038/117] Fix partial distributed commit of uncommitted changes during shard restart race (#2169) --- .../tx/datashard/datashard_dep_tracker.cpp | 4 +- ydb/core/tx/datashard/datashard_locks.cpp | 49 +++--- ydb/core/tx/datashard/datashard_locks.h | 35 +++- ydb/core/tx/datashard/datashard_locks_db.cpp | 8 + ydb/core/tx/datashard/datashard_locks_db.h | 1 + .../tx/datashard/datashard_ut_common_kqp.h | 12 +- .../tx/datashard/datashard_ut_snapshot.cpp | 165 ++++++++++++++++++ .../datashard/store_and_send_out_rs_unit.cpp | 4 +- 8 files changed, 249 insertions(+), 29 deletions(-) diff --git a/ydb/core/tx/datashard/datashard_dep_tracker.cpp b/ydb/core/tx/datashard/datashard_dep_tracker.cpp index 34d25312795e..a5874bdf6a3b 100644 --- a/ydb/core/tx/datashard/datashard_dep_tracker.cpp +++ b/ydb/core/tx/datashard/datashard_dep_tracker.cpp @@ -673,11 +673,13 @@ void TDependencyTracker::TMvccDependencyTrackingLogic::AddOperation(const TOpera if (lock) { lock->SetLastOpId(op->GetTxId()); - if (locksCache.Locks.contains(lockTxId) && lock->IsPersistent()) { + if (locksCache.Locks.contains(lockTxId) && lock->IsPersistent() && !lock->IsFrozen()) { // This lock was cached before, and since we know // it's persistent, we know it was also frozen // during that lock caching. Restore the frozen // flag for this lock. + // Note: this code path is only for older shards + // which didn't persist the frozen flag. lock->SetFrozen(); } } diff --git a/ydb/core/tx/datashard/datashard_locks.cpp b/ydb/core/tx/datashard/datashard_locks.cpp index a7e5aecbaa5c..2708f5a8bbdd 100644 --- a/ydb/core/tx/datashard/datashard_locks.cpp +++ b/ydb/core/tx/datashard/datashard_locks.cpp @@ -44,16 +44,17 @@ TLockInfo::TLockInfo(TLockLocker * locker, ui64 lockId, ui32 lockNodeId) , CreationTime(TAppData::TimeProvider->Now()) {} -TLockInfo::TLockInfo(TLockLocker * locker, ui64 lockId, ui32 lockNodeId, ui32 generation, ui64 counter, TInstant createTs) +TLockInfo::TLockInfo(TLockLocker * locker, const ILocksDb::TLockRow& row) : Locker(locker) - , LockId(lockId) - , LockNodeId(lockNodeId) - , Generation(generation) - , Counter(counter) - , CreationTime(createTs) + , LockId(row.LockId) + , LockNodeId(row.LockNodeId) + , Generation(row.Generation) + , Counter(row.Counter) + , CreationTime(TInstant::MicroSeconds(row.CreateTs)) + , Flags(ELockFlags(row.Flags)) , Persistent(true) { - if (counter == Max()) { + if (Counter == Max()) { BreakVersion.emplace(TRowVersion::Min()); } } @@ -145,7 +146,7 @@ void TLockInfo::OnRemoved() { void TLockInfo::PersistLock(ILocksDb* db) { Y_ABORT_UNLESS(!IsPersistent()); Y_ABORT_UNLESS(db, "Cannot persist lock without a db"); - db->PersistAddLock(LockId, LockNodeId, Generation, Counter, CreationTime.MicroSeconds()); + db->PersistAddLock(LockId, LockNodeId, Generation, Counter, CreationTime.MicroSeconds(), ui64(Flags)); Persistent = true; PersistRanges(db); @@ -298,11 +299,11 @@ void TLockInfo::CleanupConflicts() { } } -void TLockInfo::RestorePersistentRange(ui64 rangeId, const TPathId& tableId, ELockRangeFlags flags) { +void TLockInfo::RestorePersistentRange(const ILocksDb::TLockRange& rangeRow) { auto& range = PersistentRanges.emplace_back(); - range.Id = rangeId; - range.TableId = tableId; - range.Flags = flags; + range.Id = rangeRow.RangeId; + range.TableId = rangeRow.TableId; + range.Flags = ELockRangeFlags(rangeRow.Flags); if (!!(range.Flags & ELockRangeFlags::Read)) { if (ReadTables.insert(range.TableId).second) { @@ -334,6 +335,14 @@ void TLockInfo::RestorePersistentVolatileDependency(ui64 txId) { VolatileDependencies.insert(txId); } +void TLockInfo::SetFrozen(ILocksDb* db) { + Y_ABORT_UNLESS(IsPersistent()); + Flags |= ELockFlags::Frozen; + if (db) { + db->PersistLockFlags(LockId, ui64(Flags)); + } +} + // TTableLocks void TTableLocks::AddShardLock(TLockInfo* lock) { @@ -550,14 +559,14 @@ TLockInfo::TPtr TLockLocker::GetOrAddLock(ui64 lockId, ui32 lockNodeId) { return lock; } -TLockInfo::TPtr TLockLocker::AddLock(ui64 lockId, ui32 lockNodeId, ui32 generation, ui64 counter, TInstant createTs) { - Y_ABORT_UNLESS(Locks.find(lockId) == Locks.end()); +TLockInfo::TPtr TLockLocker::AddLock(const ILocksDb::TLockRow& row) { + Y_ABORT_UNLESS(Locks.find(row.LockId) == Locks.end()); - TLockInfo::TPtr lock(new TLockInfo(this, lockId, lockNodeId, generation, counter, createTs)); + TLockInfo::TPtr lock(new TLockInfo(this, row)); Y_ABORT_UNLESS(lock->IsPersistent()); - Locks[lockId] = lock; - if (lockNodeId) { - PendingSubscribeLocks.emplace_back(lockId, lockNodeId); + Locks[row.LockId] = lock; + if (row.LockNodeId) { + PendingSubscribeLocks.emplace_back(row.LockId, row.LockNodeId); } return lock; } @@ -1171,9 +1180,9 @@ bool TSysLocks::Load(ILocksDb& db) { Locker.Clear(); for (auto& lockRow : rows) { - TLockInfo::TPtr lock = Locker.AddLock(lockRow.LockId, lockRow.LockNodeId, lockRow.Generation, lockRow.Counter, TInstant::MicroSeconds(lockRow.CreateTs)); + TLockInfo::TPtr lock = Locker.AddLock(lockRow); for (auto& rangeRow : lockRow.Ranges) { - lock->RestorePersistentRange(rangeRow.RangeId, rangeRow.TableId, ELockRangeFlags(rangeRow.Flags)); + lock->RestorePersistentRange(rangeRow); } } diff --git a/ydb/core/tx/datashard/datashard_locks.h b/ydb/core/tx/datashard/datashard_locks.h index 2d95dc74e748..c0b0aeebd450 100644 --- a/ydb/core/tx/datashard/datashard_locks.h +++ b/ydb/core/tx/datashard/datashard_locks.h @@ -57,6 +57,7 @@ class ILocksDb { // Persist adding/removing a lock info virtual void PersistAddLock(ui64 lockId, ui32 lockNodeId, ui32 generation, ui64 counter, ui64 createTs, ui64 flags = 0) = 0; virtual void PersistLockCounter(ui64 lockId, ui64 counter) = 0; + virtual void PersistLockFlags(ui64 lockId, ui64 flags) = 0; virtual void PersistRemoveLock(ui64 lockId) = 0; // Persist adding/removing info on locked ranges @@ -206,6 +207,23 @@ struct TPendingSubscribeLock { } }; +// ELockFlags type safe enum + +enum class ELockFlags : ui64 { + None = 0, + Frozen = 1, +}; + +using ELockFlagsRaw = std::underlying_type::type; + +inline ELockFlags operator|(ELockFlags a, ELockFlags b) { return ELockFlags(ELockFlagsRaw(a) | ELockFlagsRaw(b)); } +inline ELockFlags operator&(ELockFlags a, ELockFlags b) { return ELockFlags(ELockFlagsRaw(a) & ELockFlagsRaw(b)); } +inline ELockFlags& operator|=(ELockFlags& a, ELockFlags b) { return a = a | b; } +inline ELockFlags& operator&=(ELockFlags& a, ELockFlags b) { return a = a & b; } +inline bool operator!(ELockFlags c) { return ELockFlagsRaw(c) == 0; } + +// ELockConflictFlags type safe enum + enum class ELockConflictFlags : ui8 { None = 0, BreakThemOnOurCommit = 1, @@ -220,6 +238,8 @@ inline ELockConflictFlags& operator|=(ELockConflictFlags& a, ELockConflictFlags inline ELockConflictFlags& operator&=(ELockConflictFlags& a, ELockConflictFlags b) { return a = a & b; } inline bool operator!(ELockConflictFlags c) { return ELockConflictFlagsRaw(c) == 0; } +// ELockRangeFlags type safe enum + enum class ELockRangeFlags : ui8 { None = 0, Read = 1, @@ -262,7 +282,7 @@ class TLockInfo using TPtr = TIntrusivePtr; TLockInfo(TLockLocker * locker, ui64 lockId, ui32 lockNodeId); - TLockInfo(TLockLocker * locker, ui64 lockId, ui32 lockNodeId, ui32 generation, ui64 counter, TInstant createTs); + TLockInfo(TLockLocker * locker, const ILocksDb::TLockRow& row); ~TLockInfo(); bool Empty() const { @@ -303,6 +323,9 @@ class TLockInfo ui32 GetLockNodeId() const { return LockNodeId; } TInstant GetCreationTime() const { return CreationTime; } + + ELockFlags GetFlags() const { return Flags; } + const THashSet& GetReadTables() const { return ReadTables; } const THashSet& GetWriteTables() const { return WriteTables; } @@ -320,7 +343,7 @@ class TLockInfo void PersistConflicts(ILocksDb* db); void CleanupConflicts(); - void RestorePersistentRange(ui64 rangeId, const TPathId& tableId, ELockRangeFlags flags); + void RestorePersistentRange(const ILocksDb::TLockRange& rangeRow); void RestorePersistentConflict(TLockInfo* otherLock); void RestorePersistentVolatileDependency(ui64 txId); @@ -341,8 +364,8 @@ class TLockInfo ui64 GetLastOpId() const { return LastOpId; } void SetLastOpId(ui64 opId) { LastOpId = opId; } - bool IsFrozen() const { return Frozen; } - void SetFrozen() { Frozen = true; } + bool IsFrozen() const { return !!(Flags & ELockFlags::Frozen); } + void SetFrozen(ILocksDb* db = nullptr); private: void MakeShardLock(); @@ -369,6 +392,7 @@ class TLockInfo ui32 Generation; ui64 Counter; TInstant CreationTime; + ELockFlags Flags = ELockFlags::None; THashSet ReadTables; THashSet WriteTables; TVector Points; @@ -386,7 +410,6 @@ class TLockInfo TVector PersistentRanges; ui64 LastOpId = 0; - bool Frozen = false; }; struct TTableLocksReadListTag {}; @@ -641,7 +664,7 @@ class TLockLocker { void RemoveBrokenRanges(); TLockInfo::TPtr GetOrAddLock(ui64 lockId, ui32 lockNodeId); - TLockInfo::TPtr AddLock(ui64 lockId, ui32 lockNodeId, ui32 generation, ui64 counter, TInstant createTs); + TLockInfo::TPtr AddLock(const ILocksDb::TLockRow& row); void RemoveOneLock(ui64 lockId, ILocksDb* db = nullptr); void SaveBrokenPersistentLocks(ILocksDb* db); diff --git a/ydb/core/tx/datashard/datashard_locks_db.cpp b/ydb/core/tx/datashard/datashard_locks_db.cpp index 9285acb6df44..5e5b21c173e9 100644 --- a/ydb/core/tx/datashard/datashard_locks_db.cpp +++ b/ydb/core/tx/datashard/datashard_locks_db.cpp @@ -129,6 +129,14 @@ void TDataShardLocksDb::PersistLockCounter(ui64 lockId, ui64 counter) { HasChanges_ = true; } +void TDataShardLocksDb::PersistLockFlags(ui64 lockId, ui64 flags) { + using Schema = TDataShard::Schema; + NIceDb::TNiceDb db(DB); + db.Table().Key(lockId).Update( + NIceDb::TUpdate(flags)); + HasChanges_ = true; +} + void TDataShardLocksDb::PersistRemoveLock(ui64 lockId) { // We remove lock changes unless it's managed by volatile tx manager bool isVolatile = Self.GetVolatileTxManager().FindByCommitTxId(lockId); diff --git a/ydb/core/tx/datashard/datashard_locks_db.h b/ydb/core/tx/datashard/datashard_locks_db.h index 1aba7176ec94..c9da2a157624 100644 --- a/ydb/core/tx/datashard/datashard_locks_db.h +++ b/ydb/core/tx/datashard/datashard_locks_db.h @@ -23,6 +23,7 @@ class TDataShardLocksDb // Persist adding/removing a lock info void PersistAddLock(ui64 lockId, ui32 lockNodeId, ui32 generation, ui64 counter, ui64 createTs, ui64 flags = 0) override; void PersistLockCounter(ui64 lockId, ui64 counter) override; + void PersistLockFlags(ui64 lockId, ui64 flags) override; void PersistRemoveLock(ui64 lockId) override; // Persist adding/removing info on locked ranges diff --git a/ydb/core/tx/datashard/datashard_ut_common_kqp.h b/ydb/core/tx/datashard/datashard_ut_common_kqp.h index 888711b79943..d7182e08e3da 100644 --- a/ydb/core/tx/datashard/datashard_ut_common_kqp.h +++ b/ydb/core/tx/datashard/datashard_ut_common_kqp.h @@ -146,7 +146,17 @@ namespace NKqpHelpers { if (result.result_sets_size() == 0) { return ""; } - return FormatResult(result.result_sets(0)); + if (result.result_sets_size() == 1) { + return FormatResult(result.result_sets(0)); + } + TStringBuilder sb; + for (int i = 0; i < result.result_sets_size(); ++i) { + if (i != 0) { + sb << "\n"; + } + sb << FormatResult(result.result_sets(i)); + } + return sb; } inline TString FormatResult(const Ydb::Table::ExecuteDataQueryResponse& response) { diff --git a/ydb/core/tx/datashard/datashard_ut_snapshot.cpp b/ydb/core/tx/datashard/datashard_ut_snapshot.cpp index f34a7e09942b..44e4bf7d555d 100644 --- a/ydb/core/tx/datashard/datashard_ut_snapshot.cpp +++ b/ydb/core/tx/datashard/datashard_ut_snapshot.cpp @@ -8,6 +8,7 @@ #include #include // Y_UNIT_TEST_(TWIN|QUAD) +#include #include @@ -3823,6 +3824,170 @@ Y_UNIT_TEST_SUITE(DataShardSnapshots) { UNIT_ASSERT_C(duration <= TDuration::MilliSeconds(200), "UPSERT takes too much time: " << duration); } + Y_UNIT_TEST(UncommittedWriteRestartDuringCommit) { + NKikimrConfig::TAppConfig app; + app.MutableTableServiceConfig()->SetEnableKqpDataQuerySourceRead(true); + + TPortManager pm; + TServerSettings serverSettings(pm.GetPort(2134)); + serverSettings.SetDomainName("Root") + .SetUseRealThreads(false) + .SetDomainPlanResolution(100) + .SetAppConfig(app) + // Bug was with non-volatile transactions + .SetEnableDataShardVolatileTransactions(false); + + Tests::TServer::TPtr server = new TServer(serverSettings); + auto &runtime = *server->GetRuntime(); + auto sender = runtime.AllocateEdgeActor(); + + runtime.SetLogPriority(NKikimrServices::TX_DATASHARD, NLog::PRI_TRACE); + runtime.SetLogPriority(NKikimrServices::TX_PROXY, NLog::PRI_DEBUG); + runtime.SetLogPriority(NKikimrServices::KQP_EXECUTER, NLog::PRI_TRACE); + runtime.SetLogPriority(NKikimrServices::KQP_SESSION, NLog::PRI_TRACE); + + InitRoot(server, sender); + + TDisableDataShardLogBatching disableDataShardLogBatching; + CreateShardedTable(server, sender, "/Root", "table-1", 1); + CreateShardedTable(server, sender, "/Root", "table-2", 1); + + // Insert some initial data + ExecSQL(server, sender, Q_("UPSERT INTO `/Root/table-1` (key, value) VALUES (1, 10);")); + ExecSQL(server, sender, Q_("UPSERT INTO `/Root/table-2` (key, value) VALUES (2, 20);")); + + const auto shards1 = GetTableShards(server, sender, "/Root/table-1"); + + TString sessionId, txId; + + // Start inserting a row into table-1 + Cerr << "... sending initial upsert" << Endl; + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleBegin(runtime, sessionId, txId, Q_(R"( + UPSERT INTO `/Root/table-1` (key, value) VALUES (3, 30); + )")), + ""); + + // We want to block readsets + std::vector> readSets; + auto blockReadSets = runtime.AddObserver([&](TEvTxProcessing::TEvReadSet::TPtr& ev) { + readSets.emplace_back(ev.Release()); + }); + + // Start committing an additional read/write + // Note: select on table-1 flushes accumulated changes + // Note: select on table-2 ensures we have an outgoing readset + Cerr << "... sending commit request" << Endl; + auto commitFuture = SendRequest(runtime, MakeSimpleRequestRPC(Q_(R"( + SELECT key, value FROM `/Root/table-1` + UNION ALL + SELECT key, value FROM `/Root/table-2` + ORDER BY key; + + UPSERT INTO `/Root/table-2` (key, value) VALUES (4, 40); + )"), sessionId, txId, true /* commitTx */)); + + WaitFor(runtime, [&]{ return readSets.size() >= 2; }, "readset exchange"); + UNIT_ASSERT_VALUES_EQUAL(readSets.size(), 2u); + + // We want to block local boot to make sure it stays down during rollback + std::vector> blockedLocalBoot; + auto blockLocalBoot = runtime.AddObserver([&](TEvLocal::TEvBootTablet::TPtr& ev) { + Cerr << "... blocking TEvLocal::TEvBootTablet" << Endl; + blockedLocalBoot.emplace_back(std::move(ev.Release())); + }); + + // Kill current datashard actor with TEvPoison (so it doesn't have a chance to reply) + Cerr << "... sending TEvPoison to " << shards1.at(0) << Endl; + ForwardToTablet(runtime, shards1.at(0), sender, new TEvents::TEvPoison); + + // Wait until hive tries to boot a new instance (old instance is dead by that point) + WaitFor(runtime, [&]{ return blockedLocalBoot.size() > 0; }, "blocked local boot", 3); + + // Stop blocking and resend readsets + blockReadSets.Remove(); + Cerr << "... resending readsets" << Endl; + for (auto& ev : readSets) { + runtime.Send(ev.release(), 0, true); + } + readSets.clear(); + + // Wait until commit fails with UNDETERMINED + Cerr << "... waiting for commit result" << Endl; + UNIT_ASSERT_VALUES_EQUAL( + FormatResult(AwaitResponse(runtime, std::move(commitFuture))), + "ERROR: UNDETERMINED"); + + // Sleep a little to make sure everything settles + Cerr << "... sleeping for 1 second" << Endl; + runtime.SimulateSleep(TDuration::Seconds(1)); + + // We want to detect a restarting datashard and block its progress queue + TActorId shard1actor; + std::vector> blockedProgress; + auto blockProgressQueue = runtime.AddObserver([&](TAutoPtr& ev) { + switch (ev->GetTypeRewrite()) { + case TEvTablet::TEvBoot::EventType: { + auto* msg = ev->Get(); + Cerr << "... observed TEvBoot for " << msg->TabletID << " at " << ev->GetRecipientRewrite() << Endl; + if (msg->TabletID == shards1.at(0)) { + shard1actor = ev->GetRecipientRewrite(); + } + break; + } + case EventSpaceBegin(TKikimrEvents::ES_PRIVATE) + 0 /* EvProgressTransaction */: { + if (shard1actor && ev->GetRecipientRewrite() == shard1actor) { + Cerr << "... blocking TEvProgressTranasction at " << ev->GetRecipientRewrite() << Endl; + blockedProgress.emplace_back(ev.Release()); + return; + } + break; + } + } + }); + + // Unblock local boot + blockLocalBoot.Remove(); + Cerr << "... unblocking local boot" << Endl; + for (auto& ev : blockedLocalBoot) { + runtime.Send(ev.release(), 0, true); + } + blockedLocalBoot.clear(); + + // Wait until a new instance starts and is blocked at progress queue handling + WaitFor(runtime, [&]{ return blockedProgress.size() > 0; }, "blocked progress", 10); + + // Sleep a little to make sure datashard subscribes to lock and handles the response + Cerr << "... sleeping for 1 second" << Endl; + runtime.SimulateSleep(TDuration::Seconds(1)); + + // Unblock progress queue and resend blocked messages + Cerr << "... resending progress queue" << Endl; + blockProgressQueue.Remove(); + for (auto& ev : blockedProgress) { + runtime.Send(ev.release(), 0, true); + } + blockedProgress.clear(); + + // Sleep a little to make sure everything settles + Cerr << "... sleeping for 1 second" << Endl; + runtime.SimulateSleep(TDuration::Seconds(1)); + + // Now make a read query, we must not observe partial commit + Cerr << "... checking final table state" << Endl; + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleExec(runtime, Q_(R"( + SELECT key, value FROM `/Root/table-1` + UNION ALL + SELECT key, value FROM `/Root/table-2` + ORDER BY key; + )")), + "{ items { uint32_value: 1 } items { uint32_value: 10 } }, " + "{ items { uint32_value: 2 } items { uint32_value: 20 } }, " + "{ items { uint32_value: 3 } items { uint32_value: 30 } }, " + "{ items { uint32_value: 4 } items { uint32_value: 40 } }"); + } + } } // namespace NKikimr diff --git a/ydb/core/tx/datashard/store_and_send_out_rs_unit.cpp b/ydb/core/tx/datashard/store_and_send_out_rs_unit.cpp index 71b429094464..e809c4209ce4 100644 --- a/ydb/core/tx/datashard/store_and_send_out_rs_unit.cpp +++ b/ydb/core/tx/datashard/store_and_send_out_rs_unit.cpp @@ -1,6 +1,7 @@ #include "datashard_impl.h" #include "datashard_pipeline.h" #include "execution_unit_ctors.h" +#include "datashard_locks_db.h" namespace NKikimr { namespace NDataShard { @@ -62,7 +63,8 @@ EExecutionStatus TStoreAndSendOutRSUnit::Execute(TOperation::TPtr op, ui64 lockId = pr.first; auto lock = DataShard.SysLocksTable().GetRawLock(lockId, TRowVersion::Min()); if (lock && lock->IsPersistent()) { - lock->SetFrozen(); + TDataShardLocksDb locksDb(DataShard, txc); + lock->SetFrozen(&locksDb); } } tx->MarkLocksStored(); From 5cd47d32aa92ef32e86aeacaa43a3f8d53407d01 Mon Sep 17 00:00:00 2001 From: Alexey Efimov Date: Mon, 26 Feb 2024 14:12:15 +0300 Subject: [PATCH 039/117] lower time difference issues from red to orange (#2197) (#2232) --- ydb/core/health_check/health_check.cpp | 10 +++++----- 1 file changed, 5 insertions(+), 5 deletions(-) diff --git a/ydb/core/health_check/health_check.cpp b/ydb/core/health_check/health_check.cpp index 3b3de7c61a6b..a127d271e60f 100644 --- a/ydb/core/health_check/health_check.cpp +++ b/ydb/core/health_check/health_check.cpp @@ -1305,8 +1305,8 @@ class TSelfCheckRequest : public TActorBootstrapped { void FillCompute(TDatabaseState& databaseState, Ydb::Monitoring::ComputeStatus& computeStatus, TSelfCheckContext context) { TVector* computeNodeIds = &databaseState.ComputeNodeIds; - if (databaseState.ResourcePathId - && databaseState.ServerlessComputeResourcesMode != NKikimrSubDomains::EServerlessComputeResourcesModeExclusive) + if (databaseState.ResourcePathId + && databaseState.ServerlessComputeResourcesMode != NKikimrSubDomains::EServerlessComputeResourcesModeExclusive) { auto itDatabase = FilterDomainKey.find(TSubDomainKey(databaseState.ResourcePathId.OwnerId, databaseState.ResourcePathId.LocalPathId)); if (itDatabase != FilterDomainKey.end()) { @@ -2074,7 +2074,7 @@ class TSelfCheckRequest : public TActorBootstrapped { } } - const TDuration MAX_CLOCKSKEW_RED_ISSUE_TIME = TDuration::MicroSeconds(25000); + const TDuration MAX_CLOCKSKEW_ORANGE_ISSUE_TIME = TDuration::MicroSeconds(25000); const TDuration MAX_CLOCKSKEW_YELLOW_ISSUE_TIME = TDuration::MicroSeconds(5000); void FillNodesSyncStatus(TOverallStateContext& context) { @@ -2098,8 +2098,8 @@ class TSelfCheckRequest : public TActorBootstrapped { FillNodeInfo(maxClockSkewPeerId, syncContext.Location.mutable_peer()); TDuration maxClockSkewTime = TDuration::MicroSeconds(maxClockSkewUs); - if (maxClockSkewTime > MAX_CLOCKSKEW_RED_ISSUE_TIME) { - syncContext.ReportStatus(Ydb::Monitoring::StatusFlag::RED, TStringBuilder() << "The nodes have a time difference of " << maxClockSkewTime.MilliSeconds() << " ms", ETags::SyncState); + if (maxClockSkewTime > MAX_CLOCKSKEW_ORANGE_ISSUE_TIME) { + syncContext.ReportStatus(Ydb::Monitoring::StatusFlag::ORANGE, TStringBuilder() << "The nodes have a time difference of " << maxClockSkewTime.MilliSeconds() << " ms", ETags::SyncState); } else if (maxClockSkewTime > MAX_CLOCKSKEW_YELLOW_ISSUE_TIME) { syncContext.ReportStatus(Ydb::Monitoring::StatusFlag::YELLOW, TStringBuilder() << "The nodes have a time difference of " << maxClockSkewTime.MilliSeconds() << " ms", ETags::SyncState); } else { From 6a51e53d5e8860cf5172c9eaa8d58801e685645c Mon Sep 17 00:00:00 2001 From: Nikita Vasilev Date: Tue, 27 Feb 2024 17:09:13 +0300 Subject: [PATCH 040/117] Fix ToFlow for dict join (#2267) --- ydb/core/kqp/ut/query/kqp_query_ut.cpp | 25 ++++++++++++++++++++++ ydb/library/yql/dq/opt/dq_opt_peephole.cpp | 4 +++- 2 files changed, 28 insertions(+), 1 deletion(-) diff --git a/ydb/core/kqp/ut/query/kqp_query_ut.cpp b/ydb/core/kqp/ut/query/kqp_query_ut.cpp index f57bf4005ab1..4bb15fdc62c7 100644 --- a/ydb/core/kqp/ut/query/kqp_query_ut.cpp +++ b/ydb/core/kqp/ut/query/kqp_query_ut.cpp @@ -1559,6 +1559,31 @@ Y_UNIT_TEST_SUITE(KqpQuery) { UNIT_ASSERT_VALUES_EQUAL(result.GetResultSet(0).RowsCount(), 1); } } + + Y_UNIT_TEST(DictJoin) { + TKikimrRunner kikimr; + auto client = kikimr.GetQueryClient(); + + { + const TString sql = R"( + --!syntax_v1 + + $lsource = SELECT 'test' AS ldata; + $rsource = SELECT 'test' AS rdata; + + $left = SELECT ROW_NUMBER() OVER w AS r, ldata FROM $lsource WINDOW w AS (); + $right = SELECT ROW_NUMBER() OVER w AS r, rdata FROM $rsource WINDOW w AS (); + + $result = SELECT ldata, rdata FROM $left AS tl INNER JOIN $right AS tr ON tl.r = tr.r; + + SELECT * FROM $result; + )"; + auto result = client.ExecuteQuery( + sql, + NYdb::NQuery::TTxControl::BeginTx().CommitTx()).GetValueSync(); + UNIT_ASSERT_C(result.IsSuccess(), result.GetIssues().ToString()); + } + } } } // namespace NKqp diff --git a/ydb/library/yql/dq/opt/dq_opt_peephole.cpp b/ydb/library/yql/dq/opt/dq_opt_peephole.cpp index 6ce322bfc502..d1120601ce9d 100644 --- a/ydb/library/yql/dq/opt/dq_opt_peephole.cpp +++ b/ydb/library/yql/dq/opt/dq_opt_peephole.cpp @@ -554,7 +554,9 @@ NNodes::TExprBase DqPeepholeRewriteJoinDict(const NNodes::TExprBase& node, TExpr auto unpackData = UnpackJoinedData(leftRowType, rightRowType, leftTableLabel, rightTableLabel, join.Pos(), ctx); return Build(ctx, joinDict.Pos()) - .Input(join) + .Input() + .Input(join) + .Build() .Lambda(unpackData) .Done(); } From 18848f203e4a440d7dc4807685ba31561ce3230f Mon Sep 17 00:00:00 2001 From: Ilia Shakhov Date: Thu, 29 Feb 2024 15:21:22 +0300 Subject: [PATCH 041/117] Dont return shared nodes for serverless KIKIMR-21128 (#2264) (#2305) --- ydb/core/viewer/json_nodes.h | 30 +++-- ydb/core/viewer/viewer_ut.cpp | 213 +++++++++++++++++++++++----------- 2 files changed, 158 insertions(+), 85 deletions(-) diff --git a/ydb/core/viewer/json_nodes.h b/ydb/core/viewer/json_nodes.h index f663e38a3ad4..ceab8a8cf8cf 100644 --- a/ydb/core/viewer/json_nodes.h +++ b/ydb/core/viewer/json_nodes.h @@ -411,27 +411,25 @@ class TJsonNodes : public TViewerPipeClient { const auto localPathId = entry.DomainInfo->DomainKey.LocalPathId; FilterSubDomainKey = TSubDomainKey(ownerId, localPathId); } + + if (FilterTenant.empty()) { + RequestForTenant(path); + } + if (entry.DomainInfo->ResourcesDomainKey && entry.DomainInfo->DomainKey != entry.DomainInfo->ResourcesDomainKey) { TPathId resourceDomainKey(entry.DomainInfo->ResourcesDomainKey); BLOG_TRACE("Requesting navigate for resource domain " << resourceDomainKey); RequestSchemeCacheNavigate(resourceDomainKey); ++RequestsBeforeNodeList; - } else { - if (FilterTenant.empty()) { - RequestForTenant(path); - } - if (Storage) { - if (entry.DomainDescription) { - for (const auto& storagePool : entry.DomainDescription->Description.GetStoragePools()) { - TString storagePoolName = storagePool.GetName(); - THolder request = MakeHolder(); - request->Record.SetReturnAllMatchingGroups(true); - request->Record.AddGroupParameters()->MutableStoragePoolSpecifier()->SetName(storagePoolName); - BLOG_TRACE("Requesting BSControllerSelectGroups for " << storagePoolName); - RequestBSControllerSelectGroups(std::move(request)); - ++RequestsBeforeNodeList; - } - } + } else if (Storage && entry.DomainDescription) { + for (const auto& storagePool : entry.DomainDescription->Description.GetStoragePools()) { + TString storagePoolName = storagePool.GetName(); + THolder request = MakeHolder(); + request->Record.SetReturnAllMatchingGroups(true); + request->Record.AddGroupParameters()->MutableStoragePoolSpecifier()->SetName(storagePoolName); + BLOG_TRACE("Requesting BSControllerSelectGroups for " << storagePoolName); + RequestBSControllerSelectGroups(std::move(request)); + ++RequestsBeforeNodeList; } } } else { diff --git a/ydb/core/viewer/viewer_ut.cpp b/ydb/core/viewer/viewer_ut.cpp index 6fbcfba9583a..d3f85f24837d 100644 --- a/ydb/core/viewer/viewer_ut.cpp +++ b/ydb/core/viewer/viewer_ut.cpp @@ -601,6 +601,89 @@ Y_UNIT_TEST_SUITE(Viewer) { StorageSpaceTest("space", NKikimrWhiteboard::EFlag::Green, 90, 100, true); } + const TPathId SHARED_DOMAIN_KEY = {7000000000, 1}; + const TPathId SERVERLESS_DOMAIN_KEY = {7000000000, 2}; + const TPathId SERVERLESS_TABLE = {7000000001, 2}; + + void ChangeNavigateKeySetResultServerless(TEvTxProxySchemeCache::TEvNavigateKeySetResult::TPtr* ev, + TTestActorRuntime& runtime) { + TSchemeCacheNavigate::TEntry& entry((*ev)->Get()->Request->ResultSet.front()); + TString path = CanonizePath(entry.Path); + if (path == "/Root/serverless" || entry.TableId.PathId == SERVERLESS_DOMAIN_KEY) { + entry.Status = TSchemeCacheNavigate::EStatus::Ok; + entry.Kind = TSchemeCacheNavigate::EKind::KindExtSubdomain; + entry.DomainInfo = MakeIntrusive(SERVERLESS_DOMAIN_KEY, SHARED_DOMAIN_KEY); + } else if (path == "/Root/shared" || entry.TableId.PathId == SHARED_DOMAIN_KEY) { + entry.Status = TSchemeCacheNavigate::EStatus::Ok; + entry.Kind = TSchemeCacheNavigate::EKind::KindExtSubdomain; + entry.DomainInfo = MakeIntrusive(SHARED_DOMAIN_KEY, SHARED_DOMAIN_KEY); + auto domains = runtime.GetAppData().DomainsInfo; + auto domain = domains->Domains.begin()->second; + ui64 hiveId = domains->GetHive(domain->DefaultHiveUid); + entry.DomainInfo->Params.SetHive(hiveId); + } else if (path == "/Root/serverless/users" || entry.TableId.PathId == SERVERLESS_TABLE) { + entry.Status = TSchemeCacheNavigate::EStatus::Ok; + entry.Kind = TSchemeCacheNavigate::EKind::KindTable; + entry.DomainInfo = MakeIntrusive(SERVERLESS_DOMAIN_KEY, SHARED_DOMAIN_KEY); + auto dirEntryInfo = MakeIntrusive(); + dirEntryInfo->Info.SetSchemeshardId(SERVERLESS_TABLE.OwnerId); + dirEntryInfo->Info.SetPathId(SERVERLESS_TABLE.LocalPathId); + entry.Self = dirEntryInfo; + } + } + + void ChangeBoardInfoServerless(TEvStateStorage::TEvBoardInfo::TPtr* ev, + const std::vector& sharedDynNodes = {}, + const std::vector& exclusiveDynNodes = {}) { + auto *record = (*ev)->Get(); + using EStatus = TEvStateStorage::TEvBoardInfo::EStatus; + if (record->Path == "gpc+/Root/serverless" && !exclusiveDynNodes.empty()) { + const_cast(record->Status) = EStatus::Ok; + for (auto exclusiveDynNodeId : exclusiveDynNodes) { + TActorId actorOnExclusiveDynNode = TActorId(exclusiveDynNodeId, 0, 0, 0); + record->InfoEntries[actorOnExclusiveDynNode] = {}; + } + } else if (record->Path == "gpc+/Root/shared" && !sharedDynNodes.empty()) { + const_cast(record->Status) = EStatus::Ok; + for (auto sharedDynNodeId : sharedDynNodes) { + TActorId actorOnSharedDynNode = TActorId(sharedDynNodeId, 0, 0, 0); + record->InfoEntries[actorOnSharedDynNode] = {}; + } + } + } + + void ChangeResponseHiveNodeStatsServerless(TEvHive::TEvResponseHiveNodeStats::TPtr* ev, + size_t sharedDynNode = 0, + size_t exclusiveDynNode = 0, + size_t exclusiveDynNodeWithTablet = 0) { + auto &record = (*ev)->Get()->Record; + if (sharedDynNode) { + auto *sharedNodeStats = record.MutableNodeStats()->Add(); + sharedNodeStats->SetNodeId(sharedDynNode); + sharedNodeStats->MutableNodeDomain()->SetSchemeShard(SHARED_DOMAIN_KEY.OwnerId); + sharedNodeStats->MutableNodeDomain()->SetPathId(SHARED_DOMAIN_KEY.LocalPathId); + } + + if (exclusiveDynNode) { + auto *exclusiveNodeStats = record.MutableNodeStats()->Add(); + exclusiveNodeStats->SetNodeId(exclusiveDynNode); + exclusiveNodeStats->MutableNodeDomain()->SetSchemeShard(SERVERLESS_DOMAIN_KEY.OwnerId); + exclusiveNodeStats->MutableNodeDomain()->SetPathId(SERVERLESS_DOMAIN_KEY.LocalPathId); + } + + if (exclusiveDynNodeWithTablet) { + auto *exclusiveDynNodeWithTabletStats = record.MutableNodeStats()->Add(); + exclusiveDynNodeWithTabletStats->SetNodeId(exclusiveDynNodeWithTablet); + exclusiveDynNodeWithTabletStats->MutableNodeDomain()->SetSchemeShard(SERVERLESS_DOMAIN_KEY.OwnerId); + exclusiveDynNodeWithTabletStats->MutableNodeDomain()->SetPathId(SERVERLESS_DOMAIN_KEY.LocalPathId); + + auto *stateStats = exclusiveDynNodeWithTabletStats->MutableStateStats()->Add(); + stateStats->SetTabletType(NKikimrTabletBase::TTabletTypes::DataShard); + stateStats->SetVolatileState(NKikimrHive::TABLET_VOLATILE_STATE_RUNNING); + stateStats->SetCount(1); + } + } + Y_UNIT_TEST(ServerlessNodesPage) { TPortManager tp; @@ -622,7 +705,7 @@ Y_UNIT_TEST_SUITE(Viewer) { TAutoPtr handle; THttpRequest httpReq(HTTP_METHOD_GET); - httpReq.CgiParameters.emplace("tenant", "/Root/serverless"); + httpReq.CgiParameters.emplace("path", "/Root/serverless"); httpReq.CgiParameters.emplace("tablets", "true"); httpReq.CgiParameters.emplace("enums", "true"); httpReq.CgiParameters.emplace("sort", ""); @@ -631,6 +714,39 @@ Y_UNIT_TEST_SUITE(Viewer) { TMonService2HttpRequest monReq(nullptr, &httpReq, nullptr, page.Get(), "/json/nodes", nullptr); auto request = MakeHolder(monReq); + size_t staticNodeId = 0; + size_t sharedDynNodeId = 0; + auto observerFunc = [&](TAutoPtr& ev) { + switch (ev->GetTypeRewrite()) { + case TEvTxProxySchemeCache::EvNavigateKeySetResult: { + auto *x = reinterpret_cast(&ev); + ChangeNavigateKeySetResultServerless(x, runtime); + break; + } + case TEvInterconnect::EvNodesInfo: { + auto *x = reinterpret_cast(&ev); + TVector &nodes = (*x)->Get()->Nodes; + UNIT_ASSERT_EQUAL(nodes.size(), 2); + staticNodeId = nodes[0]; + sharedDynNodeId = nodes[1]; + break; + } + case TEvStateStorage::EvBoardInfo: { + auto *x = reinterpret_cast(&ev); + ChangeBoardInfoServerless(x, { sharedDynNodeId }); + break; + } + case TEvHive::EvResponseHiveNodeStats: { + auto *x = reinterpret_cast(&ev); + ChangeResponseHiveNodeStatsServerless(x, sharedDynNodeId); + break; + } + } + + return TTestActorRuntime::EEventAction::PROCESS; + }; + runtime.SetObserverFunc(observerFunc); + runtime.Send(new IEventHandle(NKikimr::NViewer::MakeViewerID(0), sender, request.Release(), 0)); NMon::TEvHttpInfoRes* result = runtime.GrabEdgeEvent(handle); @@ -669,7 +785,7 @@ Y_UNIT_TEST_SUITE(Viewer) { TAutoPtr handle; THttpRequest httpReq(HTTP_METHOD_GET); - httpReq.CgiParameters.emplace("tenant", "/Root/serverless"); + httpReq.CgiParameters.emplace("path", "/Root/serverless"); httpReq.CgiParameters.emplace("tablets", "true"); httpReq.CgiParameters.emplace("enums", "true"); httpReq.CgiParameters.emplace("sort", ""); @@ -683,6 +799,11 @@ Y_UNIT_TEST_SUITE(Viewer) { size_t exclusiveDynNodeId = 0; auto observerFunc = [&](TAutoPtr& ev) { switch (ev->GetTypeRewrite()) { + case TEvTxProxySchemeCache::EvNavigateKeySetResult: { + auto *x = reinterpret_cast(&ev); + ChangeNavigateKeySetResultServerless(x, runtime); + break; + } case TEvInterconnect::EvNodesInfo: { auto *x = reinterpret_cast(&ev); TVector &nodes = (*x)->Get()->Nodes; @@ -694,11 +815,12 @@ Y_UNIT_TEST_SUITE(Viewer) { } case TEvStateStorage::EvBoardInfo: { auto *x = reinterpret_cast(&ev); - auto *record = (*x)->Get(); - using EStatus = TEvStateStorage::TEvBoardInfo::EStatus; - const_cast(record->Status) = EStatus::Ok; - TActorId actorOnExclusiveDynNode = TActorId(exclusiveDynNodeId, 0, 0, 0); - record->InfoEntries[actorOnExclusiveDynNode] = {}; + ChangeBoardInfoServerless(x, { sharedDynNodeId }, { exclusiveDynNodeId }); + break; + } + case TEvHive::EvResponseHiveNodeStats: { + auto *x = reinterpret_cast(&ev); + ChangeResponseHiveNodeStatsServerless(x, sharedDynNodeId, exclusiveDynNodeId); break; } } @@ -748,7 +870,7 @@ Y_UNIT_TEST_SUITE(Viewer) { TAutoPtr handle; THttpRequest httpReq(HTTP_METHOD_GET); - httpReq.CgiParameters.emplace("tenant", "Root/shared"); + httpReq.CgiParameters.emplace("path", "/Root/shared"); httpReq.CgiParameters.emplace("tablets", "true"); httpReq.CgiParameters.emplace("enums", "true"); httpReq.CgiParameters.emplace("sort", ""); @@ -762,6 +884,11 @@ Y_UNIT_TEST_SUITE(Viewer) { size_t exclusiveDynNodeId = 0; auto observerFunc = [&](TAutoPtr& ev) { switch (ev->GetTypeRewrite()) { + case TEvTxProxySchemeCache::EvNavigateKeySetResult: { + auto *x = reinterpret_cast(&ev); + ChangeNavigateKeySetResultServerless(x, runtime); + break; + } case TEvInterconnect::EvNodesInfo: { auto *x = reinterpret_cast(&ev); TVector &nodes = (*x)->Get()->Nodes; @@ -773,11 +900,12 @@ Y_UNIT_TEST_SUITE(Viewer) { } case TEvStateStorage::EvBoardInfo: { auto *x = reinterpret_cast(&ev); - auto *record = (*x)->Get(); - using EStatus = TEvStateStorage::TEvBoardInfo::EStatus; - const_cast(record->Status) = EStatus::Ok; - TActorId actorOnSharedDynNode = TActorId(sharedDynNodeId, 0, 0, 0); - record->InfoEntries[actorOnSharedDynNode] = {}; + ChangeBoardInfoServerless(x, { sharedDynNodeId }, { exclusiveDynNodeId }); + break; + } + case TEvHive::EvResponseHiveNodeStats: { + auto *x = reinterpret_cast(&ev); + ChangeResponseHiveNodeStatsServerless(x, sharedDynNodeId, exclusiveDynNodeId); break; } } @@ -827,7 +955,6 @@ Y_UNIT_TEST_SUITE(Viewer) { TAutoPtr handle; THttpRequest httpReq(HTTP_METHOD_GET); - httpReq.CgiParameters.emplace("tenant", "/Root/serverless"); httpReq.CgiParameters.emplace("path", "/Root/serverless/users"); httpReq.CgiParameters.emplace("tablets", "true"); httpReq.CgiParameters.emplace("enums", "true"); @@ -837,10 +964,6 @@ Y_UNIT_TEST_SUITE(Viewer) { TMonService2HttpRequest monReq(nullptr, &httpReq, nullptr, page.Get(), "/json/nodes", nullptr); auto request = MakeHolder(monReq); - const TPathId SERVERLESS_DOMAIN_KEY = {7000000000, 2}; - const TPathId SHARED_DOMAIN_KEY = {7000000000, 1}; - const TPathId SERVERLESS_TABLE = {7000000001, 2}; - size_t staticNodeId = 0; size_t sharedDynNodeId = 0; size_t exclusiveDynNodeId = 0; @@ -849,29 +972,7 @@ Y_UNIT_TEST_SUITE(Viewer) { switch (ev->GetTypeRewrite()) { case TEvTxProxySchemeCache::EvNavigateKeySetResult: { auto *x = reinterpret_cast(&ev); - TSchemeCacheNavigate::TEntry& entry((*x)->Get()->Request->ResultSet.front()); - TString path = CanonizePath(entry.Path); - if (path == "/Root/serverless" || entry.TableId.PathId == SERVERLESS_DOMAIN_KEY) { - entry.Status = TSchemeCacheNavigate::EStatus::Ok; - entry.Kind = TSchemeCacheNavigate::EKind::KindExtSubdomain; - entry.DomainInfo = MakeIntrusive(SERVERLESS_DOMAIN_KEY, SHARED_DOMAIN_KEY); - } else if (path == "/Root/shared" || entry.TableId.PathId == SHARED_DOMAIN_KEY) { - entry.Status = TSchemeCacheNavigate::EStatus::Ok; - entry.Kind = TSchemeCacheNavigate::EKind::KindExtSubdomain; - entry.DomainInfo = MakeIntrusive(SHARED_DOMAIN_KEY, SHARED_DOMAIN_KEY); - auto domains = runtime.GetAppData().DomainsInfo; - auto domain = domains->Domains.begin()->second; - ui64 hiveId = domains->GetHive(domain->DefaultHiveUid); - entry.DomainInfo->Params.SetHive(hiveId); - } else if (path == "/Root/serverless/users" || entry.TableId.PathId == SERVERLESS_TABLE) { - entry.Status = TSchemeCacheNavigate::EStatus::Ok; - entry.Kind = TSchemeCacheNavigate::EKind::KindTable; - entry.DomainInfo = MakeIntrusive(SERVERLESS_DOMAIN_KEY, SHARED_DOMAIN_KEY); - auto dirEntryInfo = MakeIntrusive(); - dirEntryInfo->Info.SetSchemeshardId(SERVERLESS_TABLE.OwnerId); - dirEntryInfo->Info.SetPathId(SERVERLESS_TABLE.LocalPathId); - entry.Self = dirEntryInfo; - } + ChangeNavigateKeySetResultServerless(x, runtime); break; } case TEvInterconnect::EvNodesInfo: { @@ -886,38 +987,12 @@ Y_UNIT_TEST_SUITE(Viewer) { } case TEvStateStorage::EvBoardInfo: { auto *x = reinterpret_cast(&ev); - auto *record = (*x)->Get(); - using EStatus = TEvStateStorage::TEvBoardInfo::EStatus; - const_cast(record->Status) = EStatus::Ok; - TActorId actorOnExclusiveDynNode = TActorId(exclusiveDynNodeId, 0, 0, 0); - record->InfoEntries[actorOnExclusiveDynNode] = {}; - TActorId actorOnSecondExclusiveDynNode = TActorId(secondExclusiveDynNodeId, 0, 0, 0); - record->InfoEntries[actorOnSecondExclusiveDynNode] = {}; + ChangeBoardInfoServerless(x, { sharedDynNodeId }, { exclusiveDynNodeId, secondExclusiveDynNodeId }); break; } case TEvHive::EvResponseHiveNodeStats: { auto *x = reinterpret_cast(&ev); - auto &record = (*x)->Get()->Record; - auto *sharedNodeStats = record.MutableNodeStats()->Add(); - sharedNodeStats->SetNodeId(sharedDynNodeId); - sharedNodeStats->MutableNodeDomain()->SetSchemeShard(SHARED_DOMAIN_KEY.OwnerId); - sharedNodeStats->MutableNodeDomain()->SetPathId(SHARED_DOMAIN_KEY.LocalPathId); - - auto *exclusiveNodeStats = record.MutableNodeStats()->Add(); - exclusiveNodeStats->SetNodeId(exclusiveDynNodeId); - exclusiveNodeStats->MutableNodeDomain()->SetSchemeShard(SERVERLESS_DOMAIN_KEY.OwnerId); - exclusiveNodeStats->MutableNodeDomain()->SetPathId(SERVERLESS_DOMAIN_KEY.LocalPathId); - - auto *secondExclusiveNodeStats = record.MutableNodeStats()->Add(); - secondExclusiveNodeStats->SetNodeId(secondExclusiveDynNodeId); - secondExclusiveNodeStats->MutableNodeDomain()->SetSchemeShard(SERVERLESS_DOMAIN_KEY.OwnerId); - secondExclusiveNodeStats->MutableNodeDomain()->SetPathId(SERVERLESS_DOMAIN_KEY.LocalPathId); - - // filtered one datashard from /Root/serverless/users - auto *stateStats = secondExclusiveNodeStats->MutableStateStats()->Add(); - stateStats->SetTabletType(NKikimrTabletBase::TTabletTypes::DataShard); - stateStats->SetVolatileState(NKikimrHive::TABLET_VOLATILE_STATE_RUNNING); - stateStats->SetCount(1); + ChangeResponseHiveNodeStatsServerless(x, sharedDynNodeId, exclusiveDynNodeId, secondExclusiveDynNodeId); break; } } From 385b62ed5c71202215340b3f8fbaf1a1d6f6ec9f Mon Sep 17 00:00:00 2001 From: ivanmorozov333 <111685085+ivanmorozov333@users.noreply.github.com> Date: Fri, 1 Mar 2024 10:11:46 +0300 Subject: [PATCH 042/117] Stable-24-1 CS patch (#2363) Co-authored-by: nsofya Co-authored-by: nsofya --- .../tx/columnshard/blobs_reader/actor.cpp | 2 +- .../engines/portions/column_record.cpp | 8 +--- .../engines/portions/portion_info.cpp | 36 --------------- .../engines/portions/portion_info.h | 45 +------------------ .../normalizer/abstract/abstract.h | 7 ++- .../columnshard/normalizer/portion/chunks.cpp | 2 +- .../normalizer/portion/min_max.cpp | 18 ++++---- .../normalizer/portion/normalizer.h | 14 +++--- .../tx/columnshard/splitter/chunk_meta.cpp | 6 +-- ydb/core/tx/columnshard/splitter/chunk_meta.h | 8 +--- 10 files changed, 31 insertions(+), 115 deletions(-) diff --git a/ydb/core/tx/columnshard/blobs_reader/actor.cpp b/ydb/core/tx/columnshard/blobs_reader/actor.cpp index 0ba5d774d2a9..c934ddef6d1a 100644 --- a/ydb/core/tx/columnshard/blobs_reader/actor.cpp +++ b/ydb/core/tx/columnshard/blobs_reader/actor.cpp @@ -15,7 +15,7 @@ void TActor::Handle(NBlobCache::TEvBlobCache::TEvReadBlobRangeResult::TPtr& ev) bool aborted = false; if (event.Status != NKikimrProto::EReplyStatus::OK) { WaitingBlobsCount.Sub(Task->GetWaitingCount()); - if (!Task->AddError(event.BlobRange, IBlobsReadingAction::TErrorStatus::Fail(event.Status, "cannot get blob: " + event.Data.substr(1024)))) { + if (!Task->AddError(event.BlobRange, IBlobsReadingAction::TErrorStatus::Fail(event.Status, "cannot get blob: " + event.Data.substr(0, 1024)))) { aborted = true; } } else { diff --git a/ydb/core/tx/columnshard/engines/portions/column_record.cpp b/ydb/core/tx/columnshard/engines/portions/column_record.cpp index 1c5ed366f149..07d9eb3bd397 100644 --- a/ydb/core/tx/columnshard/engines/portions/column_record.cpp +++ b/ydb/core/tx/columnshard/engines/portions/column_record.cpp @@ -14,10 +14,6 @@ TChunkMeta::TChunkMeta(const TColumnChunkLoadContext& context, const TIndexInfo& if (context.GetMetaProto().HasRawBytes()) { RawBytes = context.GetMetaProto().GetRawBytes(); } - if (context.GetMetaProto().HasMinValue()) { - AFL_VERIFY(field)("field_id", context.GetAddress().GetColumnId())("field_name", indexInfo.GetColumnName(context.GetAddress().GetColumnId())); - Min = ConstantToScalar(context.GetMetaProto().GetMinValue(), field->type()); - } if (context.GetMetaProto().HasMaxValue()) { AFL_VERIFY(field)("field_id", context.GetAddress().GetColumnId())("field_name", indexInfo.GetColumnName(context.GetAddress().GetColumnId())); Max = ConstantToScalar(context.GetMetaProto().GetMaxValue(), field->type()); @@ -37,9 +33,9 @@ NKikimrTxColumnShard::TIndexColumnMeta TChunkMeta::SerializeToProto() const { if (RawBytes) { meta.SetRawBytes(*RawBytes); } - if (HasMinMax()) { - ScalarToConstant(*Min, *meta.MutableMinValue()); + if (HasMax()) { ScalarToConstant(*Max, *meta.MutableMaxValue()); + ScalarToConstant(*Max, *meta.MutableMinValue()); } return meta; } diff --git a/ydb/core/tx/columnshard/engines/portions/portion_info.cpp b/ydb/core/tx/columnshard/engines/portions/portion_info.cpp index 23b21564ab85..f21d12eaab75 100644 --- a/ydb/core/tx/columnshard/engines/portions/portion_info.cpp +++ b/ydb/core/tx/columnshard/engines/portions/portion_info.cpp @@ -43,21 +43,6 @@ void TPortionInfo::AddMetadata(const ISnapshotSchema& snapshotSchema, const NArr Meta.SetTierName(tierName); } -std::shared_ptr TPortionInfo::MinValue(ui32 columnId) const { - std::shared_ptr result; - for (auto&& i : Records) { - if (i.ColumnId == columnId) { - if (!i.GetMeta().GetMin()) { - return nullptr; - } - if (!result || NArrow::ScalarCompare(result, i.GetMeta().GetMin()) > 0) { - result = i.GetMeta().GetMin(); - } - } - } - return result; -} - std::shared_ptr TPortionInfo::MaxValue(ui32 columnId) const { std::shared_ptr result; for (auto&& i : Records) { @@ -130,14 +115,6 @@ ui64 TPortionInfo::GetIndexBytes(const std::set& entityIds) const { return sum; } -int TPortionInfo::CompareSelfMaxItemMinByPk(const TPortionInfo& item, const TIndexInfo& info) const { - return CompareByColumnIdsImpl(item, info.KeyColumns); -} - -int TPortionInfo::CompareMinByPk(const TPortionInfo& item, const TIndexInfo& info) const { - return CompareMinByColumnIds(item, info.KeyColumns); -} - TString TPortionInfo::DebugString(const bool withDetails) const { TStringBuilder sb; sb << "(portion_id:" << Portion << ";" << @@ -179,19 +156,6 @@ void TPortionInfo::AddRecord(const TIndexInfo& indexInfo, const TColumnRecord& r } } -bool TPortionInfo::HasPkMinMax() const { - bool result = false; - for (auto&& i : Records) { - if (i.ColumnId == Meta.FirstPkColumn) { - if (!i.GetMeta().HasMinMax()) { - return false; - } - result = true; - } - } - return result; -} - std::vector TPortionInfo::GetColumnChunksPointers(const ui32 columnId) const { std::vector result; for (auto&& c : Records) { diff --git a/ydb/core/tx/columnshard/engines/portions/portion_info.h b/ydb/core/tx/columnshard/engines/portions/portion_info.h index d5a052ae52c6..30b96733868d 100644 --- a/ydb/core/tx/columnshard/engines/portions/portion_info.h +++ b/ydb/core/tx/columnshard/engines/portions/portion_info.h @@ -23,7 +23,6 @@ class TPortionInfo { TSnapshot MinSnapshot = TSnapshot::Zero(); // {PlanStep, TxId} is min snapshot for {Granule, Portion} TSnapshot RemoveSnapshot = TSnapshot::Zero(); // {XPlanStep, XTxId} is snapshot where the blob has been removed (i.e. compacted into another one) - bool HasPkMinMax() const; TPortionMeta Meta; std::shared_ptr BlobsOperator; ui64 DeprecatedGranuleId = 0; @@ -190,7 +189,7 @@ class TPortionInfo { bool Empty() const { return Records.empty(); } bool Produced() const { return Meta.GetProduced() != TPortionMeta::EProduced::UNSPECIFIED; } - bool Valid() const { return MinSnapshot.Valid() && PathId && Portion && !Empty() && Produced() && HasPkMinMax() && Meta.IndexKeyStart && Meta.IndexKeyEnd; } + bool Valid() const { return MinSnapshot.Valid() && PathId && Portion && !Empty() && Produced() && Meta.IndexKeyStart && Meta.IndexKeyEnd; } bool ValidSnapshotInfo() const { return MinSnapshot.Valid() && PathId && Portion; } bool IsInserted() const { return Meta.GetProduced() == TPortionMeta::EProduced::INSERTED; } bool IsEvicted() const { return Meta.GetProduced() == TPortionMeta::EProduced::EVICTED; } @@ -338,7 +337,6 @@ class TPortionInfo { void AddMetadata(const ISnapshotSchema& snapshotSchema, const NArrow::TFirstLastSpecialKeys& primaryKeys, const NArrow::TMinMaxSpecialKeys& snapshotKeys, const TString& tierName); - std::shared_ptr MinValue(ui32 columnId) const; std::shared_ptr MaxValue(ui32 columnId) const; const NArrow::TReplaceKey& IndexKeyStart() const { @@ -414,48 +412,7 @@ class TPortionInfo { return GetRawBytes(); } -private: - class TMinGetter { - public: - static std::shared_ptr Get(const TPortionInfo& portionInfo, const ui32 columnId) { - return portionInfo.MinValue(columnId); - } - }; - - class TMaxGetter { - public: - static std::shared_ptr Get(const TPortionInfo& portionInfo, const ui32 columnId) { - return portionInfo.MaxValue(columnId); - } - }; - - template - int CompareByColumnIdsImpl(const TPortionInfo& item, const std::vector& columnIds) const { - for (auto&& i : columnIds) { - std::shared_ptr valueSelf = TSelfGetter::Get(*this, i); - std::shared_ptr valueItem = TItemGetter::Get(item, i); - if (!!valueSelf && !!valueItem) { - const int cmpResult = NArrow::ScalarCompare(valueSelf, valueItem); - if (cmpResult) { - return cmpResult; - } - } else if (!!valueSelf) { - return 1; - } else if (!!valueItem) { - return -1; - } - } - return 0; - } public: - int CompareSelfMaxItemMinByPk(const TPortionInfo& item, const TIndexInfo& info) const; - - int CompareMinByPk(const TPortionInfo& item, const TIndexInfo& info) const; - - int CompareMinByColumnIds(const TPortionInfo& item, const std::vector& columnIds) const { - return CompareByColumnIdsImpl(item, columnIds); - } - class TAssembleBlobInfo { private: ui32 NullRowsCount = 0; diff --git a/ydb/core/tx/columnshard/normalizer/abstract/abstract.h b/ydb/core/tx/columnshard/normalizer/abstract/abstract.h index 538e1a1d44f0..fadda5ce13ac 100644 --- a/ydb/core/tx/columnshard/normalizer/abstract/abstract.h +++ b/ydb/core/tx/columnshard/normalizer/abstract/abstract.h @@ -49,6 +49,11 @@ namespace NKikimr::NOlap { class TNormalizationContext { YDB_ACCESSOR_DEF(TActorId, ResourceSubscribeActor); YDB_ACCESSOR_DEF(TActorId, ColumnshardActor); + std::shared_ptr ResourcesGuard; + public: + void SetResourcesGuard(std::shared_ptr rg) { + ResourcesGuard = rg; + } }; class TNormalizationController; @@ -117,7 +122,7 @@ namespace NKikimr::NOlap { TString DebugString() const { return TStringBuilder() << "normalizers_count=" << Normalizers.size() << ";current_normalizer_idx=" << CurrentNormalizerIndex - << ";current_normalizer=" << (CurrentNormalizerIndex < Normalizers.size()) ? Normalizers[CurrentNormalizerIndex]->GetName() : ""; + << ";current_normalizer=" << (CurrentNormalizerIndex < Normalizers.size() ? Normalizers[CurrentNormalizerIndex]->GetName() : ""); } const INormalizerComponent::TPtr& GetNormalizer() const; diff --git a/ydb/core/tx/columnshard/normalizer/portion/chunks.cpp b/ydb/core/tx/columnshard/normalizer/portion/chunks.cpp index 6ed01b83baad..81525fc0f905 100644 --- a/ydb/core/tx/columnshard/normalizer/portion/chunks.cpp +++ b/ydb/core/tx/columnshard/normalizer/portion/chunks.cpp @@ -68,7 +68,7 @@ class TRowsAndBytesChangesTask: public NConveyor::ITask { } public: - TRowsAndBytesChangesTask(THashMap&& blobs, const TNormalizationContext& nCtx, std::vector&& chunks, THashMap&&) + TRowsAndBytesChangesTask(THashMap&& blobs, const TNormalizationContext& nCtx, std::vector&& chunks, std::shared_ptr>) : Blobs(std::move(blobs)) , Chunks(std::move(chunks)) , NormContext(nCtx) diff --git a/ydb/core/tx/columnshard/normalizer/portion/min_max.cpp b/ydb/core/tx/columnshard/normalizer/portion/min_max.cpp index efdaf4d95169..974efa329712 100644 --- a/ydb/core/tx/columnshard/normalizer/portion/min_max.cpp +++ b/ydb/core/tx/columnshard/normalizer/portion/min_max.cpp @@ -16,16 +16,16 @@ class TMinMaxSnapshotChangesTask: public NConveyor::ITask { private: THashMap Blobs; TDataContainer Portions; - THashMap Schemas; + std::shared_ptr> Schemas; TNormalizationContext NormContext; protected: virtual bool DoExecute() override { - Y_ABORT_UNLESS(!Schemas.empty()); - auto pkColumnIds = Schemas.begin()->second->GetPkColumnsIds(); + Y_ABORT_UNLESS(!Schemas->empty()); + auto pkColumnIds = Schemas->begin()->second->GetPkColumnsIds(); pkColumnIds.insert(TIndexInfo::GetSpecialColumnIds().begin(), TIndexInfo::GetSpecialColumnIds().end()); for (auto&& portionInfo : Portions) { - auto blobSchema = Schemas.FindPtr(portionInfo->GetPortionId()); + auto blobSchema = Schemas->FindPtr(portionInfo->GetPortionId()); THashMap blobsDataAssemble; for (auto&& i : portionInfo->Records) { auto blobIt = Blobs.find(i.BlobRange); @@ -47,10 +47,10 @@ class TMinMaxSnapshotChangesTask: public NConveyor::ITask { } public: - TMinMaxSnapshotChangesTask(THashMap&& blobs, const TNormalizationContext& nCtx, TDataContainer&& portions, THashMap&& schemas) + TMinMaxSnapshotChangesTask(THashMap&& blobs, const TNormalizationContext& nCtx, TDataContainer&& portions, std::shared_ptr> schemas) : Blobs(std::move(blobs)) , Portions(std::move(portions)) - , Schemas(std::move(schemas)) + , Schemas(schemas) , NormContext(nCtx) {} @@ -135,7 +135,7 @@ TConclusion> TPortionsNormalizer::Init(const } THashMap> portions; - THashMap schemas; + auto schemas = std::make_shared>(); auto pkColumnIds = TMinMaxSnapshotChangesTask::GetColumnsFilter(tablesManager.GetPrimaryIndexSafe().GetVersionedIndex().GetLastSchema()); { @@ -161,7 +161,7 @@ TConclusion> TPortionsNormalizer::Init(const auto portionMeta = loadContext.GetPortionMeta(); if (it == portions.end()) { Y_ABORT_UNLESS(portion.Records.empty()); - schemas[portion.GetPortionId()] = currentSchema; + (*schemas)[portion.GetPortionId()] = currentSchema; auto portionNew = std::make_shared(portion); portionNew->AddRecord(currentSchema->GetIndexInfo(), rec, portionMeta); it = portions.emplace(portion.GetPortion(), portionNew).first; @@ -202,7 +202,7 @@ TConclusion> TPortionsNormalizer::Init(const } ++brokenPortioncCount; package.emplace_back(portion.second); - if (package.size() == 100) { + if (package.size() == 1000) { std::vector> local; local.swap(package); tasks.emplace_back(std::make_shared>(std::move(local), schemas)); diff --git a/ydb/core/tx/columnshard/normalizer/portion/normalizer.h b/ydb/core/tx/columnshard/normalizer/portion/normalizer.h index 5cb952f68ae1..7c86476e724f 100644 --- a/ydb/core/tx/columnshard/normalizer/portion/normalizer.h +++ b/ydb/core/tx/columnshard/normalizer/portion/normalizer.h @@ -18,11 +18,11 @@ class TReadPortionsTask: public NOlap::NBlobOperations::NRead::ITask { private: using TBase = NOlap::NBlobOperations::NRead::ITask; typename TConveyorTask::TDataContainer Data; - THashMap Schemas; + std::shared_ptr> Schemas; TNormalizationContext NormContext; public: - TReadPortionsTask(const TNormalizationContext& nCtx, const std::vector>& actions, typename TConveyorTask::TDataContainer&& data, THashMap&& schemas) + TReadPortionsTask(const TNormalizationContext& nCtx, const std::vector>& actions, typename TConveyorTask::TDataContainer&& data, std::shared_ptr> schemas) : TBase(actions, "CS::NORMALIZER") , Data(std::move(data)) , Schemas(std::move(schemas)) @@ -32,8 +32,8 @@ class TReadPortionsTask: public NOlap::NBlobOperations::NRead::ITask { protected: virtual void DoOnDataReady(const std::shared_ptr& resourcesGuard) override { - Y_UNUSED(resourcesGuard); - std::shared_ptr task = std::make_shared(std::move(ExtractBlobsData()), NormContext, std::move(Data), std::move(Schemas)); + NormContext.SetResourcesGuard(resourcesGuard); + std::shared_ptr task = std::make_shared(std::move(ExtractBlobsData()), NormContext, std::move(Data), Schemas); NConveyor::TCompServiceOperator::SendTaskToExecute(task); } @@ -49,13 +49,13 @@ class TReadPortionsTask: public NOlap::NBlobOperations::NRead::ITask { template class TPortionsNormalizerTask : public INormalizerTask { typename TConveyorTask::TDataContainer Package; - THashMap Schemas; + std::shared_ptr> Schemas; public: TPortionsNormalizerTask(typename TConveyorTask::TDataContainer&& package) : Package(std::move(package)) {} - TPortionsNormalizerTask(typename TConveyorTask::TDataContainer&& package, const THashMap& schemas) + TPortionsNormalizerTask(typename TConveyorTask::TDataContainer&& package, const std::shared_ptr> schemas) : Package(std::move(package)) , Schemas(schemas) {} @@ -71,7 +71,7 @@ class TPortionsNormalizerTask : public INormalizerTask { std::vector> actions = {readingAction}; NOlap::NResourceBroker::NSubscribe::ITask::StartResourceSubscription( nCtx.GetResourceSubscribeActor(),std::make_shared( - std::make_shared>( nCtx, actions, std::move(Package), std::move(Schemas) ), 1, memSize, "CS::NORMALIZER", controller.GetTaskSubscription())); + std::make_shared>(nCtx, actions, std::move(Package), Schemas), 1, memSize, "CS::NORMALIZER", controller.GetTaskSubscription())); } }; } diff --git a/ydb/core/tx/columnshard/splitter/chunk_meta.cpp b/ydb/core/tx/columnshard/splitter/chunk_meta.cpp index cfa9bb2afb19..646a458638dd 100644 --- a/ydb/core/tx/columnshard/splitter/chunk_meta.cpp +++ b/ydb/core/tx/columnshard/splitter/chunk_meta.cpp @@ -4,13 +4,13 @@ namespace NKikimr::NOlap { -TSimpleChunkMeta::TSimpleChunkMeta(const std::shared_ptr& column, const bool needMinMax, const bool isSortedColumn) { +TSimpleChunkMeta::TSimpleChunkMeta(const std::shared_ptr& column, const bool needMax, const bool isSortedColumn) { Y_ABORT_UNLESS(column); Y_ABORT_UNLESS(column->length()); NumRows = column->length(); RawBytes = NArrow::GetArrayDataSize(column); - if (needMinMax) { + if (needMax) { std::pair minMaxPos = {0, (column->length() - 1)}; if (!isSortedColumn) { minMaxPos = NArrow::FindMinMaxPosition(column); @@ -18,10 +18,8 @@ TSimpleChunkMeta::TSimpleChunkMeta(const std::shared_ptr& column, Y_ABORT_UNLESS(minMaxPos.second >= 0); } - Min = NArrow::GetScalar(column, minMaxPos.first); Max = NArrow::GetScalar(column, minMaxPos.second); - Y_ABORT_UNLESS(Min); Y_ABORT_UNLESS(Max); } } diff --git a/ydb/core/tx/columnshard/splitter/chunk_meta.h b/ydb/core/tx/columnshard/splitter/chunk_meta.h index ce23529f90f2..4f367dde2f2f 100644 --- a/ydb/core/tx/columnshard/splitter/chunk_meta.h +++ b/ydb/core/tx/columnshard/splitter/chunk_meta.h @@ -12,7 +12,6 @@ namespace NKikimr::NOlap { class TSimpleChunkMeta { protected: - std::shared_ptr Min; std::shared_ptr Max; std::optional NumRows; std::optional RawBytes; @@ -25,9 +24,6 @@ class TSimpleChunkMeta { return sizeof(ui32) + sizeof(ui32) + 8 * 3 * 2; } - std::shared_ptr GetMin() const { - return Min; - } std::shared_ptr GetMax() const { return Max; } @@ -49,8 +45,8 @@ class TSimpleChunkMeta { return *RawBytes; } - bool HasMinMax() const noexcept { - return Min.get() && Max.get(); + bool HasMax() const noexcept { + return Max.get(); } }; From b7a3970f9aa7ea1dc3690bb8cf60c274f0d6f0d6 Mon Sep 17 00:00:00 2001 From: Andrei Rykov Date: Fri, 1 Mar 2024 09:07:14 +0100 Subject: [PATCH 043/117] YDB-1453 updated CORS response headers to healthcheck handler (#2174) - merge 24-1 (#2318) --- ydb/core/viewer/counters_hosts.h | 8 +++++--- ydb/core/viewer/json_acl.h | 2 +- ydb/core/viewer/json_describe.h | 2 +- ydb/core/viewer/json_healthcheck.h | 18 ++++++++++-------- ydb/core/viewer/json_hotkeys.h | 2 +- ydb/core/viewer/json_local_rpc.h | 6 +++--- ydb/core/viewer/viewer.cpp | 28 ++++++++++++++++++++++++++++ ydb/core/viewer/viewer.h | 8 ++------ 8 files changed, 51 insertions(+), 23 deletions(-) diff --git a/ydb/core/viewer/counters_hosts.h b/ydb/core/viewer/counters_hosts.h index 55a2cc89a78b..9a65349aae2d 100644 --- a/ydb/core/viewer/counters_hosts.h +++ b/ydb/core/viewer/counters_hosts.h @@ -16,6 +16,7 @@ using namespace NActors; using namespace NNodeWhiteboard; class TCountersHostsList : public TActorBootstrapped { + IViewer* Viewer; NMon::TEvHttpInfo::TPtr Event; THolder NodesInfo; TMap> NodesResponses; @@ -29,8 +30,9 @@ class TCountersHostsList : public TActorBootstrapped { return NKikimrServices::TActivity::VIEWER_HANDLER; } - TCountersHostsList(IViewer*, NMon::TEvHttpInfo::TPtr& ev) - : Event(ev) + TCountersHostsList(IViewer* viewer, NMon::TEvHttpInfo::TPtr& ev) + : Viewer(viewer) + , Event(ev) {} void Bootstrap(const TActorContext& ctx) { @@ -145,7 +147,7 @@ class TCountersHostsList : public TActorBootstrapped { } } } - ctx.Send(Event->Sender, new NMon::TEvHttpInfoRes(HTTPOKTEXT + text.Str(), 0, NMon::IEvHttpInfoRes::EContentType::Custom)); + ctx.Send(Event->Sender, new NMon::TEvHttpInfoRes(Viewer->GetHTTPOKTEXT(Event->Get()) + text.Str(), 0, NMon::IEvHttpInfoRes::EContentType::Custom)); Die(ctx); } diff --git a/ydb/core/viewer/json_acl.h b/ydb/core/viewer/json_acl.h index d12df854f2f8..c18aff601294 100644 --- a/ydb/core/viewer/json_acl.h +++ b/ydb/core/viewer/json_acl.h @@ -155,7 +155,7 @@ class TJsonACL : public TViewerPipeClient { switch (DescribeResult->GetRecord().GetStatus()) { case NKikimrScheme::StatusAccessDenied: - headers = HTTPFORBIDDENJSON; + headers = Viewer->GetHTTPFORBIDDEN(Event->Get()); break; default: break; diff --git a/ydb/core/viewer/json_describe.h b/ydb/core/viewer/json_describe.h index 36a03a8daca4..709a7e62d2f6 100644 --- a/ydb/core/viewer/json_describe.h +++ b/ydb/core/viewer/json_describe.h @@ -265,7 +265,7 @@ class TJsonDescribe : public TViewerPipeClient { const auto *descriptor = NKikimrScheme::EStatus_descriptor(); auto accessDeniedStatus = descriptor->FindValueByNumber(NKikimrScheme::StatusAccessDenied)->name(); if (DescribeResult->GetStatus() == accessDeniedStatus) { - headers = HTTPFORBIDDENJSON; + headers = Viewer->GetHTTPFORBIDDEN(Event->Get()); } TProtoToJson::ProtoToJson(json, *DescribeResult, JsonSettings); } else { diff --git a/ydb/core/viewer/json_healthcheck.h b/ydb/core/viewer/json_healthcheck.h index fd55e460f620..67c62469cfae 100644 --- a/ydb/core/viewer/json_healthcheck.h +++ b/ydb/core/viewer/json_healthcheck.h @@ -24,6 +24,7 @@ enum HealthCheckResponseFormat { }; class TJsonHealthCheck : public TActorBootstrapped { + IViewer* Viewer; static const bool WithRetry = false; NMon::TEvHttpInfo::TPtr Event; TJsonSettings JsonSettings; @@ -36,8 +37,9 @@ class TJsonHealthCheck : public TActorBootstrapped { return NKikimrServices::TActivity::VIEWER_HANDLER; } - TJsonHealthCheck(IViewer*, NMon::TEvHttpInfo::TPtr& ev) - : Event(ev) + TJsonHealthCheck(IViewer* viewer, NMon::TEvHttpInfo::TPtr& ev) + : Viewer(viewer) + , Event(ev) {} void Bootstrap(const TActorContext& ctx) { @@ -78,7 +80,7 @@ class TJsonHealthCheck : public TActorBootstrapped { if (Ydb::Monitoring::StatusFlag_Status_Parse(params.Get("min_status"), &minStatus)) { request->Request.set_minimum_status(minStatus); } else { - Send(Event->Sender, new NMon::TEvHttpInfoRes(HTTPBADREQUEST, 0, NMon::IEvHttpInfoRes::EContentType::Custom)); + Send(Event->Sender, new NMon::TEvHttpInfoRes(Viewer->GetHTTPBADREQUEST(Event->Get()), 0, NMon::IEvHttpInfoRes::EContentType::Custom)); return PassAway(); } } @@ -104,7 +106,7 @@ class TJsonHealthCheck : public TActorBootstrapped { THashMap recordCounters; for (auto& log : ev->Get()->Result.issue_log()) { TMetricRecord record { - .Database = log.location().database().name(), + .Database = log.location().database().name(), .Message = log.message(), .Status = descriptor->FindValueByNumber(log.status())->name(), .Type = log.type() @@ -124,7 +126,7 @@ class TJsonHealthCheck : public TActorBootstrapped { void HandleJSON(NHealthCheck::TEvSelfCheckResult::TPtr& ev, const TActorContext &ctx) { TStringStream json; TProtoToJson::ProtoToJson(json, ev->Get()->Result, JsonSettings); - ctx.Send(Event->Sender, new NMon::TEvHttpInfoRes(HTTPOKJSON + json.Str(), 0, NMon::IEvHttpInfoRes::EContentType::Custom)); + ctx.Send(Event->Sender, new NMon::TEvHttpInfoRes(Viewer->GetHTTPOKJSON(Event->Get()) + json.Str(), 0, NMon::IEvHttpInfoRes::EContentType::Custom)); Die(ctx); } @@ -134,7 +136,7 @@ class TJsonHealthCheck : public TActorBootstrapped { TStringStream ss; IMetricEncoderPtr encoder = EncoderPrometheus(&ss); IMetricEncoder* e = encoder.Get(); - + TIntrusivePtr domains = AppData()->DomainsInfo; TIntrusivePtr domain = domains->Domains.begin()->second; auto filterDatabase = Database ? Database : "/" + domain->Name; @@ -173,7 +175,7 @@ class TJsonHealthCheck : public TActorBootstrapped { e->OnMetricEnd(); e->OnStreamEnd(); - ctx.Send(Event->Sender, new NMon::TEvHttpInfoRes(HTTPOKTEXT + ss.Str(), 0, NMon::IEvHttpInfoRes::EContentType::Custom)); + ctx.Send(Event->Sender, new NMon::TEvHttpInfoRes(Viewer->GetHTTPOKTEXT(Event->Get()) + ss.Str(), 0, NMon::IEvHttpInfoRes::EContentType::Custom)); Die(ctx); } @@ -186,7 +188,7 @@ class TJsonHealthCheck : public TActorBootstrapped { } void HandleTimeout(const TActorContext &ctx) { - Send(Event->Sender, new NMon::TEvHttpInfoRes(HTTPGATEWAYTIMEOUT, 0, NMon::IEvHttpInfoRes::EContentType::Custom)); + Send(Event->Sender, new NMon::TEvHttpInfoRes(Viewer->GetHTTPGATEWAYTIMEOUT(Event->Get()), 0, NMon::IEvHttpInfoRes::EContentType::Custom)); Die(ctx); } }; diff --git a/ydb/core/viewer/json_hotkeys.h b/ydb/core/viewer/json_hotkeys.h index 0aad63c9ed44..92e4b7e2a7ce 100644 --- a/ydb/core/viewer/json_hotkeys.h +++ b/ydb/core/viewer/json_hotkeys.h @@ -143,7 +143,7 @@ class TJsonHotkeys : public TViewerPipeClient { if (DescribeResult != nullptr) { switch (DescribeResult->GetRecord().GetStatus()) { case NKikimrScheme::StatusAccessDenied: - headers = HTTPFORBIDDENJSON; + headers = Viewer->GetHTTPFORBIDDEN(Event->Get()); break; default: break; diff --git a/ydb/core/viewer/json_local_rpc.h b/ydb/core/viewer/json_local_rpc.h index 6e3c54e4c516..b15a3ce88501 100644 --- a/ydb/core/viewer/json_local_rpc.h +++ b/ydb/core/viewer/json_local_rpc.h @@ -131,7 +131,7 @@ class TJsonLocalRpc : public TActorBootstrappedSender, new NMon::TEvHttpInfoRes(HTTPBADREQUEST, 0, NMon::IEvHttpInfoRes::EContentType::Custom)); + Send(Event->Sender, new NMon::TEvHttpInfoRes(Viewer->GetHTTPBADREQUEST(Event->Get(), {}, "Bad Request"), 0, NMon::IEvHttpInfoRes::EContentType::Custom)); PassAway(); } } else { @@ -195,9 +195,9 @@ class TJsonLocalRpc : public TActorBootstrappedGetHTTPOKJSON(Event->Get()); if (DescribeResult) { if (!DescribeResult->Status->IsSuccess()) { - headers = HTTPBADREQUEST; + headers = Viewer->GetHTTPBADREQUEST(Event->Get(), {}, "Bad Request"); if (DescribeResult->Status->GetStatus() == NYdb::EStatus::UNAUTHORIZED) { - headers = HTTPFORBIDDENJSON; + headers = Viewer->GetHTTPFORBIDDEN(Event->Get()); } } else { TProtoToJson::ProtoToJson(json, *(DescribeResult->Message), JsonSettings); diff --git a/ydb/core/viewer/viewer.cpp b/ydb/core/viewer/viewer.cpp index 65279dd2cbeb..42f71ad27ddb 100644 --- a/ydb/core/viewer/viewer.cpp +++ b/ydb/core/viewer/viewer.cpp @@ -152,9 +152,11 @@ class TViewer : public TActorBootstrapped, public IViewer { TString GetCORS(const NMon::TEvHttpInfo* request) override; TString GetHTTPOKJSON(const NMon::TEvHttpInfo* request, TString response) override; + TString GetHTTPOKTEXT(const NMon::TEvHttpInfo* request, TString response) override; TString GetHTTPOK(const NMon::TEvHttpInfo* request, TString type, TString response) override; TString GetHTTPGATEWAYTIMEOUT(const NMon::TEvHttpInfo* request) override; TString GetHTTPBADREQUEST(const NMon::TEvHttpInfo* request, TString type, TString response) override; + TString GetHTTPFORBIDDEN(const NMon::TEvHttpInfo* request) override; void RegisterVirtualHandler( NKikimrViewer::EObjectType parentObjectType, @@ -467,6 +469,22 @@ TString TViewer::GetHTTPOKJSON(const NMon::TEvHttpInfo* request, TString respons return res; } +TString TViewer::GetHTTPOKTEXT(const NMon::TEvHttpInfo* request, TString response) { + TStringBuilder res; + res << "HTTP/1.1 200 Ok\r\n" + << "Content-Type: text/plain; charset=utf-8\r\n" + << "X-Worker-Name: " << CurrentWorkerName << "\r\n"; + res << GetCORS(request); + if (response) { + res << "Content-Length: " << response.size() << "\r\n"; + } + res << "\r\n"; + if (response) { + res << response; + } + return res; +} + TString TViewer::GetHTTPGATEWAYTIMEOUT(const NMon::TEvHttpInfo* request) { TStringBuilder res; res << "HTTP/1.1 504 Gateway Time-out\r\n" @@ -492,6 +510,16 @@ TString TViewer::GetHTTPBADREQUEST(const NMon::TEvHttpInfo* request, TString con return res; } +TString TViewer::GetHTTPFORBIDDEN(const NMon::TEvHttpInfo* request) { + TStringBuilder res; + res << "HTTP/1.1 403 Forbidden\r\n" + << "Content-Type: application/json; charset=utf-8\r\n" + << "Connection: Close\r\n"; + res << GetCORS(request); + res << "\r\n"; + return res; +} + TString TViewer::GetHTTPOK(const NMon::TEvHttpInfo* request, TString contentType = {}, TString response = {}) { TStringBuilder res; res << "HTTP/1.1 200 Ok\r\n" diff --git a/ydb/core/viewer/viewer.h b/ydb/core/viewer/viewer.h index 7fdab30f8332..fd58e6d8f535 100644 --- a/ydb/core/viewer/viewer.h +++ b/ydb/core/viewer/viewer.h @@ -156,8 +156,10 @@ class IViewer { virtual TString GetCORS(const NMon::TEvHttpInfo* request) = 0; virtual TString GetHTTPOK(const NMon::TEvHttpInfo* request, TString contentType = {}, TString response = {}) = 0; virtual TString GetHTTPOKJSON(const NMon::TEvHttpInfo* request, TString response = {}) = 0; + virtual TString GetHTTPOKTEXT(const NMon::TEvHttpInfo* request, TString response = {}) = 0; virtual TString GetHTTPGATEWAYTIMEOUT(const NMon::TEvHttpInfo* request) = 0; virtual TString GetHTTPBADREQUEST(const NMon::TEvHttpInfo* request, TString contentType = {}, TString response = {}) = 0; + virtual TString GetHTTPFORBIDDEN(const NMon::TEvHttpInfo* request) = 0; }; void SetupPQVirtualHandlers(IViewer* viewer); @@ -184,12 +186,6 @@ struct TJsonRequestParameters { static TString GetParameters() { return TString(); } }; -static const char HTTPOKJSON[] = "HTTP/1.1 200 Ok\r\nAccess-Control-Allow-Origin: *\r\nContent-Type: application/json; charset=utf-8\r\nConnection: Close\r\n\r\n"; -static const char HTTPOKTEXT[] = "HTTP/1.1 200 Ok\r\nAccess-Control-Allow-Origin: *\r\nContent-Type: text/plain; charset=utf-8\r\nConnection: Close\r\n\r\n"; -static const char HTTPFORBIDDENJSON[] = "HTTP/1.1 403 Forbidden\r\nAccess-Control-Allow-Origin: *\r\nContent-Type: application/json; charset=utf-8\r\nConnection: Close\r\n\r\n"; -static const char HTTPGATEWAYTIMEOUT[] = "HTTP/1.1 504 Gateway Time-out\r\nConnection: Close\r\n\r\nGateway Time-out\r\n"; -static const char HTTPBADREQUEST[] = "HTTP/1.1 400 Bad Request\r\nConnection: Close\r\n\r\nBad Request\r\n"; - template void GenericSplitIds(TStringBuf source, char delim, OutputIteratorType it) { for (TStringBuf value = source.NextTok(delim); !value.empty(); value = source.NextTok(delim)) { From d2983fe915a7543e50c867faf867cdd177e80b87 Mon Sep 17 00:00:00 2001 From: Sergey Belyakov Date: Fri, 1 Mar 2024 18:27:24 +0300 Subject: [PATCH 044/117] Remove compatibility with 23-3 (#2377) --- ydb/core/driver_lib/version/version.cpp | 13 +++++++------ 1 file changed, 7 insertions(+), 6 deletions(-) diff --git a/ydb/core/driver_lib/version/version.cpp b/ydb/core/driver_lib/version/version.cpp index 37e4ae626562..b57042bde71b 100644 --- a/ydb/core/driver_lib/version/version.cpp +++ b/ydb/core/driver_lib/version/version.cpp @@ -34,21 +34,23 @@ TCompatibilityInfo::TCompatibilityInfo() { }, .CanLoadFrom = { TCompatibilityRuleConstructor{ - .Application = "ydb", - .LowerLimit = TVersionConstructor{ .Year = 23, .Major = 3 }, + .LowerLimit = TVersionConstructor{ .Year = 23, .Major = 4 }, .UpperLimit = TVersionConstructor{ .Year = 24, .Major = 1 }, }, }, .StoresReadableBy = { TCompatibilityRuleConstructor{ - .Application = "ydb", - .LowerLimit = TVersionConstructor{ .Year = 23, .Major = 3 }, + .LowerLimit = TVersionConstructor{ .Year = 23, .Major = 4 }, .UpperLimit = TVersionConstructor{ .Year = 24, .Major = 1 }, }, }, .CanConnectTo = { TCompatibilityRuleConstructor{ - .Application = "ydb", + .LowerLimit = TVersionConstructor{ .Year = 23, .Major = 4 }, + .UpperLimit = TVersionConstructor{ .Year = 24, .Major = 1 }, + }, + TCompatibilityRuleConstructor{ + .Application = "nbs", .LowerLimit = TVersionConstructor{ .Year = 23, .Major = 3 }, .UpperLimit = TVersionConstructor{ .Year = 24, .Major = 1 }, }, @@ -107,7 +109,6 @@ TMaybe VERSION = NActors::TInte // compatible versions; must include all compatible old ones, including this one; version verification occurs on both // peers and connection is accepted if at least one of peers accepts the version of the other peer { - "stable-23-3", "stable-23-4", "stable-24-1" } From 5f8846db29b5775d382c19f2263782edd0fac88c Mon Sep 17 00:00:00 2001 From: Mikhail Surin Date: Fri, 1 Mar 2024 18:32:19 +0300 Subject: [PATCH 045/117] Merge to 24-1 (#2367) --- .../opt/logical/kqp_opt_log_ranges_predext.cpp | 2 +- ydb/core/kqp/ut/opt/kqp_ne_ut.cpp | 16 ++++++++++++++++ 2 files changed, 17 insertions(+), 1 deletion(-) diff --git a/ydb/core/kqp/opt/logical/kqp_opt_log_ranges_predext.cpp b/ydb/core/kqp/opt/logical/kqp_opt_log_ranges_predext.cpp index a4ed3c3c62bf..c53270ac283d 100644 --- a/ydb/core/kqp/opt/logical/kqp_opt_log_ranges_predext.cpp +++ b/ydb/core/kqp/opt/logical/kqp_opt_log_ranges_predext.cpp @@ -366,7 +366,7 @@ TExprBase KqpPushExtractedPredicateToReadTable(TExprBase node, TExprContext& ctx if (buildResult.ExpectedMaxRanges.Defined()) { prompt.SetExpectedMaxRanges(buildResult.ExpectedMaxRanges.GetRef()); } - prompt.SetPointPrefixLen(buildResult.UsedPrefixLen); + prompt.SetPointPrefixLen(buildResult.PointPrefixLen); YQL_CLOG(DEBUG, ProviderKqp) << "Ranges extracted: " << KqpExprToPrettyString(*ranges, ctx); YQL_CLOG(DEBUG, ProviderKqp) << "Residual lambda: " << KqpExprToPrettyString(*residualLambda, ctx); diff --git a/ydb/core/kqp/ut/opt/kqp_ne_ut.cpp b/ydb/core/kqp/ut/opt/kqp_ne_ut.cpp index 8744f969f7a8..68edda6abfbf 100644 --- a/ydb/core/kqp/ut/opt/kqp_ne_ut.cpp +++ b/ydb/core/kqp/ut/opt/kqp_ne_ut.cpp @@ -2639,6 +2639,22 @@ Y_UNIT_TEST_SUITE(KqpNewEngine) { ])", FormatResultSetYson(result.GetResultSet(0))); } + Y_UNIT_TEST(DeleteON) { + auto kikimr = DefaultKikimrRunner(); + auto db = kikimr.GetTableClient(); + auto session = db.CreateSession().GetValueSync().GetSession(); + + NYdb::NTable::TExecDataQuerySettings execSettings; + execSettings.CollectQueryStats(ECollectQueryStatsMode::Basic); + + auto result = session.ExecuteDataQuery(R"( + --!syntax_v1 + + DELETE FROM `/Root/Join2` where (Key1 = 1 and Key2 = "") OR Key1 = 3; + )", TTxControl::BeginTx().CommitTx(), execSettings).ExtractValueSync(); + UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, result.GetIssues().ToString()); + } + Y_UNIT_TEST(JoinWithPrecompute) { auto kikimr = DefaultKikimrRunner(); auto db = kikimr.GetTableClient(); From fba36c09adb434f5a0b7799ef7d3b1477e9d1c5c Mon Sep 17 00:00:00 2001 From: Maxim Gorbunov Date: Sun, 3 Mar 2024 18:19:37 +0100 Subject: [PATCH 046/117] Regenerate CMakeLists (#2401) --- .../formats/arrow/CMakeLists.darwin-arm64.txt | 1 - .../arrow/CMakeLists.darwin-x86_64.txt | 1 - .../arrow/CMakeLists.linux-aarch64.txt | 1 - .../formats/arrow/CMakeLists.linux-x86_64.txt | 1 - .../arrow/CMakeLists.windows-x86_64.txt | 1 - .../serializer/CMakeLists.darwin-arm64.txt | 18 ++++++- .../serializer/CMakeLists.darwin-x86_64.txt | 18 ++++++- .../serializer/CMakeLists.linux-aarch64.txt | 19 +++++++- .../serializer/CMakeLists.linux-x86_64.txt | 19 +++++++- .../serializer/CMakeLists.windows-x86_64.txt | 18 ++++++- .../operations/CMakeLists.darwin-arm64.txt | 4 +- .../operations/CMakeLists.darwin-x86_64.txt | 4 +- .../operations/CMakeLists.linux-aarch64.txt | 4 +- .../operations/CMakeLists.linux-x86_64.txt | 4 +- .../operations/CMakeLists.windows-x86_64.txt | 4 +- .../common/CMakeLists.darwin-arm64.txt | 3 ++ .../common/CMakeLists.darwin-x86_64.txt | 3 ++ .../common/CMakeLists.linux-aarch64.txt | 3 ++ .../common/CMakeLists.linux-x86_64.txt | 3 ++ .../common/CMakeLists.windows-x86_64.txt | 3 ++ .../common/protos/CMakeLists.darwin-arm64.txt | 46 ++++++++++++++++++ .../protos/CMakeLists.darwin-x86_64.txt | 46 ++++++++++++++++++ .../protos/CMakeLists.linux-aarch64.txt | 47 +++++++++++++++++++ .../common/protos/CMakeLists.linux-x86_64.txt | 47 +++++++++++++++++++ .../columnshard/common/protos/CMakeLists.txt | 19 ++++++++ .../protos/CMakeLists.windows-x86_64.txt | 46 ++++++++++++++++++ .../counters/CMakeLists.darwin-arm64.txt | 12 +++++ .../counters/CMakeLists.darwin-x86_64.txt | 12 +++++ .../counters/CMakeLists.linux-aarch64.txt | 12 +++++ .../counters/CMakeLists.linux-x86_64.txt | 12 +++++ .../counters/CMakeLists.windows-x86_64.txt | 12 +++++ .../engines/CMakeLists.darwin-arm64.txt | 1 - .../engines/CMakeLists.darwin-x86_64.txt | 1 - .../engines/CMakeLists.linux-aarch64.txt | 1 - .../engines/CMakeLists.linux-x86_64.txt | 1 - .../engines/CMakeLists.windows-x86_64.txt | 1 - .../engines/ut/CMakeLists.darwin-arm64.txt | 7 +-- .../engines/ut/CMakeLists.darwin-x86_64.txt | 7 +-- .../engines/ut/CMakeLists.linux-aarch64.txt | 7 +-- .../engines/ut/CMakeLists.linux-x86_64.txt | 7 +-- .../engines/ut/CMakeLists.windows-x86_64.txt | 7 +-- .../splitter/ut/CMakeLists.darwin-arm64.txt | 1 - .../splitter/ut/CMakeLists.darwin-x86_64.txt | 1 - .../splitter/ut/CMakeLists.linux-aarch64.txt | 1 - .../splitter/ut/CMakeLists.linux-x86_64.txt | 1 - .../splitter/ut/CMakeLists.windows-x86_64.txt | 1 - .../schemeshard/CMakeLists.darwin-arm64.txt | 1 - .../schemeshard/CMakeLists.darwin-x86_64.txt | 1 - .../schemeshard/CMakeLists.linux-aarch64.txt | 1 - .../schemeshard/CMakeLists.linux-x86_64.txt | 1 - .../schemeshard/CMakeLists.windows-x86_64.txt | 1 - .../olap/columns/CMakeLists.darwin-arm64.txt | 3 +- .../olap/columns/CMakeLists.darwin-x86_64.txt | 3 +- .../olap/columns/CMakeLists.linux-aarch64.txt | 3 +- .../olap/columns/CMakeLists.linux-x86_64.txt | 3 +- .../columns/CMakeLists.windows-x86_64.txt | 3 +- .../olap/common/CMakeLists.darwin-arm64.txt | 1 + .../olap/common/CMakeLists.darwin-x86_64.txt | 1 + .../olap/common/CMakeLists.linux-aarch64.txt | 1 + .../olap/common/CMakeLists.linux-x86_64.txt | 1 + .../olap/common/CMakeLists.windows-x86_64.txt | 1 + .../tiering/rule/CMakeLists.darwin-arm64.txt | 2 + .../tiering/rule/CMakeLists.darwin-x86_64.txt | 2 + .../tiering/rule/CMakeLists.linux-aarch64.txt | 2 + .../tiering/rule/CMakeLists.linux-x86_64.txt | 2 + .../rule/CMakeLists.windows-x86_64.txt | 2 + .../abstract/CMakeLists.darwin-arm64.txt | 1 - .../abstract/CMakeLists.darwin-x86_64.txt | 1 - .../abstract/CMakeLists.linux-aarch64.txt | 1 - .../abstract/CMakeLists.linux-x86_64.txt | 1 - .../abstract/CMakeLists.windows-x86_64.txt | 1 - 71 files changed, 463 insertions(+), 65 deletions(-) create mode 100644 ydb/core/tx/columnshard/common/protos/CMakeLists.darwin-arm64.txt create mode 100644 ydb/core/tx/columnshard/common/protos/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/core/tx/columnshard/common/protos/CMakeLists.linux-aarch64.txt create mode 100644 ydb/core/tx/columnshard/common/protos/CMakeLists.linux-x86_64.txt create mode 100644 ydb/core/tx/columnshard/common/protos/CMakeLists.txt create mode 100644 ydb/core/tx/columnshard/common/protos/CMakeLists.windows-x86_64.txt diff --git a/ydb/core/formats/arrow/CMakeLists.darwin-arm64.txt b/ydb/core/formats/arrow/CMakeLists.darwin-arm64.txt index 96ab2157e829..8c8d349fc9ff 100644 --- a/ydb/core/formats/arrow/CMakeLists.darwin-arm64.txt +++ b/ydb/core/formats/arrow/CMakeLists.darwin-arm64.txt @@ -7,7 +7,6 @@ add_subdirectory(common) -add_subdirectory(compression) add_subdirectory(dictionary) add_subdirectory(hash) add_subdirectory(reader) diff --git a/ydb/core/formats/arrow/CMakeLists.darwin-x86_64.txt b/ydb/core/formats/arrow/CMakeLists.darwin-x86_64.txt index 96ab2157e829..8c8d349fc9ff 100644 --- a/ydb/core/formats/arrow/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/formats/arrow/CMakeLists.darwin-x86_64.txt @@ -7,7 +7,6 @@ add_subdirectory(common) -add_subdirectory(compression) add_subdirectory(dictionary) add_subdirectory(hash) add_subdirectory(reader) diff --git a/ydb/core/formats/arrow/CMakeLists.linux-aarch64.txt b/ydb/core/formats/arrow/CMakeLists.linux-aarch64.txt index bee6ba5a47fe..048cb62cfeb4 100644 --- a/ydb/core/formats/arrow/CMakeLists.linux-aarch64.txt +++ b/ydb/core/formats/arrow/CMakeLists.linux-aarch64.txt @@ -7,7 +7,6 @@ add_subdirectory(common) -add_subdirectory(compression) add_subdirectory(dictionary) add_subdirectory(hash) add_subdirectory(reader) diff --git a/ydb/core/formats/arrow/CMakeLists.linux-x86_64.txt b/ydb/core/formats/arrow/CMakeLists.linux-x86_64.txt index bee6ba5a47fe..048cb62cfeb4 100644 --- a/ydb/core/formats/arrow/CMakeLists.linux-x86_64.txt +++ b/ydb/core/formats/arrow/CMakeLists.linux-x86_64.txt @@ -7,7 +7,6 @@ add_subdirectory(common) -add_subdirectory(compression) add_subdirectory(dictionary) add_subdirectory(hash) add_subdirectory(reader) diff --git a/ydb/core/formats/arrow/CMakeLists.windows-x86_64.txt b/ydb/core/formats/arrow/CMakeLists.windows-x86_64.txt index 17376b66d573..729f3b6b52f0 100644 --- a/ydb/core/formats/arrow/CMakeLists.windows-x86_64.txt +++ b/ydb/core/formats/arrow/CMakeLists.windows-x86_64.txt @@ -7,7 +7,6 @@ add_subdirectory(common) -add_subdirectory(compression) add_subdirectory(dictionary) add_subdirectory(hash) add_subdirectory(reader) diff --git a/ydb/core/formats/arrow/serializer/CMakeLists.darwin-arm64.txt b/ydb/core/formats/arrow/serializer/CMakeLists.darwin-arm64.txt index 157c1f3be538..2c9a89ff5c5c 100644 --- a/ydb/core/formats/arrow/serializer/CMakeLists.darwin-arm64.txt +++ b/ydb/core/formats/arrow/serializer/CMakeLists.darwin-arm64.txt @@ -13,12 +13,26 @@ target_link_libraries(formats-arrow-serializer PUBLIC yutil libs-apache-arrow formats-arrow-common + services-metadata-abstract library-actors-core ydb-core-protos ) target_sources(formats-arrow-serializer PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/abstract.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/full.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/batch_only.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/stream.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/parsing.cpp +) + +add_global_library_for(formats-arrow-serializer.global formats-arrow-serializer) +target_link_libraries(formats-arrow-serializer.global PUBLIC + contrib-libs-cxxsupp + yutil + libs-apache-arrow + formats-arrow-common + services-metadata-abstract + library-actors-core + ydb-core-protos +) +target_sources(formats-arrow-serializer.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/native.cpp ) diff --git a/ydb/core/formats/arrow/serializer/CMakeLists.darwin-x86_64.txt b/ydb/core/formats/arrow/serializer/CMakeLists.darwin-x86_64.txt index 157c1f3be538..2c9a89ff5c5c 100644 --- a/ydb/core/formats/arrow/serializer/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/formats/arrow/serializer/CMakeLists.darwin-x86_64.txt @@ -13,12 +13,26 @@ target_link_libraries(formats-arrow-serializer PUBLIC yutil libs-apache-arrow formats-arrow-common + services-metadata-abstract library-actors-core ydb-core-protos ) target_sources(formats-arrow-serializer PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/abstract.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/full.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/batch_only.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/stream.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/parsing.cpp +) + +add_global_library_for(formats-arrow-serializer.global formats-arrow-serializer) +target_link_libraries(formats-arrow-serializer.global PUBLIC + contrib-libs-cxxsupp + yutil + libs-apache-arrow + formats-arrow-common + services-metadata-abstract + library-actors-core + ydb-core-protos +) +target_sources(formats-arrow-serializer.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/native.cpp ) diff --git a/ydb/core/formats/arrow/serializer/CMakeLists.linux-aarch64.txt b/ydb/core/formats/arrow/serializer/CMakeLists.linux-aarch64.txt index 9faab4d0ae87..eb79f403ca0f 100644 --- a/ydb/core/formats/arrow/serializer/CMakeLists.linux-aarch64.txt +++ b/ydb/core/formats/arrow/serializer/CMakeLists.linux-aarch64.txt @@ -14,12 +14,27 @@ target_link_libraries(formats-arrow-serializer PUBLIC yutil libs-apache-arrow formats-arrow-common + services-metadata-abstract library-actors-core ydb-core-protos ) target_sources(formats-arrow-serializer PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/abstract.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/full.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/batch_only.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/stream.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/parsing.cpp +) + +add_global_library_for(formats-arrow-serializer.global formats-arrow-serializer) +target_link_libraries(formats-arrow-serializer.global PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + libs-apache-arrow + formats-arrow-common + services-metadata-abstract + library-actors-core + ydb-core-protos +) +target_sources(formats-arrow-serializer.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/native.cpp ) diff --git a/ydb/core/formats/arrow/serializer/CMakeLists.linux-x86_64.txt b/ydb/core/formats/arrow/serializer/CMakeLists.linux-x86_64.txt index 9faab4d0ae87..eb79f403ca0f 100644 --- a/ydb/core/formats/arrow/serializer/CMakeLists.linux-x86_64.txt +++ b/ydb/core/formats/arrow/serializer/CMakeLists.linux-x86_64.txt @@ -14,12 +14,27 @@ target_link_libraries(formats-arrow-serializer PUBLIC yutil libs-apache-arrow formats-arrow-common + services-metadata-abstract library-actors-core ydb-core-protos ) target_sources(formats-arrow-serializer PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/abstract.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/full.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/batch_only.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/stream.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/parsing.cpp +) + +add_global_library_for(formats-arrow-serializer.global formats-arrow-serializer) +target_link_libraries(formats-arrow-serializer.global PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + libs-apache-arrow + formats-arrow-common + services-metadata-abstract + library-actors-core + ydb-core-protos +) +target_sources(formats-arrow-serializer.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/native.cpp ) diff --git a/ydb/core/formats/arrow/serializer/CMakeLists.windows-x86_64.txt b/ydb/core/formats/arrow/serializer/CMakeLists.windows-x86_64.txt index 157c1f3be538..2c9a89ff5c5c 100644 --- a/ydb/core/formats/arrow/serializer/CMakeLists.windows-x86_64.txt +++ b/ydb/core/formats/arrow/serializer/CMakeLists.windows-x86_64.txt @@ -13,12 +13,26 @@ target_link_libraries(formats-arrow-serializer PUBLIC yutil libs-apache-arrow formats-arrow-common + services-metadata-abstract library-actors-core ydb-core-protos ) target_sources(formats-arrow-serializer PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/abstract.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/full.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/batch_only.cpp ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/stream.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/parsing.cpp +) + +add_global_library_for(formats-arrow-serializer.global formats-arrow-serializer) +target_link_libraries(formats-arrow-serializer.global PUBLIC + contrib-libs-cxxsupp + yutil + libs-apache-arrow + formats-arrow-common + services-metadata-abstract + library-actors-core + ydb-core-protos +) +target_sources(formats-arrow-serializer.global PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/formats/arrow/serializer/native.cpp ) diff --git a/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.darwin-arm64.txt index 2b1f5330fe0e..1f72c8267ead 100644 --- a/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.darwin-arm64.txt @@ -15,7 +15,7 @@ target_link_libraries(behaviour-tablestore-operations PUBLIC contrib-libs-cxxsupp yutil services-metadata-manager - formats-arrow-compression + formats-arrow-serializer kqp-gateway-utils ydb-core-protos ) @@ -31,7 +31,7 @@ target_link_libraries(behaviour-tablestore-operations.global PUBLIC contrib-libs-cxxsupp yutil services-metadata-manager - formats-arrow-compression + formats-arrow-serializer kqp-gateway-utils ydb-core-protos ) diff --git a/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.darwin-x86_64.txt index 2b1f5330fe0e..1f72c8267ead 100644 --- a/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.darwin-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(behaviour-tablestore-operations PUBLIC contrib-libs-cxxsupp yutil services-metadata-manager - formats-arrow-compression + formats-arrow-serializer kqp-gateway-utils ydb-core-protos ) @@ -31,7 +31,7 @@ target_link_libraries(behaviour-tablestore-operations.global PUBLIC contrib-libs-cxxsupp yutil services-metadata-manager - formats-arrow-compression + formats-arrow-serializer kqp-gateway-utils ydb-core-protos ) diff --git a/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.linux-aarch64.txt index 03ac6ec850a7..105ae681cc11 100644 --- a/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.linux-aarch64.txt @@ -16,7 +16,7 @@ target_link_libraries(behaviour-tablestore-operations PUBLIC contrib-libs-cxxsupp yutil services-metadata-manager - formats-arrow-compression + formats-arrow-serializer kqp-gateway-utils ydb-core-protos ) @@ -33,7 +33,7 @@ target_link_libraries(behaviour-tablestore-operations.global PUBLIC contrib-libs-cxxsupp yutil services-metadata-manager - formats-arrow-compression + formats-arrow-serializer kqp-gateway-utils ydb-core-protos ) diff --git a/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.linux-x86_64.txt index 03ac6ec850a7..105ae681cc11 100644 --- a/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.linux-x86_64.txt @@ -16,7 +16,7 @@ target_link_libraries(behaviour-tablestore-operations PUBLIC contrib-libs-cxxsupp yutil services-metadata-manager - formats-arrow-compression + formats-arrow-serializer kqp-gateway-utils ydb-core-protos ) @@ -33,7 +33,7 @@ target_link_libraries(behaviour-tablestore-operations.global PUBLIC contrib-libs-cxxsupp yutil services-metadata-manager - formats-arrow-compression + formats-arrow-serializer kqp-gateway-utils ydb-core-protos ) diff --git a/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.windows-x86_64.txt index 2b1f5330fe0e..1f72c8267ead 100644 --- a/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/gateway/behaviour/tablestore/operations/CMakeLists.windows-x86_64.txt @@ -15,7 +15,7 @@ target_link_libraries(behaviour-tablestore-operations PUBLIC contrib-libs-cxxsupp yutil services-metadata-manager - formats-arrow-compression + formats-arrow-serializer kqp-gateway-utils ydb-core-protos ) @@ -31,7 +31,7 @@ target_link_libraries(behaviour-tablestore-operations.global PUBLIC contrib-libs-cxxsupp yutil services-metadata-manager - formats-arrow-compression + formats-arrow-serializer kqp-gateway-utils ydb-core-protos ) diff --git a/ydb/core/tx/columnshard/common/CMakeLists.darwin-arm64.txt b/ydb/core/tx/columnshard/common/CMakeLists.darwin-arm64.txt index fb413280b2d1..ee1185c2ff92 100644 --- a/ydb/core/tx/columnshard/common/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/columnshard/common/CMakeLists.darwin-arm64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(protos) add_subdirectory(tests) get_built_tool_path( TOOL_enum_parser_bin @@ -21,9 +22,11 @@ target_link_libraries(tx-columnshard-common PUBLIC ydb-core-protos libs-apache-arrow core-formats-arrow + columnshard-common-protos tools-enum_parser-enum_serialization_runtime ) target_sources(tx-columnshard-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/limits.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/reverse_accessor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/scalars.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/snapshot.cpp diff --git a/ydb/core/tx/columnshard/common/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/columnshard/common/CMakeLists.darwin-x86_64.txt index fb413280b2d1..ee1185c2ff92 100644 --- a/ydb/core/tx/columnshard/common/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/columnshard/common/CMakeLists.darwin-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(protos) add_subdirectory(tests) get_built_tool_path( TOOL_enum_parser_bin @@ -21,9 +22,11 @@ target_link_libraries(tx-columnshard-common PUBLIC ydb-core-protos libs-apache-arrow core-formats-arrow + columnshard-common-protos tools-enum_parser-enum_serialization_runtime ) target_sources(tx-columnshard-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/limits.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/reverse_accessor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/scalars.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/snapshot.cpp diff --git a/ydb/core/tx/columnshard/common/CMakeLists.linux-aarch64.txt b/ydb/core/tx/columnshard/common/CMakeLists.linux-aarch64.txt index 6d584af68a8e..ea2ea81db813 100644 --- a/ydb/core/tx/columnshard/common/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/columnshard/common/CMakeLists.linux-aarch64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(protos) add_subdirectory(tests) get_built_tool_path( TOOL_enum_parser_bin @@ -22,9 +23,11 @@ target_link_libraries(tx-columnshard-common PUBLIC ydb-core-protos libs-apache-arrow core-formats-arrow + columnshard-common-protos tools-enum_parser-enum_serialization_runtime ) target_sources(tx-columnshard-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/limits.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/reverse_accessor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/scalars.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/snapshot.cpp diff --git a/ydb/core/tx/columnshard/common/CMakeLists.linux-x86_64.txt b/ydb/core/tx/columnshard/common/CMakeLists.linux-x86_64.txt index 6d584af68a8e..ea2ea81db813 100644 --- a/ydb/core/tx/columnshard/common/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/columnshard/common/CMakeLists.linux-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(protos) add_subdirectory(tests) get_built_tool_path( TOOL_enum_parser_bin @@ -22,9 +23,11 @@ target_link_libraries(tx-columnshard-common PUBLIC ydb-core-protos libs-apache-arrow core-formats-arrow + columnshard-common-protos tools-enum_parser-enum_serialization_runtime ) target_sources(tx-columnshard-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/limits.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/reverse_accessor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/scalars.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/snapshot.cpp diff --git a/ydb/core/tx/columnshard/common/CMakeLists.windows-x86_64.txt b/ydb/core/tx/columnshard/common/CMakeLists.windows-x86_64.txt index fb413280b2d1..ee1185c2ff92 100644 --- a/ydb/core/tx/columnshard/common/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/columnshard/common/CMakeLists.windows-x86_64.txt @@ -6,6 +6,7 @@ # original buildsystem will not be accepted. +add_subdirectory(protos) add_subdirectory(tests) get_built_tool_path( TOOL_enum_parser_bin @@ -21,9 +22,11 @@ target_link_libraries(tx-columnshard-common PUBLIC ydb-core-protos libs-apache-arrow core-formats-arrow + columnshard-common-protos tools-enum_parser-enum_serialization_runtime ) target_sources(tx-columnshard-common PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/limits.h ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/reverse_accessor.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/scalars.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/snapshot.cpp diff --git a/ydb/core/tx/columnshard/common/protos/CMakeLists.darwin-arm64.txt b/ydb/core/tx/columnshard/common/protos/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..db46f04807c5 --- /dev/null +++ b/ydb/core/tx/columnshard/common/protos/CMakeLists.darwin-arm64.txt @@ -0,0 +1,46 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) + +add_library(columnshard-common-protos) +target_link_libraries(columnshard-common-protos PUBLIC + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf +) +target_proto_messages(columnshard-common-protos PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/protos/snapshot.proto +) +target_sources(columnshard-common-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/tx/columnshard/common/protos/snapshot.pb.h +) +target_proto_addincls(columnshard-common-protos + ./ + ${CMAKE_SOURCE_DIR}/ + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src +) +target_proto_outs(columnshard-common-protos + --cpp_out=${CMAKE_BINARY_DIR}/ + --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ +) diff --git a/ydb/core/tx/columnshard/common/protos/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/columnshard/common/protos/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..db46f04807c5 --- /dev/null +++ b/ydb/core/tx/columnshard/common/protos/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,46 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) + +add_library(columnshard-common-protos) +target_link_libraries(columnshard-common-protos PUBLIC + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf +) +target_proto_messages(columnshard-common-protos PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/protos/snapshot.proto +) +target_sources(columnshard-common-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/tx/columnshard/common/protos/snapshot.pb.h +) +target_proto_addincls(columnshard-common-protos + ./ + ${CMAKE_SOURCE_DIR}/ + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src +) +target_proto_outs(columnshard-common-protos + --cpp_out=${CMAKE_BINARY_DIR}/ + --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ +) diff --git a/ydb/core/tx/columnshard/common/protos/CMakeLists.linux-aarch64.txt b/ydb/core/tx/columnshard/common/protos/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..13d79958d794 --- /dev/null +++ b/ydb/core/tx/columnshard/common/protos/CMakeLists.linux-aarch64.txt @@ -0,0 +1,47 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) + +add_library(columnshard-common-protos) +target_link_libraries(columnshard-common-protos PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf +) +target_proto_messages(columnshard-common-protos PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/protos/snapshot.proto +) +target_sources(columnshard-common-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/tx/columnshard/common/protos/snapshot.pb.h +) +target_proto_addincls(columnshard-common-protos + ./ + ${CMAKE_SOURCE_DIR}/ + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src +) +target_proto_outs(columnshard-common-protos + --cpp_out=${CMAKE_BINARY_DIR}/ + --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ +) diff --git a/ydb/core/tx/columnshard/common/protos/CMakeLists.linux-x86_64.txt b/ydb/core/tx/columnshard/common/protos/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..13d79958d794 --- /dev/null +++ b/ydb/core/tx/columnshard/common/protos/CMakeLists.linux-x86_64.txt @@ -0,0 +1,47 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) + +add_library(columnshard-common-protos) +target_link_libraries(columnshard-common-protos PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf +) +target_proto_messages(columnshard-common-protos PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/protos/snapshot.proto +) +target_sources(columnshard-common-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/tx/columnshard/common/protos/snapshot.pb.h +) +target_proto_addincls(columnshard-common-protos + ./ + ${CMAKE_SOURCE_DIR}/ + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src +) +target_proto_outs(columnshard-common-protos + --cpp_out=${CMAKE_BINARY_DIR}/ + --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ +) diff --git a/ydb/core/tx/columnshard/common/protos/CMakeLists.txt b/ydb/core/tx/columnshard/common/protos/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/core/tx/columnshard/common/protos/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/core/tx/columnshard/common/protos/CMakeLists.windows-x86_64.txt b/ydb/core/tx/columnshard/common/protos/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..db46f04807c5 --- /dev/null +++ b/ydb/core/tx/columnshard/common/protos/CMakeLists.windows-x86_64.txt @@ -0,0 +1,46 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +get_built_tool_path( + TOOL_protoc_bin + TOOL_protoc_dependency + contrib/tools/protoc/bin + protoc +) +get_built_tool_path( + TOOL_cpp_styleguide_bin + TOOL_cpp_styleguide_dependency + contrib/tools/protoc/plugins/cpp_styleguide + cpp_styleguide +) + +add_library(columnshard-common-protos) +target_link_libraries(columnshard-common-protos PUBLIC + contrib-libs-cxxsupp + yutil + contrib-libs-protobuf +) +target_proto_messages(columnshard-common-protos PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/common/protos/snapshot.proto +) +target_sources(columnshard-common-protos PRIVATE + ${CMAKE_BINARY_DIR}/ydb/core/tx/columnshard/common/protos/snapshot.pb.h +) +target_proto_addincls(columnshard-common-protos + ./ + ${CMAKE_SOURCE_DIR}/ + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src + ${CMAKE_BINARY_DIR} + ${CMAKE_SOURCE_DIR}/contrib/libs/protobuf/src +) +target_proto_outs(columnshard-common-protos + --cpp_out=${CMAKE_BINARY_DIR}/ + --cpp_styleguide_out=${CMAKE_BINARY_DIR}/ +) diff --git a/ydb/core/tx/columnshard/counters/CMakeLists.darwin-arm64.txt b/ydb/core/tx/columnshard/counters/CMakeLists.darwin-arm64.txt index b67a55fc728e..4d5344c2c183 100644 --- a/ydb/core/tx/columnshard/counters/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/columnshard/counters/CMakeLists.darwin-arm64.txt @@ -7,6 +7,12 @@ add_subdirectory(common) +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) add_library(tx-columnshard-counters) target_link_libraries(tx-columnshard-counters PUBLIC @@ -15,6 +21,7 @@ target_link_libraries(tx-columnshard-counters PUBLIC cpp-monlib-dynamic_counters columnshard-counters-common ydb-core-base + tools-enum_parser-enum_serialization_runtime ) target_sources(tx-columnshard-counters PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters/indexation.cpp @@ -26,3 +33,8 @@ target_sources(tx-columnshard-counters PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters/common_data.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters/splitter.cpp ) +generate_enum_serilization(tx-columnshard-counters + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters/columnshard.h + INCLUDE_HEADERS + ydb/core/tx/columnshard/counters/columnshard.h +) diff --git a/ydb/core/tx/columnshard/counters/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/columnshard/counters/CMakeLists.darwin-x86_64.txt index b67a55fc728e..4d5344c2c183 100644 --- a/ydb/core/tx/columnshard/counters/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/columnshard/counters/CMakeLists.darwin-x86_64.txt @@ -7,6 +7,12 @@ add_subdirectory(common) +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) add_library(tx-columnshard-counters) target_link_libraries(tx-columnshard-counters PUBLIC @@ -15,6 +21,7 @@ target_link_libraries(tx-columnshard-counters PUBLIC cpp-monlib-dynamic_counters columnshard-counters-common ydb-core-base + tools-enum_parser-enum_serialization_runtime ) target_sources(tx-columnshard-counters PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters/indexation.cpp @@ -26,3 +33,8 @@ target_sources(tx-columnshard-counters PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters/common_data.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters/splitter.cpp ) +generate_enum_serilization(tx-columnshard-counters + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters/columnshard.h + INCLUDE_HEADERS + ydb/core/tx/columnshard/counters/columnshard.h +) diff --git a/ydb/core/tx/columnshard/counters/CMakeLists.linux-aarch64.txt b/ydb/core/tx/columnshard/counters/CMakeLists.linux-aarch64.txt index 24d27e404383..df515f503c80 100644 --- a/ydb/core/tx/columnshard/counters/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/columnshard/counters/CMakeLists.linux-aarch64.txt @@ -7,6 +7,12 @@ add_subdirectory(common) +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) add_library(tx-columnshard-counters) target_link_libraries(tx-columnshard-counters PUBLIC @@ -16,6 +22,7 @@ target_link_libraries(tx-columnshard-counters PUBLIC cpp-monlib-dynamic_counters columnshard-counters-common ydb-core-base + tools-enum_parser-enum_serialization_runtime ) target_sources(tx-columnshard-counters PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters/indexation.cpp @@ -27,3 +34,8 @@ target_sources(tx-columnshard-counters PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters/common_data.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters/splitter.cpp ) +generate_enum_serilization(tx-columnshard-counters + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters/columnshard.h + INCLUDE_HEADERS + ydb/core/tx/columnshard/counters/columnshard.h +) diff --git a/ydb/core/tx/columnshard/counters/CMakeLists.linux-x86_64.txt b/ydb/core/tx/columnshard/counters/CMakeLists.linux-x86_64.txt index 24d27e404383..df515f503c80 100644 --- a/ydb/core/tx/columnshard/counters/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/columnshard/counters/CMakeLists.linux-x86_64.txt @@ -7,6 +7,12 @@ add_subdirectory(common) +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) add_library(tx-columnshard-counters) target_link_libraries(tx-columnshard-counters PUBLIC @@ -16,6 +22,7 @@ target_link_libraries(tx-columnshard-counters PUBLIC cpp-monlib-dynamic_counters columnshard-counters-common ydb-core-base + tools-enum_parser-enum_serialization_runtime ) target_sources(tx-columnshard-counters PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters/indexation.cpp @@ -27,3 +34,8 @@ target_sources(tx-columnshard-counters PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters/common_data.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters/splitter.cpp ) +generate_enum_serilization(tx-columnshard-counters + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters/columnshard.h + INCLUDE_HEADERS + ydb/core/tx/columnshard/counters/columnshard.h +) diff --git a/ydb/core/tx/columnshard/counters/CMakeLists.windows-x86_64.txt b/ydb/core/tx/columnshard/counters/CMakeLists.windows-x86_64.txt index b67a55fc728e..4d5344c2c183 100644 --- a/ydb/core/tx/columnshard/counters/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/columnshard/counters/CMakeLists.windows-x86_64.txt @@ -7,6 +7,12 @@ add_subdirectory(common) +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) add_library(tx-columnshard-counters) target_link_libraries(tx-columnshard-counters PUBLIC @@ -15,6 +21,7 @@ target_link_libraries(tx-columnshard-counters PUBLIC cpp-monlib-dynamic_counters columnshard-counters-common ydb-core-base + tools-enum_parser-enum_serialization_runtime ) target_sources(tx-columnshard-counters PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters/indexation.cpp @@ -26,3 +33,8 @@ target_sources(tx-columnshard-counters PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters/common_data.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters/splitter.cpp ) +generate_enum_serilization(tx-columnshard-counters + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/counters/columnshard.h + INCLUDE_HEADERS + ydb/core/tx/columnshard/counters/columnshard.h +) diff --git a/ydb/core/tx/columnshard/engines/CMakeLists.darwin-arm64.txt b/ydb/core/tx/columnshard/engines/CMakeLists.darwin-arm64.txt index 41ff6614c5b3..dcfcc1d3275d 100644 --- a/ydb/core/tx/columnshard/engines/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/columnshard/engines/CMakeLists.darwin-arm64.txt @@ -36,7 +36,6 @@ target_link_libraries(tx-columnshard-engines PUBLIC columnshard-engines-insert_table columnshard-engines-changes columnshard-engines-portions - formats-arrow-compression core-tx-program udf-service-exception_policy ) diff --git a/ydb/core/tx/columnshard/engines/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/columnshard/engines/CMakeLists.darwin-x86_64.txt index 41ff6614c5b3..dcfcc1d3275d 100644 --- a/ydb/core/tx/columnshard/engines/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/columnshard/engines/CMakeLists.darwin-x86_64.txt @@ -36,7 +36,6 @@ target_link_libraries(tx-columnshard-engines PUBLIC columnshard-engines-insert_table columnshard-engines-changes columnshard-engines-portions - formats-arrow-compression core-tx-program udf-service-exception_policy ) diff --git a/ydb/core/tx/columnshard/engines/CMakeLists.linux-aarch64.txt b/ydb/core/tx/columnshard/engines/CMakeLists.linux-aarch64.txt index e5129086a415..9d0ab1b75f82 100644 --- a/ydb/core/tx/columnshard/engines/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/columnshard/engines/CMakeLists.linux-aarch64.txt @@ -37,7 +37,6 @@ target_link_libraries(tx-columnshard-engines PUBLIC columnshard-engines-insert_table columnshard-engines-changes columnshard-engines-portions - formats-arrow-compression core-tx-program udf-service-exception_policy ) diff --git a/ydb/core/tx/columnshard/engines/CMakeLists.linux-x86_64.txt b/ydb/core/tx/columnshard/engines/CMakeLists.linux-x86_64.txt index e5129086a415..9d0ab1b75f82 100644 --- a/ydb/core/tx/columnshard/engines/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/columnshard/engines/CMakeLists.linux-x86_64.txt @@ -37,7 +37,6 @@ target_link_libraries(tx-columnshard-engines PUBLIC columnshard-engines-insert_table columnshard-engines-changes columnshard-engines-portions - formats-arrow-compression core-tx-program udf-service-exception_policy ) diff --git a/ydb/core/tx/columnshard/engines/CMakeLists.windows-x86_64.txt b/ydb/core/tx/columnshard/engines/CMakeLists.windows-x86_64.txt index 41ff6614c5b3..dcfcc1d3275d 100644 --- a/ydb/core/tx/columnshard/engines/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/columnshard/engines/CMakeLists.windows-x86_64.txt @@ -36,7 +36,6 @@ target_link_libraries(tx-columnshard-engines PUBLIC columnshard-engines-insert_table columnshard-engines-changes columnshard-engines-portions - formats-arrow-compression core-tx-program udf-service-exception_policy ) diff --git a/ydb/core/tx/columnshard/engines/ut/CMakeLists.darwin-arm64.txt b/ydb/core/tx/columnshard/engines/ut/CMakeLists.darwin-arm64.txt index 3c22c9b91012..cd0d843a5837 100644 --- a/ydb/core/tx/columnshard/engines/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/columnshard/engines/ut/CMakeLists.darwin-arm64.txt @@ -37,9 +37,10 @@ target_link_options(ydb-core-tx-columnshard-engines-ut PRIVATE -fPIC ) target_sources(ydb-core-tx-columnshard-engines-ut PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut_insert_table.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut_logs_engine.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut_program.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut/ut_insert_table.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut/ut_logs_engine.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut/ut_program.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut/helper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard_ut_common.cpp ) set_property( diff --git a/ydb/core/tx/columnshard/engines/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/columnshard/engines/ut/CMakeLists.darwin-x86_64.txt index dc865136f54a..49565f45d672 100644 --- a/ydb/core/tx/columnshard/engines/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/columnshard/engines/ut/CMakeLists.darwin-x86_64.txt @@ -38,9 +38,10 @@ target_link_options(ydb-core-tx-columnshard-engines-ut PRIVATE -fPIC ) target_sources(ydb-core-tx-columnshard-engines-ut PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut_insert_table.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut_logs_engine.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut_program.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut/ut_insert_table.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut/ut_logs_engine.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut/ut_program.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut/helper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard_ut_common.cpp ) set_property( diff --git a/ydb/core/tx/columnshard/engines/ut/CMakeLists.linux-aarch64.txt b/ydb/core/tx/columnshard/engines/ut/CMakeLists.linux-aarch64.txt index 76a2f24b957f..edc5cadba920 100644 --- a/ydb/core/tx/columnshard/engines/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/columnshard/engines/ut/CMakeLists.linux-aarch64.txt @@ -40,9 +40,10 @@ target_link_options(ydb-core-tx-columnshard-engines-ut PRIVATE -fPIC ) target_sources(ydb-core-tx-columnshard-engines-ut PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut_insert_table.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut_logs_engine.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut_program.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut/ut_insert_table.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut/ut_logs_engine.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut/ut_program.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut/helper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard_ut_common.cpp ) set_property( diff --git a/ydb/core/tx/columnshard/engines/ut/CMakeLists.linux-x86_64.txt b/ydb/core/tx/columnshard/engines/ut/CMakeLists.linux-x86_64.txt index 87d5326bd1d9..93b62bb07fc3 100644 --- a/ydb/core/tx/columnshard/engines/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/columnshard/engines/ut/CMakeLists.linux-x86_64.txt @@ -41,9 +41,10 @@ target_link_options(ydb-core-tx-columnshard-engines-ut PRIVATE -fPIC ) target_sources(ydb-core-tx-columnshard-engines-ut PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut_insert_table.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut_logs_engine.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut_program.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut/ut_insert_table.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut/ut_logs_engine.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut/ut_program.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut/helper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard_ut_common.cpp ) set_property( diff --git a/ydb/core/tx/columnshard/engines/ut/CMakeLists.windows-x86_64.txt b/ydb/core/tx/columnshard/engines/ut/CMakeLists.windows-x86_64.txt index 455116c18f12..3a9483de8f04 100644 --- a/ydb/core/tx/columnshard/engines/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/columnshard/engines/ut/CMakeLists.windows-x86_64.txt @@ -33,9 +33,10 @@ target_link_libraries(ydb-core-tx-columnshard-engines-ut PUBLIC json2_udf ) target_sources(ydb-core-tx-columnshard-engines-ut PRIVATE - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut_insert_table.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut_logs_engine.cpp - ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut_program.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut/ut_insert_table.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut/ut_logs_engine.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut/ut_program.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/engines/ut/helper.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/columnshard/columnshard_ut_common.cpp ) set_property( diff --git a/ydb/core/tx/columnshard/splitter/ut/CMakeLists.darwin-arm64.txt b/ydb/core/tx/columnshard/splitter/ut/CMakeLists.darwin-arm64.txt index f98480ff1618..9a8cfbcb9dca 100644 --- a/ydb/core/tx/columnshard/splitter/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/columnshard/splitter/ut/CMakeLists.darwin-arm64.txt @@ -24,7 +24,6 @@ target_link_libraries(ydb-core-tx-columnshard-splitter-ut PUBLIC libs-apache-arrow ydb-library-arrow_kernels tx-columnshard-counters - formats-arrow-compression columnshard-engines-portions core-kqp-common yql-parser-pg_wrapper diff --git a/ydb/core/tx/columnshard/splitter/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/columnshard/splitter/ut/CMakeLists.darwin-x86_64.txt index 1464bd756537..424039ecc775 100644 --- a/ydb/core/tx/columnshard/splitter/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/columnshard/splitter/ut/CMakeLists.darwin-x86_64.txt @@ -25,7 +25,6 @@ target_link_libraries(ydb-core-tx-columnshard-splitter-ut PUBLIC libs-apache-arrow ydb-library-arrow_kernels tx-columnshard-counters - formats-arrow-compression columnshard-engines-portions core-kqp-common yql-parser-pg_wrapper diff --git a/ydb/core/tx/columnshard/splitter/ut/CMakeLists.linux-aarch64.txt b/ydb/core/tx/columnshard/splitter/ut/CMakeLists.linux-aarch64.txt index 9a8695fb440f..e3816268cd7e 100644 --- a/ydb/core/tx/columnshard/splitter/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/columnshard/splitter/ut/CMakeLists.linux-aarch64.txt @@ -25,7 +25,6 @@ target_link_libraries(ydb-core-tx-columnshard-splitter-ut PUBLIC libs-apache-arrow ydb-library-arrow_kernels tx-columnshard-counters - formats-arrow-compression columnshard-engines-portions core-kqp-common yql-parser-pg_wrapper diff --git a/ydb/core/tx/columnshard/splitter/ut/CMakeLists.linux-x86_64.txt b/ydb/core/tx/columnshard/splitter/ut/CMakeLists.linux-x86_64.txt index 2835eecec505..d6f87e5afc8a 100644 --- a/ydb/core/tx/columnshard/splitter/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/columnshard/splitter/ut/CMakeLists.linux-x86_64.txt @@ -26,7 +26,6 @@ target_link_libraries(ydb-core-tx-columnshard-splitter-ut PUBLIC libs-apache-arrow ydb-library-arrow_kernels tx-columnshard-counters - formats-arrow-compression columnshard-engines-portions core-kqp-common yql-parser-pg_wrapper diff --git a/ydb/core/tx/columnshard/splitter/ut/CMakeLists.windows-x86_64.txt b/ydb/core/tx/columnshard/splitter/ut/CMakeLists.windows-x86_64.txt index 93e1b126e61a..6e1d7ab6bd19 100644 --- a/ydb/core/tx/columnshard/splitter/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/columnshard/splitter/ut/CMakeLists.windows-x86_64.txt @@ -25,7 +25,6 @@ target_link_libraries(ydb-core-tx-columnshard-splitter-ut PUBLIC libs-apache-arrow ydb-library-arrow_kernels tx-columnshard-counters - formats-arrow-compression columnshard-engines-portions core-kqp-common yql-parser-pg_wrapper diff --git a/ydb/core/tx/schemeshard/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/CMakeLists.darwin-arm64.txt index 9593e617a016..30ebb7cf513b 100644 --- a/ydb/core/tx/schemeshard/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/CMakeLists.darwin-arm64.txt @@ -98,7 +98,6 @@ target_link_libraries(core-tx-schemeshard PUBLIC core-engine-minikql ydb-core-external_sources core-filestore-core - formats-arrow-compression core-kesus-tablet ydb-core-metering ydb-core-persqueue diff --git a/ydb/core/tx/schemeshard/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/CMakeLists.darwin-x86_64.txt index 9593e617a016..30ebb7cf513b 100644 --- a/ydb/core/tx/schemeshard/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/CMakeLists.darwin-x86_64.txt @@ -98,7 +98,6 @@ target_link_libraries(core-tx-schemeshard PUBLIC core-engine-minikql ydb-core-external_sources core-filestore-core - formats-arrow-compression core-kesus-tablet ydb-core-metering ydb-core-persqueue diff --git a/ydb/core/tx/schemeshard/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/CMakeLists.linux-aarch64.txt index d948f0a058a6..bf4d6101bfb0 100644 --- a/ydb/core/tx/schemeshard/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/CMakeLists.linux-aarch64.txt @@ -99,7 +99,6 @@ target_link_libraries(core-tx-schemeshard PUBLIC core-engine-minikql ydb-core-external_sources core-filestore-core - formats-arrow-compression core-kesus-tablet ydb-core-metering ydb-core-persqueue diff --git a/ydb/core/tx/schemeshard/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/CMakeLists.linux-x86_64.txt index d948f0a058a6..bf4d6101bfb0 100644 --- a/ydb/core/tx/schemeshard/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/CMakeLists.linux-x86_64.txt @@ -99,7 +99,6 @@ target_link_libraries(core-tx-schemeshard PUBLIC core-engine-minikql ydb-core-external_sources core-filestore-core - formats-arrow-compression core-kesus-tablet ydb-core-metering ydb-core-persqueue diff --git a/ydb/core/tx/schemeshard/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/CMakeLists.windows-x86_64.txt index 4cebc8ac2a46..d29f7605ede9 100644 --- a/ydb/core/tx/schemeshard/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/CMakeLists.windows-x86_64.txt @@ -98,7 +98,6 @@ target_link_libraries(core-tx-schemeshard PUBLIC core-engine-minikql ydb-core-external_sources core-filestore-core - formats-arrow-compression core-kesus-tablet ydb-core-metering ydb-core-persqueue diff --git a/ydb/core/tx/schemeshard/olap/columns/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/olap/columns/CMakeLists.darwin-arm64.txt index 963388f7d8d6..fe9aca43452d 100644 --- a/ydb/core/tx/schemeshard/olap/columns/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/olap/columns/CMakeLists.darwin-arm64.txt @@ -16,7 +16,8 @@ target_link_libraries(schemeshard-olap-columns PUBLIC yutil ydb-core-protos formats-arrow-dictionary - formats-arrow-compression + formats-arrow-serializer + schemeshard-olap-common ) target_sources(schemeshard-olap-columns PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/columns/schema.cpp diff --git a/ydb/core/tx/schemeshard/olap/columns/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/olap/columns/CMakeLists.darwin-x86_64.txt index 963388f7d8d6..fe9aca43452d 100644 --- a/ydb/core/tx/schemeshard/olap/columns/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/olap/columns/CMakeLists.darwin-x86_64.txt @@ -16,7 +16,8 @@ target_link_libraries(schemeshard-olap-columns PUBLIC yutil ydb-core-protos formats-arrow-dictionary - formats-arrow-compression + formats-arrow-serializer + schemeshard-olap-common ) target_sources(schemeshard-olap-columns PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/columns/schema.cpp diff --git a/ydb/core/tx/schemeshard/olap/columns/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/olap/columns/CMakeLists.linux-aarch64.txt index 456af1fdedae..80ab9c911616 100644 --- a/ydb/core/tx/schemeshard/olap/columns/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/olap/columns/CMakeLists.linux-aarch64.txt @@ -17,7 +17,8 @@ target_link_libraries(schemeshard-olap-columns PUBLIC yutil ydb-core-protos formats-arrow-dictionary - formats-arrow-compression + formats-arrow-serializer + schemeshard-olap-common ) target_sources(schemeshard-olap-columns PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/columns/schema.cpp diff --git a/ydb/core/tx/schemeshard/olap/columns/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/olap/columns/CMakeLists.linux-x86_64.txt index 456af1fdedae..80ab9c911616 100644 --- a/ydb/core/tx/schemeshard/olap/columns/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/olap/columns/CMakeLists.linux-x86_64.txt @@ -17,7 +17,8 @@ target_link_libraries(schemeshard-olap-columns PUBLIC yutil ydb-core-protos formats-arrow-dictionary - formats-arrow-compression + formats-arrow-serializer + schemeshard-olap-common ) target_sources(schemeshard-olap-columns PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/columns/schema.cpp diff --git a/ydb/core/tx/schemeshard/olap/columns/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/olap/columns/CMakeLists.windows-x86_64.txt index 963388f7d8d6..fe9aca43452d 100644 --- a/ydb/core/tx/schemeshard/olap/columns/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/olap/columns/CMakeLists.windows-x86_64.txt @@ -16,7 +16,8 @@ target_link_libraries(schemeshard-olap-columns PUBLIC yutil ydb-core-protos formats-arrow-dictionary - formats-arrow-compression + formats-arrow-serializer + schemeshard-olap-common ) target_sources(schemeshard-olap-columns PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/columns/schema.cpp diff --git a/ydb/core/tx/schemeshard/olap/common/CMakeLists.darwin-arm64.txt b/ydb/core/tx/schemeshard/olap/common/CMakeLists.darwin-arm64.txt index 3bb00a761514..109c6cb8cb2b 100644 --- a/ydb/core/tx/schemeshard/olap/common/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/schemeshard/olap/common/CMakeLists.darwin-arm64.txt @@ -13,6 +13,7 @@ target_link_libraries(schemeshard-olap-common PUBLIC yutil ydb-library-ydb_issue ydb-core-base + ydb-library-aclib ) target_sources(schemeshard-olap-common PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/common/common.cpp diff --git a/ydb/core/tx/schemeshard/olap/common/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/schemeshard/olap/common/CMakeLists.darwin-x86_64.txt index 3bb00a761514..109c6cb8cb2b 100644 --- a/ydb/core/tx/schemeshard/olap/common/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/schemeshard/olap/common/CMakeLists.darwin-x86_64.txt @@ -13,6 +13,7 @@ target_link_libraries(schemeshard-olap-common PUBLIC yutil ydb-library-ydb_issue ydb-core-base + ydb-library-aclib ) target_sources(schemeshard-olap-common PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/common/common.cpp diff --git a/ydb/core/tx/schemeshard/olap/common/CMakeLists.linux-aarch64.txt b/ydb/core/tx/schemeshard/olap/common/CMakeLists.linux-aarch64.txt index fc818621b3bf..c6e82a20d090 100644 --- a/ydb/core/tx/schemeshard/olap/common/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/schemeshard/olap/common/CMakeLists.linux-aarch64.txt @@ -14,6 +14,7 @@ target_link_libraries(schemeshard-olap-common PUBLIC yutil ydb-library-ydb_issue ydb-core-base + ydb-library-aclib ) target_sources(schemeshard-olap-common PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/common/common.cpp diff --git a/ydb/core/tx/schemeshard/olap/common/CMakeLists.linux-x86_64.txt b/ydb/core/tx/schemeshard/olap/common/CMakeLists.linux-x86_64.txt index fc818621b3bf..c6e82a20d090 100644 --- a/ydb/core/tx/schemeshard/olap/common/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/schemeshard/olap/common/CMakeLists.linux-x86_64.txt @@ -14,6 +14,7 @@ target_link_libraries(schemeshard-olap-common PUBLIC yutil ydb-library-ydb_issue ydb-core-base + ydb-library-aclib ) target_sources(schemeshard-olap-common PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/common/common.cpp diff --git a/ydb/core/tx/schemeshard/olap/common/CMakeLists.windows-x86_64.txt b/ydb/core/tx/schemeshard/olap/common/CMakeLists.windows-x86_64.txt index 3bb00a761514..109c6cb8cb2b 100644 --- a/ydb/core/tx/schemeshard/olap/common/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/schemeshard/olap/common/CMakeLists.windows-x86_64.txt @@ -13,6 +13,7 @@ target_link_libraries(schemeshard-olap-common PUBLIC yutil ydb-library-ydb_issue ydb-core-base + ydb-library-aclib ) target_sources(schemeshard-olap-common PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/schemeshard/olap/common/common.cpp diff --git a/ydb/core/tx/tiering/rule/CMakeLists.darwin-arm64.txt b/ydb/core/tx/tiering/rule/CMakeLists.darwin-arm64.txt index 9cf06ee67b10..f4e44e5127b2 100644 --- a/ydb/core/tx/tiering/rule/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/tiering/rule/CMakeLists.darwin-arm64.txt @@ -17,6 +17,7 @@ target_link_libraries(tx-tiering-rule PUBLIC services-metadata-abstract services-metadata-common services-metadata-initializer + services-metadata-manager services-bg_tasks-abstract core-tx-schemeshard ) @@ -38,6 +39,7 @@ target_link_libraries(tx-tiering-rule.global PUBLIC services-metadata-abstract services-metadata-common services-metadata-initializer + services-metadata-manager services-bg_tasks-abstract core-tx-schemeshard ) diff --git a/ydb/core/tx/tiering/rule/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/tiering/rule/CMakeLists.darwin-x86_64.txt index 9cf06ee67b10..f4e44e5127b2 100644 --- a/ydb/core/tx/tiering/rule/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/tiering/rule/CMakeLists.darwin-x86_64.txt @@ -17,6 +17,7 @@ target_link_libraries(tx-tiering-rule PUBLIC services-metadata-abstract services-metadata-common services-metadata-initializer + services-metadata-manager services-bg_tasks-abstract core-tx-schemeshard ) @@ -38,6 +39,7 @@ target_link_libraries(tx-tiering-rule.global PUBLIC services-metadata-abstract services-metadata-common services-metadata-initializer + services-metadata-manager services-bg_tasks-abstract core-tx-schemeshard ) diff --git a/ydb/core/tx/tiering/rule/CMakeLists.linux-aarch64.txt b/ydb/core/tx/tiering/rule/CMakeLists.linux-aarch64.txt index 38d5d642b6b3..8eecdb2c6855 100644 --- a/ydb/core/tx/tiering/rule/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/tiering/rule/CMakeLists.linux-aarch64.txt @@ -18,6 +18,7 @@ target_link_libraries(tx-tiering-rule PUBLIC services-metadata-abstract services-metadata-common services-metadata-initializer + services-metadata-manager services-bg_tasks-abstract core-tx-schemeshard ) @@ -40,6 +41,7 @@ target_link_libraries(tx-tiering-rule.global PUBLIC services-metadata-abstract services-metadata-common services-metadata-initializer + services-metadata-manager services-bg_tasks-abstract core-tx-schemeshard ) diff --git a/ydb/core/tx/tiering/rule/CMakeLists.linux-x86_64.txt b/ydb/core/tx/tiering/rule/CMakeLists.linux-x86_64.txt index 38d5d642b6b3..8eecdb2c6855 100644 --- a/ydb/core/tx/tiering/rule/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/tiering/rule/CMakeLists.linux-x86_64.txt @@ -18,6 +18,7 @@ target_link_libraries(tx-tiering-rule PUBLIC services-metadata-abstract services-metadata-common services-metadata-initializer + services-metadata-manager services-bg_tasks-abstract core-tx-schemeshard ) @@ -40,6 +41,7 @@ target_link_libraries(tx-tiering-rule.global PUBLIC services-metadata-abstract services-metadata-common services-metadata-initializer + services-metadata-manager services-bg_tasks-abstract core-tx-schemeshard ) diff --git a/ydb/core/tx/tiering/rule/CMakeLists.windows-x86_64.txt b/ydb/core/tx/tiering/rule/CMakeLists.windows-x86_64.txt index 9cf06ee67b10..f4e44e5127b2 100644 --- a/ydb/core/tx/tiering/rule/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/tiering/rule/CMakeLists.windows-x86_64.txt @@ -17,6 +17,7 @@ target_link_libraries(tx-tiering-rule PUBLIC services-metadata-abstract services-metadata-common services-metadata-initializer + services-metadata-manager services-bg_tasks-abstract core-tx-schemeshard ) @@ -38,6 +39,7 @@ target_link_libraries(tx-tiering-rule.global PUBLIC services-metadata-abstract services-metadata-common services-metadata-initializer + services-metadata-manager services-bg_tasks-abstract core-tx-schemeshard ) diff --git a/ydb/services/metadata/abstract/CMakeLists.darwin-arm64.txt b/ydb/services/metadata/abstract/CMakeLists.darwin-arm64.txt index 2bbf80e97ff1..b480cc86de32 100644 --- a/ydb/services/metadata/abstract/CMakeLists.darwin-arm64.txt +++ b/ydb/services/metadata/abstract/CMakeLists.darwin-arm64.txt @@ -23,7 +23,6 @@ target_link_libraries(services-metadata-abstract PUBLIC library-actors-core yql-core-expr_nodes api-protos - services-metadata-request ) target_sources(services-metadata-abstract PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/metadata/abstract/common.cpp diff --git a/ydb/services/metadata/abstract/CMakeLists.darwin-x86_64.txt b/ydb/services/metadata/abstract/CMakeLists.darwin-x86_64.txt index 2bbf80e97ff1..b480cc86de32 100644 --- a/ydb/services/metadata/abstract/CMakeLists.darwin-x86_64.txt +++ b/ydb/services/metadata/abstract/CMakeLists.darwin-x86_64.txt @@ -23,7 +23,6 @@ target_link_libraries(services-metadata-abstract PUBLIC library-actors-core yql-core-expr_nodes api-protos - services-metadata-request ) target_sources(services-metadata-abstract PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/metadata/abstract/common.cpp diff --git a/ydb/services/metadata/abstract/CMakeLists.linux-aarch64.txt b/ydb/services/metadata/abstract/CMakeLists.linux-aarch64.txt index a1f47a7ca217..04d589a9b173 100644 --- a/ydb/services/metadata/abstract/CMakeLists.linux-aarch64.txt +++ b/ydb/services/metadata/abstract/CMakeLists.linux-aarch64.txt @@ -24,7 +24,6 @@ target_link_libraries(services-metadata-abstract PUBLIC library-actors-core yql-core-expr_nodes api-protos - services-metadata-request ) target_sources(services-metadata-abstract PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/metadata/abstract/common.cpp diff --git a/ydb/services/metadata/abstract/CMakeLists.linux-x86_64.txt b/ydb/services/metadata/abstract/CMakeLists.linux-x86_64.txt index a1f47a7ca217..04d589a9b173 100644 --- a/ydb/services/metadata/abstract/CMakeLists.linux-x86_64.txt +++ b/ydb/services/metadata/abstract/CMakeLists.linux-x86_64.txt @@ -24,7 +24,6 @@ target_link_libraries(services-metadata-abstract PUBLIC library-actors-core yql-core-expr_nodes api-protos - services-metadata-request ) target_sources(services-metadata-abstract PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/metadata/abstract/common.cpp diff --git a/ydb/services/metadata/abstract/CMakeLists.windows-x86_64.txt b/ydb/services/metadata/abstract/CMakeLists.windows-x86_64.txt index 2bbf80e97ff1..b480cc86de32 100644 --- a/ydb/services/metadata/abstract/CMakeLists.windows-x86_64.txt +++ b/ydb/services/metadata/abstract/CMakeLists.windows-x86_64.txt @@ -23,7 +23,6 @@ target_link_libraries(services-metadata-abstract PUBLIC library-actors-core yql-core-expr_nodes api-protos - services-metadata-request ) target_sources(services-metadata-abstract PRIVATE ${CMAKE_SOURCE_DIR}/ydb/services/metadata/abstract/common.cpp From 960afca849a33c7c97f7ceb7c63e27ab0e23937d Mon Sep 17 00:00:00 2001 From: Aleksei Borzenkov Date: Mon, 4 Mar 2024 10:46:27 +0300 Subject: [PATCH 047/117] Fix stale read anomalies detected with Jepsen (#2374) --- ydb/core/tx/datashard/create_table_unit.cpp | 1 + ydb/core/tx/datashard/datashard.cpp | 182 ++++-- ydb/core/tx/datashard/datashard_split_dst.cpp | 39 +- ydb/core/tx/datashard/datashard_split_src.cpp | 9 + .../tx/datashard/datashard_ut_snapshot.cpp | 563 ++++++++++++++++++ ydb/core/tx/time_cast/time_cast.cpp | 5 +- 6 files changed, 729 insertions(+), 70 deletions(-) diff --git a/ydb/core/tx/datashard/create_table_unit.cpp b/ydb/core/tx/datashard/create_table_unit.cpp index 3f1a08d4dfc9..61d1cfc97c92 100644 --- a/ydb/core/tx/datashard/create_table_unit.cpp +++ b/ydb/core/tx/datashard/create_table_unit.cpp @@ -86,6 +86,7 @@ EExecutionStatus TCreateTableUnit::Execute(TOperation::TPtr op, txc.DB.NoMoreReadsForTx(); DataShard.SetPersistState(TShardState::Ready, txc); DataShard.CheckMvccStateChangeCanStart(ctx); // Recheck + DataShard.SendRegistrationRequestTimeCast(ctx); } return EExecutionStatus::DelayCompleteNoMoreRestarts; diff --git a/ydb/core/tx/datashard/datashard.cpp b/ydb/core/tx/datashard/datashard.cpp index 6539b5a4243e..6b10f4632c76 100644 --- a/ydb/core/tx/datashard/datashard.cpp +++ b/ydb/core/tx/datashard/datashard.cpp @@ -398,8 +398,23 @@ void TDataShard::SendRegistrationRequestTimeCast(const TActorContext &ctx) { if (RegistrationSended) return; - if (!ProcessingParams) + if (!ProcessingParams) { + LOG_DEBUG_S(ctx, NKikimrServices::TX_DATASHARD, TabletID() + << " not sending time cast registration request in state " + << DatashardStateName(State) + << ": missing processing params"); return; + } + + if (State == TShardState::WaitScheme || + State == TShardState::SplitDstReceivingSnapshot) + { + // We don't have all the necessary info yet + LOG_DEBUG_S(ctx, NKikimrServices::TX_DATASHARD, TabletID() + << " not sending time cast registration request in state " + << DatashardStateName(State)); + return; + } LOG_INFO_S(ctx, NKikimrServices::TX_DATASHARD, "Send registration request to time cast " << DatashardStateName(State) << " tabletId " << TabletID() @@ -1961,68 +1976,81 @@ TRowVersion TDataShard::GetMvccTxVersion(EMvccTxMode mode, TOperation* op) const } } - TRowVersion edge; - TRowVersion readEdge = Max( - SnapshotManager.GetCompleteEdge(), - SnapshotManager.GetUnprotectedReadEdge()); - TRowVersion writeEdge = Max(readEdge, SnapshotManager.GetIncompleteEdge()); - switch (mode) { - case EMvccTxMode::ReadOnly: - // With read-only transactions we don't need reads to include - // changes made at the incomplete edge, as that is a point where - // distributed transactions performed some reads, not writes. - // Since incomplete transactions are still inflight, the actual - // version will stick to the first incomplete transaction is queue, - // effectively reading non-repeatable state before that transaction. - edge = readEdge; - break; - case EMvccTxMode::ReadWrite: - // With read-write transactions we must choose a point that is - // greater than both complete and incomplete edges. The reason - // is that incomplete transactions performed some reads at that - // point and these snapshot points must be repeatable. - // Note that as soon as the first write past the IncompleteEdge - // happens it cements all distributed transactions up to that point - // as complete, so all future reads and writes are guaranteed to - // include that point as well. - edge = writeEdge; - break; - } + LOG_TRACE_S(*TlsActivationContext, NKikimrServices::TX_DATASHARD, "GetMvccTxVersion at " << TabletID() + << " CompleteEdge# " << SnapshotManager.GetCompleteEdge() + << " IncompleteEdge# " << SnapshotManager.GetIncompleteEdge() + << " UnprotectedReadEdge# " << SnapshotManager.GetUnprotectedReadEdge() + << " ImmediateWriteEdge# " << SnapshotManager.GetImmediateWriteEdge() + << " ImmediateWriteEdgeReplied# " << SnapshotManager.GetImmediateWriteEdgeReplied()); + + TRowVersion version = [&]() { + TRowVersion edge; + TRowVersion readEdge = Max( + SnapshotManager.GetCompleteEdge(), + SnapshotManager.GetUnprotectedReadEdge()); + TRowVersion writeEdge = Max(readEdge, SnapshotManager.GetIncompleteEdge()); + switch (mode) { + case EMvccTxMode::ReadOnly: + // With read-only transactions we don't need reads to include + // changes made at the incomplete edge, as that is a point where + // distributed transactions performed some reads, not writes. + // Since incomplete transactions are still inflight, the actual + // version will stick to the first incomplete transaction is queue, + // effectively reading non-repeatable state before that transaction. + edge = readEdge; + break; + case EMvccTxMode::ReadWrite: + // With read-write transactions we must choose a point that is + // greater than both complete and incomplete edges. The reason + // is that incomplete transactions performed some reads at that + // point and these snapshot points must be repeatable. + // Note that as soon as the first write past the IncompleteEdge + // happens it cements all distributed transactions up to that point + // as complete, so all future reads and writes are guaranteed to + // include that point as well. + edge = writeEdge; + break; + } - // If there's any planned operation that is above our edge, it would be a - // suitable version for a new immediate operation. We effectively try to - // execute "before" that point if possible. - if (auto nextOp = Pipeline.GetNextPlannedOp(edge.Step, edge.TxId)) - return TRowVersion(nextOp->GetStep(), nextOp->GetTxId()); + // If there's any planned operation that is above our edge, it would be a + // suitable version for a new immediate operation. We effectively try to + // execute "before" that point if possible. + if (auto nextOp = Pipeline.GetNextPlannedOp(edge.Step, edge.TxId)) + return TRowVersion(nextOp->GetStep(), nextOp->GetTxId()); + + // Normally we stick transactions to the end of the last known mediator step + // Note this calculations only happen when we don't have distributed + // transactions left in queue, and we won't have any more transactions + // up to the current mediator time. The mediator time itself may be stale, + // in which case we may have evidence of its higher value via complete and + // incomplete edges above. + const ui64 mediatorStep = Max(MediatorTimeCastEntry ? MediatorTimeCastEntry->Get(TabletID()) : 0, writeEdge.Step); + TRowVersion mediatorEdge(mediatorStep, ::Max()); + + switch (mode) { + case EMvccTxMode::ReadOnly: { + // We read at the end of the current step + return mediatorEdge; + } + + case EMvccTxMode::ReadWrite: { + // We write at the end of the current step, or the start of the next step when that's protected + return Max(mediatorEdge, writeEdge.Next()); + } + } - // Normally we stick transactions to the end of the last known mediator step - // Note this calculations only happen when we don't have distributed - // transactions left in queue, and we won't have any more transactions - // up to the current mediator time. The mediator time itself may be stale, - // in which case we may have evidence of its higher value via complete and - // incomplete edges above. - const ui64 mediatorStep = Max(MediatorTimeCastEntry ? MediatorTimeCastEntry->Get(TabletID()) : 0, writeEdge.Step); - TRowVersion mediatorEdge(mediatorStep, ::Max()); + Y_ABORT("unreachable"); + }(); switch (mode) { case EMvccTxMode::ReadOnly: { - // We want to include everything that was potentially confirmed to - // users, but we don't want to include anything that is not replied - // at the start of this read. - // Note it's only possible to have ImmediateWriteEdge > mediatorEdge - // when ImmediateWriteEdge == mediatorEdge + 1 - return Max(mediatorEdge, SnapshotManager.GetImmediateWriteEdgeReplied()); + // We must read all writes we have replied to already + return Max(version, SnapshotManager.GetImmediateWriteEdgeReplied()); } case EMvccTxMode::ReadWrite: { - // We must use at least a previously used immediate write edge - // But we must also avoid trumpling over any unprotected mvcc - // snapshot reads that have occurred. - // Note it's only possible to go past the last known mediator step - // when we had an unprotected read, which itself happens at the - // last mediator step. So we may only ever have a +1 step, never - // anything more. - return Max(mediatorEdge, writeEdge.Next(), SnapshotManager.GetImmediateWriteEdge()); + // We must never go backwards in our single-shard writes + return Max(version, SnapshotManager.GetImmediateWriteEdge()); } } @@ -2075,6 +2103,8 @@ TDataShard::TPromotePostExecuteEdges TDataShard::PromoteImmediatePostExecuteEdge // We need to wait for completion until the flag is committed res.WaitCompletion = true; } + LOG_TRACE_S(*TlsActivationContext, NKikimrServices::TX_DATASHARD, "PromoteImmediatePostExecuteEdges at " << TabletID() + << " promoting UnprotectedReadEdge to " << version); SnapshotManager.PromoteUnprotectedReadEdge(version); // We want to promote the complete edge when protected reads are @@ -2237,6 +2267,19 @@ void TDataShard::SendAfterMediatorStepActivate(ui64 mediatorStep, const TActorCo for (auto it = MediatorDelayedReplies.begin(); it != MediatorDelayedReplies.end();) { const ui64 step = it->first.Step; + if (SrcSplitDescription) { + if (State == TShardState::SplitSrcSendingSnapshot || + State == TShardState::SplitSrcWaitForPartitioningChanged || + State == TShardState::PreOffline || + State == TShardState::Offline) + { + // We cannot send replies, since dst shard is now in charge + // of keeping track of acknowledged writes. So we expect + // split src logic to reboot this shard later. + break; + } + } + if (step <= mediatorStep) { SnapshotManager.PromoteImmediateWriteEdgeReplied(it->first); Send(it->second.Target, it->second.Event.Release(), 0, it->second.Cookie); @@ -2304,13 +2347,16 @@ void TDataShard::CheckMediatorStateRestored() { // HEAD reads must include that in their results. const ui64 waitStep = CoordinatorPrevReadStepMax; const ui64 readStep = CoordinatorPrevReadStepMax; - - LOG_DEBUG_S(*TlsActivationContext, NKikimrServices::TX_DATASHARD, "CheckMediatorStateRestored: waitStep# " << waitStep << " readStep# " << readStep); + const ui64 observedStep = GetMaxObservedStep(); + LOG_DEBUG_S(*TlsActivationContext, NKikimrServices::TX_DATASHARD, "CheckMediatorStateRestored at " << TabletID() << ":" + << " waitStep# " << waitStep + << " readStep# " << readStep + << " observedStep# " << observedStep); // WARNING: we must perform this check BEFORE we update unprotected read edge // We may enter this code path multiple times, and we expect that the above // read step may be refined while we wait based on pessimistic backup step. - if (GetMaxObservedStep() < waitStep) { + if (observedStep < waitStep) { // We need to wait until we observe mediator step that is at least // as large as the step we found. if (MediatorTimeCastWaitingSteps.insert(waitStep).second) { @@ -2331,7 +2377,10 @@ void TDataShard::CheckMediatorStateRestored() { SnapshotManager.GetImmediateWriteEdge().Step > SnapshotManager.GetCompleteEdge().Step ? SnapshotManager.GetImmediateWriteEdge().Prev() : TRowVersion::Min(); - SnapshotManager.PromoteUnprotectedReadEdge(Max(lastReadEdge, preImmediateWriteEdge)); + const TRowVersion edge = Max(lastReadEdge, preImmediateWriteEdge); + LOG_TRACE_S(*TlsActivationContext, NKikimrServices::TX_DATASHARD, "CheckMediatorStateRestored at " << TabletID() + << " promoting UnprotectedReadEdge to " << edge); + SnapshotManager.PromoteUnprotectedReadEdge(edge); } // Promote the replied immediate write edge up to the currently observed step @@ -2340,7 +2389,7 @@ void TDataShard::CheckMediatorStateRestored() { // data that is definitely not replied yet. if (SnapshotManager.GetImmediateWriteEdgeReplied() < SnapshotManager.GetImmediateWriteEdge()) { const ui64 writeStep = SnapshotManager.GetImmediateWriteEdge().Step; - const TRowVersion edge(GetMaxObservedStep(), Max()); + const TRowVersion edge(observedStep, Max()); SnapshotManager.PromoteImmediateWriteEdgeReplied( Min(edge, SnapshotManager.GetImmediateWriteEdge())); // Try to ensure writes become visible sooner rather than later @@ -2477,6 +2526,10 @@ bool TDataShard::CheckDataTxReject(const TString& opDescr, rejectDescriptions.push_back(TStringBuilder() << "is in process of split opId " << DstSplitOpId << " state " << DatashardStateName(State)); + } else if (State == TShardState::WaitScheme) { + reject = true; + rejectReasons |= ERejectReasons::WrongState; + rejectDescriptions.push_back("is not created yet"); } else if (State == TShardState::PreOffline || State == TShardState::Offline) { reject = true; rejectStatus = NKikimrTxDataShard::TEvProposeTransactionResult::ERROR; @@ -2639,6 +2692,11 @@ void TDataShard::Handle(TEvDataShard::TEvProposeTransaction::TPtr &ev, const TAc auto* msg = ev->Get(); LWTRACK(ProposeTransactionRequest, msg->Orbit); + if (CheckDataTxRejectAndReply(ev, ctx)) { + IncCounter(COUNTER_PREPARE_REQUEST); + return; + } + // Check if we need to delay an immediate transaction if (MediatorStateWaiting && (ev->Get()->GetFlags() & TTxFlags::Immediate) && @@ -2671,10 +2729,6 @@ void TDataShard::Handle(TEvDataShard::TEvProposeTransaction::TPtr &ev, const TAc IncCounter(COUNTER_PREPARE_REQUEST); - if (CheckDataTxRejectAndReply(ev, ctx)) { - return; - } - switch (ev->Get()->GetTxKind()) { case NKikimrTxDataShard::TX_KIND_DATA: case NKikimrTxDataShard::TX_KIND_SCAN: diff --git a/ydb/core/tx/datashard/datashard_split_dst.cpp b/ydb/core/tx/datashard/datashard_split_dst.cpp index 12d152c188e5..d78ca11ccf2c 100644 --- a/ydb/core/tx/datashard/datashard_split_dst.cpp +++ b/ydb/core/tx/datashard/datashard_split_dst.cpp @@ -175,6 +175,7 @@ class TDataShard::TTxSplitTransferSnapshot : public NTabletFlatExecutor::TTransa LOG_DEBUG_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " Received snapshot for split/merge TxId " << opId << " from tabeltId " << srcTabletId); + LOG_TRACE_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " Received snapshot: " << record.DebugString()); if (!Self->DstSplitSchemaInitialized) { LegacyInitSchema(txc); @@ -291,8 +292,9 @@ class TDataShard::TTxSplitTransferSnapshot : public NTabletFlatExecutor::TTransa Self->PromoteFollowerReadEdge(txc); } - Self->State = TShardState::Ready; - Self->PersistSys(db, Schema::Sys_State, Self->State); + // Note: we persist Ready, but keep current state in memory until Complete + Self->SetPersistState(TShardState::Ready, txc); + Self->State = TShardState::SplitDstReceivingSnapshot; } return true; @@ -306,9 +308,36 @@ class TDataShard::TTxSplitTransferSnapshot : public NTabletFlatExecutor::TTransa ctx.Send(ackTo, new TEvDataShard::TEvSplitTransferSnapshotAck(opId, Self->TabletID())); - if (LastSnapshotReceived) { - // We have received all the data, reload everything from the received system tables - Self->Execute(Self->CreateTxInit(), ctx); + // Note: we skip init in an unlikely event of state resetting between Execute and Complete + if (LastSnapshotReceived && Self->State == TShardState::SplitDstReceivingSnapshot) { + // We have received all the data, finish shard initialization + // Note: previously we used TxInit, however received system tables + // have been empty for years now, and since pipes are still open we + // may receive requests between TxInit loading the Ready state and + // its Complete method initializing everything properly. Instead + // necessary steps are repeated here. + Self->State = TShardState::Ready; + + // We are already in StateWork, but we need to repeat many steps now that we are Ready + Self->SwitchToWork(ctx); + + // We can send the registration request now that we are ready + Self->SendRegistrationRequestTimeCast(ctx); + + // Initialize snapshot expiration queue with current context time + Self->GetSnapshotManager().InitExpireQueue(ctx.Now()); + if (Self->GetSnapshotManager().HasExpiringSnapshots()) { + Self->PlanCleanup(ctx); + } + + // Initialize change senders + Self->KillChangeSender(ctx); + Self->CreateChangeSender(ctx); + Self->MaybeActivateChangeSender(ctx); + Self->EmitHeartbeats(); + + // Switch mvcc state if needed + Self->CheckMvccStateChangeCanStart(ctx); } } }; diff --git a/ydb/core/tx/datashard/datashard_split_src.cpp b/ydb/core/tx/datashard/datashard_split_src.cpp index c3a4bf8df9ef..6777b666f4b1 100644 --- a/ydb/core/tx/datashard/datashard_split_src.cpp +++ b/ydb/core/tx/datashard/datashard_split_src.cpp @@ -529,6 +529,15 @@ class TDataShard::TTxSplitPartitioningChanged : public NTabletFlatExecutor::TTra } } + if (!Self->MediatorDelayedReplies.empty()) { + // We have some pending mediator replies, which must not be replied. + // Unfortunately we may linger around for a long time, and clients + // would keep awaiting replies for all that time. We have to make + // sure those clients receive an appropriate disconnection error + // instead. + ctx.Send(Self->SelfId(), new TEvents::TEvPoison); + } + // TODO: properly check if there are no loans Self->CheckStateChange(ctx); } diff --git a/ydb/core/tx/datashard/datashard_ut_snapshot.cpp b/ydb/core/tx/datashard/datashard_ut_snapshot.cpp index 44e4bf7d555d..486c88502e0e 100644 --- a/ydb/core/tx/datashard/datashard_ut_snapshot.cpp +++ b/ydb/core/tx/datashard/datashard_ut_snapshot.cpp @@ -3988,6 +3988,569 @@ Y_UNIT_TEST_SUITE(DataShardSnapshots) { "{ items { uint32_value: 4 } items { uint32_value: 40 } }"); } + /** + * This observer forces newly created nodes to start on particular nodes + */ + class TCreateTabletNodePinning { + public: + TCreateTabletNodePinning(TTestActorRuntime& runtime) + : Runtime(runtime) + , Node1(Runtime.GetNodeId(0)) + , Observer(Runtime.AddObserver([this](auto& ev) { this->Process(ev); })) + {} + + void SetNodeIndexes(std::initializer_list nodeIndexes) { + AllowedNodes.clear(); + for (ui32 nodeIndex : nodeIndexes) { + AllowedNodes.push_back(Node1 + nodeIndex); + } + } + + void Remove() { + Observer.Remove(); + } + + private: + void Process(TEvHive::TEvCreateTablet::TPtr& ev) { + auto* msg = ev->Get(); + msg->Record.ClearAllowedNodeIDs(); + for (ui32 nodeId : AllowedNodes) { + msg->Record.AddAllowedNodeIDs(nodeId); + } + } + + private: + TTestActorRuntime& Runtime; + const ui32 Node1; + std::vector AllowedNodes; + TTestActorRuntime::TEventObserverHolder Observer; + }; + + /** + * This observer allows blocking timecast updates at different nodes + */ + class TMediatorTimeCastBlocking { + public: + TMediatorTimeCastBlocking(TTestActorRuntime& runtime) + : Runtime(runtime) + , Node1(Runtime.GetNodeId(0)) + , Observer(Runtime.AddObserver([this](auto& ev) { this->Process(ev); })) + {} + + void SetMaxAllowedStep(ui32 nodeIndex, ui64 step) { + while (Nodes.size() <= nodeIndex) { + Nodes.emplace_back(); + } + Nodes[nodeIndex].MaxAllowedStep = step; + } + + void Unblock(ui32 nodeIndex) { + while (Nodes.size() <= nodeIndex) { + Nodes.emplace_back(); + } + auto& state = Nodes[nodeIndex]; + state.MaxAllowedStep = Max(); + for (auto& kv : state.Buckets) { + if (kv.second.LastBlocked) { + Runtime.Send(kv.second.LastBlocked.release(), nodeIndex, true); + } + } + } + + ui64 WaitNextStep() { + ui64 step = LastStep; + WaitFor(Runtime, [&]{ return LastStep > step; }, "next timecast step", 10); + return LastStep; + } + + void Remove() { + Observer.Remove(); + } + + private: + void Process(TEvMediatorTimecast::TEvUpdate::TPtr& ev) { + auto* msg = ev->Get(); + ui32 nodeId = ev->GetRecipientRewrite().NodeId(); + ui32 nodeIndex = nodeId - Node1; + auto bucket = msg->Record.GetBucket(); + auto step = msg->Record.GetTimeBarrier(); + Cerr << "... observed step " << step << " at node " << nodeId << " bucket " << bucket << Endl; + LastStep = Max(LastStep, step); + while (Nodes.size() <= nodeIndex) { + Nodes.emplace_back(); + } + auto& state = Nodes[nodeIndex]; + auto& bucketState = state.Buckets[bucket]; + ui64 prevObserved = bucketState.LastObservedStep; + bucketState.LastObservedStep = step; + bucketState.LastBlocked.reset(); + if (step > state.MaxAllowedStep) { + Cerr << "... blocked step " << step << " at node " << nodeId << " bucket " << bucket << Endl; + // Generate an blocked event we would resend when on unblock + auto* newMsg = new TEvMediatorTimecast::TEvUpdate; + newMsg->Record = msg->Record; + bucketState.LastBlocked.reset(new IEventHandle( + ev->Recipient, + ev->Sender, + newMsg, + ev->Flags, + ev->Cookie)); + bucketState.LastBlocked->Rewrite(ev->GetTypeRewrite(), ev->GetRecipientRewrite()); + // Modify the original event to send the max allowed step when necessary + if (prevObserved < state.MaxAllowedStep) { + Cerr << "... synthetic step " << state.MaxAllowedStep << " at node " << nodeId << " bucket " << bucket << Endl; + msg->Record.SetTimeBarrier(state.MaxAllowedStep); + } else { + ev.Reset(); + } + return; + } + } + + private: + struct TBucketState { + ui64 LastObservedStep = 0; + std::unique_ptr LastBlocked; + }; + + struct TNodeState { + ui64 MaxAllowedStep = Max(); + std::map Buckets; + }; + + public: + ui64 LastStep = 0; + + private: + TTestActorRuntime& Runtime; + const ui32 Node1; + std::vector Nodes; + TTestActorRuntime::TEventObserverHolder Observer; + }; + + /** + * Observer for blocking split at src tablets + */ + class TSplitSrcBlocking { + public: + TSplitSrcBlocking(TTestActorRuntime& runtime) + : Runtime(runtime) + , Node1(Runtime.GetNodeId(0)) + , Observer(Runtime.AddObserver([this](auto& ev) { this->Process(ev); })) + {} + + void Unblock() { + Observer.Remove(); + for (auto& ev : Blocked) { + ui32 nodeIndex = ev->GetRecipientRewrite().NodeId() - Node1; + Runtime.Send(ev.release(), nodeIndex, true); + } + Blocked.clear(); + } + + private: + void Process(TEvDataShard::TEvSplit::TPtr& ev) { + Cerr << "... blocking TEvSplit" << Endl; + Blocked.emplace_back(ev.Release()); + } + + private: + TTestActorRuntime& Runtime; + const ui32 Node1; + std::vector> Blocked; + TTestActorRuntime::TEventObserverHolder Observer; + }; + + Y_UNIT_TEST(RepeatableReadAfterSplitRace) { + TPortManager pm; + TServerSettings serverSettings(pm.GetPort(2134)); + serverSettings.SetDomainName("Root") + .SetNodeCount(2) + .SetUseRealThreads(false) + .SetDomainPlanResolution(100); + + Tests::TServer::TPtr server = new TServer(serverSettings); + auto &runtime = *server->GetRuntime(); + auto sender = runtime.AllocateEdgeActor(); + + runtime.SetLogPriority(NKikimrServices::TX_DATASHARD, NLog::PRI_TRACE); + runtime.SetLogPriority(NKikimrServices::TX_PROXY, NLog::PRI_DEBUG); + runtime.SetLogPriority(NKikimrServices::KQP_EXECUTER, NLog::PRI_TRACE); + runtime.SetLogPriority(NKikimrServices::KQP_SESSION, NLog::PRI_TRACE); + + InitRoot(server, sender); + + TCreateTabletNodePinning createTabletNodePinning(runtime); + + // Create table-1 at node 1 + createTabletNodePinning.SetNodeIndexes({ 0 }); + CreateShardedTable(server, sender, "/Root", "table-1", 1); + auto shards1 = GetTableShards(server, sender, "/Root/table-1"); + + // Create table-2 at node 2 + createTabletNodePinning.SetNodeIndexes({ 1 }); + CreateShardedTable(server, sender, "/Root", "table-2", 1); + + // Insert initial values + ExecSQL(server, sender, Q_("UPSERT INTO `/Root/table-1` (key, value) VALUES (1, 10);")); + ExecSQL(server, sender, Q_("UPSERT INTO `/Root/table-2` (key, value) VALUES (2, 20);")); + + TSplitSrcBlocking splitSrcBlocking(runtime); + TMediatorTimeCastBlocking mediatorTimeCastBlocking(runtime); + + // We need to make a snapshot read to force unprotected reads + // This will also ensure both nodes have an updated mediator time cast + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleExec(runtime, Q_(R"( + SELECT key, value FROM `/Root/table-1` + UNION ALL + SELECT key, value FROM `/Root/table-2` + ORDER BY key; + )")), + "{ items { uint32_value: 1 } items { uint32_value: 10 } }, " + "{ items { uint32_value: 2 } items { uint32_value: 20 } }"); + + // One more upsert to table-2, this will bump mediator time at node 2 past the snapshot + ExecSQL(server, sender, Q_("UPSERT INTO `/Root/table-2` (key, value) VALUES (3, 30);")); + + // We won't allow node 2 to go past that write version + mediatorTimeCastBlocking.SetMaxAllowedStep(1, mediatorTimeCastBlocking.LastStep); + + // Start split of table-1 at key 10 + auto splitSender = runtime.AllocateEdgeActor(); + SetSplitMergePartCountLimit(server->GetRuntime(), -1); + Cerr << "... starting split of table-1" << Endl; + ui64 splitTxId = AsyncSplitTable(server, splitSender, "/Root/table-1", shards1.at(0), 10); + + // We want to mediator time to advance, so the next snapshot is greater than the last write version + mediatorTimeCastBlocking.WaitNextStep(); + + // Start a snapshot read from table-1 + // This will run at node 1 shard where mediator time is recent + Cerr << "... reading from table-1" << Endl; + TString sessionId, txId; + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleBegin(runtime, sessionId, txId, Q_(R"( + SELECT key, value FROM `/Root/table-1` + ORDER BY key; + )")), + "{ items { uint32_value: 1 } items { uint32_value: 10 } }"); + + // Now unblock TEvSplit and wait until it finishes + splitSrcBlocking.Unblock(); + + // Wait until split finishes, so we can continue working with the new shards + Cerr << "... waiting for split to finish" << Endl; + WaitTxNotification(server, splitSender, splitTxId); + + // Start an upsert into newly split table-1 + TString upsertSessionId = CreateSessionRPC(runtime); + auto upsertFuture = SendRequest(runtime, MakeSimpleRequestRPC(Q_(R"( + UPSERT INTO `/Root/table-1` (key, value) VALUES (4, 40); + )"), upsertSessionId, "", /* commit */ true)); + + // We cannot wait for it to finish (bug may be fixed) + // So we sleep for several seconds instead + Cerr << "... sleeping for 2 seconds" << Endl; + runtime.SimulateSleep(TDuration::Seconds(2)); + + // Unblock mediator timecast at node 2 + mediatorTimeCastBlocking.Unblock(1); + + // Wait until upsert finishes + UNIT_ASSERT_VALUES_EQUAL( + FormatResult(AwaitResponse(runtime, std::move(upsertFuture))), + ""); + + // Repeat read in a previous tx, this read must be repeatable + // In other words we must not observe the new 4/40 row + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleContinue(runtime, sessionId, txId, Q_(R"( + SELECT key, value FROM `/Root/table-1` + UNION ALL + SELECT key, value FROM `/Root/table-2` + ORDER BY key; + )")), + "{ items { uint32_value: 1 } items { uint32_value: 10 } }, " + "{ items { uint32_value: 2 } items { uint32_value: 20 } }, " + "{ items { uint32_value: 3 } items { uint32_value: 30 } }"); + } + + Y_UNIT_TEST(DelayedWriteReadableAfterSplit) { + TPortManager pm; + TServerSettings serverSettings(pm.GetPort(2134)); + serverSettings.SetDomainName("Root") + .SetNodeCount(2) + .SetUseRealThreads(false) + .SetDomainPlanResolution(100); + + Tests::TServer::TPtr server = new TServer(serverSettings); + auto &runtime = *server->GetRuntime(); + auto sender = runtime.AllocateEdgeActor(); + + runtime.SetLogPriority(NKikimrServices::TX_DATASHARD, NLog::PRI_TRACE); + runtime.SetLogPriority(NKikimrServices::TX_PROXY, NLog::PRI_DEBUG); + runtime.SetLogPriority(NKikimrServices::KQP_EXECUTER, NLog::PRI_TRACE); + runtime.SetLogPriority(NKikimrServices::KQP_SESSION, NLog::PRI_TRACE); + + InitRoot(server, sender); + + TCreateTabletNodePinning createTabletNodePinning(runtime); + + // Create table-1 at node 1 + createTabletNodePinning.SetNodeIndexes({ 0 }); + CreateShardedTable(server, sender, "/Root", "table-1", 1); + auto shards1 = GetTableShards(server, sender, "/Root/table-1"); + + // Create table-2 at node 2 + createTabletNodePinning.SetNodeIndexes({ 1 }); + CreateShardedTable(server, sender, "/Root", "table-2", 1); + + // Insert initial values + ExecSQL(server, sender, Q_("UPSERT INTO `/Root/table-1` (key, value) VALUES (1, 10);")); + ExecSQL(server, sender, Q_("UPSERT INTO `/Root/table-2` (key, value) VALUES (2, 20);")); + + TSplitSrcBlocking splitSrcBlocking(runtime); + TMediatorTimeCastBlocking mediatorTimeCastBlocking(runtime); + + // We need to make a snapshot read to force unprotected reads + // This will also ensure both nodes have an updated mediator time cast + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleExec(runtime, Q_(R"( + SELECT key, value FROM `/Root/table-1` + UNION ALL + SELECT key, value FROM `/Root/table-2` + ORDER BY key; + )")), + "{ items { uint32_value: 1 } items { uint32_value: 10 } }, " + "{ items { uint32_value: 2 } items { uint32_value: 20 } }"); + + // One more upsert to table-2, this will bump mediator time past the snapshot + ExecSQL(server, sender, Q_("UPSERT INTO `/Root/table-2` (key, value) VALUES (3, 30);")); + + // Wait for the next step, we will expect to read at that step + ui64 step = mediatorTimeCastBlocking.WaitNextStep(); + Cerr << "... expecting next read at step " << step << Endl; + + // We won't allow node 2 to go past that snapshot + mediatorTimeCastBlocking.SetMaxAllowedStep(1, step); + + // Start a snapshot read from table-1 + // This will run at node 1 shard where mediator time is recent + Cerr << "... reading from table-1" << Endl; + TString sessionId, txId; + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleBegin(runtime, sessionId, txId, Q_(R"( + SELECT key, value FROM `/Root/table-1` + ORDER BY key; + )")), + "{ items { uint32_value: 1 } items { uint32_value: 10 } }"); + + // Start split of table-1 at key 10 + auto splitSender = runtime.AllocateEdgeActor(); + SetSplitMergePartCountLimit(server->GetRuntime(), -1); + Cerr << "... starting split of table-1" << Endl; + ui64 splitTxId = AsyncSplitTable(server, splitSender, "/Root/table-1", shards1.at(0), 10); + + // Perform an immediate write, which will happen after the above snapshot + // We also wait for the result to make sure mediator time advances at node 1 + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleExec(runtime, Q_(R"( + UPSERT INTO `/Root/table-1` (key, value) VALUES (4, 40); + )")), + ""); + + // Unblock split at src + splitSrcBlocking.Unblock(); + + // Wait until split finishes, so we can continue working with the new shards + Cerr << "... waiting for split to finish" << Endl; + WaitTxNotification(server, splitSender, splitTxId); + + // Start an immediate read from the new left shard of table-1 + TString readSessionId = CreateSessionRPC(runtime); + Cerr << "... starting immediate read from table-1" << Endl; + auto readFuture = SendRequest(runtime, MakeSimpleRequestRPC(Q_(R"( + SELECT key, value FROM `/Root/table-1` + WHERE key <= 5 + ORDER BY key; + )"), readSessionId, "", /* commit */ true)); + + // We cannot wait for it to finish (bug may be fixed) + // So we sleep for several seconds instead + Cerr << "... sleeping for 2 seconds" << Endl; + runtime.SimulateSleep(TDuration::Seconds(2)); + + // Unblock mediator timecast at node 2 + mediatorTimeCastBlocking.Unblock(1); + + // Wait until read finishes, we must observe previously inserted row + Cerr << "... waiting for table-1 read to finish" << Endl; + UNIT_ASSERT_VALUES_EQUAL( + FormatResult(AwaitResponse(runtime, std::move(readFuture))), + "{ items { uint32_value: 1 } items { uint32_value: 10 } }, " + "{ items { uint32_value: 4 } items { uint32_value: 40 } }"); + + // Repeat read in a previous tx, this read must be repeatable + // In other words we must not observe the new 4/40 row + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleContinue(runtime, sessionId, txId, Q_(R"( + SELECT key, value FROM `/Root/table-1` + UNION ALL + SELECT key, value FROM `/Root/table-2` + ORDER BY key; + )")), + "{ items { uint32_value: 1 } items { uint32_value: 10 } }, " + "{ items { uint32_value: 2 } items { uint32_value: 20 } }, " + "{ items { uint32_value: 3 } items { uint32_value: 30 } }"); + } + + Y_UNIT_TEST(DelayedWriteReplyAfterSplit) { + TPortManager pm; + TServerSettings serverSettings(pm.GetPort(2134)); + serverSettings.SetDomainName("Root") + .SetNodeCount(2) + .SetUseRealThreads(false) + .SetDomainPlanResolution(100); + + Tests::TServer::TPtr server = new TServer(serverSettings); + auto &runtime = *server->GetRuntime(); + auto sender = runtime.AllocateEdgeActor(); + + runtime.SetLogPriority(NKikimrServices::TX_DATASHARD, NLog::PRI_TRACE); + runtime.SetLogPriority(NKikimrServices::TX_PROXY, NLog::PRI_DEBUG); + runtime.SetLogPriority(NKikimrServices::KQP_EXECUTER, NLog::PRI_TRACE); + runtime.SetLogPriority(NKikimrServices::KQP_SESSION, NLog::PRI_TRACE); + + InitRoot(server, sender); + + TDisableDataShardLogBatching disableDataShardLogBatching; + TCreateTabletNodePinning createTabletNodePinning(runtime); + + // Create table-1 at node 1 + createTabletNodePinning.SetNodeIndexes({ 0 }); + CreateShardedTable(server, sender, "/Root", "table-1", 1); + auto shards1 = GetTableShards(server, sender, "/Root/table-1"); + + // Create table-2 at node 2 + createTabletNodePinning.SetNodeIndexes({ 1 }); + CreateShardedTable(server, sender, "/Root", "table-2", 1); + + // Insert initial values + ExecSQL(server, sender, Q_("UPSERT INTO `/Root/table-1` (key, value) VALUES (1, 10);")); + ExecSQL(server, sender, Q_("UPSERT INTO `/Root/table-2` (key, value) VALUES (2, 20);")); + + TSplitSrcBlocking splitSrcBlocking(runtime); + TMediatorTimeCastBlocking mediatorTimeCastBlocking(runtime); + + // We need to make a snapshot read to force unprotected reads + // This will also ensure both nodes have an updated mediator time cast + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleExec(runtime, Q_(R"( + SELECT key, value FROM `/Root/table-1` + UNION ALL + SELECT key, value FROM `/Root/table-2` + ORDER BY key; + )")), + "{ items { uint32_value: 1 } items { uint32_value: 10 } }, " + "{ items { uint32_value: 2 } items { uint32_value: 20 } }"); + + // One more upsert to table-2, this will bump mediator time past the snapshot + ExecSQL(server, sender, Q_("UPSERT INTO `/Root/table-2` (key, value) VALUES (3, 30);")); + + // Wait for the next step, we will expect to read at that step + ui64 step = mediatorTimeCastBlocking.WaitNextStep(); + Cerr << "... expecting next read at step " << step << Endl; + + // We won't allow neither node 1 nor node 2 to go past that snapshot + mediatorTimeCastBlocking.SetMaxAllowedStep(0, step); + mediatorTimeCastBlocking.SetMaxAllowedStep(1, step); + + // Start a snapshot read from table-1 + // This will run at node 1 shard + Cerr << "... reading from table-1" << Endl; + TString sessionId, txId; + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleBegin(runtime, sessionId, txId, Q_(R"( + SELECT key, value FROM `/Root/table-1` + ORDER BY key; + )")), + "{ items { uint32_value: 1 } items { uint32_value: 10 } }"); + + // Start split of table-1 at key 10 + auto splitSender = runtime.AllocateEdgeActor(); + SetSplitMergePartCountLimit(server->GetRuntime(), -1); + Cerr << "... starting split of table-1" << Endl; + ui64 splitTxId = AsyncSplitTable(server, splitSender, "/Root/table-1", shards1.at(0), 10); + + // Start upserting a row into table-1, since mediator time is blocked + // this will not be able to reply until mediator time advances. + TString upsertSessionId = CreateSessionRPC(runtime); + Cerr << "... starting upsert into table-1" << Endl; + auto upsertFuture = SendRequest(runtime, MakeSimpleRequestRPC(Q_(R"( + UPSERT INTO `/Root/table-1` (key, value) VALUES (4, 40); + )"), upsertSessionId, "", /* commit */ true)); + + // Sleep a little, so the above upsert is fully executed at future step and reply is enqueued + runtime.SimulateSleep(TDuration::MicroSeconds(100)); + + // We expect mediator time to be at the last step + UNIT_ASSERT_VALUES_EQUAL(mediatorTimeCastBlocking.LastStep, step); + + // Now unblock the split and wait until it finishes + splitSrcBlocking.Unblock(); + Cerr << "... waiting for split to finish" << Endl; + WaitTxNotification(server, splitSender, splitTxId); + + // We expect mediator time to still be at the last step + UNIT_ASSERT_VALUES_EQUAL(mediatorTimeCastBlocking.LastStep, step); + + // The new shard should be ready to take requests, validate by an immediate read + // The new row must not be visible, since mediator time is still in the past, + // and the write could not have sent a successful reply yet. + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleExec(runtime, Q_(R"( + SELECT key, value FROM `/Root/table-1` + WHERE key <= 5 + ORDER BY key; + )")), + "{ items { uint32_value: 1 } items { uint32_value: 10 } }"); + + // Now that we confirmed the new shard is readable, allow mediator time to advance at node 1 + mediatorTimeCastBlocking.Unblock(0); + + // Sleep for a couple of seconds and check whether upsert has replied + runtime.SimulateSleep(TDuration::Seconds(2)); + + // When upsert replies, only errors are allowed, otherwise new reads + // at node 2 would keep reading stale values. + if (upsertFuture.HasValue() || upsertFuture.HasException()) { + Cerr << "... upsert finished before unblocking node 2" << Endl; + auto upsertResult = FormatResult(upsertFuture.ExtractValueSync()); + if (upsertResult == "") { + // It was successful, double check that node 2 can see the result + // For obvious reasons it cannot (due to blocked mediator time) + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleExec(runtime, Q_(R"( + SELECT key, value FROM `/Root/table-1` + WHERE key <= 5 + ORDER BY key; + )")), + "{ items { uint32_value: 1 } items { uint32_value: 10 } }, " + "{ items { uint32_value: 4 } items { uint32_value: 40 } }, "); + } else { + // Otherwise we must get an UNDETERMINED error + // The upsert hasn't happened yet, but will happen later + UNIT_ASSERT_VALUES_EQUAL( + upsertResult, + "ERROR: UNDETERMINED"); + } + } else { + // Try to be future proof, in case we implement waiting with dst shards + Cerr << "... upsert did not finish before unblocking node 2" << Endl; + } + } + } } // namespace NKikimr diff --git a/ydb/core/tx/time_cast/time_cast.cpp b/ydb/core/tx/time_cast/time_cast.cpp index b4703e9f52bb..3348711bcea9 100644 --- a/ydb/core/tx/time_cast/time_cast.cpp +++ b/ydb/core/tx/time_cast/time_cast.cpp @@ -30,7 +30,10 @@ void TMediatorTimecastEntry::Update(ui64 step, ui64 *exemption, ui64 exsz) { Y_UNUSED(exemption); Y_UNUSED(exsz); - AtomicSet(Step, step); + // Mediator time shouldn't go back while shards are running + if (Get(0) < step) { + AtomicSet(Step, step); + } } class TMediatorTimecastProxy : public TActor { From f2b72c645059db957e0a27990c4af5b2948af5a8 Mon Sep 17 00:00:00 2001 From: Nikolay Shestakov Date: Mon, 4 Mar 2024 15:04:24 +0500 Subject: [PATCH 048/117] Improove tablet generation value in Topic protocol (#2375) (#2382) --- .github/config/muted_ya.txt | 1 - ydb/core/persqueue/partition.cpp | 2 +- ydb/services/persqueue_v1/actors/partition_actor.cpp | 7 +++---- ydb/services/persqueue_v1/persqueue_ut.cpp | 8 ++++---- 4 files changed, 8 insertions(+), 10 deletions(-) diff --git a/.github/config/muted_ya.txt b/.github/config/muted_ya.txt index d8a23a51436d..21bbd82cd10e 100644 --- a/.github/config/muted_ya.txt +++ b/.github/config/muted_ya.txt @@ -66,7 +66,6 @@ ydb/services/persqueue_v1/ut TPersQueueTest.CheckACLForGrpcWrite ydb/services/persqueue_v1/ut TPersQueueTest.DirectRead* ydb/services/persqueue_v1/ut TPersQueueTest.SetupLockSession ydb/services/persqueue_v1/ut TPersQueueTest.TopicServiceCommitOffsetBadOffsets -ydb/services/persqueue_v1/ut TPersQueueTest.UpdatePartitionLocation ydb/services/persqueue_v1/ut TPQCompatTest.BadTopics ydb/services/persqueue_v1/ut [3/10]* ydb/services/ydb/sdk_sessions_pool_ut YdbSdkSessionsPool.StressTestSync* diff --git a/ydb/core/persqueue/partition.cpp b/ydb/core/persqueue/partition.cpp index f29e9511f7c2..ca2d1443ce4c 100644 --- a/ydb/core/persqueue/partition.cpp +++ b/ydb/core/persqueue/partition.cpp @@ -501,7 +501,7 @@ void TPartition::InitComplete(const TActorContext& ctx) { LOG_INFO_S( ctx, NKikimrServices::PERSQUEUE, - "init complete for topic '" << TopicName() << "' partition " << Partition << " " << ctx.SelfID + "init complete for topic '" << TopicName() << "' partition " << Partition << " generation " << TabletGeneration << " " << ctx.SelfID ); TStringBuilder ss; diff --git a/ydb/services/persqueue_v1/actors/partition_actor.cpp b/ydb/services/persqueue_v1/actors/partition_actor.cpp index dd736fc68d39..6e22363df045 100644 --- a/ydb/services/persqueue_v1/actors/partition_actor.cpp +++ b/ydb/services/persqueue_v1/actors/partition_actor.cpp @@ -593,7 +593,7 @@ void TPartitionActor::Handle(TEvPersQueue::TEvResponse::TPtr& ev, const TActorCo if (!StartReading) { - ctx.Send(ParentId, new TEvPQProxy::TEvPartitionStatus(Partition, CommittedOffset, EndOffset, WriteTimestampEstimateMs, TabletGeneration, NodeId)); + ctx.Send(ParentId, new TEvPQProxy::TEvPartitionStatus(Partition, CommittedOffset, EndOffset, WriteTimestampEstimateMs, NodeId, TabletGeneration)); } else { InitStartReading(ctx); } @@ -802,15 +802,14 @@ void TPartitionActor::Handle(TEvTabletPipe::TEvClientConnected::TPtr& ev, const TEvTabletPipe::TEvClientConnected *msg = ev->Get(); LOG_INFO_S(ctx, NKikimrServices::PQ_READ_PROXY, PQ_LOG_PREFIX << " " << Partition - << " pipe restart attempt " << PipeGeneration << " pipe creation result: " << msg->Status); + << " pipe restart attempt " << PipeGeneration << " pipe creation result: " << msg->Status + << " TabletId: " << msg->TabletId << " Generation: " << msg->Generation); if (msg->Status != NKikimrProto::OK) { RestartPipe(ctx, TStringBuilder() << "pipe to tablet is dead " << msg->TabletId, NPersQueue::NErrorCode::TABLET_PIPE_DISCONNECTED); return; } - auto prevGeneration = TabletGeneration; - Y_UNUSED(prevGeneration); TabletGeneration = msg->Generation; NodeId = msg->ServerId.NodeId(); diff --git a/ydb/services/persqueue_v1/persqueue_ut.cpp b/ydb/services/persqueue_v1/persqueue_ut.cpp index a223ec34ff89..73b29d3bdd11 100644 --- a/ydb/services/persqueue_v1/persqueue_ut.cpp +++ b/ydb/services/persqueue_v1/persqueue_ut.cpp @@ -716,7 +716,7 @@ Y_UNIT_TEST_SUITE(TPersQueueTest) { TPersQueueV1TestServer server; SET_LOCALS; MAKE_INSECURE_STUB(Ydb::Topic::V1::TopicService); - server.EnablePQLogs({ NKikimrServices::PQ_METACACHE, NKikimrServices::PQ_READ_PROXY}); + server.EnablePQLogs({ NKikimrServices::PQ_METACACHE, NKikimrServices::PQ_READ_PROXY, NKikimrServices::PERSQUEUE}); server.EnablePQLogs({ NKikimrServices::KQP_PROXY }, NLog::EPriority::PRI_EMERG); server.EnablePQLogs({ NKikimrServices::FLAT_TX_SCHEMESHARD }, NLog::EPriority::PRI_ERROR); @@ -742,8 +742,8 @@ Y_UNIT_TEST_SUITE(TPersQueueTest) { } // await and confirm CreatePartitionStreamRequest from server - i64 assignId = 0; - i64 generation = 0; + i64 assignId; + i64 generation; { Ydb::Topic::StreamReadMessage::FromServer resp; @@ -756,8 +756,8 @@ Y_UNIT_TEST_SUITE(TPersQueueTest) { UNIT_ASSERT_VALUES_EQUAL(resp.start_partition_session_request().partition_session().path(), "acc/topic1"); UNIT_ASSERT(resp.start_partition_session_request().partition_session().partition_id() == 0); UNIT_ASSERT(resp.start_partition_session_request().partition_location().generation() > 0); - generation = resp.start_partition_session_request().partition_location().generation(); assignId = resp.start_partition_session_request().partition_session().partition_session_id(); + generation = resp.start_partition_session_request().partition_location().generation(); } server.Server->AnnoyingClient->RestartPartitionTablets(server.Server->CleverServer->GetRuntime(), "rt3.dc1--acc--topic1"); From 5b1040149295655fdbd4be18ea2a2777fcc0439f Mon Sep 17 00:00:00 2001 From: FloatingCrowbar <103565628+FloatingCrowbar@users.noreply.github.com> Date: Tue, 5 Mar 2024 09:56:43 +0300 Subject: [PATCH 049/117] Fix 24-1 read quoter crash (#2436) --- ydb/core/persqueue/partition.cpp | 2 +- ydb/core/persqueue/partition_read.cpp | 2 +- 2 files changed, 2 insertions(+), 2 deletions(-) diff --git a/ydb/core/persqueue/partition.cpp b/ydb/core/persqueue/partition.cpp index ca2d1443ce4c..5b646acc1c9f 100644 --- a/ydb/core/persqueue/partition.cpp +++ b/ydb/core/persqueue/partition.cpp @@ -996,7 +996,7 @@ void TPartition::Handle(TEvPQ::TEvBlobResponse::TPtr& ev, const TActorContext& c TabletCounters.Cumulative()[COUNTER_PQ_READ_BYTES].Increment(resp->ByteSize()); } ctx.Send(info.Destination != 0 ? Tablet : ctx.SelfID, answer.Event.Release()); - OnReadRequestFinished(cookie, answer.Size, info.User, ctx); + OnReadRequestFinished(info.Destination, answer.Size, info.User, ctx); } void TPartition::Handle(TEvPQ::TEvError::TPtr& ev, const TActorContext& ctx) { diff --git a/ydb/core/persqueue/partition_read.cpp b/ydb/core/persqueue/partition_read.cpp index 7173ebbf2ae2..eae972be6e2c 100644 --- a/ydb/core/persqueue/partition_read.cpp +++ b/ydb/core/persqueue/partition_read.cpp @@ -973,7 +973,7 @@ void TPartition::ProcessRead(const TActorContext& ctx, TReadInfo&& info, const u TabletCounters.Cumulative()[COUNTER_PQ_READ_BYTES].Increment(resp->ByteSize()); ctx.Send(info.Destination != 0 ? Tablet : ctx.SelfID, answer.Event.Release()); - OnReadRequestFinished(cookie, answer.Size, info.User, ctx); + OnReadRequestFinished(info.Destination, answer.Size, info.User, ctx); return; } From c9a38da70a6bf7f4b4b33cce9cda0c58227e4c11 Mon Sep 17 00:00:00 2001 From: niksaveliev Date: Tue, 5 Mar 2024 14:38:47 +0600 Subject: [PATCH 050/117] Kafka, read without consumer fixes and metrics fixes to 24-1 (#2412) --- ydb/core/kafka_proxy/actors/actors.h | 5 ++ .../actors/kafka_api_versions_actor.cpp | 28 ++++---- .../actors/kafka_find_coordinator_actor.cpp | 17 ++++- .../actors/kafka_metadata_actor.cpp | 5 -- .../actors/kafka_offset_fetch_actor.cpp | 1 + .../actors/kafka_read_session_actor.cpp | 12 ++-- ydb/core/kafka_proxy/kafka_connection.cpp | 9 ++- .../kafka_proxy/kafka_consumer_protocol.cpp | 10 ++- ydb/core/kafka_proxy/kafka_messages.cpp | 7 +- ydb/core/kafka_proxy/ut/ut_protocol.cpp | 7 +- ydb/core/persqueue/partition.cpp | 20 +++++- ydb/core/persqueue/partition_init.cpp | 6 +- .../ut/resources/counters_datastreams.html | 30 ++++----- .../ut/resources/counters_topics.html | 2 + ydb/core/persqueue/writer/writer.cpp | 65 +++++++------------ ydb/core/protos/counters_pq.proto | 3 + .../commands/topic_operations_scenario.cpp | 1 + .../commands/topic_operations_scenario.h | 1 + .../topic_workload/topic_workload_reader.cpp | 30 ++++++--- .../topic_workload/topic_workload_reader.h | 1 + .../topic_workload_run_read.cpp | 3 + .../persqueue_new_schemecache_ut.cpp | 2 +- 22 files changed, 160 insertions(+), 105 deletions(-) diff --git a/ydb/core/kafka_proxy/actors/actors.h b/ydb/core/kafka_proxy/actors/actors.h index e1c287a8654e..8ae2710a6792 100644 --- a/ydb/core/kafka_proxy/actors/actors.h +++ b/ydb/core/kafka_proxy/actors/actors.h @@ -10,6 +10,11 @@ namespace NKafka { +static constexpr int ProxyNodeId = 1; +static constexpr char UnderlayPrefix[] = "u-"; + +static_assert(sizeof(UnderlayPrefix) == 3); + enum EAuthSteps { WAIT_HANDSHAKE, WAIT_AUTH, diff --git a/ydb/core/kafka_proxy/actors/kafka_api_versions_actor.cpp b/ydb/core/kafka_proxy/actors/kafka_api_versions_actor.cpp index 96c628477a5c..dc74d519630a 100644 --- a/ydb/core/kafka_proxy/actors/kafka_api_versions_actor.cpp +++ b/ydb/core/kafka_proxy/actors/kafka_api_versions_actor.cpp @@ -30,21 +30,21 @@ TApiVersionsResponseData::TPtr GetApiVersions() { TApiVersionsResponseData::TPtr response = std::make_shared(); response->ErrorCode = EKafkaErrors::NONE_ERROR; - AddApiKey(response->ApiKeys, PRODUCE, {.MinVersion=3}); - AddApiKey(response->ApiKeys, API_VERSIONS); - AddApiKey(response->ApiKeys, METADATA); - AddApiKey(response->ApiKeys, INIT_PRODUCER_ID); - AddApiKey(response->ApiKeys, SASL_HANDSHAKE); - AddApiKey(response->ApiKeys, SASL_AUTHENTICATE); - AddApiKey(response->ApiKeys, LIST_OFFSETS); + AddApiKey(response->ApiKeys, PRODUCE, {.MinVersion=3, .MaxVersion=9}); + AddApiKey(response->ApiKeys, API_VERSIONS, {.MaxVersion=2}); + AddApiKey(response->ApiKeys, METADATA, {.MaxVersion=9}); + AddApiKey(response->ApiKeys, INIT_PRODUCER_ID, {.MaxVersion=4}); + AddApiKey(response->ApiKeys, SASL_HANDSHAKE, {.MaxVersion=1}); + AddApiKey(response->ApiKeys, SASL_AUTHENTICATE, {.MaxVersion=2}); + AddApiKey(response->ApiKeys, LIST_OFFSETS, {.MinVersion=1, .MaxVersion=1}); AddApiKey(response->ApiKeys, FETCH, {.MaxVersion=3}); - AddApiKey(response->ApiKeys, JOIN_GROUP); - AddApiKey(response->ApiKeys, SYNC_GROUP); - AddApiKey(response->ApiKeys, LEAVE_GROUP); - AddApiKey(response->ApiKeys, HEARTBEAT); - AddApiKey(response->ApiKeys, FIND_COORDINATOR); - AddApiKey(response->ApiKeys, OFFSET_COMMIT, {.MaxVersion=1}); - AddApiKey(response->ApiKeys, OFFSET_FETCH); + AddApiKey(response->ApiKeys, JOIN_GROUP, {.MaxVersion=9}); + AddApiKey(response->ApiKeys, SYNC_GROUP, {.MaxVersion=3}); + AddApiKey(response->ApiKeys, LEAVE_GROUP, {.MaxVersion=5}); + AddApiKey(response->ApiKeys, HEARTBEAT, {.MaxVersion=4}); + AddApiKey(response->ApiKeys, FIND_COORDINATOR, {.MaxVersion=0}); + AddApiKey(response->ApiKeys, OFFSET_COMMIT, {.MaxVersion=0}); + AddApiKey(response->ApiKeys, OFFSET_FETCH, {.MaxVersion=8}); return response; } diff --git a/ydb/core/kafka_proxy/actors/kafka_find_coordinator_actor.cpp b/ydb/core/kafka_proxy/actors/kafka_find_coordinator_actor.cpp index 63709d8385c4..de97d767227c 100644 --- a/ydb/core/kafka_proxy/actors/kafka_find_coordinator_actor.cpp +++ b/ydb/core/kafka_proxy/actors/kafka_find_coordinator_actor.cpp @@ -25,7 +25,7 @@ void TKafkaFindCoordinatorActor::Bootstrap(const NActors::TActorContext& ctx) { bool withProxy = Context->Config.HasProxy() && !Context->Config.GetProxy().GetHostname().Empty(); if (withProxy) { - SendResponseOkAndDie(Context->Config.GetProxy().GetHostname(), Context->Config.GetProxy().GetPort(), -1, ctx); + SendResponseOkAndDie(Context->Config.GetProxy().GetHostname(), Context->Config.GetProxy().GetPort(), NKafka::ProxyNodeId, ctx); return; } @@ -49,6 +49,13 @@ void TKafkaFindCoordinatorActor::SendResponseOkAndDie(const TString& host, i32 p response->Coordinators.push_back(coordinator); } + response->ErrorCode = NONE_ERROR; + response->Host = host; + response->Port = port; + response->NodeId = nodeId; + + KAFKA_LOG_D("FIND_COORDINATOR response. Host#: " << host << ", Port#: " << port << ", NodeId# " << nodeId); + Send(Context->ConnectionId, new TEvKafka::TEvResponse(CorrelationId, response, static_cast(response->ErrorCode))); Die(ctx); } @@ -66,7 +73,9 @@ void TKafkaFindCoordinatorActor::SendResponseFailAndDie(EKafkaErrors error, cons response->Coordinators.push_back(coordinator); } - + + response->ErrorCode = error; + Send(Context->ConnectionId, new TEvKafka::TEvResponse(CorrelationId, response, static_cast(response->ErrorCode))); Die(ctx); } @@ -74,7 +83,11 @@ void TKafkaFindCoordinatorActor::SendResponseFailAndDie(EKafkaErrors error, cons void TKafkaFindCoordinatorActor::Handle(NKikimr::NIcNodeCache::TEvICNodesInfoCache::TEvGetAllNodesInfoResponse::TPtr& ev, const NActors::TActorContext& ctx) { auto iter = ev->Get()->NodeIdsMapping->find(ctx.SelfID.NodeId()); Y_ABORT_UNLESS(!iter.IsEnd()); + auto host = (*ev->Get()->Nodes)[iter->second].Host; + if (host.StartsWith(UnderlayPrefix)) { + host = host.substr(sizeof(UnderlayPrefix) - 1); + } KAFKA_LOG_D("FIND_COORDINATOR incoming TEvGetAllNodesInfoResponse. Host#: " << host); SendResponseOkAndDie(host, Context->Config.GetListeningPort(), ctx.SelfID.NodeId(), ctx); } diff --git a/ydb/core/kafka_proxy/actors/kafka_metadata_actor.cpp b/ydb/core/kafka_proxy/actors/kafka_metadata_actor.cpp index 9a9029a9f2d8..b51d3b6badeb 100644 --- a/ydb/core/kafka_proxy/actors/kafka_metadata_actor.cpp +++ b/ydb/core/kafka_proxy/actors/kafka_metadata_actor.cpp @@ -6,11 +6,6 @@ namespace NKafka { using namespace NKikimr::NGRpcProxy::V1; -static constexpr int ProxyNodeId = 1; -static constexpr char UnderlayPrefix[] = "u-"; - -static_assert(sizeof(UnderlayPrefix) == 3); - NActors::IActor* CreateKafkaMetadataActor(const TContext::TPtr context, const ui64 correlationId, const TMessagePtr& message) { diff --git a/ydb/core/kafka_proxy/actors/kafka_offset_fetch_actor.cpp b/ydb/core/kafka_proxy/actors/kafka_offset_fetch_actor.cpp index 01cee28a259c..96893aaa59ce 100644 --- a/ydb/core/kafka_proxy/actors/kafka_offset_fetch_actor.cpp +++ b/ydb/core/kafka_proxy/actors/kafka_offset_fetch_actor.cpp @@ -204,6 +204,7 @@ TOffsetFetchResponseData::TPtr TKafkaOffsetFetchActor::GetOffsetFetchResponse() partition.CommittedOffset = sourcePartition.CommittedOffset; partition.PartitionIndex = sourcePartition.PartitionIndex; partition.ErrorCode = sourcePartition.ErrorCode; + topic.Partitions.push_back(partition); } response->Topics.push_back(topic); } diff --git a/ydb/core/kafka_proxy/actors/kafka_read_session_actor.cpp b/ydb/core/kafka_proxy/actors/kafka_read_session_actor.cpp index e788f7ceb736..cd3f6dd7d674 100644 --- a/ydb/core/kafka_proxy/actors/kafka_read_session_actor.cpp +++ b/ydb/core/kafka_proxy/actors/kafka_read_session_actor.cpp @@ -39,7 +39,7 @@ void TKafkaReadSessionActor::HandleWakeup(TEvKafka::TEvWakeup::TPtr, const TActo for (auto& topicToPartitions: NewPartitionsToLockOnTime) { auto& partitions = topicToPartitions.second; for (auto partitionsIt = partitions.begin(); partitionsIt != partitions.end(); ) { - if (partitionsIt->LockOn >= ctx.Now()) { + if (partitionsIt->LockOn <= ctx.Now()) { TopicPartitions[topicToPartitions.first].ToLock.emplace(partitionsIt->PartitionId); NeedRebalance = true; partitionsIt = partitions.erase(partitionsIt); @@ -86,8 +86,8 @@ void TKafkaReadSessionActor::HandleJoinGroup(TEvKafka::TEvJoinGroupRequest::TPtr switch (ReadStep) { case WAIT_JOIN_GROUP: { // join first time - if (joinGroupRequest->ProtocolType != SUPPORTED_JOIN_GROUP_PROTOCOL) { - SendJoinGroupResponseFail(ctx, ev->Get()->CorrelationId, INVALID_REQUEST, TStringBuilder() << "unknown protocolType# " << joinGroupRequest->ProtocolType); + if (joinGroupRequest->ProtocolType.has_value() && !joinGroupRequest->ProtocolType.value().empty() && joinGroupRequest->ProtocolType.value() != SUPPORTED_JOIN_GROUP_PROTOCOL) { + SendJoinGroupResponseFail(ctx, ev->Get()->CorrelationId, INVALID_REQUEST, TStringBuilder() << "unknown protocolType# " << joinGroupRequest->ProtocolType.value()); CloseReadSession(ctx); return; } @@ -156,8 +156,8 @@ void TKafkaReadSessionActor::HandleSyncGroup(TEvKafka::TEvSyncGroupRequest::TPtr return; } - if (syncGroupRequest->ProtocolType != SUPPORTED_JOIN_GROUP_PROTOCOL) { - SendJoinGroupResponseFail(ctx, ev->Get()->CorrelationId, INVALID_REQUEST, TStringBuilder() << "unknown protocolType# " << syncGroupRequest->ProtocolType); + if (syncGroupRequest->ProtocolType.has_value() && !syncGroupRequest->ProtocolType.value().empty() && syncGroupRequest->ProtocolType.value() != SUPPORTED_JOIN_GROUP_PROTOCOL) { + SendSyncGroupResponseFail(ctx, ev->Get()->CorrelationId, INVALID_REQUEST, TStringBuilder() << "unknown protocolType# " << syncGroupRequest->ProtocolType.value()); CloseReadSession(ctx); return; } @@ -361,9 +361,9 @@ TConsumerProtocolAssignment TKafkaReadSessionActor::BuildAssignmentAndInformBala for (auto part: finalPartitionsToRead) { KAFKA_LOG_D("SYNC_GROUP assigned partition number: " << part); topicPartition.Partitions.push_back(part); - assignment.AssignedPartitions.push_back(topicPartition); partitions.ReadingNow.emplace(part); } + assignment.AssignedPartitions.push_back(topicPartition); } return assignment; diff --git a/ydb/core/kafka_proxy/kafka_connection.cpp b/ydb/core/kafka_proxy/kafka_connection.cpp index cca305787023..48fd041bf145 100644 --- a/ydb/core/kafka_proxy/kafka_connection.cpp +++ b/ydb/core/kafka_proxy/kafka_connection.cpp @@ -319,7 +319,14 @@ class TKafkaConnection: public TActorBootstrapped, public TNet KAFKA_LOG_D("process message: ApiKey=" << Request->Header.RequestApiKey << ", ExpectedSize=" << Request->ExpectedSize << ", Size=" << Request->Size); - Request->Method = EApiKeyNames.find(static_cast(Request->Header.RequestApiKey))->second; + auto apiKeyNameIt = EApiKeyNames.find(static_cast(Request->Header.RequestApiKey)); + if (apiKeyNameIt == EApiKeyNames.end()) { + KAFKA_LOG_ERROR("Unsupported message: ApiKey=" << Request->Header.RequestApiKey); + PassAway(); + return false; + } + + Request->Method = apiKeyNameIt->second; PendingRequestsQueue.push_back(Request); PendingRequests[Request->Header.CorrelationId] = Request; diff --git a/ydb/core/kafka_proxy/kafka_consumer_protocol.cpp b/ydb/core/kafka_proxy/kafka_consumer_protocol.cpp index dd2e52eb7a64..ce54125ffd56 100644 --- a/ydb/core/kafka_proxy/kafka_consumer_protocol.cpp +++ b/ydb/core/kafka_proxy/kafka_consumer_protocol.cpp @@ -143,12 +143,20 @@ void TConsumerProtocolAssignment::Read(TKafkaReadable& _readable, TKafkaVersion } void TConsumerProtocolAssignment::Write(TKafkaWritable& _writable, TKafkaVersion _version) const { + auto useVarintSize = _version > 3; _version = ASSIGNMENT_VERSION; + if (!NPrivate::VersionCheck(_version)) { ythrow yexception() << "Can't write version " << _version << " of TConsumerProtocolAssignment"; } - _writable.writeUnsignedVarint(Size(ASSIGNMENT_VERSION) + 1); + if (useVarintSize) { + _writable.writeUnsignedVarint(Size(_version) + 1); + } else { + TKafkaInt32 size = Size(_version); + _writable << size; + } + _writable << _version; NPrivate::TWriteCollector _collector; NPrivate::Write(_collector, _writable, _version, AssignedPartitions); diff --git a/ydb/core/kafka_proxy/kafka_messages.cpp b/ydb/core/kafka_proxy/kafka_messages.cpp index 8b08d98ce472..b68f3cd9ba77 100644 --- a/ydb/core/kafka_proxy/kafka_messages.cpp +++ b/ydb/core/kafka_proxy/kafka_messages.cpp @@ -4517,7 +4517,12 @@ i32 TSyncGroupResponseData::Size(TKafkaVersion _version) const { if (NPrivate::VersionCheck(_version)) { _collector.Size += NPrivate::SizeOfUnsignedVarint(_collector.NumTaggedFields); } - return _collector.Size + NPrivate::SizeOfUnsignedVarint(_assignmentCollector.Size + 1); + auto useVarintSize = _version > 3; + if (useVarintSize) { + return _collector.Size + NPrivate::SizeOfUnsignedVarint(_assignmentCollector.Size + 1); + } else { + return _collector.Size + sizeof(TKafkaInt32); + } } diff --git a/ydb/core/kafka_proxy/ut/ut_protocol.cpp b/ydb/core/kafka_proxy/ut/ut_protocol.cpp index 46e982aa8a59..a4115a4f043e 100644 --- a/ydb/core/kafka_proxy/ut/ut_protocol.cpp +++ b/ydb/core/kafka_proxy/ut/ut_protocol.cpp @@ -532,7 +532,12 @@ class TTestClient { TReadInfo readInfo; for (;;) { readInfo = JoinAndSyncGroup(topics, groupId); - if (readInfo.Partitions.size() == expectedPartitionsCount) { + ui32 partitionsCount = 0; + for (auto topicPartitions: readInfo.Partitions) { + partitionsCount += topicPartitions.Partitions.size(); + } + + if (partitionsCount == expectedPartitionsCount) { break; } WaitRebalance(readInfo.MemberId, readInfo.GenerationId, groupId); diff --git a/ydb/core/persqueue/partition.cpp b/ydb/core/persqueue/partition.cpp index 5b646acc1c9f..d8f90cb3de79 100644 --- a/ydb/core/persqueue/partition.cpp +++ b/ydb/core/persqueue/partition.cpp @@ -748,7 +748,7 @@ void TPartition::Handle(TEvPQ::TEvPartitionStatus::TPtr& ev, const TActorContext auto& userInfo = userInfoPair.second; if (!userInfo.LabeledCounters) continue; - if (!userInfo.HasReadRule && !userInfo.Important) + if (userInfoPair.first != CLIENTID_WITHOUT_CONSUMER && !userInfo.HasReadRule && !userInfo.Important) continue; auto* cac = ac->AddConsumerAggregatedCounters(); cac->SetConsumer(userInfo.User); @@ -1083,7 +1083,7 @@ bool TPartition::UpdateCounters(const TActorContext& ctx, bool force) { auto& userInfo = userInfoPair.second; if (!userInfo.LabeledCounters) continue; - if (!userInfo.HasReadRule && !userInfo.Important) + if (userInfoPair.first != CLIENTID_WITHOUT_CONSUMER && !userInfo.HasReadRule && !userInfo.Important) continue; bool haveChanges = false; userInfo.EndOffset = EndOffset; @@ -1187,6 +1187,12 @@ bool TPartition::UpdateCounters(const TActorContext& ctx, bool force) { userInfo.LabeledCounters->GetCounters()[METRIC_READ_QUOTA_PER_CONSUMER_USAGE].Set(quotaUsage); } } + + if (userInfoPair.first == CLIENTID_WITHOUT_CONSUMER ) { + PartitionCountersLabeled->GetCounters()[METRIC_READ_QUOTA_NO_CONSUMER_BYTES].Set(userInfo.LabeledCounters->GetCounters()[METRIC_READ_QUOTA_PER_CONSUMER_BYTES].Get()); + PartitionCountersLabeled->GetCounters()[METRIC_READ_QUOTA_NO_CONSUMER_USAGE].Set(userInfo.LabeledCounters->GetCounters()[METRIC_READ_QUOTA_PER_CONSUMER_USAGE].Get()); + } + if (haveChanges) { ctx.Send(Tablet, new TEvPQ::TEvPartitionLabeledCounters(Partition, *userInfo.LabeledCounters)); } @@ -1299,6 +1305,14 @@ bool TPartition::UpdateCounters(const TActorContext& ctx, bool force) { PartitionCountersLabeled->GetCounters()[METRIC_READ_QUOTA_PARTITION_TOTAL_USAGE].Set(quotaUsage); } } + + if (PartitionCountersLabeled->GetCounters()[METRIC_READ_QUOTA_NO_CONSUMER_BYTES].Get()) { + ui64 quotaUsage = ui64(AvgReadBytes.GetValue()) * 1000000 / PartitionCountersLabeled->GetCounters()[METRIC_READ_QUOTA_PARTITION_TOTAL_BYTES].Get() / 60; + if (quotaUsage != PartitionCountersLabeled->GetCounters()[METRIC_READ_QUOTA_PARTITION_TOTAL_USAGE].Get()) { + haveChanges = true; + PartitionCountersLabeled->GetCounters()[METRIC_READ_QUOTA_PARTITION_TOTAL_USAGE].Set(quotaUsage); + } + } return haveChanges; } @@ -1805,7 +1819,7 @@ void TPartition::OnProcessTxsAndUserActsWriteComplete(ui64 cookie, const TActorC } else { TabletCounters.Cumulative()[COUNTER_PQ_WRITE_TIMESTAMP_CACHE_HIT].Increment(1); } - } else { + } else if (user != CLIENTID_WITHOUT_CONSUMER) { auto ui = UsersInfoStorage->GetIfExists(user); if (ui && ui->LabeledCounters) { ScheduleDropPartitionLabeledCounters(ui->LabeledCounters->GetGroup()); diff --git a/ydb/core/persqueue/partition_init.cpp b/ydb/core/persqueue/partition_init.cpp index fcab0f62f360..305a6b7fce63 100644 --- a/ydb/core/persqueue/partition_init.cpp +++ b/ydb/core/persqueue/partition_init.cpp @@ -885,8 +885,8 @@ void TPartition::SetupStreamCounters(const TActorContext& ctx) { 5000, 10'000, 30'000, 99'999'999}); SLIBigLatency = NKikimr::NPQ::TMultiCounter(subGroup, aggr, {}, {"WriteBigLatency"}, true, "name", false); WritesTotal = NKikimr::NPQ::TMultiCounter(subGroup, aggr, {}, {"WritesTotal"}, true, "name", false); - if (IsQuotingEnabled() && !TopicWriteQuotaResourcePath.empty()) { - subgroups.push_back({"name", "api.grpc.topic.stream_write.topic_throttled_milliseconds"}); + if (IsQuotingEnabled()) { + subgroups.push_back({"name", "topic.write.topic_throttled_milliseconds"}); TopicWriteQuotaWaitCounter = THolder( new NKikimr::NPQ::TPercentileCounter( NPersQueue::GetCountersForTopic(counters, IsServerless), {}, @@ -899,7 +899,7 @@ void TPartition::SetupStreamCounters(const TActorContext& ctx) { subgroups.pop_back(); } - subgroups.push_back({"name", "api.grpc.topic.stream_write.partition_throttled_milliseconds"}); + subgroups.push_back({"name", "topic.write.partition_throttled_milliseconds"}); PartitionWriteQuotaWaitCounter = THolder( new NKikimr::NPQ::TPercentileCounter( NPersQueue::GetCountersForTopic(counters, IsServerless), {}, subgroups, "bin", diff --git a/ydb/core/persqueue/ut/resources/counters_datastreams.html b/ydb/core/persqueue/ut/resources/counters_datastreams.html index 4293a0c49e47..6f7e35c67c88 100644 --- a/ydb/core/persqueue/ut/resources/counters_datastreams.html +++ b/ydb/core/persqueue/ut/resources/counters_datastreams.html @@ -25,21 +25,6 @@ bin=60000: 0 bin=999999: 0 - name=api.grpc.topic.stream_write.partition_throttled_milliseconds: - bin=0: 30 - bin=1: 0 - bin=10: 0 - bin=100: 0 - bin=1000: 0 - bin=10000: 0 - bin=20: 0 - bin=2500: 0 - bin=5: 0 - bin=50: 0 - bin=500: 0 - bin=5000: 0 - bin=999999: 0 - name=topic.write.lag_milliseconds: bin=100: 0 bin=1000: 10 @@ -68,4 +53,19 @@ bin=5242880: 0 bin=67108864: 0 bin=99999999: 0 + + name=topic.write.partition_throttled_milliseconds: + bin=0: 30 + bin=1: 0 + bin=10: 0 + bin=100: 0 + bin=1000: 0 + bin=10000: 0 + bin=20: 0 + bin=2500: 0 + bin=5: 0 + bin=50: 0 + bin=500: 0 + bin=5000: 0 + bin=999999: 0 diff --git a/ydb/core/persqueue/ut/resources/counters_topics.html b/ydb/core/persqueue/ut/resources/counters_topics.html index 2084d1e21989..d5a4414a6c17 100644 --- a/ydb/core/persqueue/ut/resources/counters_topics.html +++ b/ydb/core/persqueue/ut/resources/counters_topics.html @@ -16,6 +16,8 @@ name=topic.partition.read.inflight_throttled_microseconds_max: 0 name=topic.partition.read.speed_limit_bytes_per_second: 20000000000 name=topic.partition.read.throttled_microseconds_max: 0 + name=topic.partition.read_without_consumer.speed_limit_bytes_per_second: 0 + name=topic.partition.read_without_consumer.throttled_microseconds_max: 0 name=topic.partition.storage_bytes_max: 0 name=topic.partition.total_count: 2 name=topic.partition.uptime_milliseconds_min: 30000 diff --git a/ydb/core/persqueue/writer/writer.cpp b/ydb/core/persqueue/writer/writer.cpp index 5fac083b6c6d..8fec66d14a5f 100644 --- a/ydb/core/persqueue/writer/writer.cpp +++ b/ydb/core/persqueue/writer/writer.cpp @@ -470,7 +470,7 @@ class TPartitionWriter: public TActorBootstrapped, private TRl return; } - const bool checkQuota = Opts.CheckRequestUnits() && IsQuotaRequired(); + const bool needToRequestQuota = Opts.CheckRequestUnits() && IsQuotaRequired(); size_t processed = 0; PendingQuotaAmount = 0; @@ -490,7 +490,7 @@ class TPartitionWriter: public TActorBootstrapped, private TRl cmd.SetSize(it->second.ByteSize()); cmd.SetLastRequest(false); - if (checkQuota) { + if (needToRequestQuota) { ++processed; PendingQuotaAmount += CalcRuConsumption(it->second.ByteSize()); PendingQuota.emplace_back(it->first); @@ -498,15 +498,15 @@ class TPartitionWriter: public TActorBootstrapped, private TRl NTabletPipe::SendData(SelfId(), PipeClient, ev.Release()); - PendingReserve.emplace(it->first, RequestHolder{ std::move(it->second), checkQuota }); + PendingReserve.emplace(it->first, RequestHolder{ std::move(it->second), needToRequestQuota }); Pending.erase(it); - if (checkQuota && processed == MAX_QUOTA_INFLIGHT) { + if (needToRequestQuota && processed == MAX_QUOTA_INFLIGHT) { break; } } - if (checkQuota) { + if (needToRequestQuota) { RequestDataQuota(PendingQuotaAmount, ctx); } } @@ -527,18 +527,18 @@ class TPartitionWriter: public TActorBootstrapped, private TRl ReceivedReserve.emplace(it->first, std::move(it->second)); - ProcessQuota(); + ProcessQuotaAndWrite(); } - void ProcessQuota() { + void ProcessQuotaAndWrite() { auto rit = ReceivedReserve.begin(); auto qit = ReceivedQuota.begin(); while(rit != ReceivedReserve.end() && qit != ReceivedQuota.end()) { auto& request = rit->second; const auto cookie = rit->first; - TRACE("processing quota for request cookie=" << cookie << ", QuotaChecked=" << request.QuotaChecked << ", QuotaAccepted=" << request.QuotaAccepted); - if (!request.QuotaChecked || request.QuotaAccepted) { + TRACE("processing quota for request cookie=" << cookie << ", QuotaCheckEnabled=" << request.QuotaCheckEnabled << ", QuotaAccepted=" << request.QuotaAccepted); + if (!request.QuotaCheckEnabled || request.QuotaAccepted) { // A situation when a quota was not requested or was received while waiting for a reserve Write(cookie, std::move(request.Request)); ReceivedReserve.erase(rit++); @@ -559,8 +559,8 @@ class TPartitionWriter: public TActorBootstrapped, private TRl while(rit != ReceivedReserve.end()) { auto& request = rit->second; const auto cookie = rit->first; - TRACE("processing quota for request cookie=" << cookie << ", QuotaChecked=" << request.QuotaChecked << ", QuotaAccepted=" << request.QuotaAccepted); - if (request.QuotaChecked && !request.QuotaAccepted) { + TRACE("processing quota for request cookie=" << cookie << ", QuotaCheckEnabled=" << request.QuotaCheckEnabled << ", QuotaAccepted=" << request.QuotaAccepted); + if (request.QuotaCheckEnabled && !request.QuotaAccepted) { break; } @@ -587,27 +587,6 @@ class TPartitionWriter: public TActorBootstrapped, private TRl ReceivedQuota.clear(); } - void Write(ui64 cookie) { - if (PendingReserve.empty()) { - ERROR("The state of the PartitionWriter is invalid. PendingReserve is empty. Marker #02"); - Disconnected(EErrorCode::InternalError); - return; - } - auto it = PendingReserve.begin(); - - auto cookieReserveValid = (it->first == cookie); - auto cookieWriteValid = (PendingWrite.empty() || PendingWrite.back() < cookie); - if (!(cookieReserveValid && cookieWriteValid)) { - ERROR("The cookie of Write is invalid. Cookie=" << cookie); - Disconnected(EErrorCode::InternalError); - return; - } - - Write(cookie, std::move(it->second.Request)); - - PendingReserve.erase(it); - } - void Write(ui64 cookie, NKikimrClient::TPersQueueRequest&& req) { auto ev = MakeHolder(); ev->Record = std::move(req); @@ -651,24 +630,26 @@ class TPartitionWriter: public TActorBootstrapped, private TRl return WriteResult(EErrorCode::InternalError, error, std::move(record)); } - WriteAccepted(cookie); - - if (PendingReserve.empty()) { - ERROR("The state of the PartitionWriter is invalid. PendingReserve is empty. Marker #03"); + auto cookieWriteValid = (PendingWrite.empty() || PendingWrite.back() < cookie); + if (!cookieWriteValid) { + ERROR("The cookie of Write is invalid. Cookie=" << cookie); Disconnected(EErrorCode::InternalError); return; } + + WriteAccepted(cookie); auto it = PendingReserve.begin(); auto& holder = it->second; - if ((holder.QuotaChecked && !holder.QuotaAccepted)|| !ReceivedReserve.empty()) { + if ((holder.QuotaCheckEnabled && !holder.QuotaAccepted) || !ReceivedReserve.empty()) { // There may be two situations: // - a quota has been requested, and the quota has not been received yet // - the quota was not requested, for example, due to a change in the metering option, but the previous quota requests have not yet been processed EnqueueReservedAndProcess(cookie); } else { - Write(cookie); + Write(cookie, std::move(it->second.Request)); } + PendingReserve.erase(it); } else { if (PendingWrite.empty()) { return WriteResult(EErrorCode::InternalError, "Unexpected Write response", std::move(record)); @@ -740,7 +721,7 @@ class TPartitionWriter: public TActorBootstrapped, private TRl ReceivedQuota.insert(ReceivedQuota.end(), PendingQuota.begin(), PendingQuota.end()); PendingQuota.clear(); - ProcessQuota(); + ProcessQuotaAndWrite(); break; @@ -829,12 +810,12 @@ class TPartitionWriter: public TActorBootstrapped, private TRl struct RequestHolder { NKikimrClient::TPersQueueRequest Request; - bool QuotaChecked; + bool QuotaCheckEnabled; bool QuotaAccepted; - RequestHolder(NKikimrClient::TPersQueueRequest&& request, bool quotaChecked) + RequestHolder(NKikimrClient::TPersQueueRequest&& request, bool quotaCheckEnabled) : Request(std::move(request)) - , QuotaChecked(quotaChecked) + , QuotaCheckEnabled(quotaCheckEnabled) , QuotaAccepted(false) { } }; diff --git a/ydb/core/protos/counters_pq.proto b/ydb/core/protos/counters_pq.proto index c381e0f1eb97..8c975d9a4b7b 100644 --- a/ydb/core/protos/counters_pq.proto +++ b/ydb/core/protos/counters_pq.proto @@ -237,4 +237,7 @@ enum EPartitionLabeledCounters { METRIC_READ_QUOTA_PARTITION_TOTAL_BYTES = 38 [(LabeledCounterOpts) = {Name: "" AggrFunc : EAF_MIN SVName: "topic.partition.read.speed_limit_bytes_per_second"}]; METRIC_READ_INFLIGHT_LIMIT_THROTTLED = 39 [(LabeledCounterOpts) = {Name: "" AggrFunc : EAF_MAX SVName: "topic.partition.read.inflight_throttled_microseconds_max"}]; + + METRIC_READ_QUOTA_NO_CONSUMER_BYTES = 40 [(LabeledCounterOpts) = {Name: "" AggrFunc : EAF_MIN SVName: "topic.partition.read_without_consumer.speed_limit_bytes_per_second"}]; + METRIC_READ_QUOTA_NO_CONSUMER_USAGE = 41 [(LabeledCounterOpts) = {Name: "" AggrFunc : EAF_MAX SVName: "topic.partition.read_without_consumer.throttled_microseconds_max"}]; } diff --git a/ydb/public/lib/ydb_cli/commands/topic_operations_scenario.cpp b/ydb/public/lib/ydb_cli/commands/topic_operations_scenario.cpp index 01860f43c19c..037e921ccf7a 100644 --- a/ydb/public/lib/ydb_cli/commands/topic_operations_scenario.cpp +++ b/ydb/public/lib/ydb_cli/commands/topic_operations_scenario.cpp @@ -206,6 +206,7 @@ void TTopicOperationsScenario::StartConsumerThreads(std::vector(params.Driver); std::optional txSupport; - auto consumerName = TCommandWorkloadTopicDescribe::GenerateConsumerName(params.ConsumerPrefix, params.ConsumerIdx); auto describeTopicResult = TCommandWorkloadTopicDescribe::DescribeTopic(params.Database, params.TopicName, params.Driver); - auto consumers = describeTopicResult.GetConsumers(); + NYdb::NTopic::TReadSessionSettings settings; + + if (!params.ReadWithoutConsumer) { + auto consumerName = TCommandWorkloadTopicDescribe::GenerateConsumerName(params.ConsumerPrefix, params.ConsumerIdx); + auto consumers = describeTopicResult.GetConsumers(); - if (!std::any_of(consumers.begin(), consumers.end(), [consumerName](const auto& consumer) { return consumer.GetConsumerName() == consumerName; })) - { - WRITE_LOG(params.Log, ELogPriority::TLOG_EMERG, TStringBuilder() << "Topic '" << params.TopicName << "' doesn't have a consumer '" << consumerName << "'. Run command 'workload init' with parameter '--consumers'."); - exit(EXIT_FAILURE); + if (!std::any_of(consumers.begin(), consumers.end(), [consumerName](const auto& consumer) { return consumer.GetConsumerName() == consumerName; })) + { + WRITE_LOG(params.Log, ELogPriority::TLOG_EMERG, TStringBuilder() << "Topic '" << params.TopicName << "' doesn't have a consumer '" << consumerName << "'. Run command 'workload init' with parameter '--consumers'."); + exit(EXIT_FAILURE); + } + settings.ConsumerName(consumerName).AppendTopics(params.TopicName); + } else { + NYdb::NTopic::TTopicReadSettings topic = params.TopicName; + auto partitions = describeTopicResult.GetPartitions(); + for(auto partition: partitions) { + topic.AppendPartitionIds(partition.GetPartitionId()); + } + settings.WithoutConsumer().AppendTopics(topic); } + if (params.UseTransactions) { txSupport.emplace(params.Driver, params.ReadOnlyTableName, params.TableName); } - NYdb::NTopic::TReadSessionSettings settings; - settings.ConsumerName(consumerName).AppendTopics(params.TopicName); - auto readSession = topicClient->CreateReadSession(settings); WRITE_LOG(params.Log, ELogPriority::TLOG_INFO, "Reader session was created."); @@ -93,7 +103,7 @@ void TTopicWorkloadReader::ReaderLoop(TTopicWorkloadReaderParams& params, TInsta << " createTime " << message.GetCreateTime() << " fullTimeMs " << fullTime); } - if (!txSupport || params.UseTopicCommit) { + if (!params.ReadWithoutConsumer && (!txSupport || params.UseTopicCommit)) { dataEvent->Commit(); } } else if (auto* createPartitionStreamEvent = std::get_if(&event)) { diff --git a/ydb/public/lib/ydb_cli/commands/topic_workload/topic_workload_reader.h b/ydb/public/lib/ydb_cli/commands/topic_workload/topic_workload_reader.h index 09ced96f1786..39b091856dab 100644 --- a/ydb/public/lib/ydb_cli/commands/topic_workload/topic_workload_reader.h +++ b/ydb/public/lib/ydb_cli/commands/topic_workload/topic_workload_reader.h @@ -30,6 +30,7 @@ namespace NYdb { bool UseTopicCommit = false; bool UseTableSelect = true; bool UseTableUpsert = true; + bool ReadWithoutConsumer = false; size_t CommitPeriod = 15; size_t CommitMessages = 1'000'000; }; diff --git a/ydb/public/lib/ydb_cli/commands/topic_workload/topic_workload_run_read.cpp b/ydb/public/lib/ydb_cli/commands/topic_workload/topic_workload_run_read.cpp index 555ca5eb488b..11ac51580b02 100644 --- a/ydb/public/lib/ydb_cli/commands/topic_workload/topic_workload_run_read.cpp +++ b/ydb/public/lib/ydb_cli/commands/topic_workload/topic_workload_run_read.cpp @@ -34,6 +34,9 @@ void TCommandWorkloadTopicRunRead::Config(TConfig& config) config.Opts->AddLongOption("topic", "Topic name.") .DefaultValue(TOPIC) .StoreResult(&Scenario.TopicName); + config.Opts->AddLongOption("no-consumer", "Read without consumer") + .Hidden() + .StoreTrue(&Scenario.ReadWithoutConsumer); // Specific params config.Opts->AddLongOption("consumer-prefix", "Use consumers with names '-0' ... '-' where n is set in the '--consumers' option.") diff --git a/ydb/services/persqueue_v1/persqueue_new_schemecache_ut.cpp b/ydb/services/persqueue_v1/persqueue_new_schemecache_ut.cpp index 5258dfd286b2..8e617380ae17 100644 --- a/ydb/services/persqueue_v1/persqueue_new_schemecache_ut.cpp +++ b/ydb/services/persqueue_v1/persqueue_new_schemecache_ut.cpp @@ -463,7 +463,7 @@ namespace NKikimr::NPersQueueTests { "topic.write.bytes", "topic.write.messages", "api.grpc.topic.stream_write.bytes", - "api.grpc.topic.stream_write.partition_throttled_milliseconds", + "topic.write.partition_throttled_milliseconds", "topic.write.message_size_bytes", "api.grpc.topic.stream_write.messages", "topic.write.lag_milliseconds", From 07bfc08be7784777d419fd87b913cfdf2b8f2147 Mon Sep 17 00:00:00 2001 From: Sergey Belyakov Date: Tue, 5 Mar 2024 13:34:59 +0300 Subject: [PATCH 051/117] Mute OperationLog.ConcurrentWrites (#2450) --- .github/config/muted_ya.txt | 1 + 1 file changed, 1 insertion(+) diff --git a/.github/config/muted_ya.txt b/.github/config/muted_ya.txt index 21bbd82cd10e..97770b38528e 100644 --- a/.github/config/muted_ya.txt +++ b/.github/config/muted_ya.txt @@ -13,6 +13,7 @@ ydb/core/client/ut TClientTest.PromoteFollower ydb/core/client/ut TClientTest.ReadFromFollower ydb/core/client/ut TFlatTest.AutoSplitMergeQueue ydb/core/cms/ut_sentinel TSentinelTests.BSControllerCantChangeStatus +ydb/core/debug_tools/ut OperationLog.ConcurrentWrites ydb/core/persqueue/ut [31/40]* ydb/core/persqueue/ut TopicSplitMerge.PartitionSplit ydb/core/persqueue/ut TPersQueueMirrorer.TestBasicRemote From c591cd04c6cadef8d4a563b4f0afab98cd44b907 Mon Sep 17 00:00:00 2001 From: FloatingCrowbar <103565628+FloatingCrowbar@users.noreply.github.com> Date: Tue, 5 Mar 2024 14:23:37 +0300 Subject: [PATCH 052/117] Add deduplication options checks (#2254) (#2416) --- ydb/core/persqueue/writer/writer.cpp | 25 ++++------ .../ydb_topic/impl/write_session_impl.h | 1 - .../client/ydb_topic/ut/basic_usage_ut.cpp | 26 ++++++++-- .../actors/write_session_actor.ipp | 24 +++++---- ydb/services/persqueue_v1/persqueue_ut.cpp | 49 +++++++++++++++++++ 5 files changed, 97 insertions(+), 28 deletions(-) diff --git a/ydb/core/persqueue/writer/writer.cpp b/ydb/core/persqueue/writer/writer.cpp index 8fec66d14a5f..bf12ab4cafb5 100644 --- a/ydb/core/persqueue/writer/writer.cpp +++ b/ydb/core/persqueue/writer/writer.cpp @@ -33,7 +33,7 @@ namespace NKikimr::NPQ { #define INFO(message) LOG_INFO_S(*NActors::TlsActivationContext, NKikimrServices::PQ_WRITE_PROXY, LOG_PREFIX << message); #define ERROR(message) LOG_ERROR_S(*NActors::TlsActivationContext, NKikimrServices::PQ_WRITE_PROXY, LOG_PREFIX << message); -static const ui64 WRITE_BLOCK_SIZE = 4_KB; +static const ui64 WRITE_BLOCK_SIZE = 4_KB; TString TEvPartitionWriter::TEvInitResult::TSuccess::ToString() const { auto out = TStringBuilder() << "Success {" @@ -106,7 +106,7 @@ class TPartitionWriter: public TActorBootstrapped, private TRl using EErrorCode = TEvPartitionWriter::TEvWriteResponse::EErrorCode; static constexpr size_t MAX_QUOTA_INFLIGHT = 3; - + static void FillHeader(NKikimrClient::TPersQueuePartitionRequest& request, ui32 partitionId, const TActorId& pipeClient) { @@ -272,12 +272,9 @@ class TPartitionWriter: public TActorBootstrapped, private TRl void GetOwnership() { auto ev = MakeRequest(PartitionId, PipeClient); - auto& cmd = *ev->Record.MutablePartitionRequest()->MutableCmdGetOwnership(); - if (Opts.UseDeduplication) { - cmd.SetOwner(SourceId); - } else { - cmd.SetOwner(CreateGuidAsString()); - } + auto& request = *ev->Record.MutablePartitionRequest(); + auto& cmd = *request.MutableCmdGetOwnership(); + cmd.SetOwner(SourceId); cmd.SetForce(true); NTabletPipe::SendData(SelfId(), PipeClient, ev.Release()); @@ -720,17 +717,15 @@ class TPartitionWriter: public TActorBootstrapped, private TRl case EWakeupTag::RlAllowed: ReceivedQuota.insert(ReceivedQuota.end(), PendingQuota.begin(), PendingQuota.end()); PendingQuota.clear(); - - ProcessQuotaAndWrite(); - + ProcessQuotaAndWrite(); break; case EWakeupTag::RlNoResource: - // Re-requesting the quota. We do this until we get a quota. + // Re-requesting the quota. We do this until we get a quota. // We do not request a quota with a long waiting time because the writer may already be a destroyer, and the quota will still be waiting to be received. RequestDataQuota(PendingQuotaAmount, ctx); break; - + default: Y_VERIFY_DEBUG_S(false, "Unsupported tag: " << static_cast(tag)); } @@ -751,7 +746,7 @@ class TPartitionWriter: public TActorBootstrapped, private TRl , TabletId(tabletId) , PartitionId(partitionId) , ExpectedGeneration(opts.ExpectedGeneration) - , SourceId(opts.SourceId) + , SourceId(opts.UseDeduplication ? opts.SourceId : CreateGuidAsString()) , Opts(opts) { if (Opts.MeteringMode) { @@ -837,7 +832,7 @@ class TPartitionWriter: public TActorBootstrapped, private TRl IActor* CreatePartitionWriter(const TActorId& client, // const NKikimrSchemeOp::TPersQueueGroupDescription& config, ui64 tabletId, - ui32 partitionId, + ui32 partitionId, const TPartitionWriterOpts& opts) { return new TPartitionWriter(client, tabletId, partitionId, opts); } diff --git a/ydb/public/sdk/cpp/client/ydb_topic/impl/write_session_impl.h b/ydb/public/sdk/cpp/client/ydb_topic/impl/write_session_impl.h index 8c527ac8437f..1b25030a8a4d 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/impl/write_session_impl.h +++ b/ydb/public/sdk/cpp/client/ydb_topic/impl/write_session_impl.h @@ -317,7 +317,6 @@ class TWriteSessionImpl : public TContinuationTokenIssuer, }; THandleResult OnErrorImpl(NYdb::TPlainStatus&& status); // true - should Start(), false - should Close(), empty - no action - public: TWriteSessionImpl(const TWriteSessionSettings& settings, std::shared_ptr client, diff --git a/ydb/public/sdk/cpp/client/ydb_topic/ut/basic_usage_ut.cpp b/ydb/public/sdk/cpp/client/ydb_topic/ut/basic_usage_ut.cpp index d0b53205782a..09a378760e4b 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/ut/basic_usage_ut.cpp +++ b/ydb/public/sdk/cpp/client/ydb_topic/ut/basic_usage_ut.cpp @@ -697,9 +697,29 @@ Y_UNIT_TEST_SUITE(BasicUsage) { UNIT_ASSERT_VALUES_EQUAL(stats->GetEndOffset(), count); } +} // Y_UNIT_TEST_SUITE(BasicUsage) +Y_UNIT_TEST_SUITE(TSettingsValidation) { + Y_UNIT_TEST(TWriteSessionProducerSettings) { + TTopicSdkTestSetup setup(TEST_CASE_NAME); + TTopicClient client = setup.MakeClient(); + { + auto writeSettings = TWriteSessionSettings() + .Path(TEST_TOPIC) + .ProducerId("something") + .DeduplicationEnabled(false); + try { + auto writeSession = client.CreateWriteSession(writeSettings); + auto event = writeSession->GetEvent(true); + UNIT_ASSERT(event.Defined()); + auto* closedEvent = std::get_if(&event.GetRef()); + UNIT_ASSERT(closedEvent); + } catch (NYdb::TContractViolation&) { + //pass + } + } + } +} // Y_UNIT_TEST_SUITE(TSettingsValidation) -} - -} +} // namespace diff --git a/ydb/services/persqueue_v1/actors/write_session_actor.ipp b/ydb/services/persqueue_v1/actors/write_session_actor.ipp index 972e76a179f5..b76ab8fb24a7 100644 --- a/ydb/services/persqueue_v1/actors/write_session_actor.ipp +++ b/ydb/services/persqueue_v1/actors/write_session_actor.ipp @@ -389,11 +389,12 @@ void TWriteSessionActor::Handle(typename TEvWriteInit::TPt // 1.2. non-empty partition_id (explicit partitioning) // 1.3. non-empty partition_with_generation (explicit partitioning && direct write to partition host) // 2. Empty producer id (no deduplication, partition is selected using round-robin). - bool isScenarioSupported = + bool isScenarioSupported = !InitRequest.producer_id().empty() && ( - InitRequest.has_message_group_id() && InitRequest.message_group_id() == InitRequest.producer_id() || + InitRequest.has_message_group_id() && InitRequest.message_group_id() == InitRequest.producer_id() || InitRequest.has_partition_id() || - InitRequest.has_partition_with_generation()) || + InitRequest.has_partition_with_generation()) + || InitRequest.producer_id().empty(); if (!isScenarioSupported) { @@ -424,7 +425,6 @@ void TWriteSessionActor::Handle(typename TEvWriteInit::TPt return InitRequest.has_message_group_id() ? InitRequest.message_group_id() : InitRequest.producer_id(); } }(); - LOG_INFO_S(ctx, NKikimrServices::PQ_WRITE_PROXY, "session request cookie: " << Cookie << " " << InitRequest.ShortDebugString() << " from " << PeerName); if (!UseDeduplication) { LOG_DEBUG_S(ctx, NKikimrServices::PQ_WRITE_PROXY, "session request cookie: " << Cookie << ". Disable deduplication for empty producer id"); @@ -467,8 +467,9 @@ template void TWriteSessionActor::InitAfterDiscovery(const TActorContext& ctx) { Y_UNUSED(ctx); - if (SourceId.empty()) { - Y_ABORT_UNLESS(!UseDeduplication); + if (SourceId.empty() && UseDeduplication) { + CloseSession("Internal server error: got empty SourceId with enabled deduplication", PersQueue::ErrorCode::ERROR, ctx); + return; } InitMeta = GetInitialDataChunk(InitRequest, FullConverter->GetClientsideName(), PeerName); // ToDo[migration] - check? @@ -835,9 +836,14 @@ void TWriteSessionActor::Handle(NPQ::TEvPartitionWriter::T OwnerCookie = result.GetResult().OwnerCookie; const auto& maxSeqNo = result.GetResult().SourceIdInfo.GetSeqNo(); - if (!UseDeduplication) { - Y_ABORT_UNLESS(maxSeqNo == 0); - } + + // ToDo: uncomment after fixing KIKIMR-21124 + // if (!UseDeduplication) { + // if (maxSeqNo != 0) { + // return CloseSession("Internal server error: have maxSeqNo != with deduplication disabled", + // PersQueue::ErrorCode::ERROR, ctx); + // } + // } OwnerCookie = result.GetResult().OwnerCookie; MakeAndSentInitResponse(maxSeqNo, ctx); diff --git a/ydb/services/persqueue_v1/persqueue_ut.cpp b/ydb/services/persqueue_v1/persqueue_ut.cpp index 73b29d3bdd11..c0cc198921cd 100644 --- a/ydb/services/persqueue_v1/persqueue_ut.cpp +++ b/ydb/services/persqueue_v1/persqueue_ut.cpp @@ -6694,6 +6694,55 @@ Y_UNIT_TEST_SUITE(TPersQueueTest) { } } + Y_UNIT_TEST(DisableWrongSettings) { + NPersQueue::TTestServer server; + server.EnableLogs({NKikimrServices::PQ_READ_PROXY, NKikimrServices::BLACKBOX_VALIDATOR }); + server.EnableLogs({NKikimrServices::PERSQUEUE}, NActors::NLog::EPriority::PRI_INFO); + TString topicFullName = "rt3.dc1--acc--topic1"; + auto driver = SetupTestAndGetDriver(server, topicFullName, 3); + + std::shared_ptr Channel_; + std::unique_ptr TopicStubP_; + { + Channel_ = grpc::CreateChannel("localhost:" + ToString(server.GrpcPort), grpc::InsecureChannelCredentials()); + TopicStubP_ = Ydb::Topic::V1::TopicService::NewStub(Channel_); + } + + { + grpc::ClientContext rcontext1; + auto writeStream1 = TopicStubP_->StreamWrite(&rcontext1); + UNIT_ASSERT(writeStream1); + Ydb::Topic::StreamWriteMessage::FromClient req; + Ydb::Topic::StreamWriteMessage::FromServer resp; + + req.mutable_init_request()->set_path("acc/topic1"); + req.mutable_init_request()->set_message_group_id("some-group"); + if (!writeStream1->Write(req)) { + ythrow yexception() << "write fail"; + } + UNIT_ASSERT(writeStream1->Read(&resp)); + Cerr << "===Got response: " << resp.ShortDebugString() << Endl; + UNIT_ASSERT(resp.status() == Ydb::StatusIds::SUCCESS); + } + { + grpc::ClientContext rcontext1; + auto writeStream1 = TopicStubP_->StreamWrite(&rcontext1); + UNIT_ASSERT(writeStream1); + Ydb::Topic::StreamWriteMessage::FromClient req; + Ydb::Topic::StreamWriteMessage::FromServer resp; + + req.mutable_init_request()->set_path("acc/topic1"); + req.mutable_init_request()->set_message_group_id("some-group"); + req.mutable_init_request()->set_producer_id("producer"); + if (!writeStream1->Write(req)) { + ythrow yexception() << "write fail"; + } + UNIT_ASSERT(writeStream1->Read(&resp)); + Cerr << "===Got response: " << resp.ShortDebugString() << Endl; + UNIT_ASSERT(resp.status() == Ydb::StatusIds::BAD_REQUEST); + } + } + Y_UNIT_TEST(DisableDeduplication) { NPersQueue::TTestServer server; TString topicFullName = "rt3.dc1--topic1"; From fad6d73c1503e0df7a4750e2c33dd65baaa5f739 Mon Sep 17 00:00:00 2001 From: EvgeniyKozev <127485837+EvgeniyKozev@users.noreply.github.com> Date: Tue, 5 Mar 2024 16:45:47 +0300 Subject: [PATCH 053/117] NBS-4415: changed log level for ReasonPill (#2271) --- ydb/core/tablet/tablet_sys.cpp | 8 ++++++-- 1 file changed, 6 insertions(+), 2 deletions(-) diff --git a/ydb/core/tablet/tablet_sys.cpp b/ydb/core/tablet/tablet_sys.cpp index a2c0dbd2ee19..dfb540001395 100644 --- a/ydb/core/tablet/tablet_sys.cpp +++ b/ydb/core/tablet/tablet_sys.cpp @@ -15,10 +15,11 @@ #include #include -#if defined BLOG_D || defined BLOG_I || defined BLOG_ERROR +#if defined BLOG_D || defined BLOG_I || defined BLOG_ERROR || defined BLOG_LEVEL #error log macro definition clash #endif +#define BLOG_LEVEL(level, stream, marker) LOG_LOG_S(*TlsActivationContext, level, NKikimrServices::TABLET_MAIN, "Tablet: " << TabletID() << " " << stream << " Marker# " << marker) #define BLOG_D(stream, marker) LOG_DEBUG_S(*TlsActivationContext, NKikimrServices::TABLET_MAIN, "Tablet: " << TabletID() << " " << stream << " Marker# " << marker) #define BLOG_I(stream, marker) LOG_INFO_S(*TlsActivationContext, NKikimrServices::TABLET_MAIN, "Tablet: " << TabletID() << " " << stream << " Marker# " << marker) #define BLOG_ERROR(stream, marker) LOG_ERROR_S(*TlsActivationContext, NKikimrServices::TABLET_MAIN, "Tablet: " << TabletID() << " " << stream << " Marker# " << marker) @@ -1745,7 +1746,10 @@ void TTablet::ReassignYellowChannels(TVector &&yellowMoveChannels) { } void TTablet::CancelTablet(TEvTablet::TEvTabletDead::EReason reason, const TString &details) { - BLOG_ERROR( + BLOG_LEVEL( + reason == TEvTablet::TEvTabletDead::ReasonPill + ? NActors::NLog::PRI_NOTICE + : NActors::NLog::PRI_ERROR, " Type: " << TTabletTypes::TypeToStr((TTabletTypes::EType)Info->TabletType) << ", EReason: " << TEvTablet::TEvTabletDead::Str(reason) << ", SuggestedGeneration: " << SuggestedGeneration From c735d224749973ef2bbffed4c90e3a84c1897048 Mon Sep 17 00:00:00 2001 From: ildar-khisambeev Date: Tue, 5 Mar 2024 18:05:26 +0300 Subject: [PATCH 054/117] Cherry pick commit offsets fix (#2451) --- .../sdk/cpp/client/ydb_persqueue_core/impl/read_session.ipp | 2 +- .../sdk/cpp/client/ydb_persqueue_core/ut/read_session_ut.cpp | 4 ++-- 2 files changed, 3 insertions(+), 3 deletions(-) diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session.ipp b/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session.ipp index a7eda27d9fd7..d04d5fd843ed 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session.ipp +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session.ipp @@ -77,7 +77,7 @@ void TPartitionStreamImpl::Commit(ui64 startOffset, ui64 e Commits.EraseInterval(0, endOffset); // Drop only committed ranges; } for (auto range: toCommit) { - sessionShared->Commit(this, range.first, range.second); + sessionShared->Commit(this, range.first, Min(range.second, endOffset)); } } } diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/read_session_ut.cpp b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/read_session_ut.cpp index 627d7c0f257d..03c386b16421 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/read_session_ut.cpp +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/ut/read_session_ut.cpp @@ -1579,8 +1579,8 @@ Y_UNIT_TEST_SUITE(ReadSessionImplTest) { } for (const auto& range : req.offset_ranges()) { Cerr << "RANGE " << range.start_offset() << " " << range.end_offset() << "\n"; - if (range.start_offset() == 10 && range.end_offset() == 12) has1 = true; - else if (range.start_offset() == 0 && range.end_offset() == 10) has2 = true; + if (range.start_offset() == 3 && range.end_offset() == 12) has1 = true; + else if (range.start_offset() == 0 && range.end_offset() == 3) has2 = true; else UNIT_ASSERT(false); } })); From a6072853bfe45a4e7e31458cdcab0676f43b99f8 Mon Sep 17 00:00:00 2001 From: ijon Date: Tue, 5 Mar 2024 18:34:47 +0300 Subject: [PATCH 055/117] schemeboard: pass describe-result as an opaque payload (#2391) Cherry-pick 3819aed from main (#2083). Make schemeboard replicas consume less CPU, especially when processing rapid updates for tables with huge amount of partitions. Schema information on a path exist in the form of `DescribeSchemeResult` object: schemeshard generates those objects and publishes them to the schemeboard, schemeboard notifies scheme-caches on the nodes about path info changes. So schemeshard generates `DescribeSchemeResult`, scheme-cache serves `DescribeSchemeResult` to the consumers. But schemeboard components in-between do not require the full content of a TEvDescribeSchemeResult to operate efficiently. This update enables the schemeboard to transmit `DescribeSchemeResult` through as an opaque payload rather than as a fully detailed protobuf object. Thus reducing the unnecessary memory management and serialization/deserialization overhead. --- ydb/core/protos/flat_tx_scheme.proto | 3 +- ydb/core/protos/scheme_board.proto | 82 +++++- .../datashard_ut_change_exchange.cpp | 43 +-- ydb/core/tx/scheme_board/cache_ut.cpp | 5 + ydb/core/tx/scheme_board/events.cpp | 152 ++++++++++ ydb/core/tx/scheme_board/events.h | 126 +++----- ydb/core/tx/scheme_board/helpers.cpp | 99 +++++-- ydb/core/tx/scheme_board/helpers.h | 21 +- ydb/core/tx/scheme_board/load_test.cpp | 14 +- .../scheme_board/opaque_path_description.cpp | 41 +++ .../tx/scheme_board/opaque_path_description.h | 46 +++ ydb/core/tx/scheme_board/populator.cpp | 96 +++---- ydb/core/tx/scheme_board/populator.h | 2 +- ydb/core/tx/scheme_board/replica.cpp | 268 +++++++++--------- ydb/core/tx/scheme_board/replica_ut.cpp | 49 ++-- ydb/core/tx/scheme_board/subscriber.cpp | 100 +++++-- ydb/core/tx/scheme_board/subscriber_ut.cpp | 2 +- ydb/core/tx/scheme_board/ut_helpers.cpp | 5 +- ydb/core/tx/scheme_board/ya.make | 2 + ydb/core/tx/schemeshard/schemeshard.h | 7 +- .../schemeshard__init_populator.cpp | 4 +- .../schemeshard_path_describer.cpp | 8 +- ydb/core/tx/tx_proxy/describe.cpp | 6 +- ydb/core/viewer/json_describe.h | 2 - ydb/core/viewer/protos/viewer.proto | 2 +- 25 files changed, 786 insertions(+), 399 deletions(-) create mode 100644 ydb/core/tx/scheme_board/events.cpp create mode 100644 ydb/core/tx/scheme_board/opaque_path_description.cpp create mode 100644 ydb/core/tx/scheme_board/opaque_path_description.h diff --git a/ydb/core/protos/flat_tx_scheme.proto b/ydb/core/protos/flat_tx_scheme.proto index 0ee8122cd057..694ee37abd00 100644 --- a/ydb/core/protos/flat_tx_scheme.proto +++ b/ydb/core/protos/flat_tx_scheme.proto @@ -106,12 +106,13 @@ message TEvDescribeSchemeResult { optional string Reason = 2; optional string Path = 3; optional NKikimrSchemeOp.TPathDescription PathDescription = 4; - optional fixed64 PathOwner = 5; + optional fixed64 DEPRECATED_PathOwner = 5; // replaced by PathOwnerId optional fixed64 PathId = 6; optional string LastExistedPrefixPath = 7; optional fixed64 LastExistedPrefixPathId = 8; optional NKikimrSchemeOp.TPathDescription LastExistedPrefixDescription = 9; + optional fixed64 PathOwnerId = 10; } diff --git a/ydb/core/protos/scheme_board.proto b/ydb/core/protos/scheme_board.proto index f063144f5d03..a663fb8e5a59 100644 --- a/ydb/core/protos/scheme_board.proto +++ b/ydb/core/protos/scheme_board.proto @@ -1,4 +1,4 @@ -import "ydb/core/protos/flat_tx_scheme.proto"; +import "ydb/core/scheme/protos/pathid.proto"; package NKikimrSchemeBoard; option java_package = "ru.yandex.kikimr.proto"; @@ -13,22 +13,76 @@ message TEvHandshake { optional uint64 Generation = 2; } -// here and below -// Owner is the tablet id of schemeshard witch holds the records -// LocalPathId is a second part of TPathId -// PathOwnerId is a first part of TPathId +// Here and below. +// Owner is the tablet id of schemeshard which holds the records. +// (PathOwnerId, LocalPathId) constitute TPathId of the object. +// TEvUpdate.DescribeSchemeResultSerialized is a NKikimrScheme.TEvDescribeSchemeResult +// in the form of opaque payload. +// Originally, that field existed as a properly typed TEvDescribeSchemeResult message. +// However, that induce additional overhead to serialize and deserialize this message +// when transferring over wire. +// This performance cost is usually either negligible or imperceptible. +// But in specific situations, particularly when rapidly updating partitioning information +// for tables with huge number of shards, this overhead could lead to significant issues. +// Schemeboard replicas could get overloaded and become unresponsive to further requests. +// This is problematic, especially considering the schemeboard subsystem's critical role +// in servicing all databases within a cluster, making it a Single Point of Failure (SPOF). +// +// The core realization is that the schemeboard components do not require the full content of +// a TEvDescribeSchemeResult message to operate efficiently. Instead, only a limited set of +// fields (path, path-id, version and info about subdomain/database) is required for processing. +// And a whole TEvDescribeSchemeResult could be passed through as an opaque payload. +// +// Type change from TEvDescribeSchemeResult to (repeated) bytes without changing field number +// is a safe move. Actual value of the field remains unchanged at the wire-format level. +// Thus, older implementations will interpret the payload as a TEvDescribeSchemeResult message +// and proceed with deserialization as usual. And newer implementations will recognize the data +// as a binary blob and will deserialize it explicitly only when necessary. +// +// Note that the `repeated` label for the `DescribeSchemeResultSerialized` field is essential +// to remain backward-compatible with the previous implementation. This is because even if +// DescribeSchemeResult previously was labeled `optional` but actual value used at +// the wire-format level was (and is) a pack of TEvDescribeSchemeResult messages. +// Automerge of consecutive messages for the same field is a prominent feature of the protobuf. +// Schemeshard use that feature to supply full TEvDescribeSchemeResult as a sequence of +// partially filled TEvDescribeSchemeResult's. +// +// - Path +// - PathOwnerId, LocalPathId +// - PathDirEntryPathVersion +// - PathSubdomainPathId +// - PathAbandonedTenantsSchemeShards +// are taken from the original TEvDescribeSchemeResult (one way or another). +// message TEvUpdate { optional uint64 Owner = 1; optional uint64 Generation = 2; optional TLocalPathIdRange DeletedLocalPathIds = 3; - optional string Path = 4; - optional uint64 LocalPathId = 5; + + optional string Path = 4; // extracted from DescribeSchemeResult.Path + optional uint64 LocalPathId = 5; // extracted from DescribeSchemeResult.PathId + optional bool IsDeletion = 6 [default = false]; - optional NKikimrScheme.TEvDescribeSchemeResult DescribeSchemeResult = 7; + + repeated bytes DescribeSchemeResultSerialized = 7; + optional bool NeedAck = 8 [default = false]; - optional uint64 PathOwnerId = 9; + + optional uint64 PathOwnerId = 9; // extracted from DescribeSchemeResult.PathOwnerId, DescribeSchemeResult.PathDescription.Self.SchemeshardId in order of presence + optional TLocalPathIdRange MigratedLocalPathIds = 10; + + // Explicit values extracted from DescribeSchemeResultSerialized + + // DescribeSchemeResult.PathDescription.Self.PathVersion + optional uint64 PathDirEntryPathVersion = 11; + + // DescribeSchemeResult.PathDescription.DomainDescription.DomainKey + optional NKikimrProto.TPathID PathSubdomainPathId = 13; + + // DescribeSchemeResult.PathDescription.AbandonedTenantsSchemeShards + repeated uint64 PathAbandonedTenantsSchemeShards = 14; } message TEvUpdateAck { @@ -65,6 +119,7 @@ message TEvUnsubscribe { optional uint64 LocalPathId = 3; } + // See comments for TEvUpdate. message TEvNotify { optional string Path = 1; // and/or @@ -72,9 +127,14 @@ message TEvNotify { optional uint64 LocalPathId = 3; // common fields optional bool IsDeletion = 4 [default = false]; - optional NKikimrScheme.TEvDescribeSchemeResult DescribeSchemeResult = 5; - optional uint64 Version = 6; + + optional bytes DescribeSchemeResultSerialized = 5; + + optional uint64 Version = 6; // same as TEvUpdate.PathDirEntryPathVersion optional bool Strong = 7 [default = false]; + + optional NKikimrProto.TPathID PathSubdomainPathId = 8; + repeated uint64 PathAbandonedTenantsSchemeShards = 9; } message TEvNotifyAck { diff --git a/ydb/core/tx/datashard/datashard_ut_change_exchange.cpp b/ydb/core/tx/datashard/datashard_ut_change_exchange.cpp index 601a8c579ec3..9ec786dada11 100644 --- a/ydb/core/tx/datashard/datashard_ut_change_exchange.cpp +++ b/ydb/core/tx/datashard/datashard_ut_change_exchange.cpp @@ -789,7 +789,7 @@ Y_UNIT_TEST_SUITE(Cdc) { static THolder MakeClient(const NYdb::TDriver& driver, const TString& database) { return MakeHolder(driver, NYdb::TCommonClientSettings().Database(database)); } - }; + }; class TTestTopicEnv: public TTestEnv { public: @@ -798,7 +798,7 @@ Y_UNIT_TEST_SUITE(Cdc) { static THolder MakeClient(const NYdb::TDriver& driver, const TString& database) { return MakeHolder(driver, NYdb::NTopic::TTopicClientSettings().Database(database)); } - }; + }; TShardedTableOptions SimpleTable() { return TShardedTableOptions() @@ -1344,7 +1344,7 @@ Y_UNIT_TEST_SUITE(Cdc) { (3, 30); )", R"( DELETE FROM `/Root/Table` WHERE key = 1; - )"}, { + )"}, { R"({"update":{},"key":[1]})", R"({"update":{},"key":[2]})", R"({"update":{},"key":[3]})", @@ -1360,7 +1360,7 @@ Y_UNIT_TEST_SUITE(Cdc) { (3, 30); )", R"( DELETE FROM `/Root/Table` WHERE key = 1; - )"}, { + )"}, { {DebeziumBody("u", nullptr, nullptr), {{"__key", R"({"payload":{"key":1}})"}}}, {DebeziumBody("u", nullptr, nullptr), {{"__key", R"({"payload":{"key":2}})"}}}, {DebeziumBody("u", nullptr, nullptr), {{"__key", R"({"payload":{"key":3}})"}}}, @@ -1376,7 +1376,7 @@ Y_UNIT_TEST_SUITE(Cdc) { (3, 30); )", R"( DELETE FROM `/Root/Table` WHERE key = 1; - )"}, { + )"}, { R"({"update":{"value":10},"key":[1]})", R"({"update":{"value":20},"key":[2]})", R"({"update":{"value":30},"key":[3]})", @@ -1397,7 +1397,7 @@ Y_UNIT_TEST_SUITE(Cdc) { (3, 300); )", R"( DELETE FROM `/Root/Table` WHERE key = 1; - )"}, { + )"}, { R"({"update":{},"newImage":{"value":10},"key":[1]})", R"({"update":{},"newImage":{"value":20},"key":[2]})", R"({"update":{},"newImage":{"value":30},"key":[3]})", @@ -1421,7 +1421,7 @@ Y_UNIT_TEST_SUITE(Cdc) { (3, 300); )", R"( DELETE FROM `/Root/Table` WHERE key = 1; - )"}, { + )"}, { {DebeziumBody("c", nullptr, R"({"key":1,"value":10})"), {{"__key", R"({"payload":{"key":1}})"}}}, {DebeziumBody("c", nullptr, R"({"key":2,"value":20})"), {{"__key", R"({"payload":{"key":2}})"}}}, {DebeziumBody("c", nullptr, R"({"key":3,"value":30})"), {{"__key", R"({"payload":{"key":3}})"}}}, @@ -1445,7 +1445,7 @@ Y_UNIT_TEST_SUITE(Cdc) { (3, 300); )", R"( DELETE FROM `/Root/Table` WHERE key = 1; - )"}, { + )"}, { {DebeziumBody("u", nullptr, nullptr), {{"__key", R"({"payload":{"key":1}})"}}}, {DebeziumBody("u", nullptr, nullptr), {{"__key", R"({"payload":{"key":2}})"}}}, {DebeziumBody("u", nullptr, nullptr), {{"__key", R"({"payload":{"key":3}})"}}}, @@ -1456,7 +1456,7 @@ Y_UNIT_TEST_SUITE(Cdc) { }); } - Y_UNIT_TEST(NewImageLogDebezium) { + Y_UNIT_TEST(NewImageLogDebezium) { TopicRunner::Read(SimpleTable(), NewImage(NKikimrSchemeOp::ECdcStreamFormatDebeziumJson), {R"( UPSERT INTO `/Root/Table` (key, value) VALUES (1, 10), @@ -1469,7 +1469,7 @@ Y_UNIT_TEST_SUITE(Cdc) { (3, 300); )", R"( DELETE FROM `/Root/Table` WHERE key = 1; - )"}, { + )"}, { {DebeziumBody("u", nullptr, R"({"key":1,"value":10})"), {{"__key", R"({"payload":{"key":1}})"}}}, {DebeziumBody("u", nullptr, R"({"key":2,"value":20})"), {{"__key", R"({"payload":{"key":2}})"}}}, {DebeziumBody("u", nullptr, R"({"key":3,"value":30})"), {{"__key", R"({"payload":{"key":3}})"}}}, @@ -1486,7 +1486,7 @@ Y_UNIT_TEST_SUITE(Cdc) { (1, 10), (2, 20), (3, 30); - )"}, { + )"}, { R"({"update":{},"key":[1],"ts":"***"})", R"({"update":{},"key":[2],"ts":"***"})", R"({"update":{},"key":[3],"ts":"***"})", @@ -1512,7 +1512,7 @@ Y_UNIT_TEST_SUITE(Cdc) { UPSERT INTO `/Root/Table` (__Hash, id_shard, id_sort, __RowData) VALUES ( 1, "10", "100", JsonDocument('{"M":{"color":{"S":"pink"},"weight":{"N":"4.5"}}}') ); - )"}, { + )"}, { WriteJson(NJson::TJsonMap({ {"awsRegion", ""}, {"dynamodb", NJson::TJsonMap({ @@ -1541,7 +1541,7 @@ Y_UNIT_TEST_SUITE(Cdc) { ); )", R"( DELETE FROM `/Root/Table` WHERE __Hash = 1; - )"}, { + )"}, { WriteJson(NJson::TJsonMap({ {"awsRegion", ""}, {"dynamodb", NJson::TJsonMap({ @@ -1639,7 +1639,7 @@ Y_UNIT_TEST_SUITE(Cdc) { (1, 0.0%s/0.0%s), (2, 1.0%s/0.0%s), (3, -1.0%s/0.0%s); - )", s, s, s, s, s, s)}, { + )", s, s, s, s, s, s)}, { R"({"update":{"value":"nan"},"key":[1]})", R"({"update":{"value":"inf"},"key":[2]})", R"({"update":{"value":"-inf"},"key":[3]})", @@ -1674,7 +1674,7 @@ Y_UNIT_TEST_SUITE(Cdc) { TopicRunner::Read(table, KeysOnly(NKikimrSchemeOp::ECdcStreamFormatDebeziumJson), {Sprintf(R"( UPSERT INTO `/Root/Table` (key, value) VALUES ("%s", 1); - )", key.c_str())}, { + )", key.c_str())}, { {DebeziumBody("u", nullptr, nullptr), {{"__key", Sprintf(R"({"payload":{"key":"%s"}})", key.c_str())}}}, }); } @@ -2043,7 +2043,7 @@ Y_UNIT_TEST_SUITE(Cdc) { ExecSQL(env.GetServer(), env.GetEdgeActor(), R"( UPSERT INTO `/Root/TableAux` (key, value) VALUES (1, 10); - )"); + )"); SetSplitMergePartCountLimit(&runtime, -1); const auto tabletIds = GetTableShards(env.GetServer(), env.GetEdgeActor(), "/Root/Table"); @@ -2292,7 +2292,7 @@ Y_UNIT_TEST_SUITE(Cdc) { auto tabletIds = GetTableShards(env.GetServer(), env.GetEdgeActor(), "/Root/Table"); UNIT_ASSERT_VALUES_EQUAL(tabletIds.size(), 1); - WaitTxNotification(env.GetServer(), env.GetEdgeActor(), + WaitTxNotification(env.GetServer(), env.GetEdgeActor(), AsyncSplitTable(env.GetServer(), env.GetEdgeActor(), "/Root/Table", tabletIds.at(0), 4)); // execute on old partitions @@ -2376,7 +2376,8 @@ Y_UNIT_TEST_SUITE(Cdc) { case TSchemeBoardEvents::EvUpdate: if (auto* msg = ev->Get()) { - const auto desc = msg->GetRecord().GetDescribeSchemeResult(); + NKikimrScheme::TEvDescribeSchemeResult desc; + Y_ABORT_UNLESS(ParseFromStringNoSizeLimit(desc, *msg->GetRecord().GetDescribeSchemeResultSerialized().begin())); if (desc.GetPath() == "/Root/Table/Stream" && desc.GetPathDescription().GetSelf().GetCreateFinished()) { delayed.emplace_back(ev.Release()); return TTestActorRuntime::EEventAction::DROP; @@ -2446,7 +2447,7 @@ Y_UNIT_TEST_SUITE(Cdc) { ExecSQL(env.GetServer(), env.GetEdgeActor(), R"( UPSERT INTO `/Root/Table` (key, value) VALUES (1, 10); - )"); + )"); SetSplitMergePartCountLimit(&runtime, -1); const auto tabletIds = GetTableShards(env.GetServer(), env.GetEdgeActor(), "/Root/Table"); @@ -3266,7 +3267,7 @@ Y_UNIT_TEST_SUITE(Cdc) { auto tabletIds = GetTableShards(env.GetServer(), env.GetEdgeActor(), "/Root/Table"); UNIT_ASSERT_VALUES_EQUAL(tabletIds.size(), 1); - WaitTxNotification(env.GetServer(), env.GetEdgeActor(), + WaitTxNotification(env.GetServer(), env.GetEdgeActor(), AsyncSplitTable(env.GetServer(), env.GetEdgeActor(), "/Root/Table", tabletIds.at(0), 4)); // merge @@ -3298,7 +3299,7 @@ template <> void Out>(IOutputStream& output, const std::pair& x) { output << x.first << ":" << x.second; } - + void AppendToString(TString& dst, const std::pair& x) { TStringOutput output(dst); output << x; diff --git a/ydb/core/tx/scheme_board/cache_ut.cpp b/ydb/core/tx/scheme_board/cache_ut.cpp index 745fdf839b2a..7fc37dffbcb9 100644 --- a/ydb/core/tx/scheme_board/cache_ut.cpp +++ b/ydb/core/tx/scheme_board/cache_ut.cpp @@ -37,6 +37,11 @@ class TCacheTest: public TTestWithSchemeshard { " Kind: \"pool-kind-1\" " "} " " Name: \"Root\" "); + + // Context->SetLogPriority(NKikimrServices::SCHEME_BOARD_REPLICA, NLog::PRI_DEBUG); + // Context->SetLogPriority(NKikimrServices::SCHEME_BOARD_SUBSCRIBER, NLog::PRI_DEBUG); + // Context->SetLogPriority(NKikimrServices::TX_PROXY_SCHEME_CACHE, NLog::PRI_DEBUG); + // Context->SetLogPriority(NKikimrServices::FLAT_TX_SCHEMESHARD, NLog::PRI_DEBUG); } UNIT_TEST_SUITE(TCacheTest); diff --git a/ydb/core/tx/scheme_board/events.cpp b/ydb/core/tx/scheme_board/events.cpp new file mode 100644 index 000000000000..ba721e3790b6 --- /dev/null +++ b/ydb/core/tx/scheme_board/events.cpp @@ -0,0 +1,152 @@ +#include + +#include "helpers.h" +#include "opaque_path_description.h" +#include "events.h" + + +namespace NKikimr { + +using namespace NSchemeBoard; + +namespace { + +//NOTE: MakeOpaquePathDescription moves out DescribeSchemeResultSerialized from TEvUpdate message. +// It cannot be used twice on the same message. +// +// This code would be much simpler without backward compatibility support. +// Consider removing compatibility support at version stable-25-1. +TOpaquePathDescription MakeOpaquePathDescription(NKikimrSchemeBoard::TEvUpdate& update) { + // PathSubdomainPathId's absence is a marker that input message was sent + // from the older populator implementation + + // Move out elements out of the repeated field. + // Mark field as empty to prevent subsequent extraction attempts + TString data; + auto* field = update.MutableDescribeSchemeResultSerialized(); + if (field->size() == 1) { + data = std::move(*field->begin()); + } else { + data = JoinRange("", field->begin(), field->end()); + } + field->Clear(); + + if (update.HasPathSubdomainPathId()) { + return TOpaquePathDescription{ + .DescribeSchemeResultSerialized = std::move(data), + //NOTE: unsuccessful describe results cannot be here, by design + .Status = NKikimrScheme::StatusSuccess, + .PathId = TPathId(update.GetPathOwnerId(), update.GetLocalPathId()), + .Path = update.GetPath(), + .PathVersion = update.GetPathDirEntryPathVersion(), + .SubdomainPathId = PathIdFromPathId(update.GetPathSubdomainPathId()), + .PathAbandonedTenantsSchemeShards = TSet( + update.GetPathAbandonedTenantsSchemeShards().begin(), + update.GetPathAbandonedTenantsSchemeShards().end() + ) + }; + + } else { + google::protobuf::Arena arena; + const auto* proto = DeserializeDescribeSchemeResult(data, &arena); + + return TOpaquePathDescription{ + .DescribeSchemeResultSerialized = std::move(data), + //NOTE: unsuccessful describe results cannot be here, by design + .Status = NKikimrScheme::StatusSuccess, + .PathId = NSchemeBoard::GetPathId(*proto), + .Path = proto->GetPath(), + .PathVersion = NSchemeBoard::GetPathVersion(*proto), + .SubdomainPathId = NSchemeBoard::GetDomainId(*proto), + .PathAbandonedTenantsSchemeShards = NSchemeBoard::GetAbandonedSchemeShardIds(*proto) + }; + } +} + +} // anonymous namespace + +// TSchemeBoardEvents::TEvUpdate +// + +TOpaquePathDescription TSchemeBoardEvents::TEvUpdate::ExtractPathDescription() { + return MakeOpaquePathDescription(Record); +} + +// TSchemeBoardEvents::TEvUpdateBuilder +// + +TSchemeBoardEvents::TEvUpdateBuilder::TEvUpdateBuilder(const ui64 owner, const ui64 generation) { + Record.SetOwner(owner); + Record.SetGeneration(generation); +} + +TSchemeBoardEvents::TEvUpdateBuilder::TEvUpdateBuilder(const ui64 owner, const ui64 generation, const TPathId& pathId) { + Record.SetOwner(owner); + Record.SetGeneration(generation); + Record.SetPathOwnerId(pathId.OwnerId); + Record.SetLocalPathId(pathId.LocalPathId); + Record.SetIsDeletion(true); +} + +TSchemeBoardEvents::TEvUpdateBuilder::TEvUpdateBuilder( + const ui64 owner, + const ui64 generation, + const TOpaquePathDescription& pathDescription, + const bool isDeletion +) { + Record.SetOwner(owner); + Record.SetGeneration(generation); + Record.SetIsDeletion(isDeletion); + + Record.SetPath(pathDescription.Path); + Record.SetPathOwnerId(pathDescription.PathId.OwnerId); + Record.SetLocalPathId(pathDescription.PathId.LocalPathId); + + Record.SetPathDirEntryPathVersion(pathDescription.PathVersion); + PathIdFromPathId(pathDescription.SubdomainPathId, Record.MutablePathSubdomainPathId()); + + Record.MutablePathAbandonedTenantsSchemeShards()->Assign( + pathDescription.PathAbandonedTenantsSchemeShards.begin(), + pathDescription.PathAbandonedTenantsSchemeShards.end() + ); +} + +void TSchemeBoardEvents::TEvUpdateBuilder::SetDescribeSchemeResultSerialized(const TString& serialized) { + Record.AddDescribeSchemeResultSerialized(serialized); +} + +void TSchemeBoardEvents::TEvUpdateBuilder::SetDescribeSchemeResultSerialized(TString&& serialized) { + Record.AddDescribeSchemeResultSerialized(std::move(serialized)); +} + +// TSchemeBoardEvents::TEvNotifyBuilder +// + +TSchemeBoardEvents::TEvNotifyBuilder::TEvNotifyBuilder(const TString& path, const bool isDeletion /*= false*/) { + Record.SetPath(path); + Record.SetIsDeletion(isDeletion); +} + +TSchemeBoardEvents::TEvNotifyBuilder::TEvNotifyBuilder(const TPathId& pathId, const bool isDeletion /*= false*/) { + Record.SetPathOwnerId(pathId.OwnerId); + Record.SetLocalPathId(pathId.LocalPathId); + Record.SetIsDeletion(isDeletion); +} + +TSchemeBoardEvents::TEvNotifyBuilder::TEvNotifyBuilder(const TString& path, const TPathId& pathId, const bool isDeletion /*= false*/) { + Record.SetPath(path); + Record.SetPathOwnerId(pathId.OwnerId); + Record.SetLocalPathId(pathId.LocalPathId); + Record.SetIsDeletion(isDeletion); +} + +void TSchemeBoardEvents::TEvNotifyBuilder::SetPathDescription(const TOpaquePathDescription& pathDescription) { + Record.SetDescribeSchemeResultSerialized(pathDescription.DescribeSchemeResultSerialized); + PathIdFromPathId(pathDescription.SubdomainPathId, Record.MutablePathSubdomainPathId()); + Record.MutablePathAbandonedTenantsSchemeShards()->Assign( + pathDescription.PathAbandonedTenantsSchemeShards.begin(), + pathDescription.PathAbandonedTenantsSchemeShards.end() + ); +} + +} // NKikimr diff --git a/ydb/core/tx/scheme_board/events.h b/ydb/core/tx/scheme_board/events.h index 8e686e8b92d3..0c00d939b0da 100644 --- a/ydb/core/tx/scheme_board/events.h +++ b/ydb/core/tx/scheme_board/events.h @@ -2,7 +2,7 @@ #include "defs.h" #include "helpers.h" -#include "two_part_description.h" +#include "opaque_path_description.h" #include #include @@ -14,6 +14,8 @@ namespace NKikimr { +using namespace NSchemeBoard; + struct TSchemeBoardEvents { using TDescribeSchemeResult = NKikimrScheme::TEvDescribeSchemeResult; @@ -114,7 +116,7 @@ struct TSchemeBoardEvents { const TLocalPathId DeletedPathBegin = 0; // The points are inclusive const TLocalPathId DeletedPathEnd = 0; // [DeletedPathBegin; DeletedPathEnd] const TLocalPathId MigratedPathId = InvalidLocalPathId; - NSchemeBoard::TTwoPartDescription Description; + TOpaquePathDescription Description; TEvDescribeResult() = default; @@ -132,7 +134,7 @@ struct TSchemeBoardEvents { explicit TEvDescribeResult( TLocalPathId deletedPathBegin, TLocalPathId deletedPathEnd, - const NSchemeBoard::TTwoPartDescription& description) + const TOpaquePathDescription& description) : Commit(false) , DeletedPathBegin(deletedPathBegin) , DeletedPathEnd(deletedPathEnd) @@ -159,16 +161,24 @@ struct TSchemeBoardEvents { } bool HasDescription() const { - return Description; + return !Description.IsEmpty(); } TString ToString() const override { - return TStringBuilder() << ToStringHeader() << " {" + auto builder = TStringBuilder() << ToStringHeader() << " {" << " Commit: " << (Commit ? "true" : "false") << " DeletedPathBegin: " << DeletedPathBegin << " DeletedPathEnd: " << DeletedPathEnd - << " msg: " << Description.Record.ShortDebugString() - << " }"; + ; + if (HasDescription()) { + builder << " { Path: " << Description.Path + << " PathId: " << Description.PathId + << " PathVersion: " << Description.PathVersion + << " }" + ; + } + builder << " }"; + return builder; } }; @@ -219,6 +229,9 @@ struct TSchemeBoardEvents { struct TEvUpdate: public TEventPreSerializedPB { TEvUpdate() = default; + TString GetPath() const { + return Record.GetPath(); + } TPathId GetPathId() const { if (!Record.HasLocalPathId()) { return TPathId(); @@ -230,6 +243,8 @@ struct TSchemeBoardEvents { ); } + TOpaquePathDescription ExtractPathDescription(); + TString ToString() const override { return PrintOwnerGeneration(this, Record); } @@ -240,58 +255,17 @@ struct TSchemeBoardEvents { TEvUpdateBuilder() = default; - explicit TEvUpdateBuilder(const ui64 owner, const ui64 generation) { - Record.SetOwner(owner); - Record.SetGeneration(generation); - } - - explicit TEvUpdateBuilder(const ui64 owner, const ui64 generation, const TPathId& pathId) { - Record.SetOwner(owner); - Record.SetGeneration(generation); - Record.SetPathOwnerId(pathId.OwnerId); - Record.SetLocalPathId(pathId.LocalPathId); - Record.SetIsDeletion(true); - } - + explicit TEvUpdateBuilder(const ui64 owner, const ui64 generation); + explicit TEvUpdateBuilder(const ui64 owner, const ui64 generation, const TPathId& pathId); explicit TEvUpdateBuilder( const ui64 owner, const ui64 generation, - const TDescribeSchemeResult& describeSchemeResult, + const TOpaquePathDescription& pathDescription, const bool isDeletion = false - ) { - Record.SetOwner(owner); - Record.SetGeneration(generation); - if (describeSchemeResult.HasPath()) { - Record.SetPath(describeSchemeResult.GetPath()); - } - if (describeSchemeResult.HasPathDescription() - && describeSchemeResult.GetPathDescription().HasSelf()) { - Record.SetPathOwnerId(describeSchemeResult.GetPathDescription().GetSelf().GetSchemeshardId()); - } - Record.SetLocalPathId(describeSchemeResult.GetPathId()); - if (describeSchemeResult.HasPathOwnerId()) { - Record.SetPathOwnerId(describeSchemeResult.GetPathOwnerId()); - } - Record.SetIsDeletion(isDeletion); - } - - void SetDescribeSchemeResult(TString preSerialized) { - PreSerializedData = NSchemeBoard::PreSerializedProtoField( - std::move(preSerialized), Record.kDescribeSchemeResultFieldNumber); - } + ); - void SetDescribeSchemeResult(TDescribeSchemeResult describeSchemeResult) { - *Record.MutableDescribeSchemeResult() = std::move(describeSchemeResult); - } - - void SetDescribeSchemeResult(TString preSerialized, TDescribeSchemeResult describeSchemeResult) { - SetDescribeSchemeResult(std::move(preSerialized)); - SetDescribeSchemeResult(std::move(describeSchemeResult)); - } - - void SetDescribeSchemeResult(NSchemeBoard::TTwoPartDescription twoPart) { - SetDescribeSchemeResult(std::move(twoPart.PreSerialized), std::move(twoPart.Record)); - } + void SetDescribeSchemeResultSerialized(const TString& serialized); + void SetDescribeSchemeResultSerialized(TString&& serialized); }; struct TEvUpdateAck: public TEventPB { @@ -398,6 +372,21 @@ struct TSchemeBoardEvents { } }; + template + static TStringBuilder& PrintPathVersion(TStringBuilder& out, const T& record) { + return out + << " Version: " << NSchemeBoard::GetPathVersion(record) + ; + } + + template <> + TString PrintPath(const IEventBase* ev, const NKikimrSchemeBoard::TEvNotify& record) { + auto out = TStringBuilder() << ev->ToStringHeader() << " {"; + PrintPath(out, record); + PrintPathVersion(out, record); + return out << " }"; + } + struct TEvNotify: public TEventPreSerializedPB { TEvNotify() = default; @@ -411,32 +400,11 @@ struct TSchemeBoardEvents { TEvNotifyBuilder() = default; - explicit TEvNotifyBuilder(const TString& path, const bool isDeletion = false) { - Record.SetPath(path); - Record.SetIsDeletion(isDeletion); - } + explicit TEvNotifyBuilder(const TString& path, const bool isDeletion = false); + explicit TEvNotifyBuilder(const TPathId& pathId, const bool isDeletion = false); + explicit TEvNotifyBuilder(const TString& path, const TPathId& pathId, const bool isDeletion = false); - explicit TEvNotifyBuilder(const TPathId& pathId, const bool isDeletion = false) { - Record.SetPathOwnerId(pathId.OwnerId); - Record.SetLocalPathId(pathId.LocalPathId); - Record.SetIsDeletion(isDeletion); - } - - explicit TEvNotifyBuilder( - const TString& path, - const TPathId& pathId, - const bool isDeletion = false - ) { - Record.SetPath(path); - Record.SetPathOwnerId(pathId.OwnerId); - Record.SetLocalPathId(pathId.LocalPathId); - Record.SetIsDeletion(isDeletion); - } - - void SetDescribeSchemeResult(const TString& preSerialized) { - PreSerializedData = NSchemeBoard::PreSerializedProtoField( - preSerialized, Record.kDescribeSchemeResultFieldNumber); - } + void SetPathDescription(const TOpaquePathDescription& pathDescription); }; struct TEvNotifyAck: public TEventPB { diff --git a/ydb/core/tx/scheme_board/helpers.cpp b/ydb/core/tx/scheme_board/helpers.cpp index 7505f1c39f28..89cbaf614cc2 100644 --- a/ydb/core/tx/scheme_board/helpers.cpp +++ b/ydb/core/tx/scheme_board/helpers.cpp @@ -1,13 +1,10 @@ #include "helpers.h" -#include -#include -#include +#include -#include -#include +#include -#include +#include namespace NKikimr { namespace NSchemeBoard { @@ -16,6 +13,9 @@ TActorId MakeInterconnectProxyId(const ui32 nodeId) { return TActivationContext::InterconnectProxy(nodeId); } +// NKikimrScheme::TEvDescribeSchemeResult +// + ui64 GetPathVersion(const NKikimrScheme::TEvDescribeSchemeResult& record) { if (!record.HasPathDescription()) { return 0; @@ -34,6 +34,10 @@ ui64 GetPathVersion(const NKikimrScheme::TEvDescribeSchemeResult& record) { return self.GetPathVersion(); } +// Object path-id is determined from TDescribeSchemeResult with backward compatibility support. +// DescribeSchemeResult.PathOwnerId should be used. +// DescribeSchemeResult.PathDescription.Self.SchemeshardId is deprecated. +// DescribeSchemeResult.PathOwnerId takes preference. TPathId GetPathId(const NKikimrScheme::TEvDescribeSchemeResult &record) { if (record.HasPathId() && record.HasPathOwnerId()) { return TPathId(record.GetPathOwnerId(), record.GetPathId()); @@ -81,6 +85,40 @@ TSet GetAbandonedSchemeShardIds(const NKikimrScheme::TEvDescribeSchemeResu ); } +// NKikimrSchemeBoard::TEvUpdate +// + +ui64 GetPathVersion(const NKikimrSchemeBoard::TEvUpdate& record) { + return record.GetPathDirEntryPathVersion(); +} + +TSet GetAbandonedSchemeShardIds(const NKikimrSchemeBoard::TEvUpdate& record) { + return TSet( + record.GetPathAbandonedTenantsSchemeShards().begin(), + record.GetPathAbandonedTenantsSchemeShards().end() + ); +} + +// NKikimrSchemeBoard::TEvNotify +// + +ui64 GetPathVersion(const NKikimrSchemeBoard::TEvNotify& record) { + return record.GetVersion(); +} + +NSchemeBoard::TDomainId GetDomainId(const NKikimrSchemeBoard::TEvNotify& record) { + return PathIdFromPathId(record.GetPathSubdomainPathId()); +} + +TSet GetAbandonedSchemeShardIds(const NKikimrSchemeBoard::TEvNotify& record) { + return TSet( + record.GetPathAbandonedTenantsSchemeShards().begin(), + record.GetPathAbandonedTenantsSchemeShards().end() + ); +} + +// Assorted methods +// TIntrusivePtr SerializeEvent(IEventBase* ev) { TAllocChunkSerializer serializer; Y_ABORT_UNLESS(ev->SerializeToArcadiaStream(&serializer)); @@ -96,21 +134,44 @@ void MultiSend(const TVector& recipients, const TActorId& sende } } -TString PreSerializedProtoField(TString data, int fieldNo) { - using CodedOutputStream = google::protobuf::io::CodedOutputStream; - using StringOutputStream = google::protobuf::io::StringOutputStream; - using WireFormat = google::protobuf::internal::WireFormatLite; +// Work with TEvDescribeSchemeResult and its parts +// - TString key; - { - StringOutputStream stream(&key); - CodedOutputStream output(&stream); - WireFormat::WriteTag(fieldNo, WireFormat::WireType::WIRETYPE_LENGTH_DELIMITED, &output); - output.WriteVarint32(data.size()); - } +TString SerializeDescribeSchemeResult(const NKikimrScheme::TEvDescribeSchemeResult& proto) { + TString serialized; + Y_PROTOBUF_SUPPRESS_NODISCARD proto.SerializeToString(&serialized); + return serialized; +} + +TString SerializeDescribeSchemeResult(const TString& preSerializedPart, const NKikimrScheme::TEvDescribeSchemeResult& protoPart) { + return Join("", preSerializedPart, SerializeDescribeSchemeResult(protoPart)); +} + +NKikimrScheme::TEvDescribeSchemeResult DeserializeDescribeSchemeResult(const TString& serialized) { + NKikimrScheme::TEvDescribeSchemeResult result; + Y_ABORT_UNLESS(ParseFromStringNoSizeLimit(result, serialized)); + return result; +} + +NKikimrScheme::TEvDescribeSchemeResult* DeserializeDescribeSchemeResult(const TString& serialized, google::protobuf::Arena* arena) { + auto* proto = google::protobuf::Arena::CreateMessage(arena); + Y_ABORT_UNLESS(ParseFromStringNoSizeLimit(*proto, serialized)); + return proto; +} + +TString JsonFromDescribeSchemeResult(const TString& serialized) { + using namespace google::protobuf::util; + + google::protobuf::Arena arena; + const auto* proto = DeserializeDescribeSchemeResult(serialized, &arena); + + JsonPrintOptions opts; + opts.preserve_proto_field_names = true; + + TString json; + MessageToJsonString(*proto, &json, opts); - data.prepend(key); - return data; + return json; } } // NSchemeBoard diff --git a/ydb/core/tx/scheme_board/helpers.h b/ydb/core/tx/scheme_board/helpers.h index f9c5e9c378b1..a00fb1f44354 100644 --- a/ydb/core/tx/scheme_board/helpers.h +++ b/ydb/core/tx/scheme_board/helpers.h @@ -4,6 +4,7 @@ #include #include +#include #include @@ -34,12 +35,20 @@ namespace NSchemeBoard { using TDomainId = TPathId; TActorId MakeInterconnectProxyId(const ui32 nodeId); + +// Extract metainfo directly from DescribeSchemeResult message ui64 GetPathVersion(const NKikimrScheme::TEvDescribeSchemeResult& record); TPathId GetPathId(const NKikimrScheme::TEvDescribeSchemeResult& record); TDomainId GetDomainId(const NKikimrScheme::TEvDescribeSchemeResult& record); -TSet GetAbandonedSchemeShardIds(const NKikimrScheme::TEvDescribeSchemeResult &record); +TSet GetAbandonedSchemeShardIds(const NKikimrScheme::TEvDescribeSchemeResult& record); + +// Extract metainfo from TEvUpdate message +ui64 GetPathVersion(const NKikimrSchemeBoard::TEvUpdate& record); -TIntrusivePtr SerializeEvent(IEventBase* ev); +// Extract metainfo from TEvNotify message +ui64 GetPathVersion(const NKikimrSchemeBoard::TEvNotify& record); +NSchemeBoard::TDomainId GetDomainId(const NKikimrSchemeBoard::TEvNotify& record); +TSet GetAbandonedSchemeShardIds(const NKikimrSchemeBoard::TEvNotify& record); void MultiSend(const TVector& recipients, const TActorId& sender, TAutoPtr ev, ui32 flags = 0, ui64 cookie = 0); @@ -48,8 +57,12 @@ void MultiSend(const TVector& recipients, const TActorId& sende MultiSend(recipients, sender, static_cast(ev.Release()), flags, cookie); } -// Only string or embed message fields are supported (it used wire type = 2 internally) -TString PreSerializedProtoField(TString data, int fieldNo); +// Work with TEvDescribeSchemeResult and its parts +TString SerializeDescribeSchemeResult(const NKikimrScheme::TEvDescribeSchemeResult& proto); +TString SerializeDescribeSchemeResult(const TString& preSerializedPart, const NKikimrScheme::TEvDescribeSchemeResult& protoPart); +NKikimrScheme::TEvDescribeSchemeResult DeserializeDescribeSchemeResult(const TString& serialized); +NKikimrScheme::TEvDescribeSchemeResult* DeserializeDescribeSchemeResult(const TString& serialized, google::protobuf::Arena* arena); +TString JsonFromDescribeSchemeResult(const TString& serialized); } // NSchemeBoard } // NKikimr diff --git a/ydb/core/tx/scheme_board/load_test.cpp b/ydb/core/tx/scheme_board/load_test.cpp index 1e2b0f6a88f3..48f3999cc7c4 100644 --- a/ydb/core/tx/scheme_board/load_test.cpp +++ b/ydb/core/tx/scheme_board/load_test.cpp @@ -57,14 +57,14 @@ class TLoadProducer: public TActorBootstrapped { TDescription& dirDesc = dirDescTwoPart.Record; dirDesc.SetStatus(NKikimrScheme::StatusSuccess); - dirDesc.SetPathOwner(owner); + dirDesc.SetPathOwnerId(owner); dirDesc.SetPathId(nextPathId++); dirDesc.SetPath(dirPath); auto& dirSelf = *dirDesc.MutablePathDescription()->MutableSelf(); dirSelf.SetName(dirName); dirSelf.SetPathId(dirDesc.GetPathId()); - dirSelf.SetSchemeshardId(dirDesc.GetPathOwner()); + dirSelf.SetSchemeshardId(dirDesc.GetPathOwnerId()); dirSelf.SetPathType(NKikimrSchemeOp::EPathTypeDir); dirSelf.SetCreateFinished(true); dirSelf.SetCreateTxId(1); @@ -84,7 +84,7 @@ class TLoadProducer: public TActorBootstrapped { TDescription& objDesc = objDescTwoPart.Record; objDesc.SetStatus(NKikimrScheme::StatusSuccess); - objDesc.SetPathOwner(owner); + objDesc.SetPathOwnerId(owner); objDesc.SetPathId(nextPathId++); objDesc.SetPath(objPath); @@ -94,7 +94,7 @@ class TLoadProducer: public TActorBootstrapped { dirChildren.Add()->CopyFrom(objSelf); objSelf.SetPathId(objDesc.GetPathId()); - objSelf.SetSchemeshardId(objDesc.GetPathOwner()); + objSelf.SetSchemeshardId(objDesc.GetPathOwnerId()); objSelf.SetCreateFinished(true); objSelf.SetCreateTxId(1); objSelf.SetCreateStep(1); @@ -194,7 +194,7 @@ class TLoadProducer: public TActorBootstrapped { Descriptions = GenerateDescriptions(Owner, Config, NextPathId); Populator = Register(CreateSchemeBoardPopulator( - Owner, Max(), ssId, Descriptions, NextPathId + Owner, Max(), ssId, std::vector>(Descriptions.begin(), Descriptions.end()), NextPathId )); TPathId pathId(Owner, NextPathId - 1); @@ -236,7 +236,7 @@ class TLoadProducer: public TActorBootstrapped { Send(Subscriber, new TEvents::TEvPoisonPill()); Subscriber = TActorId(); - const TInstant ts = TInstant::FromValue(GetPathVersion(msg->DescribeSchemeResult)); + const TInstant ts = TInstant::FromValue(NSchemeBoard::GetPathVersion(msg->DescribeSchemeResult)); *SyncDuration = (TlsActivationContext->Now() - ts).MilliSeconds(); Test(); @@ -352,7 +352,7 @@ class TLoadConsumer: public TActorBootstrapped { void Handle(TSchemeBoardEvents::TEvNotifyUpdate::TPtr& ev) { const auto* msg = ev->Get(); - const TInstant ts = TInstant::FromValue(GetPathVersion(msg->DescribeSchemeResult)); + const TInstant ts = TInstant::FromValue(NSchemeBoard::GetPathVersion(msg->DescribeSchemeResult)); if (IsDir(msg->DescribeSchemeResult)) { LatencyDir->Collect((TlsActivationContext->Now() - ts).MilliSeconds()); } else { diff --git a/ydb/core/tx/scheme_board/opaque_path_description.cpp b/ydb/core/tx/scheme_board/opaque_path_description.cpp new file mode 100644 index 000000000000..a78a0dc58877 --- /dev/null +++ b/ydb/core/tx/scheme_board/opaque_path_description.cpp @@ -0,0 +1,41 @@ +#include "helpers.h" +#include "two_part_description.h" +#include "opaque_path_description.h" + +namespace NKikimr::NSchemeBoard { + +bool TOpaquePathDescription::IsEmpty() const { + return DescribeSchemeResultSerialized.empty(); +} + +TString TOpaquePathDescription::ToString() const { + // fields are reordered to be more useful to people reading logs + return TStringBuilder() << "{" + << "Status " << Status + << ", Path " << Path + << ", PathId " << PathId + << ", PathVersion " << PathVersion + << ", SubdomainPathId " << SubdomainPathId + << ", PathAbandonedTenantsSchemeShards size " << PathAbandonedTenantsSchemeShards.size() + << ", DescribeSchemeResultSerialized size " << DescribeSchemeResultSerialized.size() + << "}" + ; +} + +TOpaquePathDescription MakeOpaquePathDescription(const TString& preSerializedPart, const NKikimrScheme::TEvDescribeSchemeResult& protoPart) { + return TOpaquePathDescription{ + .DescribeSchemeResultSerialized = SerializeDescribeSchemeResult(preSerializedPart, protoPart), + .Status = protoPart.GetStatus(), + .PathId = GetPathId(protoPart), + .Path = protoPart.GetPath(), + .PathVersion = GetPathVersion(protoPart), + .SubdomainPathId = GetDomainId(protoPart), + .PathAbandonedTenantsSchemeShards = GetAbandonedSchemeShardIds(protoPart), + }; +} + +TOpaquePathDescription MakeOpaquePathDescription(const TTwoPartDescription& twoPartDescription) { + return MakeOpaquePathDescription(twoPartDescription.PreSerialized, twoPartDescription.Record); +} + +} // NKikimr::NSchemeBoard diff --git a/ydb/core/tx/scheme_board/opaque_path_description.h b/ydb/core/tx/scheme_board/opaque_path_description.h new file mode 100644 index 000000000000..384d7c2ac25e --- /dev/null +++ b/ydb/core/tx/scheme_board/opaque_path_description.h @@ -0,0 +1,46 @@ +#pragma once + +#include +#include + +#include +#include + + +namespace NKikimr::NSchemeBoard { + +struct TOpaquePathDescription { + // Serialized TEvDescribeSchemeResult + TString DescribeSchemeResultSerialized; + + // Explicit values extracted from original TEvDescribeSchemeResult + + // TEvDescribeSchemeResult.Status, invalid status value by default + NKikimrScheme::EStatus Status = NKikimrScheme::EStatus_MAX; + + // TEvDescribeSchemeResult.(PathOwnerId,PathId) or TEvDescribeSchemeResult.PathDescription.Self.(SchemeshardId,PathId) in order of presence + TPathId PathId; + + // TEvDescribeSchemeResult.Path + TString Path; + + // TEvDescribeSchemeResult.PathDescription.Self.PathVersion + ui64 PathVersion = 0; + + // TEvDescribeSchemeResult.PathDescription.DomainDescription.DomainKey + TPathId SubdomainPathId; + + // TEvDescribeSchemeResult.PathDescription.AbandonedTenantsSchemeShards + TSet PathAbandonedTenantsSchemeShards; + + bool IsEmpty() const; + + TString ToString() const; +}; + +struct TTwoPartDescription; + +TOpaquePathDescription MakeOpaquePathDescription(const TString& preSerializedPart, const NKikimrScheme::TEvDescribeSchemeResult& protoPart); +TOpaquePathDescription MakeOpaquePathDescription(const TTwoPartDescription& twoPartDescription); + +} // NKikimr::NSchemeBoard diff --git a/ydb/core/tx/scheme_board/populator.cpp b/ydb/core/tx/scheme_board/populator.cpp index c0a25fc039dc..28c305aaee09 100644 --- a/ydb/core/tx/scheme_board/populator.cpp +++ b/ydb/core/tx/scheme_board/populator.cpp @@ -1,10 +1,9 @@ #include "events.h" #include "helpers.h" #include "monitorable_actor.h" +#include "opaque_path_description.h" #include "populator.h" -#include - #include #include #include @@ -64,7 +63,7 @@ class TReplicaPopulator: public TMonitorableActor { } auto update = msg->HasDescription() - ? MakeHolder(Owner, Generation, msg->Description.Record) + ? MakeHolder(Owner, Generation, msg->Description) : MakeHolder(Owner, Generation); if (msg->HasDeletedLocalPathIds()) { @@ -77,17 +76,11 @@ class TReplicaPopulator: public TMonitorableActor { } if (msg->HasDescription()) { - auto& record = msg->Description.Record; - - if (!record.HasStatus()) { - SBP_LOG_E("Ignore description without status"); - } else if (record.GetStatus() != NKikimrScheme::StatusSuccess) { - SBP_LOG_E("Ignore description" - << ": status# " << record.GetStatus() - << ", msg# " << record.ShortDebugString()); + if (msg->Description.Status != NKikimrScheme::StatusSuccess) { + SBP_LOG_E("Ignore description: " << msg->Description.ToString()); } else { - CurPathId = GetPathId(record); - update->SetDescribeSchemeResult(std::move(msg->Description)); + CurPathId = msg->Description.PathId; + update->SetDescribeSchemeResultSerialized(std::move(msg->Description.DescribeSchemeResultSerialized)); } } @@ -121,7 +114,7 @@ class TReplicaPopulator: public TMonitorableActor { void EnqueueUpdate(TSchemeBoardEvents::TEvUpdate::TPtr& ev, bool canSend = false) { const TPathId pathId = ev->Get()->GetPathId(); const auto& record = (static_cast(ev->Get()))->Record; - const ui64 version = record.GetIsDeletion() ? Max() : GetPathVersion(record.GetDescribeSchemeResult()); + const ui64 version = record.GetIsDeletion() ? Max() : NSchemeBoard::GetPathVersion(record); if (canSend && UpdatesInFlight.size() < BatchSizeLimit) { bool needSend = true; @@ -509,16 +502,16 @@ class TPopulator: public TMonitorableActor { auto it = Descriptions.find(pathId); Y_ABORT_UNLESS(it != Descriptions.end()); - const auto& record = it->second.Record; + const TOpaquePathDescription& desc = it->second; - TConstArrayRef replicas = SelectReplicas(pathId, record.GetPath()); + TConstArrayRef replicas = SelectReplicas(pathId, desc.Path); for (const auto& replica : replicas) { const TActorId* replicaPopulator = ReplicaToReplicaPopulator.FindPtr(replica); Y_ABORT_UNLESS(replicaPopulator != nullptr); - auto update = MakeHolder(Owner, Generation, record, isDeletion); + auto update = MakeHolder(Owner, Generation, desc, isDeletion); if (!isDeletion) { - update->SetDescribeSchemeResult(it->second); + update->SetDescribeSchemeResultSerialized(desc.DescribeSchemeResultSerialized); } update->Record.SetNeedAck(true); @@ -557,7 +550,8 @@ class TPopulator: public TMonitorableActor { } while (it != Descriptions.end()) { // skip irrelevant to the replica - if (it->second.Record.GetStatus() == NKikimrScheme::StatusPathDoesNotExist) { + const auto& desc = it->second; + if (desc.Status == NKikimrScheme::StatusPathDoesNotExist) { // KIKIMR-13173 // it is assumed that not deleted pathes present in Descriptions // but it might be, since we have the difference at path description and init population @@ -568,8 +562,7 @@ class TPopulator: public TMonitorableActor { continue; } - TPathId pathId(it->second.Record.GetPathOwnerId(), it->second.Record.GetPathId()); - TConstArrayRef replicas = SelectReplicas(pathId, it->second.Record.GetPath()); + TConstArrayRef replicas = SelectReplicas(desc.PathId, desc.Path); if (Find(replicas, replica) != replicas.end()) { break; } @@ -591,17 +584,15 @@ class TPopulator: public TMonitorableActor { } const auto& description = it->second; - const auto& record = description.Record; - auto pathId = TPathId(it->second.Record.GetPathOwnerId(), it->second.Record.GetPathId()); - if (pathId.OwnerId != Owner) { + if (description.PathId.OwnerId != Owner) { // this is an alien migrated migrated path from another owner, push it as a dot Send(replicaPopulator, new TSchemeBoardEvents::TEvDescribeResult(0, 0, description)); return; } TLocalPathId deletedBegin = startPathId.LocalPathId; - TLocalPathId deletedEnd = record.GetPathId() - 1; + TLocalPathId deletedEnd = description.PathId.LocalPathId - 1; if (startPathId.OwnerId != Owner) { deletedBegin = 1; @@ -613,7 +604,7 @@ class TPopulator: public TMonitorableActor { deletedEnd = 0; } - if (record.GetStatus() == NKikimrScheme::EStatus::StatusRedirectDomain) { + if (description.Status == NKikimrScheme::EStatus::StatusRedirectDomain) { // this path has been migrated to another owner Send(replicaPopulator, new TSchemeBoardEvents::TEvDescribeResult(deletedBegin, deletedEnd, it->first.LocalPathId)); return; @@ -633,11 +624,12 @@ class TPopulator: public TMonitorableActor { if (it == Descriptions.end()) { update = MakeHolder(Owner, Generation, pathId); } else { - update = MakeHolder(Owner, Generation, it->second.Record); - update->SetDescribeSchemeResult(it->second); + const auto& desc = it->second; + update = MakeHolder(Owner, Generation, desc); + update->SetDescribeSchemeResultSerialized(desc.DescribeSchemeResultSerialized); } - update->Record.SetNeedAck(true); + Send(ev->Sender, std::move(update)); } @@ -650,13 +642,19 @@ class TPopulator: public TMonitorableActor { } void Handle(NSchemeShard::TEvSchemeShard::TEvDescribeSchemeResult::TPtr& ev) { - SBP_LOG_D("Handle " << ev->Get()->ToString() - << ": sender# " << ev->Sender - << ", cookie# " << ev->Cookie); - + //NOTE: avoid using TEventPreSerializedPB::GetRecord() or TEventPreSerializedPB::ToString() + // that will cause full reconstruction of TEvDescribeSchemeResult from base stab + // and PreSerializedData auto* msg = static_cast(ev->Get()); auto& record = msg->Record; + SBP_LOG_D("Handle TEvSchemeShard::TEvDescribeSchemeResult { " << record.ShortDebugString() << " }" + << ": sender# " << ev->Sender + << ", cookie# " << ev->Cookie + << ", event size# " << msg->GetCachedByteSize() + << ", preserialized size# " << msg->PreSerializedData.size() + ); + if (!record.HasStatus()) { SBP_LOG_E("Description without status"); return; @@ -664,13 +662,15 @@ class TPopulator: public TMonitorableActor { const TPathId pathId = GetPathId(record); const bool isDeletion = record.GetStatus() == NKikimrScheme::StatusPathDoesNotExist; - const ui64 version = isDeletion ? Max() : GetPathVersion(record); + const ui64 version = isDeletion ? Max() : NSchemeBoard::GetPathVersion(record); SBP_LOG_N("Update description" << ": owner# " << Owner << ", pathId# " << pathId << ", cookie# " << ev->Cookie - << ", is deletion# " << (isDeletion ? "true" : "false")); + << ", is deletion# " << (isDeletion ? "true" : "false") + << ", version: " << (isDeletion ? 0 : version) + ); if (isDeletion) { if (!Descriptions.contains(pathId)) { @@ -684,7 +684,7 @@ class TPopulator: public TMonitorableActor { return; } } else { - Descriptions[pathId] = TTwoPartDescription(std::move(msg->PreSerializedData), std::move(record)); + Descriptions[pathId] = MakeOpaquePathDescription(msg->PreSerializedData, record); MaxPathId = Max(MaxPathId, pathId.NextId()); } @@ -819,22 +819,14 @@ class TPopulator: public TMonitorableActor { void Handle(TSchemeBoardMonEvents::TEvDescribeRequest::TPtr& ev) { const auto& record = ev->Get()->Record; - TTwoPartDescription* desc = nullptr; + TOpaquePathDescription* desc = nullptr; if (record.HasPathId()) { desc = Descriptions.FindPtr(TPathId(record.GetPathId().GetOwnerId(), record.GetPathId().GetLocalPathId())); } TString json; if (desc) { - NKikimrScheme::TEvDescribeSchemeResult fullProto; - Y_PROTOBUF_SUPPRESS_NODISCARD fullProto.ParseFromString(desc->PreSerialized); - fullProto.MergeFrom(desc->Record); - - using namespace google::protobuf::util; - - JsonPrintOptions opts; - opts.preserve_proto_field_names = true; - MessageToJsonString(fullProto, &json, opts); + json = JsonFromDescribeSchemeResult(desc->DescribeSchemeResultSerialized); } else { json = "{}"; } @@ -872,14 +864,16 @@ class TPopulator: public TMonitorableActor { const ui64 owner, const ui64 generation, const ui32 ssId, - TMap descriptions, + std::vector>&& twoPartDescriptions, const ui64 maxPathId) : Owner(owner) , Generation(generation) , StateStorageGroup(ssId) - , Descriptions(std::move(descriptions)) , MaxPathId(TPathId(owner, maxPathId)) { + for (const auto& [pathId, twoPart] : twoPartDescriptions) { + Descriptions.emplace(pathId, MakeOpaquePathDescription(twoPart)); + } } void Bootstrap() { @@ -933,7 +927,7 @@ class TPopulator: public TMonitorableActor { const ui64 Generation; const ui64 StateStorageGroup; - TMap Descriptions; + TMap Descriptions; TPathId MaxPathId; TDelayedUpdates DelayedUpdates; @@ -958,10 +952,10 @@ IActor* CreateSchemeBoardPopulator( const ui64 owner, const ui64 generation, const ui32 ssId, - TMap descriptions, + std::vector>&& twoPartDescriptions, const ui64 maxPathId ) { - return new NSchemeBoard::TPopulator(owner, generation, ssId, std::move(descriptions), maxPathId); + return new NSchemeBoard::TPopulator(owner, generation, ssId, std::move(twoPartDescriptions), maxPathId); } } // NKikimr diff --git a/ydb/core/tx/scheme_board/populator.h b/ydb/core/tx/scheme_board/populator.h index ff0b4cead4b0..d1b5cb9f7cae 100644 --- a/ydb/core/tx/scheme_board/populator.h +++ b/ydb/core/tx/scheme_board/populator.h @@ -13,7 +13,7 @@ IActor* CreateSchemeBoardPopulator( const ui64 owner, const ui64 generation, const ui32 schemeBoardSSId, - TMap descriptions, + std::vector>&& twoPartDescriptions, const ui64 maxPathId ); diff --git a/ydb/core/tx/scheme_board/replica.cpp b/ydb/core/tx/scheme_board/replica.cpp index 07b81862fc29..c1600b4bd644 100644 --- a/ydb/core/tx/scheme_board/replica.cpp +++ b/ydb/core/tx/scheme_board/replica.cpp @@ -2,11 +2,11 @@ #include "events.h" #include "helpers.h" #include "monitorable_actor.h" +#include "opaque_path_description.h" #include "replica.h" -#include +#include -#include #include #include @@ -192,24 +192,16 @@ class TReplica: public TMonitorableActor { MultiSend(subscribers, Owner->SelfId(), std::move(notify)); } - void CalculateResultSize() { - ResultSize = DescribeSchemeResult.ByteSizeLong(); - } - - size_t FullSize() const { - size_t size = ResultSize; - if (PreSerializedDescribeSchemeResult) { - size += PreSerializedDescribeSchemeResult->size(); - } - return size; - } - void TrackMemory() const { - NActors::NMemory::TLabel::Add(FullSize()); + NActors::NMemory::TLabel::Add( + PathDescription.DescribeSchemeResultSerialized.size() + ); } void UntrackMemory() const { - NActors::NMemory::TLabel::Sub(FullSize()); + NActors::NMemory::TLabel::Sub( + PathDescription.DescribeSchemeResultSerialized.size() + ); } void Move(TDescription&& other) { @@ -219,13 +211,10 @@ class TReplica: public TMonitorableActor { Owner = other.Owner; Path = std::move(other.Path); PathId = std::move(other.PathId); - DescribeSchemeResult = std::move(other.DescribeSchemeResult); - PreSerializedDescribeSchemeResult = std::move(other.PreSerializedDescribeSchemeResult); + PathDescription = std::move(other.PathDescription); ExplicitlyDeleted = other.ExplicitlyDeleted; Subscribers = std::move(other.Subscribers); - ResultSize = other.ResultSize; - other.ResultSize = 0; TrackNotify = other.TrackNotify; TrackMemory(); @@ -262,12 +251,11 @@ class TReplica: public TMonitorableActor { explicit TDescription( TReplica* owner, const TPathId& pathId, - TDescribeSchemeResult&& describeSchemeResult) + TOpaquePathDescription&& pathDescription) : Owner(owner) , PathId(pathId) - , DescribeSchemeResult(std::move(describeSchemeResult)) + , PathDescription(std::move(pathDescription)) { - CalculateResultSize(); TrackMemory(); } @@ -275,13 +263,12 @@ class TReplica: public TMonitorableActor { TReplica* owner, const TString& path, const TPathId& pathId, - TDescribeSchemeResult&& describeSchemeResult) + TOpaquePathDescription&& pathDescription) : Owner(owner) , Path(path) , PathId(pathId) - , DescribeSchemeResult(std::move(describeSchemeResult)) + , PathDescription(std::move(pathDescription)) { - CalculateResultSize(); TrackMemory(); } @@ -339,22 +326,18 @@ class TReplica: public TMonitorableActor { other.TrackNotify = false; if (*this > other) { - other.DescribeSchemeResult.Swap(&DescribeSchemeResult); - other.PreSerializedDescribeSchemeResult.Clear(); + // this desc is newer then the other + std::swap(other.PathDescription, PathDescription); other.ExplicitlyDeleted = ExplicitlyDeleted; other.Notify(); - DescribeSchemeResult.Swap(&other.DescribeSchemeResult); - other.PreSerializedDescribeSchemeResult.Clear(); + std::swap(PathDescription, other.PathDescription); } else if (*this < other) { - DescribeSchemeResult = std::move(other.DescribeSchemeResult); - PreSerializedDescribeSchemeResult.Clear(); + // this desc is older then the other + PathDescription = std::move(other.PathDescription); ExplicitlyDeleted = other.ExplicitlyDeleted; Notify(); } - CalculateResultSize(); - other.CalculateResultSize(); - TrackNotify = true; other.TrackNotify = true; TrackMemory(); @@ -365,15 +348,15 @@ class TReplica: public TMonitorableActor { return *this; } - const TDescribeSchemeResult& GetProto() const { - return DescribeSchemeResult; + TString GetDescribeSchemeResultSerialized() const { + return PathDescription.DescribeSchemeResultSerialized; } TString ToString() const { return TStringBuilder() << "{" << " Path# " << Path << " PathId# " << PathId - << " DescribeSchemeResult# " << DescribeSchemeResult.ShortDebugString() + << " PathDescription# " << PathDescription.ToString() << " ExplicitlyDeleted# " << (ExplicitlyDeleted ? "true" : "false") << " }"; } @@ -403,28 +386,34 @@ class TReplica: public TMonitorableActor { if (ExplicitlyDeleted) { return Max(); } - - return ::NKikimr::NSchemeBoard::GetPathVersion(DescribeSchemeResult); + return PathDescription.PathVersion; } TDomainId GetDomainId() const { - return IsFilled() ? ::NKikimr::NSchemeBoard::GetDomainId(DescribeSchemeResult) : TDomainId(); + if (IsEmpty()) { + return TDomainId(); + } + return PathDescription.SubdomainPathId; } TSet GetAbandonedSchemeShardIds() const { - return IsFilled() ? ::NKikimr::NSchemeBoard::GetAbandonedSchemeShardIds(DescribeSchemeResult) : TSet(); + if (IsEmpty()) { + return TSet(); + } + return PathDescription.PathAbandonedTenantsSchemeShards; } - bool IsFilled() const { - return DescribeSchemeResult.ByteSizeLong(); + bool IsEmpty() const { + return PathDescription.IsEmpty(); } void Clear() { ExplicitlyDeleted = true; UntrackMemory(); - TDescribeSchemeResult().Swap(&DescribeSchemeResult); - PreSerializedDescribeSchemeResult.Clear(); - ResultSize = 0; + { + TOpaquePathDescription empty; + std::swap(PathDescription, empty); + } TrackMemory(); Notify(); } @@ -432,7 +421,7 @@ class TReplica: public TMonitorableActor { THolder BuildNotify(bool forceStrong = false) const { THolder notify; - const bool isDeletion = !IsFilled(); + const bool isDeletion = IsEmpty(); if (!PathId) { Y_ABORT_UNLESS(isDeletion); @@ -445,23 +434,15 @@ class TReplica: public TMonitorableActor { } if (!isDeletion) { - if (!PreSerializedDescribeSchemeResult) { - TString serialized; - Y_PROTOBUF_SUPPRESS_NODISCARD DescribeSchemeResult.SerializeToString(&serialized); - if (TrackNotify) { - UntrackMemory(); - } - PreSerializedDescribeSchemeResult = std::move(serialized); - if (TrackNotify) { - TrackMemory(); - } + notify->SetPathDescription(PathDescription); + if (TrackNotify) { + TrackMemory(); } - - notify->SetDescribeSchemeResult(*PreSerializedDescribeSchemeResult); } notify->Record.SetVersion(GetVersion()); - if (IsFilled() || IsExplicitlyDeleted() || forceStrong) { + + if (!IsEmpty() || IsExplicitlyDeleted() || forceStrong) { notify->Record.SetStrong(true); } @@ -505,15 +486,14 @@ class TReplica: public TMonitorableActor { // data TString Path; TPathId PathId; - TDescribeSchemeResult DescribeSchemeResult; - mutable TMaybe PreSerializedDescribeSchemeResult; + TOpaquePathDescription PathDescription; + bool ExplicitlyDeleted = false; // subscribers THashMap Subscribers; // memory tracking - size_t ResultSize = 0; bool TrackNotify = true; }; // TDescription @@ -541,6 +521,7 @@ class TReplica: public TMonitorableActor { return false; } + // register empty entry by path OR pathId template TDescription& UpsertDescription(const TPath& path) { SBR_LOG_I("Upsert description" @@ -549,6 +530,7 @@ class TReplica: public TMonitorableActor { return Descriptions.Upsert(path, TDescription(this, path)); } + // register empty entry by path AND pathId both TDescription& UpsertDescription(const TString& path, const TPathId& pathId) { SBR_LOG_I("Upsert description" << ": path# " << path @@ -557,25 +539,25 @@ class TReplica: public TMonitorableActor { return Descriptions.Upsert(path, pathId, TDescription(this, path, pathId)); } - template - TDescription& UpsertDescription(const TPath& path, TDescription&& description) { + // upsert description only by pathId + TDescription& UpsertDescription(const TPathId& pathId, TOpaquePathDescription&& pathDescription) { SBR_LOG_I("Upsert description" - << ": path# " << path - << ", desc# " << description.ToLogString()); + << ": pathId# " << pathId + << ", pathDescription# " << pathDescription.ToString() + ); - return Descriptions.Upsert(path, std::move(description)); + return Descriptions.Upsert(pathId, TDescription(this, pathId, std::move(pathDescription))); } - TDescription& UpsertDescription( - const TString& path, - const TPathId& pathId, - TDescribeSchemeResult&& describeSchemeResult - ) { + // upsert description by path AND pathId both + TDescription& UpsertDescription(const TString& path, const TPathId& pathId, TOpaquePathDescription&& pathDescription) { SBR_LOG_I("Upsert description" << ": path# " << path - << ", pathId# " << pathId); + << ", pathId# " << pathId + << ", pathDescription# " << pathDescription.ToString() + ); - return Descriptions.Upsert(path, pathId, TDescription(this, path, pathId, std::move(describeSchemeResult))); + return Descriptions.Upsert(path, pathId, TDescription(this, path, pathId, std::move(pathDescription))); } void SoftDeleteDescription(const TPathId& pathId, bool createIfNotExists = false) { @@ -590,7 +572,7 @@ class TReplica: public TMonitorableActor { return; } - if (!desc->IsFilled()) { + if (desc->IsEmpty()) { return; } @@ -601,7 +583,7 @@ class TReplica: public TMonitorableActor { << ", pathId# " << pathId); if (TDescription* descByPath = Descriptions.FindPtr(path)) { - if (descByPath != desc && descByPath->IsFilled()) { + if (descByPath != desc && !descByPath->IsEmpty()) { if (descByPath->GetPathId().OwnerId != pathId.OwnerId) { auto curPathId = descByPath->GetPathId(); auto curDomainId = descByPath->GetDomainId(); @@ -803,51 +785,55 @@ class TReplica: public TMonitorableActor { void Handle(TSchemeBoardEvents::TEvUpdate::TPtr& ev) { SBR_LOG_D("Handle " << ev->Get()->ToString() << ": sender# " << ev->Sender - << ", cookie# " << ev->Cookie); - - auto& record = *ev->Get()->MutableRecord(); - const ui64 owner = record.GetOwner(); - const ui64 generation = record.GetGeneration(); - - const auto populatorIt = Populators.find(owner); - if (populatorIt == Populators.end()) { - SBR_LOG_E("Reject update from unknown populator" - << ": sender# " << ev->Sender - << ", owner# " << owner - << ", generation# " << generation); - return; - } - if (generation != populatorIt->second.PendingGeneration) { - SBR_LOG_E("Reject update from stale populator" - << ": sender# " << ev->Sender - << ", owner# " << owner - << ", generation# " << generation - << ", pending generation# " << populatorIt->second.PendingGeneration); - return; - } - - if (record.HasDeletedLocalPathIds()) { - const TPathId begin(owner, record.GetDeletedLocalPathIds().GetBegin()); - const TPathId end(owner, record.GetDeletedLocalPathIds().GetEnd()); - SoftDeleteDescriptions(begin, end); - } + << ", cookie# " << ev->Cookie + << ", event size# " << ev->Get()->GetCachedByteSize() + ); + + const TString& path = ev->Get()->GetPath(); + const TPathId& pathId = ev->Get()->GetPathId(); + + { + auto& record = *ev->Get()->MutableRecord(); + const ui64 owner = record.GetOwner(); + const ui64 generation = record.GetGeneration(); + + const auto populatorIt = Populators.find(owner); + if (populatorIt == Populators.end()) { + SBR_LOG_E("Reject update from unknown populator" + << ": sender# " << ev->Sender + << ", owner# " << owner + << ", generation# " << generation); + return; + } + if (generation != populatorIt->second.PendingGeneration) { + SBR_LOG_E("Reject update from stale populator" + << ": sender# " << ev->Sender + << ", owner# " << owner + << ", generation# " << generation + << ", pending generation# " << populatorIt->second.PendingGeneration); + return; + } - if (!record.HasLocalPathId()) { - return AckUpdate(ev); - } + if (record.HasDeletedLocalPathIds()) { + const TPathId begin(owner, record.GetDeletedLocalPathIds().GetBegin()); + const TPathId end(owner, record.GetDeletedLocalPathIds().GetEnd()); + SoftDeleteDescriptions(begin, end); + } - const TString& path = record.GetPath(); - const TPathId pathId = ev->Get()->GetPathId(); + if (!record.HasLocalPathId()) { + return AckUpdate(ev); + } - SBR_LOG_N("Update description" - << ": path# " << path - << ", pathId# " << pathId - << ", deletion# " << (record.GetIsDeletion() ? "true" : "false")); + SBR_LOG_N("Update description" + << ": path# " << path + << ", pathId# " << pathId + << ", deletion# " << (record.GetIsDeletion() ? "true" : "false")); - if (record.GetIsDeletion()) { - SoftDeleteDescription(pathId, true); - return AckUpdate(ev); - } + if (record.GetIsDeletion()) { + SoftDeleteDescription(pathId, true); + return AckUpdate(ev); + } + } if (TDescription* desc = Descriptions.FindPtr(pathId)) { if (desc->IsExplicitlyDeleted()) { @@ -859,20 +845,24 @@ class TReplica: public TMonitorableActor { } } + // TEvUpdate is partially consumed here, with DescribeSchemeResult blob being moved out. + // AckUpdate(ev) calls below are ok, AckUpdate() doesn't use DescribeSchemeResult. + TOpaquePathDescription pathDescription = ev->Get()->ExtractPathDescription(); + TDescription* desc = Descriptions.FindPtr(path); if (!desc) { - UpsertDescription(path, pathId, std::move(*record.MutableDescribeSchemeResult())); + UpsertDescription(path, pathId, std::move(pathDescription)); return AckUpdate(ev); } if (!desc->GetPathId()) { - UpsertDescription(path, pathId, std::move(*record.MutableDescribeSchemeResult())); + UpsertDescription(path, pathId, std::move(pathDescription)); return AckUpdate(ev); } auto curPathId = desc->GetPathId(); - if (curPathId.OwnerId == pathId.OwnerId || !desc->IsFilled()) { + if (curPathId.OwnerId == pathId.OwnerId || desc->IsEmpty()) { if (curPathId > pathId) { return AckUpdate(ev); } @@ -883,15 +873,15 @@ class TReplica: public TMonitorableActor { RelinkSubscribers(desc, path); } - UpsertDescription(path, pathId, std::move(*record.MutableDescribeSchemeResult())); + UpsertDescription(path, pathId, std::move(pathDescription)); return AckUpdate(ev); } - Y_VERIFY_S(desc->IsFilled(), "Description is not filled" + Y_VERIFY_S(!desc->IsEmpty(), "Description is not filled" << ": desc# " << desc->ToLogString()); auto curDomainId = desc->GetDomainId(); - auto domainId = GetDomainId(record.GetDescribeSchemeResult()); + const auto& domainId = pathDescription.SubdomainPathId; auto log = [&](const TString& message) { SBR_LOG_N("" << message @@ -904,36 +894,36 @@ class TReplica: public TMonitorableActor { if (curPathId == domainId) { // Update from TSS, GSS->TSS // it is only because we need to manage undo of upgrade subdomain, finally remove it - auto abandonedSchemeShards = desc->GetAbandonedSchemeShardIds(); + const auto& abandonedSchemeShards = desc->GetAbandonedSchemeShardIds(); if (abandonedSchemeShards.contains(pathId.OwnerId)) { // TSS is ignored, present GSS reverted it log("Replace GSS by TSS description is rejected, GSS implicitly knows that TSS has been reverted" ", but still inject description only by pathId for safe"); - UpsertDescription(pathId, TDescription(this, path, pathId, std::move(*record.MutableDescribeSchemeResult()))); + UpsertDescription(pathId, std::move(pathDescription)); return AckUpdate(ev); } log("Replace GSS by TSS description"); - // unlick GSS desc by path + // unlink GSS desc by path Descriptions.DeleteIndex(path); RelinkSubscribers(desc, path); - UpsertDescription(path, pathId, std::move(*record.MutableDescribeSchemeResult())); + UpsertDescription(path, pathId, std::move(pathDescription)); return AckUpdate(ev); } if (curDomainId == pathId) { // Update from GSS, TSS->GSS // it is only because we need to manage undo of upgrade subdomain, finally remove it - auto abandonedSchemeShards = GetAbandonedSchemeShardIds(record.GetDescribeSchemeResult()); + const auto& abandonedSchemeShards = pathDescription.PathAbandonedTenantsSchemeShards; if (abandonedSchemeShards.contains(curPathId.OwnerId)) { // GSS reverts TSS log("Replace TSS by GSS description, TSS was implicitly reverted by GSS"); - // unlick TSS desc by path + // unlink TSS desc by path Descriptions.DeleteIndex(path); RelinkSubscribers(desc, path); - UpsertDescription(path, pathId, std::move(*record.MutableDescribeSchemeResult())); + UpsertDescription(path, pathId, std::move(pathDescription)); return AckUpdate(ev); } log("Inject description only by pathId, it is update from GSS"); - UpsertDescription(pathId, TDescription(this, path, pathId, std::move(*record.MutableDescribeSchemeResult()))); + UpsertDescription(pathId, std::move(pathDescription)); return AckUpdate(ev); } @@ -950,13 +940,13 @@ class TReplica: public TMonitorableActor { RelinkSubscribers(desc, path); } - UpsertDescription(path, pathId, std::move(*record.MutableDescribeSchemeResult())); + UpsertDescription(path, pathId, std::move(pathDescription)); return AckUpdate(ev); } else if (curDomainId < domainId) { log("Update description by newest path with newer domainId"); Descriptions.DeleteIndex(path); RelinkSubscribers(desc, path); - UpsertDescription(path, pathId, std::move(*record.MutableDescribeSchemeResult())); + UpsertDescription(path, pathId, std::move(pathDescription)); return AckUpdate(ev); } else { log("Totally ignore description, path with obsolete domainId"); @@ -1147,7 +1137,7 @@ class TReplica: public TMonitorableActor { auto it = Subscribers.find(ev->Sender); if (it == Subscribers.end()) { - // for backward compatability + // for backward compatibility ui64 version = 0; if (record.HasPath()) { @@ -1237,11 +1227,7 @@ class TReplica: public TMonitorableActor { TString json; if (desc) { - using namespace google::protobuf::util; - - JsonPrintOptions opts; - opts.preserve_proto_field_names = true; - MessageToJsonString(desc->GetProto(), &json, opts); + json = JsonFromDescribeSchemeResult(desc->GetDescribeSchemeResultSerialized()); } else { json = "{}"; } diff --git a/ydb/core/tx/scheme_board/replica_ut.cpp b/ydb/core/tx/scheme_board/replica_ut.cpp index 44dead06581c..2a91c719ed86 100644 --- a/ydb/core/tx/scheme_board/replica_ut.cpp +++ b/ydb/core/tx/scheme_board/replica_ut.cpp @@ -678,13 +678,11 @@ void TReplicaCombinationTest::UpdatesCombinationsDomainRoot() { UNIT_ASSERT_VALUES_EQUAL(std::get<2>(winId), TPathId(ev->Get()->GetRecord().GetPathOwnerId(), ev->Get()->GetRecord().GetLocalPathId())); UNIT_ASSERT_VALUES_EQUAL(std::get<3>(winId), ev->Get()->GetRecord().GetVersion()); - UNIT_ASSERT(ev->Get()->GetRecord().HasDescribeSchemeResult()); - const NKikimrScheme::TEvDescribeSchemeResult& descr = ev->Get()->GetRecord().GetDescribeSchemeResult(); - auto& domainKey = descr.GetPathDescription().GetDomainDescription().GetDomainKey(); - UNIT_ASSERT_VALUES_EQUAL(std::get<0>(winId), TDomainId(domainKey.GetSchemeShard(), domainKey.GetPathId())); - } - + UNIT_ASSERT(ev->Get()->GetRecord().HasDescribeSchemeResultSerialized()); + UNIT_ASSERT(ev->Get()->GetRecord().HasPathSubdomainPathId()); + UNIT_ASSERT_VALUES_EQUAL(std::get<0>(winId), PathIdFromPathId(ev->Get()->GetRecord().GetPathSubdomainPathId())); + } } } } @@ -731,7 +729,7 @@ void TReplicaCombinationTest::MigratedPathRecreation() { << " DomainId: " << std::get<0>(winId) << " IsDeletion: " << std::get<1>(winId) << " PathId: " << std::get<2>(winId) - << " Verions: " << std::get<3>(winId) + << " Versions: " << std::get<3>(winId) << Endl; UNIT_ASSERT_VALUES_EQUAL("/root/db/dir_inside", ev->Get()->GetRecord().GetPath()); @@ -740,10 +738,10 @@ void TReplicaCombinationTest::MigratedPathRecreation() { UNIT_ASSERT_VALUES_EQUAL(std::get<2>(winId), TPathId(ev->Get()->GetRecord().GetPathOwnerId(), ev->Get()->GetRecord().GetLocalPathId())); UNIT_ASSERT_VALUES_EQUAL(std::get<3>(winId), ev->Get()->GetRecord().GetVersion()); - UNIT_ASSERT(ev->Get()->GetRecord().HasDescribeSchemeResult()); - const NKikimrScheme::TEvDescribeSchemeResult& descr = ev->Get()->GetRecord().GetDescribeSchemeResult(); - auto& domainKey = descr.GetPathDescription().GetDomainDescription().GetDomainKey(); - UNIT_ASSERT_VALUES_EQUAL(std::get<0>(winId), TDomainId(domainKey.GetSchemeShard(), domainKey.GetPathId())); + UNIT_ASSERT(ev->Get()->GetRecord().HasDescribeSchemeResultSerialized()); + UNIT_ASSERT(ev->Get()->GetRecord().HasPathSubdomainPathId()); + + UNIT_ASSERT_VALUES_EQUAL(std::get<0>(winId), PathIdFromPathId(ev->Get()->GetRecord().GetPathSubdomainPathId())); } void TReplicaCombinationTest::UpdatesCombinationsMigratedPath() { @@ -776,9 +774,6 @@ void TReplicaCombinationTest::UpdatesCombinationsMigratedPath() { auto finalSubscriber = Context->AllocateEdgeActor(); auto ev = Context->SubscribeReplica(replica, finalSubscriber, "/Root/Tenant/table_inside"); - const NKikimrScheme::TEvDescribeSchemeResult& descr = ev->Get()->GetRecord().GetDescribeSchemeResult(); - auto& domainKey = descr.GetPathDescription().GetDomainDescription().GetDomainKey(); - Cerr << "=========== Left ==" << argsLeft.GenerateDescribe().ShortDebugString() << "\n=========== Right ==" << argsRight.GenerateDescribe().ShortDebugString() << "\n=========== super id ==" @@ -792,7 +787,7 @@ void TReplicaCombinationTest::UpdatesCombinationsMigratedPath() { << " PathID: " << TPathId(ev->Get()->GetRecord().GetPathOwnerId(), ev->Get()->GetRecord().GetLocalPathId()) << " deleted: " << ev->Get()->GetRecord().GetIsDeletion() << " version: " << ev->Get()->GetRecord().GetVersion() - << " domainId: " << TDomainId(domainKey.GetSchemeShard(), domainKey.GetPathId()) + << " domainId: " << PathIdFromPathId(ev->Get()->GetRecord().GetPathSubdomainPathId()) << Endl; if (argsLeft.PathId == TPathId(gssID, gssLocalId) && !argsLeft.IsDeletion && argsLeft.DomainId == TPathId(gssID, 2) @@ -813,10 +808,10 @@ void TReplicaCombinationTest::UpdatesCombinationsMigratedPath() { UNIT_ASSERT_VALUES_EQUAL(std::get<2>(argsRight.GetSuperId()), TPathId(ev->Get()->GetRecord().GetPathOwnerId(), ev->Get()->GetRecord().GetLocalPathId())); UNIT_ASSERT_VALUES_EQUAL(std::get<3>(argsRight.GetSuperId()), ev->Get()->GetRecord().GetVersion()); - UNIT_ASSERT(ev->Get()->GetRecord().HasDescribeSchemeResult()); - const NKikimrScheme::TEvDescribeSchemeResult& descr = ev->Get()->GetRecord().GetDescribeSchemeResult(); - auto& domainKey = descr.GetPathDescription().GetDomainDescription().GetDomainKey(); - UNIT_ASSERT_VALUES_EQUAL(std::get<0>(argsRight.GetSuperId()), TDomainId(domainKey.GetSchemeShard(), domainKey.GetPathId())); + UNIT_ASSERT(ev->Get()->GetRecord().HasDescribeSchemeResultSerialized()); + UNIT_ASSERT(ev->Get()->GetRecord().HasPathSubdomainPathId()); + + UNIT_ASSERT_VALUES_EQUAL(std::get<0>(argsRight.GetSuperId()), PathIdFromPathId(ev->Get()->GetRecord().GetPathSubdomainPathId())); continue; } @@ -832,10 +827,10 @@ void TReplicaCombinationTest::UpdatesCombinationsMigratedPath() { UNIT_ASSERT_VALUES_EQUAL(std::get<2>(argsLeft.GetSuperId()), TPathId(ev->Get()->GetRecord().GetPathOwnerId(), ev->Get()->GetRecord().GetLocalPathId())); UNIT_ASSERT_VALUES_EQUAL(std::get<3>(argsLeft.GetSuperId()), ev->Get()->GetRecord().GetVersion()); - UNIT_ASSERT(ev->Get()->GetRecord().HasDescribeSchemeResult()); - const NKikimrScheme::TEvDescribeSchemeResult& descr = ev->Get()->GetRecord().GetDescribeSchemeResult(); - auto& domainKey = descr.GetPathDescription().GetDomainDescription().GetDomainKey(); - UNIT_ASSERT_VALUES_EQUAL(std::get<0>(argsLeft.GetSuperId()), TDomainId(domainKey.GetSchemeShard(), domainKey.GetPathId())); + UNIT_ASSERT(ev->Get()->GetRecord().HasDescribeSchemeResultSerialized()); + UNIT_ASSERT(ev->Get()->GetRecord().HasPathSubdomainPathId()); + + UNIT_ASSERT_VALUES_EQUAL(std::get<0>(argsLeft.GetSuperId()), PathIdFromPathId(ev->Get()->GetRecord().GetPathSubdomainPathId())); continue; } @@ -882,10 +877,10 @@ void TReplicaCombinationTest::UpdatesCombinationsMigratedPath() { UNIT_ASSERT_VALUES_EQUAL(std::get<2>(winId), TPathId(ev->Get()->GetRecord().GetPathOwnerId(), ev->Get()->GetRecord().GetLocalPathId())); UNIT_ASSERT_VALUES_EQUAL(std::get<3>(winId), ev->Get()->GetRecord().GetVersion()); - UNIT_ASSERT(ev->Get()->GetRecord().HasDescribeSchemeResult()); - const NKikimrScheme::TEvDescribeSchemeResult& descr = ev->Get()->GetRecord().GetDescribeSchemeResult(); - auto& domainKey = descr.GetPathDescription().GetDomainDescription().GetDomainKey(); - UNIT_ASSERT_VALUES_EQUAL(std::get<0>(winId), TDomainId(domainKey.GetSchemeShard(), domainKey.GetPathId())); + UNIT_ASSERT(ev->Get()->GetRecord().HasDescribeSchemeResultSerialized()); + UNIT_ASSERT(ev->Get()->GetRecord().HasPathSubdomainPathId()); + + UNIT_ASSERT_VALUES_EQUAL(std::get<0>(winId), PathIdFromPathId(ev->Get()->GetRecord().GetPathSubdomainPathId())); } } } diff --git a/ydb/core/tx/scheme_board/subscriber.cpp b/ydb/core/tx/scheme_board/subscriber.cpp index 76264b385a60..4fdeb8479ecc 100644 --- a/ydb/core/tx/scheme_board/subscriber.cpp +++ b/ydb/core/tx/scheme_board/subscriber.cpp @@ -127,6 +127,67 @@ namespace { } }; + // TNotifyResponse isolates changes of how NKikimrSchemeBoard::TEvNotify is filled + // by previous and recent replica implementation. + // + // TNotifyResponse wouldn't be even needed if not for backward compatibility support. + // Consider removing compatibility support at version stable-25-1. + struct TNotifyResponse { + NKikimrSchemeBoard::TEvNotify Notify; + TPathId SubdomainPathId; + TSet PathAbandonedTenantsSchemeShards; + TMaybe DescribeSchemeResult; + + static TNotifyResponse FromNotify(NKikimrSchemeBoard::TEvNotify&& record) { + // PathSubdomainPathId's absence is a marker that input message was sent + // from the older replica implementation + + if (record.HasPathSubdomainPathId()) { + // Sender implementation is as recent as ours. + // Just copy two fields from the notify message (this branch is practically a stub) + + auto subdomainPathId = PathIdFromPathId(record.GetPathSubdomainPathId()); + auto pathAbandonedTenantsSchemeShards = TSet( + record.GetPathAbandonedTenantsSchemeShards().begin(), + record.GetPathAbandonedTenantsSchemeShards().end() + ); + return TNotifyResponse{ + .Notify = std::move(record), + .SubdomainPathId = std::move(subdomainPathId), + .PathAbandonedTenantsSchemeShards = std::move(pathAbandonedTenantsSchemeShards), + }; + + } else { + // Sender implementation is older then ours. + // Extract two essential fields from the payload, hold deserialized proto, + // drop original payload to save on memory + + // Move DescribeSchemeResult blob out of the input message. + auto data = std::move(*record.MutableDescribeSchemeResultSerialized()); + record.ClearDescribeSchemeResultSerialized(); + + // it's inconvenient to use arena here + auto proto = DeserializeDescribeSchemeResult(data); + + return TNotifyResponse{ + .Notify = std::move(record), + .SubdomainPathId = NSchemeBoard::GetDomainId(proto), + .PathAbandonedTenantsSchemeShards = NSchemeBoard::GetAbandonedSchemeShardIds(proto), + .DescribeSchemeResult = std::move(proto), + }; + } + } + + NKikimrScheme::TEvDescribeSchemeResult GetDescribeSchemeResult() { + if (DescribeSchemeResult) { + return *DescribeSchemeResult; + } else { + // it's inconvenient to use arena here + return DeserializeDescribeSchemeResult(Notify.GetDescribeSchemeResultSerialized()); + } + } + }; + struct TState { bool Deleted = false; bool Strong = false; @@ -154,15 +215,17 @@ namespace { } public: - static TState FromNotify(const NKikimrSchemeBoard::TEvNotify& record) { + static TState FromNotify(const TNotifyResponse& notifyResponse) { + const auto& record = notifyResponse.Notify; + const TPathVersion& pathVersion = TPathVersion::FromNotify(record); if (!record.GetIsDeletion()) { return TState( - TPathVersion::FromNotify(record), - GetDomainId(record.GetDescribeSchemeResult()), - GetAbandonedSchemeShardIds(record.GetDescribeSchemeResult()) + pathVersion, + notifyResponse.SubdomainPathId, + notifyResponse.PathAbandonedTenantsSchemeShards ); } else { - return TState(record.GetStrong(), TPathVersion::FromNotify(record)); + return TState(record.GetStrong(), pathVersion); } } @@ -229,7 +292,7 @@ namespace { if (Version.PathId == other.DomainId) { // Update from TSS, GSS->TSS if (AbandonedSchemeShards.contains(other.Version.PathId.OwnerId)) { // TSS is ignored, present GSS reverted that TSS - reason = "Update was ignored, GSS implisytly banned that TSS"; + reason = "Update was ignored, GSS implicitly banned that TSS"; return false; } @@ -685,7 +748,7 @@ class TSubscriber: public TMonitorableActor { return it->second; } - NKikimrSchemeBoard::TEvNotify& SelectResponse() { + TNotifyResponse* SelectResponse() { Y_ABORT_UNLESS(IsMajorityReached()); auto newest = SelectStateImpl(); @@ -694,7 +757,7 @@ class TSubscriber: public TMonitorableActor { auto it = InitialResponses.find(newest->first); Y_ABORT_UNLESS(it != InitialResponses.end()); - return it->second; + return &it->second; } bool IsMajorityReached() const { @@ -723,23 +786,25 @@ class TSubscriber: public TMonitorableActor { } void Handle(TSchemeBoardEvents::TEvNotify::TPtr& ev) { - auto& record = *ev->Get()->MutableRecord(); - SBS_LOG_D("Handle " << ev->Get()->ToString() << ": sender# " << ev->Sender); - if (!IsValidNotification(Path, record)) { + if (!IsValidNotification(Path, ev->Get()->GetRecord())) { SBS_LOG_E("Suspicious " << ev->Get()->ToString() << ": sender# " << ev->Sender); return; } - States[ev->Sender] = TState::FromNotify(record); + // TEvNotify message is consumed here, can't be used after this point + TNotifyResponse notifyResponse = TNotifyResponse::FromNotify(std::move(*ev->Get()->MutableRecord())); + TNotifyResponse* selectedNotify = ¬ifyResponse; + + States[ev->Sender] = TState::FromNotify(notifyResponse); if (!IsMajorityReached()) { - InitialResponses[ev->Sender] = std::move(record); + InitialResponses[ev->Sender] = std::move(notifyResponse); if (IsMajorityReached()) { MaybeRunVersionSync(); - record = SelectResponse(); + selectedNotify = SelectResponse(); } else { return; } @@ -773,8 +838,11 @@ class TSubscriber: public TMonitorableActor { return; } + const auto& record = selectedNotify->Notify; + if (!record.GetIsDeletion()) { - this->Send(Owner, BuildNotify(record, std::move(*record.MutableDescribeSchemeResult()))); + NKikimrScheme::TEvDescribeSchemeResult proto = selectedNotify->GetDescribeSchemeResult(); + this->Send(Owner, BuildNotify(record, std::move(proto))); } else { this->Send(Owner, BuildNotify(record, record.GetStrong())); } @@ -1032,7 +1100,7 @@ class TSubscriber: public TMonitorableActor { TSet Proxies; TMap States; - TMap InitialResponses; + TMap InitialResponses; TMaybe State; ui64 DelayedSyncRequest; diff --git a/ydb/core/tx/scheme_board/subscriber_ut.cpp b/ydb/core/tx/scheme_board/subscriber_ut.cpp index 4a33a9f5ab00..ffaaf856ebd4 100644 --- a/ydb/core/tx/scheme_board/subscriber_ut.cpp +++ b/ydb/core/tx/scheme_board/subscriber_ut.cpp @@ -152,7 +152,7 @@ void TSubscriberTest::InvalidNotification() { // send notification directly to subscriber auto* notify = new TSchemeBoardEvents::TEvNotifyBuilder(TPathId(1, 1)); - notify->Record.MutableDescribeSchemeResult()->CopyFrom(GenerateDescribe("another/path", TPathId(1, 1))); + notify->SetPathDescription(MakeOpaquePathDescription("", GenerateDescribe("another/path", TPathId(1, 1)))); Context->Send(subscriber, edge, notify); size_t counter = Context->CountEdgeEvents(); diff --git a/ydb/core/tx/scheme_board/ut_helpers.cpp b/ydb/core/tx/scheme_board/ut_helpers.cpp index 762d8ddea12f..63bdd22c7174 100644 --- a/ydb/core/tx/scheme_board/ut_helpers.cpp +++ b/ydb/core/tx/scheme_board/ut_helpers.cpp @@ -31,10 +31,11 @@ TSchemeBoardEvents::TEvUpdate* GenerateUpdate( ui64 generation, bool isDeletion ) { - auto* update = new TSchemeBoardEvents::TEvUpdateBuilder(owner, generation, describe, isDeletion); + const auto& pathDescription = MakeOpaquePathDescription("", describe); + auto* update = new TSchemeBoardEvents::TEvUpdateBuilder(owner, generation, pathDescription, isDeletion); if (!isDeletion) { - update->SetDescribeSchemeResult(describe); + update->SetDescribeSchemeResultSerialized(std::move(pathDescription.DescribeSchemeResultSerialized)); } return update; diff --git a/ydb/core/tx/scheme_board/ya.make b/ydb/core/tx/scheme_board/ya.make index a04c3b5c32bd..22f66c217f09 100644 --- a/ydb/core/tx/scheme_board/ya.make +++ b/ydb/core/tx/scheme_board/ya.make @@ -13,6 +13,7 @@ PEERDIR( SRCS( cache.cpp + events.cpp helpers.cpp load_test.cpp monitoring.cpp @@ -20,6 +21,7 @@ SRCS( replica.cpp subscriber.cpp two_part_description.cpp + opaque_path_description.cpp ) GENERATE_ENUM_SERIALIZATION(subscriber.h) diff --git a/ydb/core/tx/schemeshard/schemeshard.h b/ydb/core/tx/schemeshard/schemeshard.h index d86d17ffe9ad..f8aeb16ea5bf 100644 --- a/ydb/core/tx/schemeshard/schemeshard.h +++ b/ydb/core/tx/schemeshard/schemeshard.h @@ -331,10 +331,9 @@ struct TEvSchemeShard { EvDescribeSchemeResult> { TEvDescribeSchemeResult() = default; - TEvDescribeSchemeResult(const TString& path, ui64 pathOwner, TPathId pathId) + TEvDescribeSchemeResult(const TString& path, TPathId pathId) { Record.SetPath(path); - Record.SetPathOwner(pathOwner); Record.SetPathId(pathId.LocalPathId); Record.SetPathOwnerId(pathId.OwnerId); } @@ -345,8 +344,8 @@ struct TEvSchemeShard { TEvDescribeSchemeResultBuilder() = default; - TEvDescribeSchemeResultBuilder(const TString& path, ui64 pathOwner, TPathId pathId) - : TEvDescribeSchemeResult(path, pathOwner, pathId) + TEvDescribeSchemeResultBuilder(const TString& path, TPathId pathId) + : TEvDescribeSchemeResult(path, pathId) { } }; diff --git a/ydb/core/tx/schemeshard/schemeshard__init_populator.cpp b/ydb/core/tx/schemeshard/schemeshard__init_populator.cpp index aeda8d0aa0cf..9824caa2f528 100644 --- a/ydb/core/tx/schemeshard/schemeshard__init_populator.cpp +++ b/ydb/core/tx/schemeshard/schemeshard__init_populator.cpp @@ -13,7 +13,7 @@ using namespace NTabletFlatExecutor; struct TSchemeShard::TTxInitPopulator : public TTransactionBase { using TDescription = NSchemeBoard::TTwoPartDescription; - TMap Descriptions; + std::vector> Descriptions; TSideEffects::TPublications DelayedPublications; explicit TTxInitPopulator(TSelf *self, TSideEffects::TPublications&& publications) @@ -49,7 +49,7 @@ struct TSchemeShard::TTxInitPopulator : public TTransactionBase { auto result = DescribePath(Self, ctx, pathId); TDescription description(std::move(result->PreSerializedData), std::move(result->Record)); - Descriptions.emplace(pathId, std::move(description)); + Descriptions.emplace_back(pathId, std::move(description)); } return true; diff --git a/ydb/core/tx/schemeshard/schemeshard_path_describer.cpp b/ydb/core/tx/schemeshard/schemeshard_path_describer.cpp index 943844615294..234706bba62c 100644 --- a/ydb/core/tx/schemeshard/schemeshard_path_describer.cpp +++ b/ydb/core/tx/schemeshard/schemeshard_path_describer.cpp @@ -944,11 +944,7 @@ THolder TPathDescriber::Describe pathStr = path.PathString(); } - Result.Reset(new TEvSchemeShard::TEvDescribeSchemeResultBuilder( - pathStr, - Self->TabletID(), - pathId - )); + Result.Reset(new TEvSchemeShard::TEvDescribeSchemeResultBuilder(pathStr, pathId)); Result->Record.SetStatus(checks.GetStatus()); Result->Record.SetReason(checks.GetError()); @@ -963,7 +959,7 @@ THolder TPathDescriber::Describe } } - Result = MakeHolder(pathStr, Self->TabletID(), pathId); + Result = MakeHolder(pathStr, pathId); auto descr = Result->Record.MutablePathDescription()->MutableSelf(); FillPathDescr(descr, path); diff --git a/ydb/core/tx/tx_proxy/describe.cpp b/ydb/core/tx/tx_proxy/describe.cpp index aed5e9c91d8c..980cebb18c8c 100644 --- a/ydb/core/tx/tx_proxy/describe.cpp +++ b/ydb/core/tx/tx_proxy/describe.cpp @@ -83,7 +83,7 @@ class TDescribeReq : public TActor { auto schemeShardId = entry.DomainInfo->DomainKey.OwnerId; auto result = MakeHolder( - path, schemeShardId, TPathId()); + path, TPathId()); auto* pathDescription = result->Record.MutablePathDescription(); auto* self = pathDescription->MutableSelf(); @@ -151,7 +151,7 @@ class TDescribeReq : public TActor { auto schemeShardId = entry.DomainInfo->DomainKey.OwnerId; auto result = MakeHolder( - path, schemeShardId, TPathId()); + path, TPathId()); auto* pathDescription = result->Record.MutablePathDescription(); auto* self = pathDescription->MutableSelf(); @@ -237,7 +237,7 @@ void TDescribeReq::Handle(TEvTxProxyReq::TEvNavigateScheme::TPtr &ev, const TAct if (record.GetDescribePath().GetPath() == "/") { // Special handling for enumerating roots TAutoPtr result = - new NSchemeShard::TEvSchemeShard::TEvDescribeSchemeResultBuilder("/", NSchemeShard::RootSchemeShardId, TPathId(NSchemeShard::RootSchemeShardId, NSchemeShard::RootPathId)); + new NSchemeShard::TEvSchemeShard::TEvDescribeSchemeResultBuilder("/", TPathId(NSchemeShard::RootSchemeShardId, NSchemeShard::RootPathId)); auto descr = result->Record.MutablePathDescription(); FillRootDescr(descr->MutableSelf(), "/", NSchemeShard::RootSchemeShardId); for (const auto& domain : domainsInfo->Domains) { diff --git a/ydb/core/viewer/json_describe.h b/ydb/core/viewer/json_describe.h index 709a7e62d2f6..8d4958295c5a 100644 --- a/ydb/core/viewer/json_describe.h +++ b/ydb/core/viewer/json_describe.h @@ -187,7 +187,6 @@ class TJsonDescribe : public TViewerPipeClient { result->SetReason(record.GetReason()); result->SetPath(record.GetPath()); result->MutablePathDescription()->CopyFrom(record.GetPathDescription()); - result->SetPathOwner(record.GetPathOwner()); result->SetPathId(record.GetPathId()); result->SetLastExistedPrefixPath(record.GetLastExistedPrefixPath()); result->SetLastExistedPrefixPathId(record.GetLastExistedPrefixPathId()); @@ -206,7 +205,6 @@ class TJsonDescribe : public TViewerPipeClient { TAutoPtr result(new NKikimrViewer::TEvDescribeSchemeInfo()); result->SetPath(path); - result->SetPathOwner(schemeShardId); result->SetPathId(pathId.LocalPathId); result->SetPathOwnerId(pathId.OwnerId); diff --git a/ydb/core/viewer/protos/viewer.proto b/ydb/core/viewer/protos/viewer.proto index 62218dde8ac5..61d0bc3ce413 100644 --- a/ydb/core/viewer/protos/viewer.proto +++ b/ydb/core/viewer/protos/viewer.proto @@ -561,7 +561,7 @@ message TEvDescribeSchemeInfo { optional string Reason = 2; optional string Path = 3; optional NKikimrSchemeOp.TPathDescription PathDescription = 4; - optional fixed64 PathOwner = 5; + optional fixed64 DEPRECATED_PathOwner = 5; // replaced by PathOwnerId optional fixed64 PathId = 6; optional string LastExistedPrefixPath = 7; From 5635e2b3861415a967ee84538225501ef7decfd4 Mon Sep 17 00:00:00 2001 From: Alexander Petrukhin Date: Tue, 5 Mar 2024 21:14:15 +0300 Subject: [PATCH 056/117] [cms] add start_time in public cms maintenance api (#2452) (#2472) --- ydb/core/cms/api_adapters.cpp | 1 + ydb/core/cms/cms.cpp | 1 + ydb/core/protos/cms.proto | 1 + ydb/public/api/protos/draft/ydb_maintenance.proto | 2 ++ 4 files changed, 5 insertions(+) diff --git a/ydb/core/cms/api_adapters.cpp b/ydb/core/cms/api_adapters.cpp index 4ec7c2c7c11b..18fe27185554 100644 --- a/ydb/core/cms/api_adapters.cpp +++ b/ydb/core/cms/api_adapters.cpp @@ -163,6 +163,7 @@ class TListClusterNodes: public TAdapterActor< out.set_host(in.Host); out.set_port(in.IcPort); out.set_state(ConvertNodeState(in.State)); + *out.mutable_start_time() = TimeUtil::MicrosecondsToTimestamp(in.StartTime.GetValue()); auto& location = *out.mutable_location(); location.set_data_center(in.Location.GetDataCenterId()); diff --git a/ydb/core/cms/cms.cpp b/ydb/core/cms/cms.cpp index 12f543aa5cc8..6e3335b45695 100644 --- a/ydb/core/cms/cms.cpp +++ b/ydb/core/cms/cms.cpp @@ -1160,6 +1160,7 @@ void TCms::AddHostState(const TClusterInfoPtr &clusterInfo, const TNodeInfo &nod host->SetNodeId(node.NodeId); host->SetInterconnectPort(node.IcPort); host->SetTimestamp(timestamp.GetValue()); + host->SetStartTimeSeconds(node.StartTime.Seconds()); node.Location.Serialize(host->MutableLocation(), false); for (auto marker : node.Markers) { host->AddMarkers(marker); diff --git a/ydb/core/protos/cms.proto b/ydb/core/protos/cms.proto index e8d9160f3332..680a5b72accf 100644 --- a/ydb/core/protos/cms.proto +++ b/ydb/core/protos/cms.proto @@ -77,6 +77,7 @@ message THostState { optional uint32 InterconnectPort = 7; repeated EMarker Markers = 8; optional NActorsInterconnect.TNodeLocation Location = 9; + optional uint32 StartTimeSeconds = 10; } message TClusterState { diff --git a/ydb/public/api/protos/draft/ydb_maintenance.proto b/ydb/public/api/protos/draft/ydb_maintenance.proto index 904fdc2ed331..8dc461221314 100644 --- a/ydb/public/api/protos/draft/ydb_maintenance.proto +++ b/ydb/public/api/protos/draft/ydb_maintenance.proto @@ -41,6 +41,8 @@ message Node { StorageNode storage = 6; DynamicNode dynamic = 7; } + // start_time defines time when node was registered in cms. + google.protobuf.Timestamp start_time = 8; } message ListClusterNodesRequest { From 0378eff1b6d21a559496c09f16b28f2f3dd22a9b Mon Sep 17 00:00:00 2001 From: Daniil Demin Date: Wed, 6 Mar 2024 16:23:51 +0300 Subject: [PATCH 057/117] Invalidate query compilation cache entries with outdated VIEWs (#1960) (#2479) KIKIMR-21002 In this PR we add the following algorithm for invalidating cache entries for outdated VIEWs: 1. Store path ids and schema versions of the views that were used in the query in the cache entries, so they can be accessed later. 2. Whenever we retrieve a compilation result from cache, send a request for SchemeCache to check if the schema version of the views used in this query (if any) has not changed since we compiled this query. 3. Send a recompilation request if any view is outdated. There are two important things to note about this solution: - We make a SchemeCache request for each repeated query and there is a lot of these in an OLTP-focused database like YDB. However, we have already been sending these request for preliminary (this is not the last check of schema version mismatch (at least for tables)) cache invalidation for tables, so views should not incur an additional performance impact here. - This solution does not guarantee strong consistency for queries using views, because query cache invalidation will not happen instantly after the view definition is updated. The node should get an update from the SchemeCache, which takes some time. --- .../kqp/provider/yql_kikimr_datasource.cpp | 12 +++ .../kqp/session_actor/kqp_query_state.cpp | 11 +++ ydb/core/kqp/session_actor/kqp_query_state.h | 2 + ydb/core/kqp/ut/view/view_ut.cpp | 82 ++++++++++++++++++- ydb/core/protos/kqp_physical.proto | 2 + 5 files changed, 107 insertions(+), 2 deletions(-) diff --git a/ydb/core/kqp/provider/yql_kikimr_datasource.cpp b/ydb/core/kqp/provider/yql_kikimr_datasource.cpp index 4e45f0a21853..af95adf40d5a 100644 --- a/ydb/core/kqp/provider/yql_kikimr_datasource.cpp +++ b/ydb/core/kqp/provider/yql_kikimr_datasource.cpp @@ -351,6 +351,18 @@ class TKiSourceLoadTableMetadataTransformer : public TGraphTransformerBase { if (!AddCluster(table, res, input, ctx)) { return TStatus::Error; } + + if (const auto& preparingQuery = SessionCtx->Query().PreparingQuery; + preparingQuery + && res.Metadata->Kind == EKikimrTableKind::View + ) { + const auto& viewMetadata = *res.Metadata; + auto* viewInfo = preparingQuery->MutablePhysicalQuery()->MutableViewInfos()->Add(); + auto* pathId = viewInfo->MutableTableId(); + pathId->SetOwnerId(viewMetadata.PathId.OwnerId()); + pathId->SetTableId(viewMetadata.PathId.TableId()); + viewInfo->SetSchemaVersion(viewMetadata.SchemaVersion); + } } else { TIssueScopeGuard issueScope(ctx.IssueManager, [input, &table, &ctx]() { return MakeIntrusive(TIssue(ctx.GetPosition(input->Pos()), TStringBuilder() diff --git a/ydb/core/kqp/session_actor/kqp_query_state.cpp b/ydb/core/kqp/session_actor/kqp_query_state.cpp index 7ea7dfa77bfe..eebe3c33a468 100644 --- a/ydb/core/kqp/session_actor/kqp_query_state.cpp +++ b/ydb/core/kqp/session_actor/kqp_query_state.cpp @@ -71,6 +71,16 @@ bool TKqpQueryState::EnsureTableVersions(const TEvTxProxySchemeCache::TEvNavigat return true; } +void TKqpQueryState::FillViews(const google::protobuf::RepeatedPtrField< ::NKqpProto::TKqpTableInfo>& views) { + for (const auto& view : views) { + const auto& pathId = view.GetTableId(); + const auto schemaVersion = view.GetSchemaVersion(); + auto [it, isInserted] = TableVersions.emplace(TTableId(pathId.GetOwnerId(), pathId.GetTableId()), schemaVersion); + if (!isInserted) { + Y_ENSURE(it->second == schemaVersion); + } + } +} std::unique_ptr TKqpQueryState::BuildNavigateKeySet() { TableVersions.clear(); @@ -78,6 +88,7 @@ std::unique_ptr TKqpQueryState::BuildN for (const auto& tx : PreparedQuery->GetPhysicalQuery().GetTransactions()) { FillTables(tx); } + FillViews(PreparedQuery->GetPhysicalQuery().GetViewInfos()); auto navigate = MakeHolder(); navigate->DatabaseName = Database; diff --git a/ydb/core/kqp/session_actor/kqp_query_state.h b/ydb/core/kqp/session_actor/kqp_query_state.h index 7766ddd70116..48f32a7342a2 100644 --- a/ydb/core/kqp/session_actor/kqp_query_state.h +++ b/ydb/core/kqp/session_actor/kqp_query_state.h @@ -234,6 +234,8 @@ class TKqpQueryState : public TNonCopyable { } } + void FillViews(const google::protobuf::RepeatedPtrField< ::NKqpProto::TKqpTableInfo>& views); + bool NeedCheckTableVersions() const { return CompileStats.FromCache; } diff --git a/ydb/core/kqp/ut/view/view_ut.cpp b/ydb/core/kqp/ut/view/view_ut.cpp index fed6b336e75b..cfd6adf5c654 100644 --- a/ydb/core/kqp/ut/view/view_ut.cpp +++ b/ydb/core/kqp/ut/view/view_ut.cpp @@ -1,6 +1,7 @@ #include #include #include +#include #include @@ -8,6 +9,7 @@ using namespace NKikimr; using namespace NKikimr::NKqp; +using namespace NYdb; using namespace NYdb::NTable; namespace { @@ -60,10 +62,14 @@ void ExecuteDataDefinitionQuery(TSession& session, const TString& script) { << script << "\nThe issues:\n" << result.GetIssues().ToString()); } -TDataQueryResult ExecuteDataModificationQuery(TSession& session, const TString& script) { +TDataQueryResult ExecuteDataModificationQuery(TSession& session, + const TString& script, + const TExecDataQuerySettings& settings = {} +) { const auto result = session.ExecuteDataQuery( script, - TTxControl::BeginTx(TTxSettings::SerializableRW()).CommitTx() + TTxControl::BeginTx(TTxSettings::SerializableRW()).CommitTx(), + settings ).ExtractValueSync(); UNIT_ASSERT_C(result.IsSuccess(), "Failed to execute the following DML script:\n" << script << "\nThe issues:\n" << result.GetIssues().ToString()); @@ -71,6 +77,31 @@ TDataQueryResult ExecuteDataModificationQuery(TSession& session, const TString& return result; } +TValue GetSingleResult(const TDataQueryResult& rawResults) { + auto resultSetParser = rawResults.GetResultSetParser(0); + UNIT_ASSERT(resultSetParser.TryNextRow()); + return resultSetParser.GetValue(0); +} + +int GetInteger(const TValue& value) { + return TValueParser(value).GetInt32(); +} + +TMaybe GetFromCacheStat(const TQueryStats& stats) { + const auto& proto = TProtoAccessor::GetProto(stats); + if (!proto.Hascompilation()) { + return Nothing(); + } + return proto.Getcompilation().Getfrom_cache(); +} + +void AssertFromCache(const TMaybe& stats, bool expectedValue) { + UNIT_ASSERT(stats.Defined()); + const auto isFromCache = GetFromCacheStat(*stats); + UNIT_ASSERT_C(isFromCache.Defined(), stats->ToString()); + UNIT_ASSERT_VALUES_EQUAL_C(*isFromCache, expectedValue, stats->ToString()); +} + void CompareResults(const TDataQueryResult& first, const TDataQueryResult& second) { const auto& firstResults = first.GetResultSets(); const auto& secondResults = second.GetResultSets(); @@ -376,4 +407,51 @@ Y_UNIT_TEST_SUITE(TSelectFromViewTest) { ExecuteDataDefinitionQuery(session, ReadWholeFile(pathPrefix + "drop_view.sql")); } } + + Y_UNIT_TEST(QueryCacheIsUpdated) { + TKikimrRunner kikimr(TKikimrSettings().SetWithSampleTables(false)); + EnableViewsFeatureFlag(kikimr); + auto session = kikimr.GetTableClient().CreateSession().GetValueSync().GetSession(); + + constexpr const char* viewName = "TheView"; + + const auto getCreationQuery = [&viewName](const char* innerQuery) -> TString { + return std::format(R"( + CREATE VIEW {} WITH (security_invoker = TRUE) AS {}; + )", + viewName, + innerQuery + ); + }; + constexpr const char* firstInnerQuery = "SELECT 1"; + ExecuteDataDefinitionQuery(session, getCreationQuery(firstInnerQuery)); + + const TString selectFromViewQuery = std::format(R"( + SELECT * FROM {}; + )", + viewName + ); + TExecDataQuerySettings queryExecutionSettings; + queryExecutionSettings.KeepInQueryCache(true); + queryExecutionSettings.CollectQueryStats(ECollectQueryStatsMode::Basic); + ExecuteDataModificationQuery(session, selectFromViewQuery, queryExecutionSettings); + // make sure the server side cache is working by calling the same query twice + const auto cachedQueryRawResult = ExecuteDataModificationQuery(session, selectFromViewQuery, queryExecutionSettings); + AssertFromCache(cachedQueryRawResult.GetStats(), true); + UNIT_ASSERT_VALUES_EQUAL(GetInteger(GetSingleResult(cachedQueryRawResult)), 1); + + // recreate the view with a different query inside + ExecuteDataDefinitionQuery(session, std::format(R"( + DROP VIEW {}; + )", + viewName + ) + ); + constexpr const char* secondInnerQuery = "SELECT 2"; + ExecuteDataDefinitionQuery(session, getCreationQuery(secondInnerQuery)); + + const auto secondCallRawResult = ExecuteDataModificationQuery(session, selectFromViewQuery, queryExecutionSettings); + AssertFromCache(secondCallRawResult.GetStats(), false); + UNIT_ASSERT_VALUES_EQUAL(GetInteger(GetSingleResult(secondCallRawResult)), 2); + } } diff --git a/ydb/core/protos/kqp_physical.proto b/ydb/core/protos/kqp_physical.proto index 9ee7b069ed04..98351bfe1f1e 100644 --- a/ydb/core/protos/kqp_physical.proto +++ b/ydb/core/protos/kqp_physical.proto @@ -507,4 +507,6 @@ message TKqpPhyQuery { bool HasUncommittedChangesRead = 9; string QueryDiagnostics = 10; + + repeated TKqpTableInfo ViewInfos = 11; } From 4192b14ebd7f919b89ee5f1df247fd80dd6bdc2c Mon Sep 17 00:00:00 2001 From: Alexander Petrukhin Date: Thu, 7 Mar 2024 12:03:00 +0300 Subject: [PATCH 058/117] =?UTF-8?q?[ratelimiter]=20fix=20not=5Fallowed=20m?= =?UTF-8?q?essage=20if=20no=20admins=20on=20cluster=20in=20conf=E2=80=A6?= =?UTF-8?q?=20(#2540)?= MIME-Version: 1.0 Content-Type: text/plain; charset=UTF-8 Content-Transfer-Encoding: 8bit --- ydb/core/grpc_services/rpc_rate_limiter_api.cpp | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/ydb/core/grpc_services/rpc_rate_limiter_api.cpp b/ydb/core/grpc_services/rpc_rate_limiter_api.cpp index c7ab9a8d3121..288527ae1e95 100644 --- a/ydb/core/grpc_services/rpc_rate_limiter_api.cpp +++ b/ydb/core/grpc_services/rpc_rate_limiter_api.cpp @@ -67,7 +67,7 @@ class TRateLimiterRequest : public TRpcOperationRequestActor if (resource.has_metering_config()) { auto self = static_cast(this); const auto& userTokenStr = self->Request_->GetSerializedToken(); - bool allowed = false; + bool allowed = AppData()->AdministrationAllowedSIDs.empty(); if (userTokenStr) { NACLib::TUserToken userToken(userTokenStr); for (auto &sid : AppData()->AdministrationAllowedSIDs) { From c206738ec8a833e60504273b6df0f909160bdb26 Mon Sep 17 00:00:00 2001 From: Nikolay Shestakov Date: Thu, 7 Mar 2024 17:22:26 +0500 Subject: [PATCH 059/117] Fix Verify in pqv0 (#2552) --- ydb/services/deprecated/persqueue_v0/grpc_pq_write_actor.cpp | 4 +++- 1 file changed, 3 insertions(+), 1 deletion(-) diff --git a/ydb/services/deprecated/persqueue_v0/grpc_pq_write_actor.cpp b/ydb/services/deprecated/persqueue_v0/grpc_pq_write_actor.cpp index 0b7b645c8b4d..e29b4bc4f304 100644 --- a/ydb/services/deprecated/persqueue_v0/grpc_pq_write_actor.cpp +++ b/ydb/services/deprecated/persqueue_v0/grpc_pq_write_actor.cpp @@ -864,7 +864,9 @@ void TWriteSessionActor::LogSession(const TActorContext& ctx) { } void TWriteSessionActor::HandleWakeup(const TActorContext& ctx) { - Y_ABORT_UNLESS(State == ES_INITED); + if (State != ES_INITED) { + return; + } auto now = ctx.Now(); From 52d299a4eb8b6c2f630bd91dc116fc1baabb9118 Mon Sep 17 00:00:00 2001 From: spuchin Date: Thu, 7 Mar 2024 22:26:46 +0300 Subject: [PATCH 060/117] Enable feature flags for QueryService. (#2560) --- ydb/core/protos/feature_flags.proto | 2 +- ydb/core/protos/table_service_config.proto | 2 +- 2 files changed, 2 insertions(+), 2 deletions(-) diff --git a/ydb/core/protos/feature_flags.proto b/ydb/core/protos/feature_flags.proto index 5035f3b0f897..30c770825054 100644 --- a/ydb/core/protos/feature_flags.proto +++ b/ydb/core/protos/feature_flags.proto @@ -104,7 +104,7 @@ message TFeatureFlags { optional bool EnableTopicDiskSubDomainQuota = 89 [default = true]; optional bool EnableSeparationComputeActorsFromRead = 90 [default = false]; optional bool EnablePQConfigTransactionsAtSchemeShard = 91 [default = false]; - optional bool EnableScriptExecutionOperations = 92 [default = false]; + optional bool EnableScriptExecutionOperations = 92 [default = true]; optional bool EnableImplicitQueryParameterTypes = 93 [default = false]; optional bool EnableForceImmediateEffectsExecution = 94 [default = false]; optional bool EnableTopicSplitMerge = 95 [default = false]; diff --git a/ydb/core/protos/table_service_config.proto b/ydb/core/protos/table_service_config.proto index 8653d314d56a..1bb2f32f8ef3 100644 --- a/ydb/core/protos/table_service_config.proto +++ b/ydb/core/protos/table_service_config.proto @@ -234,7 +234,7 @@ message TTableServiceConfig { optional bool EnablePredicateExtractForDataQueries = 37 [default = true]; optional bool EnableKqpImmediateEffects = 38 [default = true]; optional bool EnableSequentialReads = 39 [default = true]; - optional bool EnablePreparedDdl = 42 [default = false]; + optional bool EnablePreparedDdl = 42 [default = true]; optional bool EnableSequences = 43 [default = false]; optional bool EnableAsyncComputationPatternCompilation = 48 [default = true]; optional TCompileComputationPatternServiceConfig CompileComputationPatternServiceConfig = 47; From 7444062926c57835a2f629480cc270d02a10f1b3 Mon Sep 17 00:00:00 2001 From: Vitalii Gridnev Date: Fri, 8 Mar 2024 17:45:12 +0300 Subject: [PATCH 061/117] Merge fix delete on queries with default values (#2569) --- ydb/core/kqp/provider/yql_kikimr_type_ann.cpp | 2 +- ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp | 93 +++++++++++++++++++ 2 files changed, 94 insertions(+), 1 deletion(-) diff --git a/ydb/core/kqp/provider/yql_kikimr_type_ann.cpp b/ydb/core/kqp/provider/yql_kikimr_type_ann.cpp index 12eaf9cd1432..527cc1dce28e 100644 --- a/ydb/core/kqp/provider/yql_kikimr_type_ann.cpp +++ b/ydb/core/kqp/provider/yql_kikimr_type_ann.cpp @@ -429,7 +429,7 @@ class TKiSinkTypeAnnotationTransformer : public TKiSinkVisitorTransformer continue; } - if (op == TYdbOperation::UpdateOn) { + if (op == TYdbOperation::UpdateOn || op == TYdbOperation::DeleteOn) { continue; } diff --git a/ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp b/ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp index e0ab76506b08..71ff6bc7da91 100644 --- a/ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp +++ b/ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp @@ -287,6 +287,99 @@ Y_UNIT_TEST_SUITE(KqpConstraints) { TestSerialType("serial8"); } + Y_UNIT_TEST(DefaultsAndDeleteAndUpdate) { + NKikimrConfig::TAppConfig appConfig; + appConfig.MutableTableServiceConfig()->SetEnableSequences(false); + appConfig.MutableTableServiceConfig()->SetEnableColumnsWithDefault(true); + auto serverSettings = TKikimrSettings().SetAppConfig(appConfig); + TKikimrRunner kikimr(serverSettings); + auto db = kikimr.GetTableClient(); + auto session = db.CreateSession().GetValueSync().GetSession(); + + { + auto query = R"( + --!syntax_v1 + CREATE TABLE `/Root/DefaultsAndDeleteAndUpdate` ( + Key Int32, + Value String DEFAULT "somestring", + PRIMARY KEY (Key) + ); + )"; + + auto result = session.ExecuteSchemeQuery(query).GetValueSync(); + UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, + result.GetIssues().ToString()); + } + + { + TString query = R"( + UPSERT INTO `/Root/DefaultsAndDeleteAndUpdate` (Key) VALUES (1), (2), (3), (4); + )"; + + NYdb::NTable::TExecDataQuerySettings execSettings; + execSettings.KeepInQueryCache(true); + execSettings.CollectQueryStats(ECollectQueryStatsMode::Basic); + + auto result = + session + .ExecuteDataQuery(query, TTxControl::BeginTx().CommitTx(), + execSettings) + .ExtractValueSync(); + + UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, + result.GetIssues().ToString()); + } + + { + TString query = R"( + SELECT * FROM `/Root/DefaultsAndDeleteAndUpdate`; + )"; + + NYdb::NTable::TExecDataQuerySettings execSettings; + execSettings.KeepInQueryCache(true); + execSettings.CollectQueryStats(ECollectQueryStatsMode::Basic); + + auto result = + session + .ExecuteDataQuery(query, TTxControl::BeginTx().CommitTx(), + execSettings) + .ExtractValueSync(); + + UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, + result.GetIssues().ToString()); + CompareYson(R"( + [ + [[1];["somestring"]]; + [[2];["somestring"]]; + [[3];["somestring"]]; + [[4];["somestring"]] + ] + )", + NYdb::FormatResultSetYson(result.GetResultSet(0))); + } + + { + TString query = R"( + $object_pk = <|Key:1|>; + DELETE FROM `/Root/DefaultsAndDeleteAndUpdate` ON + SELECT * FROM AS_TABLE(AsList($object_pk)); + )"; + + NYdb::NTable::TExecDataQuerySettings execSettings; + execSettings.KeepInQueryCache(true); + execSettings.CollectQueryStats(ECollectQueryStatsMode::Basic); + + auto result = + session + .ExecuteDataQuery(query, TTxControl::BeginTx().CommitTx(), + execSettings) + .ExtractValueSync(); + + UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, + result.GetIssues().ToString()); + } + } + Y_UNIT_TEST(AlterTableAddColumnWithDefaultValue) { NKikimrConfig::TAppConfig appConfig; appConfig.MutableTableServiceConfig()->SetEnableSequences(false); From 179a3cba638d758b9c463996aa82aad1a6a8f3c7 Mon Sep 17 00:00:00 2001 From: ildar-khisambeev Date: Fri, 8 Mar 2024 18:12:32 +0300 Subject: [PATCH 062/117] cherry pick library fix (#2481) --- .../disjoint_interval_tree/disjoint_interval_tree.h | 2 +- .../ut/disjoint_interval_tree_ut.cpp | 12 ++++++++++++ 2 files changed, 13 insertions(+), 1 deletion(-) diff --git a/library/cpp/containers/disjoint_interval_tree/disjoint_interval_tree.h b/library/cpp/containers/disjoint_interval_tree/disjoint_interval_tree.h index 3f51c61277c5..f0c6644d4be7 100644 --- a/library/cpp/containers/disjoint_interval_tree/disjoint_interval_tree.h +++ b/library/cpp/containers/disjoint_interval_tree/disjoint_interval_tree.h @@ -132,7 +132,7 @@ class TDisjointIntervalTree { } TIterator completelyRemoveEnd = completelyRemoveBegin != Tree.end() ? Tree.lower_bound(end) : Tree.end(); - if (completelyRemoveEnd != Tree.end() && completelyRemoveEnd != Tree.begin() && completelyRemoveEnd->first != end) { + if (completelyRemoveEnd != Tree.begin() && (completelyRemoveEnd == Tree.end() || completelyRemoveEnd->first != end)) { TIterator containingEnd = completelyRemoveEnd; --containingEnd; if (containingEnd->second > end) { diff --git a/library/cpp/containers/disjoint_interval_tree/ut/disjoint_interval_tree_ut.cpp b/library/cpp/containers/disjoint_interval_tree/ut/disjoint_interval_tree_ut.cpp index 8474ae89b04b..508a82459af6 100644 --- a/library/cpp/containers/disjoint_interval_tree/ut/disjoint_interval_tree_ut.cpp +++ b/library/cpp/containers/disjoint_interval_tree/ut/disjoint_interval_tree_ut.cpp @@ -232,6 +232,18 @@ Y_UNIT_TEST_SUITE(DisjointIntervalTreeTest) { UNIT_ASSERT_VALUES_EQUAL(tree.GetNumIntervals(), 2); UNIT_ASSERT_VALUES_EQUAL(tree.GetNumElements(), 8); } + + // 12. The only one interval + { + TDisjointIntervalTree tree; + tree.InsertInterval(1, 10); + UNIT_ASSERT_VALUES_EQUAL(tree.GetNumIntervals(), 1); + UNIT_ASSERT_VALUES_EQUAL(tree.GetNumElements(), 9); + UNIT_ASSERT_VALUES_EQUAL(tree.EraseInterval(0, 6), 5); + UNIT_ASSERT_VALUES_EQUAL(tree.GetNumIntervals(), 1); + UNIT_ASSERT_VALUES_EQUAL(tree.GetNumElements(), 4); + UNIT_ASSERT(tree.Intersects(5, 10)); + } } Y_UNIT_TEST(IntersectsTest) { From f24b02a98f048c5a9461d20c9a15fb06eb80bb13 Mon Sep 17 00:00:00 2001 From: ijon Date: Sun, 10 Mar 2024 20:21:31 +0300 Subject: [PATCH 063/117] schemeboard: fix path updates from both root and tenant schemeshards (#2574) --- ydb/core/tx/scheme_board/replica.cpp | 19 ++++--------------- 1 file changed, 4 insertions(+), 15 deletions(-) diff --git a/ydb/core/tx/scheme_board/replica.cpp b/ydb/core/tx/scheme_board/replica.cpp index c1600b4bd644..cb5ddd2e923f 100644 --- a/ydb/core/tx/scheme_board/replica.cpp +++ b/ydb/core/tx/scheme_board/replica.cpp @@ -248,17 +248,6 @@ class TReplica: public TMonitorableActor { TrackMemory(); } - explicit TDescription( - TReplica* owner, - const TPathId& pathId, - TOpaquePathDescription&& pathDescription) - : Owner(owner) - , PathId(pathId) - , PathDescription(std::move(pathDescription)) - { - TrackMemory(); - } - explicit TDescription( TReplica* owner, const TString& path, @@ -540,13 +529,13 @@ class TReplica: public TMonitorableActor { } // upsert description only by pathId - TDescription& UpsertDescription(const TPathId& pathId, TOpaquePathDescription&& pathDescription) { + TDescription& UpsertDescriptionByPathId(const TString& path, const TPathId& pathId, TOpaquePathDescription&& pathDescription) { SBR_LOG_I("Upsert description" << ": pathId# " << pathId << ", pathDescription# " << pathDescription.ToString() ); - return Descriptions.Upsert(pathId, TDescription(this, pathId, std::move(pathDescription))); + return Descriptions.Upsert(pathId, TDescription(this, path, pathId, std::move(pathDescription))); } // upsert description by path AND pathId both @@ -898,7 +887,7 @@ class TReplica: public TMonitorableActor { if (abandonedSchemeShards.contains(pathId.OwnerId)) { // TSS is ignored, present GSS reverted it log("Replace GSS by TSS description is rejected, GSS implicitly knows that TSS has been reverted" ", but still inject description only by pathId for safe"); - UpsertDescription(pathId, std::move(pathDescription)); + UpsertDescriptionByPathId(path, pathId, std::move(pathDescription)); return AckUpdate(ev); } @@ -923,7 +912,7 @@ class TReplica: public TMonitorableActor { } log("Inject description only by pathId, it is update from GSS"); - UpsertDescription(pathId, std::move(pathDescription)); + UpsertDescriptionByPathId(path, pathId, std::move(pathDescription)); return AckUpdate(ev); } From 6a84178e8322f986768e543eb325d1235f92c18e Mon Sep 17 00:00:00 2001 From: Nikolay Shestakov Date: Tue, 12 Mar 2024 08:55:03 +0500 Subject: [PATCH 064/117] Allow important consumer for all installations (#2518) --- ydb/services/lib/actors/pq_schema_actor.cpp | 6 ------ 1 file changed, 6 deletions(-) diff --git a/ydb/services/lib/actors/pq_schema_actor.cpp b/ydb/services/lib/actors/pq_schema_actor.cpp index c6564b247985..8d18aa9edde2 100644 --- a/ydb/services/lib/actors/pq_schema_actor.cpp +++ b/ydb/services/lib/actors/pq_schema_actor.cpp @@ -136,12 +136,6 @@ namespace NKikimr::NGRpcProxy::V1 { } if (rr.important()) { - if (AppData(ctx)->PQConfig.GetTopicsAreFirstClassCitizen()) { - return TMsgPqCodes( - TStringBuilder() << "important flag is forbiden for consumer " << rr.consumer_name(), - Ydb::PersQueue::ErrorCode::VALIDATION_ERROR - ); - } config->MutablePartitionConfig()->AddImportantClientId(consumerName); } From 623524f47684187229370abeb822d2347208d521 Mon Sep 17 00:00:00 2001 From: spuchin Date: Tue, 12 Mar 2024 09:37:16 +0300 Subject: [PATCH 065/117] [KIKIMR-21174] Remove wrong RuntimeVersion check (#2605) (#2629) Co-authored-by: Andrey Neporada --- ydb/library/yql/minikql/mkql_node.cpp | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/ydb/library/yql/minikql/mkql_node.cpp b/ydb/library/yql/minikql/mkql_node.cpp index 82815a8e3e4b..6fa8d8f55db9 100644 --- a/ydb/library/yql/minikql/mkql_node.cpp +++ b/ydb/library/yql/minikql/mkql_node.cpp @@ -2525,7 +2525,7 @@ EValueRepresentation GetValueRepresentation(const TType* type) { } TArrayRef GetWideComponents(const TFlowType* type) { - if (RuntimeVersion > 35) { + if (type->GetItemType()->IsMulti()) { return AS_TYPE(TMultiType, type->GetItemType())->GetElements(); } return AS_TYPE(TTupleType, type->GetItemType())->GetElements(); From ed139afb902b59155e07d3de4fc5d1b6db326fe0 Mon Sep 17 00:00:00 2001 From: Aleksei Borzenkov Date: Tue, 12 Mar 2024 10:53:53 +0300 Subject: [PATCH 066/117] Fix volatile result sent before it is fully committed (24-1) (#2624) --- .../kqp/executer_actor/kqp_data_executer.cpp | 123 ++++++------ .../datashard_active_transaction.cpp | 4 +- .../tx/datashard/datashard_ut_common_kqp.h | 22 +-- ydb/core/tx/datashard/datashard_ut_order.cpp | 34 ++-- .../datashard/datashard_ut_read_iterator.cpp | 19 +- ydb/core/tx/datashard/datashard_ut_rs.cpp | 32 ++- .../tx/datashard/datashard_ut_volatile.cpp | 183 ++++++++++++++++++ ydb/core/tx/datashard/finish_propose_unit.cpp | 7 +- .../datashard/finish_propose_write_unit.cpp | 7 +- ydb/core/tx/datashard/operation.h | 13 +- 10 files changed, 336 insertions(+), 108 deletions(-) diff --git a/ydb/core/kqp/executer_actor/kqp_data_executer.cpp b/ydb/core/kqp/executer_actor/kqp_data_executer.cpp index b8dd4a1824ba..15fe364f8d25 100644 --- a/ydb/core/kqp/executer_actor/kqp_data_executer.cpp +++ b/ydb/core/kqp/executer_actor/kqp_data_executer.cpp @@ -2006,16 +2006,12 @@ class TKqpDataExecuter : public TKqpExecuterBase affectedShardsSet; - affectedShardsSet.reserve(datashardTasks.size()); - for (auto& [shardId, tasks]: datashardTasks) { auto [it, success] = datashardTxs.emplace( shardId, TasksGraph.GetMeta().Allocate()); YQL_ENSURE(success, "unexpected duplicates in datashard transactions"); - affectedShardsSet.emplace_back(shardId); NKikimrTxDataShard::TKqpTransaction* dsTxs = it->second; dsTxs->MutableTasks()->Reserve(tasks.size()); for (auto& task: tasks) { @@ -2023,6 +2019,55 @@ class TKqpDataExecuter : public TKqpExecuterBase()); + + YQL_ENSURE(success, "unexpected failure to emplace a datashard transaction"); + it = emplaced; + } + + NKikimrTxDataShard::TKqpTransaction* tx = it->second; + switch (Request.LocksOp) { + case ELocksOp::Commit: + tx->MutableLocks()->SetOp(NKikimrDataEvents::TKqpLocks::Commit); + break; + case ELocksOp::Rollback: + tx->MutableLocks()->SetOp(NKikimrDataEvents::TKqpLocks::Rollback); + break; + case ELocksOp::Unspecified: + break; + } + + // Move lock descriptions to the datashard tx + auto* protoLocks = tx->MutableLocks()->MutableLocks(); + protoLocks->Reserve(locksList.size()); + bool hasWrites = false; + for (auto& lock : locksList) { + hasWrites = hasWrites || lock.GetHasWrites(); + protoLocks->Add(std::move(lock)); + } + locksList.clear(); + + // When locks with writes are committed this commits accumulated effects + if (Request.LocksOp == ELocksOp::Commit && hasWrites) { + ShardsWithEffects.insert(shardId); + YQL_ENSURE(!ReadOnlyTx); + } + } + Request.TopicOperations.BuildTopicTxs(topicTxs); const bool needRollback = Request.LocksOp == ELocksOp::Rollback; @@ -2042,7 +2087,7 @@ class TKqpDataExecuter : public TKqpExecuterBase 1 && + (datashardTxs.size() + topicTxs.size()) > 1 && // We cannot use volatile transactions with persistent channels // Note: currently persistent channels are never used !HasPersistentChannels); @@ -2055,30 +2100,29 @@ class TKqpDataExecuter : public TKqpExecuterBase sendingShardsSet; absl::flat_hash_set receivingShardsSet; // Gather shards that need to send/receive readsets (shards with effects) if (needCommit) { - for (auto& shardId: affectedShardsSet) { + for (auto& [shardId, tx] : datashardTxs) { + if (tx->HasLocks()) { + // Locks may be broken so shards with locks need to send readsets + sendingShardsSet.insert(shardId); + } if (ShardsWithEffects.contains(shardId)) { // Volatile transactions may abort effects, so they send readsets if (VolatileTx) { sendingShardsSet.insert(shardId); } + // Effects are only applied when all locks are valid receivingShardsSet.insert(shardId); } } @@ -2093,44 +2137,7 @@ class TKqpDataExecuter : public TKqpExecuterBasesecond; - } else { - auto [eIt, success] = datashardTxs.emplace( - shardId, - TasksGraph.GetMeta().Allocate()); - tx = eIt->second; - } - - tx->MutableLocks()->SetOp(locksOp); - - if (!locksList.empty()) { - auto* protoLocks = tx->MutableLocks()->MutableLocks(); - protoLocks->Reserve(locksList.size()); - bool hasWrites = false; - for (auto& lock : locksList) { - hasWrites = hasWrites || lock.GetHasWrites(); - protoLocks->Add()->Swap(&lock); - } - - if (needCommit) { - // We also send the result on commit - sendingShardsSet.insert(shardId); - - if (hasWrites) { - // Tx with uncommitted changes can be aborted due to conflicts, - // so shards with write locks should receive readsets - receivingShardsSet.insert(shardId); - YQL_ENSURE(!ReadOnlyTx); - } - } - } - } - + // Encode sending/receiving shards in tx bodies if (needCommit) { NProtoBuf::RepeatedField sendingShards(sendingShardsSet.begin(), sendingShardsSet.end()); NProtoBuf::RepeatedField receivingShards(receivingShardsSet.begin(), receivingShardsSet.end()); @@ -2139,23 +2146,13 @@ class TKqpDataExecuter : public TKqpExecuterBaseMutableLocks()->SetOp(locksOp); + shardTx->MutableLocks()->SetOp(NKikimrDataEvents::TKqpLocks::Commit); *shardTx->MutableLocks()->MutableSendingShards() = sendingShards; *shardTx->MutableLocks()->MutableReceivingShards() = receivingShards; } for (auto& [_, tx] : topicTxs) { - switch (locksOp) { - case NKikimrDataEvents::TKqpLocks::Commit: - tx.SetOp(NKikimrPQ::TDataTransaction::Commit); - break; - case NKikimrDataEvents::TKqpLocks::Rollback: - tx.SetOp(NKikimrPQ::TDataTransaction::Rollback); - break; - case NKikimrDataEvents::TKqpLocks::Unspecified: - break; - } - + tx.SetOp(NKikimrPQ::TDataTransaction::Commit); *tx.MutableSendingShards() = sendingShards; *tx.MutableReceivingShards() = receivingShards; } diff --git a/ydb/core/tx/datashard/datashard_active_transaction.cpp b/ydb/core/tx/datashard/datashard_active_transaction.cpp index a4a2c4ea5b5a..745010c5401d 100644 --- a/ydb/core/tx/datashard/datashard_active_transaction.cpp +++ b/ydb/core/tx/datashard/datashard_active_transaction.cpp @@ -404,7 +404,7 @@ TValidatedDataTx::TPtr TActiveTransaction::BuildDataTx(TDataShard *self, if (!DataTx) { Y_ABORT_UNLESS(TxBody); DataTx = std::make_shared(self, txc, ctx, GetStepOrder(), - GetReceivedAt(), TxBody, MvccSnapshotRepeatable); + GetReceivedAt(), TxBody, IsMvccSnapshotRepeatable()); if (DataTx->HasStreamResponse()) SetStreamSink(DataTx->GetSink()); } @@ -635,7 +635,7 @@ ERestoreDataStatus TActiveTransaction::RestoreTxData( bool extractKeys = DataTx->IsTxInfoLoaded(); DataTx = std::make_shared(self, txc, ctx, GetStepOrder(), - GetReceivedAt(), TxBody, MvccSnapshotRepeatable); + GetReceivedAt(), TxBody, IsMvccSnapshotRepeatable()); if (DataTx->Ready() && extractKeys) { DataTx->ExtractKeys(true); } diff --git a/ydb/core/tx/datashard/datashard_ut_common_kqp.h b/ydb/core/tx/datashard/datashard_ut_common_kqp.h index d7182e08e3da..de0e2ef7a24d 100644 --- a/ydb/core/tx/datashard/datashard_ut_common_kqp.h +++ b/ydb/core/tx/datashard/datashard_ut_common_kqp.h @@ -42,7 +42,7 @@ namespace NKqpHelpers { inline TString CreateSessionRPC(TTestActorRuntime& runtime, const TString& database = {}) { Ydb::Table::CreateSessionRequest request; auto future = NRpcService::DoLocalRpc( - std::move(request), database, "", /* token */ runtime.GetActorSystem(0)); + std::move(request), database, /* token */ "", runtime.GetActorSystem(0)); TString sessionId; auto response = AwaitResponse(runtime, future); UNIT_ASSERT_VALUES_EQUAL(response.operation().status(), Ydb::StatusIds::SUCCESS); @@ -71,7 +71,7 @@ namespace NKqpHelpers { TTestActorRuntime& runtime, Ydb::Table::ExecuteDataQueryRequest&& request, const TString& database = {}) { return NRpcService::DoLocalRpc( - std::move(request), database, "" /* token */, runtime.GetActorSystem(0)); + std::move(request), database, /* token */ "", runtime.GetActorSystem(0)); } inline Ydb::Table::ExecuteDataQueryRequest MakeSimpleRequestRPC( @@ -119,7 +119,7 @@ namespace NKqpHelpers { Ydb::Table::DeleteSessionRequest request; request.set_session_id(sessionId); auto future = NRpcService::DoLocalRpc( - std::move(request), "", "", /* token */ runtime.GetActorSystem(0)); + std::move(request), "", /* token */ "", runtime.GetActorSystem(0)); } inline THolder MakeStreamRequest( @@ -168,17 +168,15 @@ namespace NKqpHelpers { return FormatResult(result); } - inline TString KqpSimpleExec(TTestActorRuntime& runtime, const TString& query, bool staleRo = false, const TString& database = {}) { + inline auto KqpSimpleSend(TTestActorRuntime& runtime, const TString& query, bool staleRo = false, const TString& database = {}) { TString sessionId = CreateSessionRPC(runtime, database); TString txId; - auto response = AwaitResponse( - runtime, SendRequest(runtime, MakeSimpleRequestRPC(query, sessionId, txId, true /* commitTx */, staleRo), database)); - if (response.operation().status() != Ydb::StatusIds::SUCCESS) { - return TStringBuilder() << "ERROR: " << response.operation().status(); - } - Ydb::Table::ExecuteQueryResult result; - response.operation().result().UnpackTo(&result); - return FormatResult(result); + return SendRequest(runtime, MakeSimpleRequestRPC(query, sessionId, txId, /* commitTx */ true, staleRo), database); + } + + inline TString KqpSimpleExec(TTestActorRuntime& runtime, const TString& query, bool staleRo = false, const TString& database = {}) { + auto response = AwaitResponse(runtime, KqpSimpleSend(runtime, query, staleRo, database)); + return FormatResult(response); } inline TString KqpSimpleStaleRoExec(TTestActorRuntime& runtime, const TString& query, const TString& database = {}) { diff --git a/ydb/core/tx/datashard/datashard_ut_order.cpp b/ydb/core/tx/datashard/datashard_ut_order.cpp index ee1af9e056c1..4f58e3fe804f 100644 --- a/ydb/core/tx/datashard/datashard_ut_order.cpp +++ b/ydb/core/tx/datashard/datashard_ut_order.cpp @@ -4279,6 +4279,7 @@ Y_UNIT_TEST(UncommittedReadSetAck) { bool capturePlanSteps = true; TVector> capturedPlanSteps; + TVector capturedPlanTxIds; THashSet passReadSetTxIds; ui64 observedReadSets = 0; TVector> capturedReadSets; @@ -4294,6 +4295,12 @@ Y_UNIT_TEST(UncommittedReadSetAck) { case TEvTxProcessing::TEvPlanStep::EventType: { if (nodeIndex == 1 && ev->GetRecipientRewrite() == table3actor && capturePlanSteps) { Cerr << "... captured plan step for table-3" << Endl; + auto* msg = ev->Get(); + for (const auto& tx : msg->Record.GetTransactions()) { + ui64 txId = tx.GetTxId(); + capturedPlanTxIds.push_back(txId); + Cerr << "... captured plan step tx " << txId << " for table-3" << Endl; + } capturedPlanSteps.emplace_back(ev.Release()); return TTestActorRuntime::EEventAction::DROP; } @@ -4303,6 +4310,12 @@ Y_UNIT_TEST(UncommittedReadSetAck) { if (nodeIndex == 1 && ev->GetRecipientRewrite() == table3actor) { auto* msg = ev->Get(); ui64 txId = msg->Record.GetTxId(); + if ((msg->Record.GetFlags() & NKikimrTx::TEvReadSet::FLAG_EXPECT_READSET) && + (msg->Record.GetFlags() & NKikimrTx::TEvReadSet::FLAG_NO_DATA)) + { + Cerr << "... passing expectation for txid# " << txId << Endl; + break; + } ++observedReadSets; if (!passReadSetTxIds.contains(txId)) { Cerr << "... readset for txid# " << txId << " was blocked" << Endl; @@ -4353,20 +4366,11 @@ Y_UNIT_TEST(UncommittedReadSetAck) { } }; - waitFor([&]{ return capturedPlanSteps.size() > 0; }, "plan step"); - UNIT_ASSERT_VALUES_EQUAL(capturedPlanSteps.size(), 1u); - ui64 realTxId1, realTxId2; - { - auto* msg = capturedPlanSteps[0]->Get(); - TVector realTxIds; - for (const auto& tx : msg->Record.GetTransactions()) { - realTxIds.emplace_back(tx.GetTxId()); - } - UNIT_ASSERT_VALUES_EQUAL(realTxIds.size(), 2u); - std::sort(realTxIds.begin(), realTxIds.end()); - realTxId1 = realTxIds.at(0); - realTxId2 = realTxIds.at(1); - } + waitFor([&]{ return capturedPlanTxIds.size() >= 2; }, "captured transactions"); + UNIT_ASSERT_C(capturedPlanTxIds.size(), 2u); + std::sort(capturedPlanTxIds.begin(), capturedPlanTxIds.end()); + ui64 realTxId1 = capturedPlanTxIds.at(0); + ui64 realTxId2 = capturedPlanTxIds.at(1); // Unblock and resend the plan step message capturePlanSteps = false; @@ -4375,7 +4379,7 @@ Y_UNIT_TEST(UncommittedReadSetAck) { } capturedPlanSteps.clear(); - // Wait until there are 2 readset messages + // Wait until there are 2 readset messages (with data) waitFor([&]{ return capturedReadSets.size() >= 2; }, "initial readsets"); SimulateSleep(runtime, TDuration::MilliSeconds(5)); diff --git a/ydb/core/tx/datashard/datashard_ut_read_iterator.cpp b/ydb/core/tx/datashard/datashard_ut_read_iterator.cpp index 044080f8d711..cd3889c58d3c 100644 --- a/ydb/core/tx/datashard/datashard_ut_read_iterator.cpp +++ b/ydb/core/tx/datashard/datashard_ut_read_iterator.cpp @@ -348,7 +348,7 @@ struct TTestHelper { auto &runtime = *Server->GetRuntime(); Sender = runtime.AllocateEdgeActor(); - runtime.SetLogPriority(NKikimrServices::TX_DATASHARD, NLog::PRI_NOTICE); + runtime.SetLogPriority(NKikimrServices::TX_DATASHARD, NLog::PRI_TRACE); runtime.SetLogPriority(NKikimrServices::TX_PROXY, NLog::PRI_INFO); InitRoot(Server, Sender); @@ -818,7 +818,11 @@ struct TTestHelper { break; } case TEvTxProcessing::EvReadSet: { - if (dropRS) { + auto* msg = event->Get(); + auto flags = msg->Record.GetFlags(); + auto isExpect = flags & NKikimrTx::TEvReadSet::FLAG_EXPECT_READSET; + auto isNoData = flags & NKikimrTx::TEvReadSet::FLAG_NO_DATA; + if (dropRS && !(isExpect && isNoData)) { result.ReadSets.push_back(std::move(event)); return TTestActorRuntime::EEventAction::DROP; } @@ -852,7 +856,10 @@ struct TTestHelper { )")); } - waitFor([&]{ return result.ReadSets.size() == 1; }, "intercepted RS"); + const bool usesVolatileTxs = runtime.GetAppData(0).FeatureFlags.GetEnableDataShardVolatileTransactions(); + const size_t expectedReadSets = 1 + (finalUpserts && usesVolatileTxs ? 2 : 0); + + waitFor([&]{ return result.ReadSets.size() == expectedReadSets; }, "intercepted RS"); // restore original observer (note we used lambda function and stack variables) Server->GetRuntime()->SetObserverFunc(prevObserverFunc); @@ -2576,7 +2583,9 @@ Y_UNIT_TEST_SUITE(DataShardReadIterator) { TPortManager pm; TServerSettings serverSettings(pm.GetPort(2134)); serverSettings.SetDomainName("Root") - .SetUseRealThreads(false); + .SetUseRealThreads(false) + // Blocked volatile transactions block reads, disable + .SetEnableDataShardVolatileTransactions(false); const ui64 shardCount = 1; TTestHelper helper(serverSettings, shardCount); @@ -3600,7 +3609,7 @@ Y_UNIT_TEST_SUITE(DataShardReadIteratorPageFaults) { auto& runtime = *server->GetRuntime(); auto sender = runtime.AllocateEdgeActor(); - runtime.SetLogPriority(NKikimrServices::TX_DATASHARD, NLog::PRI_NOTICE); + runtime.SetLogPriority(NKikimrServices::TX_DATASHARD, NLog::PRI_TRACE); runtime.SetLogPriority(NKikimrServices::TX_PROXY, NLog::PRI_INFO); // runtime.SetLogPriority(NKikimrServices::TABLET_EXECUTOR, NLog::PRI_DEBUG); diff --git a/ydb/core/tx/datashard/datashard_ut_rs.cpp b/ydb/core/tx/datashard/datashard_ut_rs.cpp index 1f6ca976a929..b15784d66c22 100644 --- a/ydb/core/tx/datashard/datashard_ut_rs.cpp +++ b/ydb/core/tx/datashard/datashard_ut_rs.cpp @@ -48,7 +48,10 @@ struct IsReadSet { { if (ev.GetTypeRewrite() == TEvTxProcessing::EvReadSet) { auto &rec = ev.Get()->Record; - if (rec.GetTabletSource() == Source && rec.GetTabletDest() == Dest) { + bool isExpectation = ( + (rec.GetFlags() & NKikimrTx::TEvReadSet::FLAG_EXPECT_READSET) && + (rec.GetFlags() & NKikimrTx::TEvReadSet::FLAG_NO_DATA)); + if (rec.GetTabletSource() == Source && rec.GetTabletDest() == Dest && !isExpectation) { return true; } } @@ -64,7 +67,9 @@ Y_UNIT_TEST_SUITE(TDataShardRSTest) { TPortManager pm; TServerSettings serverSettings(pm.GetPort(2134)); serverSettings.SetDomainName("Root") - .SetUseRealThreads(false); + .SetUseRealThreads(false) + // Volatile transactions avoid storing readsets in InReadSets table + .SetEnableDataShardVolatileTransactions(false); Tests::TServer::TPtr server = new TServer(serverSettings); auto &runtime = *server->GetRuntime(); @@ -250,7 +255,13 @@ Y_UNIT_TEST_SUITE(TDataShardRSTest) { TPortManager pm; TServerSettings serverSettings(pm.GetPort(2134)); serverSettings.SetDomainName("Root") - .SetUseRealThreads(false); + .SetUseRealThreads(false) + // This test expects rs acks to be delayed during one of restarts, + // which doesn't happen with volatile transactions. With volatile + // transactions both upserts have already executed, one of them is + // just waiting for confirmation before making changes visible. + // Since acks are not delayed they are just gone when dropped. + .SetEnableDataShardVolatileTransactions(false); Tests::TServer::TPtr server = new TServer(serverSettings); auto &runtime = *server->GetRuntime(); @@ -278,7 +289,10 @@ Y_UNIT_TEST_SUITE(TDataShardRSTest) { auto captureRS = [shard1,shard3](TAutoPtr &event) -> auto { if (event->GetTypeRewrite() == TEvTxProcessing::EvReadSet) { auto &rec = event->Get()->Record; - if (rec.GetTabletSource() == shard1) { + bool isExpectation = ( + (rec.GetFlags() & NKikimrTx::TEvReadSet::FLAG_EXPECT_READSET) && + (rec.GetFlags() & NKikimrTx::TEvReadSet::FLAG_NO_DATA)); + if (rec.GetTabletSource() == shard1 && !isExpectation) { return TTestActorRuntime::EEventAction::DROP; } } else if (event->GetTypeRewrite() == TEvTxProcessing::EvReadSetAck) { @@ -359,6 +373,9 @@ Y_UNIT_TEST_SUITE(TDataShardRSTest) { switch (ev->GetTypeRewrite()) { case TEvTxProcessing::TEvReadSet::EventType: { auto* msg = ev->Get(); + if (msg->Record.GetFlags() & NKikimrTx::TEvReadSet::FLAG_NO_DATA) { + break; + } NKikimrTx::TReadSetData genericData; Y_ABORT_UNLESS(genericData.ParseFromString(msg->Record.GetReadSet())); Cerr << "... generic readset: " << genericData.DebugString() << Endl; @@ -419,6 +436,13 @@ Y_UNIT_TEST_SUITE(TDataShardRSTest) { switch (ev->GetTypeRewrite()) { case TEvTxProcessing::TEvReadSet::EventType: { auto* msg = ev->Get(); + if (msg->Record.GetFlags() & NKikimrTx::TEvReadSet::FLAG_NO_DATA) { + if (!(msg->Record.GetFlags() & NKikimrTx::TEvReadSet::FLAG_EXPECT_READSET)) { + Cerr << "... nodata readset" << Endl; + ++readSets; + } + break; + } NKikimrTx::TReadSetData genericData; Y_ABORT_UNLESS(genericData.ParseFromString(msg->Record.GetReadSet())); Cerr << "... generic readset: " << genericData.DebugString() << Endl; diff --git a/ydb/core/tx/datashard/datashard_ut_volatile.cpp b/ydb/core/tx/datashard/datashard_ut_volatile.cpp index 9d12f0ee2deb..c5eff03c43b3 100644 --- a/ydb/core/tx/datashard/datashard_ut_volatile.cpp +++ b/ydb/core/tx/datashard/datashard_ut_volatile.cpp @@ -2214,6 +2214,189 @@ Y_UNIT_TEST_SUITE(DataShardVolatile) { "{ items { uint32_value: 4 } items { uint32_value: 40 } }"); } + Y_UNIT_TEST(TwoAppendsMustBeVolatile) { + TPortManager pm; + TServerSettings serverSettings(pm.GetPort(2134)); + serverSettings.SetDomainName("Root") + .SetNodeCount(2) + .SetUseRealThreads(false) + .SetDomainPlanResolution(100) + .SetEnableDataShardVolatileTransactions(true); + + Tests::TServer::TPtr server = new TServer(serverSettings); + auto &runtime = *server->GetRuntime(); + auto sender = runtime.AllocateEdgeActor(); + + runtime.SetLogPriority(NKikimrServices::TX_DATASHARD, NLog::PRI_TRACE); + runtime.SetLogPriority(NKikimrServices::TX_PROXY, NLog::PRI_DEBUG); + runtime.SetLogPriority(NKikimrServices::KQP_EXECUTER, NLog::PRI_TRACE); + runtime.SetLogPriority(NKikimrServices::KQP_SESSION, NLog::PRI_TRACE); + + InitRoot(server, sender); + + CreateShardedTable(server, sender, "/Root", "table-1", 1); + CreateShardedTable(server, sender, "/Root", "table-2", 1); + + // Insert initial values + ExecSQL(server, sender, Q_("UPSERT INTO `/Root/table-1` (key, value) VALUES (1, 10);")); + ExecSQL(server, sender, Q_("UPSERT INTO `/Root/table-2` (key, value) VALUES (2, 20);")); + + size_t volatileTxs = 0; + auto proposeObserver = runtime.AddObserver([&](TEvDataShard::TEvProposeTransaction::TPtr& ev) { + auto* msg = ev->Get(); + if (msg->Record.GetFlags() & TTxFlags::VolatilePrepare) { + ++volatileTxs; + } + }); + + // This simulates a jepsen transaction that appends two values at different shards + TString sessionId, txId; + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleBegin(runtime, sessionId, txId, Q_(R"( + $next_index = ( + SELECT COALESCE(MAX(key) + 1u, 0u) + FROM ( + SELECT key FROM `/Root/table-1` + UNION ALL + SELECT key FROM `/Root/table-2` + ) + ); + UPSERT INTO `/Root/table-1` (key, value) VALUES ($next_index, 30u); + )")), + ""); + + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleCommit(runtime, sessionId, txId, Q_(R"( + $next_index = ( + SELECT COALESCE(MAX(key) + 1u, 0u) + FROM ( + SELECT key FROM `/Root/table-1` + UNION ALL + SELECT key FROM `/Root/table-2` + ) + ); + UPSERT INTO `/Root/table-2` (key, value) VALUES ($next_index, 40u); + )")), + ""); + + // There should have been volatile transactions at both shards + UNIT_ASSERT_VALUES_EQUAL(volatileTxs, 2u); + } + + // Regression test for KIKIMR-21156 + Y_UNIT_TEST(VolatileCommitOnBlobStorageFailure) { + TPortManager pm; + TServerSettings serverSettings(pm.GetPort(2134)); + serverSettings.SetDomainName("Root") + .SetUseRealThreads(false) + .SetDomainPlanResolution(1000) + .SetEnableDataShardVolatileTransactions(true); + + Tests::TServer::TPtr server = new TServer(serverSettings); + auto &runtime = *server->GetRuntime(); + auto sender = runtime.AllocateEdgeActor(); + + runtime.SetLogPriority(NKikimrServices::TX_DATASHARD, NLog::PRI_TRACE); + runtime.SetLogPriority(NKikimrServices::TX_PROXY, NLog::PRI_DEBUG); + runtime.SetLogPriority(NKikimrServices::KQP_EXECUTER, NLog::PRI_TRACE); + runtime.SetLogPriority(NKikimrServices::KQP_SESSION, NLog::PRI_TRACE); + + InitRoot(server, sender); + + TDisableDataShardLogBatching disableDataShardLogBatching; + CreateShardedTable(server, sender, "/Root", "table-1", 1); + CreateShardedTable(server, sender, "/Root", "table-2", 1); + + // Make sure read flags are persisted by performing a snapshot read + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleExec(runtime, R"( + SELECT key, value FROM `/Root/table-1` + UNION ALL + SELECT key, value FROM `/Root/table-2` + ORDER BY key + )"), + ""); + + // Insert initial values + ExecSQL(server, sender, Q_("UPSERT INTO `/Root/table-1` (key, value) VALUES (1, 10);")); + ExecSQL(server, sender, Q_("UPSERT INTO `/Root/table-2` (key, value) VALUES (2, 20);")); + + // Start blocking commits for table-1 + const auto shards1 = GetTableShards(server, sender, "/Root/table-1"); + UNIT_ASSERT_VALUES_EQUAL(shards1.size(), 1u); + std::deque blockedPuts; + auto blockCommits = runtime.AddObserver([&](TEvBlobStorage::TEvPut::TPtr& ev) { + auto* msg = ev->Get(); + // Drop all put requests for table-1 + if (msg->Id.TabletID() == shards1.at(0)) { + Cerr << "... blocking put " << msg->Id << Endl; + blockedPuts.push_back(std::move(ev)); + } + }); + + // Start an upsert to table-1, this will block further readonly localdb tx completions + Cerr << "... starting an upsert to table-1" << Endl; + auto firstUpsertFuture = KqpSimpleSend(runtime, R"( + UPSERT INTO `/Root/table-1` (key, value) VALUES (3, 30); + )"); + + // Wait until puts are blocked + WaitFor(runtime, [&]{ return blockedPuts.size() > 0; }, "blocked puts"); + auto firstUpsertPuts = std::move(blockedPuts); + UNIT_ASSERT(blockedPuts.empty()); + + // Read from table-2 and write to table-1 based on the result + // This will result in a two-shard volatile tx writing to table-1 + Cerr << "... starting distributed tx between table-1 and table-2" << Endl; + auto volatileFuture = KqpSimpleSend(runtime, R"( + UPSERT INTO `/Root/table-1` + SELECT key + 2u AS key, value + 2u AS value + FROM `/Root/table-2`; + )"); + + // Wait until it also tries to commit + WaitFor(runtime, [&]{ return blockedPuts.size() > 0; }, "blocked puts"); + + // Now unblock the first upsert puts + blockCommits.Remove(); + for (auto& ev : firstUpsertPuts) { + runtime.Send(ev.Release(), 0, true); + } + firstUpsertPuts.clear(); + + // And wait for it to finish successfully + Cerr << "... waiting for first upsert result" << Endl; + UNIT_ASSERT_VALUES_EQUAL( + FormatResult(AwaitResponse(runtime, std::move(firstUpsertFuture))), + ""); + + // Reply to everything previously blocked with an error, the shard will restart + for (auto& ev : blockedPuts) { + auto proxy = ev->Recipient; + ui32 groupId = GroupIDFromBlobStorageProxyID(proxy); + auto res = ev->Get()->MakeErrorResponse(NKikimrProto::ERROR, "Something went wrong", groupId); + runtime.Send(new IEventHandle(ev->Sender, proxy, res.release()), 0, true); + } + + // Wait for the volatile tx result + Cerr << "... waiting for volatile tx result" << Endl; + auto result = FormatResult(AwaitResponse(runtime, std::move(volatileFuture))); + if (result == "") { + // A success result is not ok now, but in the future we might migrate state + // Check that the supposedly committed row actually exists + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleExec(runtime, R"( + SELECT key, value FROM `/Root/table-1` ORDER BY key; + )"), + "{ items { uint32_value: 1 } items { uint32_value: 10 } }, " + "{ items { uint32_value: 3 } items { uint32_value: 30 } }, " + "{ items { uint32_value: 4 } items { uint32_value: 22 } }"); + } else { + // Otherwise the result must be undetermined + UNIT_ASSERT_VALUES_EQUAL(result, "ERROR: UNDETERMINED"); + } + } + } // Y_UNIT_TEST_SUITE(DataShardVolatile) } // namespace NKikimr diff --git a/ydb/core/tx/datashard/finish_propose_unit.cpp b/ydb/core/tx/datashard/finish_propose_unit.cpp index 7c30cb960093..bfc7a166d2aa 100644 --- a/ydb/core/tx/datashard/finish_propose_unit.cpp +++ b/ydb/core/tx/datashard/finish_propose_unit.cpp @@ -99,8 +99,11 @@ EExecutionStatus TFinishProposeUnit::Execute(TOperation::TPtr op, op->SetFinishProposeTs(DataShard.ConfirmReadOnlyLease()); } - if (!op->HasResultSentFlag() && (op->IsDirty() || op->HasVolatilePrepareFlag() || !Pipeline.WaitCompletion(op))) + if (!op->HasResultSentFlag() && (op->IsDirty() || op->HasVolatilePrepareFlag() || !Pipeline.WaitCompletion(op))) { + DataShard.IncCounter(COUNTER_PREPARE_COMPLETE); + op->SetProposeResultSentEarly(); CompleteRequest(op, ctx); + } if (!DataShard.IsFollower()) DataShard.PlanCleanup(ctx); @@ -128,7 +131,7 @@ EExecutionStatus TFinishProposeUnit::Execute(TOperation::TPtr op, void TFinishProposeUnit::Complete(TOperation::TPtr op, const TActorContext &ctx) { - if (!op->HasResultSentFlag()) { + if (!op->HasResultSentFlag() && !op->IsProposeResultSentEarly()) { DataShard.IncCounter(COUNTER_PREPARE_COMPLETE); if (op->Result()) diff --git a/ydb/core/tx/datashard/finish_propose_write_unit.cpp b/ydb/core/tx/datashard/finish_propose_write_unit.cpp index d6c9dffa10fa..7ed6d64ff24f 100644 --- a/ydb/core/tx/datashard/finish_propose_write_unit.cpp +++ b/ydb/core/tx/datashard/finish_propose_write_unit.cpp @@ -97,8 +97,11 @@ EExecutionStatus TFinishProposeWriteUnit::Execute(TOperation::TPtr op, op->SetFinishProposeTs(DataShard.ConfirmReadOnlyLease()); } - if (!op->HasResultSentFlag() && (op->IsDirty() || op->HasVolatilePrepareFlag() || !Pipeline.WaitCompletion(op))) + if (!op->HasResultSentFlag() && (op->IsDirty() || op->HasVolatilePrepareFlag() || !Pipeline.WaitCompletion(op))) { + DataShard.IncCounter(COUNTER_PREPARE_COMPLETE); + op->SetProposeResultSentEarly(); CompleteRequest(op, ctx); + } if (!DataShard.IsFollower()) DataShard.PlanCleanup(ctx); @@ -127,7 +130,7 @@ void TFinishProposeWriteUnit::Complete(TOperation::TPtr op, const TActorContext { TWriteOperation* writeOp = TWriteOperation::CastWriteOperation(op); - if (!op->HasResultSentFlag()) { + if (!op->HasResultSentFlag() && !op->IsProposeResultSentEarly()) { DataShard.IncCounter(COUNTER_WRITE_COMPLETE); if (writeOp->GetWriteResult()) diff --git a/ydb/core/tx/datashard/operation.h b/ydb/core/tx/datashard/operation.h index 201e22636a74..8cffc801f97b 100644 --- a/ydb/core/tx/datashard/operation.h +++ b/ydb/core/tx/datashard/operation.h @@ -402,12 +402,15 @@ class TBasicOpInfo { bool IsMvccSnapshotRead() const { return !MvccSnapshot.IsMax(); } const TRowVersion& GetMvccSnapshot() const { return MvccSnapshot; } - bool IsMvccSnapshotRepeatable() const { return MvccSnapshotRepeatable; } + bool IsMvccSnapshotRepeatable() const { return MvccSnapshotRepeatable_; } void SetMvccSnapshot(const TRowVersion& snapshot, bool isRepeatable = true) { MvccSnapshot = snapshot; - MvccSnapshotRepeatable = isRepeatable; + MvccSnapshotRepeatable_ = isRepeatable; } + bool IsProposeResultSentEarly() const { return ProposeResultSentEarly_; } + void SetProposeResultSentEarly(bool value = true) { ProposeResultSentEarly_ = value; } + /////////////////////////////////// // DEBUG AND MONITORING // /////////////////////////////////// @@ -429,7 +432,11 @@ class TBasicOpInfo { TSnapshotKey AcquiredSnapshotKey; TRowVersion MvccSnapshot = TRowVersion::Max(); - bool MvccSnapshotRepeatable = false; + +private: + // Runtime flags + ui8 MvccSnapshotRepeatable_ : 1 = 0; + ui8 ProposeResultSentEarly_ : 1 = 0; }; struct TRSData { From 3f9368008384cdc11b48219d07b64aa6bf1e8d6b Mon Sep 17 00:00:00 2001 From: Maxim Gorbunov Date: Tue, 12 Mar 2024 10:31:34 +0100 Subject: [PATCH 067/117] Generate CMakeLists (#2648) --- ydb/core/tx/scheme_board/CMakeLists.darwin-arm64.txt | 2 ++ ydb/core/tx/scheme_board/CMakeLists.darwin-x86_64.txt | 2 ++ ydb/core/tx/scheme_board/CMakeLists.linux-aarch64.txt | 2 ++ ydb/core/tx/scheme_board/CMakeLists.linux-x86_64.txt | 2 ++ ydb/core/tx/scheme_board/CMakeLists.windows-x86_64.txt | 2 ++ 5 files changed, 10 insertions(+) diff --git a/ydb/core/tx/scheme_board/CMakeLists.darwin-arm64.txt b/ydb/core/tx/scheme_board/CMakeLists.darwin-arm64.txt index 65a6b9453ca1..1a1f1257a6a5 100644 --- a/ydb/core/tx/scheme_board/CMakeLists.darwin-arm64.txt +++ b/ydb/core/tx/scheme_board/CMakeLists.darwin-arm64.txt @@ -35,6 +35,7 @@ target_link_libraries(core-tx-scheme_board PUBLIC ) target_sources(core-tx-scheme_board PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/cache.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/events.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/load_test.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/monitoring.cpp @@ -42,6 +43,7 @@ target_sources(core-tx-scheme_board PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/replica.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/subscriber.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/two_part_description.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/opaque_path_description.cpp ) generate_enum_serilization(core-tx-scheme_board ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/subscriber.h diff --git a/ydb/core/tx/scheme_board/CMakeLists.darwin-x86_64.txt b/ydb/core/tx/scheme_board/CMakeLists.darwin-x86_64.txt index 65a6b9453ca1..1a1f1257a6a5 100644 --- a/ydb/core/tx/scheme_board/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/tx/scheme_board/CMakeLists.darwin-x86_64.txt @@ -35,6 +35,7 @@ target_link_libraries(core-tx-scheme_board PUBLIC ) target_sources(core-tx-scheme_board PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/cache.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/events.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/load_test.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/monitoring.cpp @@ -42,6 +43,7 @@ target_sources(core-tx-scheme_board PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/replica.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/subscriber.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/two_part_description.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/opaque_path_description.cpp ) generate_enum_serilization(core-tx-scheme_board ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/subscriber.h diff --git a/ydb/core/tx/scheme_board/CMakeLists.linux-aarch64.txt b/ydb/core/tx/scheme_board/CMakeLists.linux-aarch64.txt index ec77757c3e0f..b3b223597a8d 100644 --- a/ydb/core/tx/scheme_board/CMakeLists.linux-aarch64.txt +++ b/ydb/core/tx/scheme_board/CMakeLists.linux-aarch64.txt @@ -36,6 +36,7 @@ target_link_libraries(core-tx-scheme_board PUBLIC ) target_sources(core-tx-scheme_board PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/cache.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/events.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/load_test.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/monitoring.cpp @@ -43,6 +44,7 @@ target_sources(core-tx-scheme_board PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/replica.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/subscriber.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/two_part_description.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/opaque_path_description.cpp ) generate_enum_serilization(core-tx-scheme_board ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/subscriber.h diff --git a/ydb/core/tx/scheme_board/CMakeLists.linux-x86_64.txt b/ydb/core/tx/scheme_board/CMakeLists.linux-x86_64.txt index ec77757c3e0f..b3b223597a8d 100644 --- a/ydb/core/tx/scheme_board/CMakeLists.linux-x86_64.txt +++ b/ydb/core/tx/scheme_board/CMakeLists.linux-x86_64.txt @@ -36,6 +36,7 @@ target_link_libraries(core-tx-scheme_board PUBLIC ) target_sources(core-tx-scheme_board PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/cache.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/events.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/load_test.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/monitoring.cpp @@ -43,6 +44,7 @@ target_sources(core-tx-scheme_board PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/replica.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/subscriber.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/two_part_description.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/opaque_path_description.cpp ) generate_enum_serilization(core-tx-scheme_board ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/subscriber.h diff --git a/ydb/core/tx/scheme_board/CMakeLists.windows-x86_64.txt b/ydb/core/tx/scheme_board/CMakeLists.windows-x86_64.txt index 65a6b9453ca1..1a1f1257a6a5 100644 --- a/ydb/core/tx/scheme_board/CMakeLists.windows-x86_64.txt +++ b/ydb/core/tx/scheme_board/CMakeLists.windows-x86_64.txt @@ -35,6 +35,7 @@ target_link_libraries(core-tx-scheme_board PUBLIC ) target_sources(core-tx-scheme_board PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/cache.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/events.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/helpers.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/load_test.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/monitoring.cpp @@ -42,6 +43,7 @@ target_sources(core-tx-scheme_board PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/replica.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/subscriber.cpp ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/two_part_description.cpp + ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/opaque_path_description.cpp ) generate_enum_serilization(core-tx-scheme_board ${CMAKE_SOURCE_DIR}/ydb/core/tx/scheme_board/subscriber.h From 8688b17de51a27873881ccf2215c25cda8b4576c Mon Sep 17 00:00:00 2001 From: Sergey Belyakov Date: Tue, 12 Mar 2024 12:38:15 +0300 Subject: [PATCH 068/117] Move construction of current compatibility information out of driver_lib (#2633) --- ydb/apps/version/version_definition.cpp | 38 +++++++++++++++++++ ydb/apps/version/ya.make | 11 ++++++ ydb/apps/ydbd/ya.make | 1 + ydb/core/actorlib_impl/ut/ya.make | 1 + ydb/core/blobstorage/incrhuge/ut/ya.make | 1 + .../blobstorage/ut_blobstorage/lib/ya.make | 1 + ydb/core/blobstorage/ut_group/ya.make | 1 + ydb/core/blobstorage/ut_mirror3of4/ya.make | 1 + ydb/core/blobstorage/ut_vdisk/ya.make | 1 + ydb/core/blobstorage/ut_vdisk2/ya.make | 1 + ydb/core/blobstorage/vdisk/syncer/ya.make | 1 + ydb/core/driver_lib/version/ut/ya.make | 1 + ydb/core/driver_lib/version/version.cpp | 33 +--------------- ydb/core/driver_lib/version/version.h | 2 + .../mind/bscontroller/ut_selfheal/ya.make | 1 + ydb/core/testlib/actors/ya.make | 1 + ydb/core/testlib/ya.make | 1 + 17 files changed, 65 insertions(+), 32 deletions(-) create mode 100644 ydb/apps/version/version_definition.cpp create mode 100644 ydb/apps/version/ya.make diff --git a/ydb/apps/version/version_definition.cpp b/ydb/apps/version/version_definition.cpp new file mode 100644 index 000000000000..6f71ec44e6d4 --- /dev/null +++ b/ydb/apps/version/version_definition.cpp @@ -0,0 +1,38 @@ +#include + +NKikimrConfig::TCurrentCompatibilityInfo NKikimr::TCompatibilityInfo::MakeCurrent() { + using TCurrentConstructor = NKikimr::TCompatibilityInfo::TProtoConstructor::TCurrentCompatibilityInfo; + using TVersionConstructor = NKikimr::TCompatibilityInfo::TProtoConstructor::TVersion; + using TCompatibilityRuleConstructor = NKikimr::TCompatibilityInfo::TProtoConstructor::TCompatibilityRule; + + return TCurrentConstructor{ + .Application = "ydb", + .Version = TVersionConstructor{ + .Year = 24, + .Major = 1, + }, + .CanLoadFrom = { + TCompatibilityRuleConstructor{ + .LowerLimit = TVersionConstructor{ .Year = 23, .Major = 4 }, + .UpperLimit = TVersionConstructor{ .Year = 24, .Major = 1 }, + }, + }, + .StoresReadableBy = { + TCompatibilityRuleConstructor{ + .LowerLimit = TVersionConstructor{ .Year = 23, .Major = 4 }, + .UpperLimit = TVersionConstructor{ .Year = 24, .Major = 1 }, + }, + }, + .CanConnectTo = { + TCompatibilityRuleConstructor{ + .LowerLimit = TVersionConstructor{ .Year = 23, .Major = 4 }, + .UpperLimit = TVersionConstructor{ .Year = 24, .Major = 1 }, + }, + TCompatibilityRuleConstructor{ + .Application = "nbs", + .LowerLimit = TVersionConstructor{ .Year = 23, .Major = 3 }, + .UpperLimit = TVersionConstructor{ .Year = 24, .Major = 1 }, + }, + } + }.ToPB(); +} diff --git a/ydb/apps/version/ya.make b/ydb/apps/version/ya.make new file mode 100644 index 000000000000..d3b1eb34a7f1 --- /dev/null +++ b/ydb/apps/version/ya.make @@ -0,0 +1,11 @@ +LIBRARY(version_definition) + +SRCS( + version_definition.cpp +) + +PEERDIR( + ydb/core/driver_lib/version +) + +END() diff --git a/ydb/apps/ydbd/ya.make b/ydb/apps/ydbd/ya.make index 4f15c464fba0..e4176a682398 100644 --- a/ydb/apps/ydbd/ya.make +++ b/ydb/apps/ydbd/ya.make @@ -35,6 +35,7 @@ IF (ARCH_X86_64) ENDIF() PEERDIR( + ydb/apps/version ydb/core/driver_lib/run ydb/core/protos ydb/core/security diff --git a/ydb/core/actorlib_impl/ut/ya.make b/ydb/core/actorlib_impl/ut/ya.make index 0a89b3e4b6e9..d4f2a0bb1540 100644 --- a/ydb/core/actorlib_impl/ut/ya.make +++ b/ydb/core/actorlib_impl/ut/ya.make @@ -13,6 +13,7 @@ ELSE() ENDIF() PEERDIR( + ydb/apps/version ydb/library/actors/core ydb/library/actors/interconnect library/cpp/getopt diff --git a/ydb/core/blobstorage/incrhuge/ut/ya.make b/ydb/core/blobstorage/incrhuge/ut/ya.make index 1dab38ef3f26..c7936f615c71 100644 --- a/ydb/core/blobstorage/incrhuge/ut/ya.make +++ b/ydb/core/blobstorage/incrhuge/ut/ya.make @@ -12,6 +12,7 @@ ELSE() ENDIF() PEERDIR( + ydb/apps/version ydb/library/actors/protos ydb/core/blobstorage ydb/core/blobstorage/incrhuge diff --git a/ydb/core/blobstorage/ut_blobstorage/lib/ya.make b/ydb/core/blobstorage/ut_blobstorage/lib/ya.make index 0572ce32b6a4..58b44a1be8e2 100644 --- a/ydb/core/blobstorage/ut_blobstorage/lib/ya.make +++ b/ydb/core/blobstorage/ut_blobstorage/lib/ya.make @@ -16,6 +16,7 @@ SRCS( PEERDIR( library/cpp/digest/md5 library/cpp/testing/unittest + ydb/apps/version ydb/core/base ydb/core/blob_depot ydb/core/blobstorage/backpressure diff --git a/ydb/core/blobstorage/ut_group/ya.make b/ydb/core/blobstorage/ut_group/ya.make index aa0a9c0ebab8..88e601a9eaa3 100644 --- a/ydb/core/blobstorage/ut_group/ya.make +++ b/ydb/core/blobstorage/ut_group/ya.make @@ -16,6 +16,7 @@ ELSE() ENDIF() PEERDIR( + ydb/apps/version ydb/library/actors/interconnect/mock library/cpp/testing/unittest ydb/core/blobstorage/crypto diff --git a/ydb/core/blobstorage/ut_mirror3of4/ya.make b/ydb/core/blobstorage/ut_mirror3of4/ya.make index 4d89f5e383fd..bfd43f049cd1 100644 --- a/ydb/core/blobstorage/ut_mirror3of4/ya.make +++ b/ydb/core/blobstorage/ut_mirror3of4/ya.make @@ -9,6 +9,7 @@ SIZE(MEDIUM) TIMEOUT(600) PEERDIR( + ydb/apps/version ydb/library/actors/interconnect/mock library/cpp/testing/unittest ydb/core/blobstorage/backpressure diff --git a/ydb/core/blobstorage/ut_vdisk/ya.make b/ydb/core/blobstorage/ut_vdisk/ya.make index 6b95175079a9..526d1e82de93 100644 --- a/ydb/core/blobstorage/ut_vdisk/ya.make +++ b/ydb/core/blobstorage/ut_vdisk/ya.make @@ -18,6 +18,7 @@ SRCS( ) PEERDIR( + ydb/apps/version ydb/library/actors/protos library/cpp/codecs ydb/core/base diff --git a/ydb/core/blobstorage/ut_vdisk2/ya.make b/ydb/core/blobstorage/ut_vdisk2/ya.make index 8d2d47103207..394f0576b6ac 100644 --- a/ydb/core/blobstorage/ut_vdisk2/ya.make +++ b/ydb/core/blobstorage/ut_vdisk2/ya.make @@ -16,6 +16,7 @@ SRCS( ) PEERDIR( + ydb/apps/version library/cpp/testing/unittest ydb/core/blobstorage/backpressure ydb/core/blobstorage/groupinfo diff --git a/ydb/core/blobstorage/vdisk/syncer/ya.make b/ydb/core/blobstorage/vdisk/syncer/ya.make index fae14c758326..176da08e58e0 100644 --- a/ydb/core/blobstorage/vdisk/syncer/ya.make +++ b/ydb/core/blobstorage/vdisk/syncer/ya.make @@ -1,6 +1,7 @@ LIBRARY() PEERDIR( + ydb/apps/version ydb/library/actors/core ydb/library/actors/interconnect library/cpp/monlib/service/pages diff --git a/ydb/core/driver_lib/version/ut/ya.make b/ydb/core/driver_lib/version/ut/ya.make index 0c5a755c2a82..4b3833beacea 100644 --- a/ydb/core/driver_lib/version/ut/ya.make +++ b/ydb/core/driver_lib/version/ut/ya.make @@ -7,6 +7,7 @@ SIZE(MEDIUM) PEERDIR( ydb/core/driver_lib/version + ydb/apps/version ) END() diff --git a/ydb/core/driver_lib/version/version.cpp b/ydb/core/driver_lib/version/version.cpp index b57042bde71b..3852aea33897 100644 --- a/ydb/core/driver_lib/version/version.cpp +++ b/ydb/core/driver_lib/version/version.cpp @@ -17,45 +17,14 @@ using EComponentId = NKikimrConfig::TCompatibilityRule; using TComponentId = NKikimrConfig::TCompatibilityRule::EComponentId; TCompatibilityInfo::TCompatibilityInfo() { - using TCurrentConstructor = TCompatibilityInfo::TProtoConstructor::TCurrentCompatibilityInfo; using TStoredConstructor = TCompatibilityInfo::TProtoConstructor::TStoredCompatibilityInfo; - using TCompatibilityRuleConstructor = TCompatibilityInfo::TProtoConstructor::TCompatibilityRule; using TVersionConstructor = TCompatibilityInfo::TProtoConstructor::TVersion; ///////////////////////////////////////////////////////// // Current CompatibilityInfo ///////////////////////////////////////////////////////// - auto current = TCurrentConstructor{ - .Application = "ydb", - .Version = TVersionConstructor{ - .Year = 24, - .Major = 1, - }, - .CanLoadFrom = { - TCompatibilityRuleConstructor{ - .LowerLimit = TVersionConstructor{ .Year = 23, .Major = 4 }, - .UpperLimit = TVersionConstructor{ .Year = 24, .Major = 1 }, - }, - }, - .StoresReadableBy = { - TCompatibilityRuleConstructor{ - .LowerLimit = TVersionConstructor{ .Year = 23, .Major = 4 }, - .UpperLimit = TVersionConstructor{ .Year = 24, .Major = 1 }, - }, - }, - .CanConnectTo = { - TCompatibilityRuleConstructor{ - .LowerLimit = TVersionConstructor{ .Year = 23, .Major = 4 }, - .UpperLimit = TVersionConstructor{ .Year = 24, .Major = 1 }, - }, - TCompatibilityRuleConstructor{ - .Application = "nbs", - .LowerLimit = TVersionConstructor{ .Year = 23, .Major = 3 }, - .UpperLimit = TVersionConstructor{ .Year = 24, .Major = 1 }, - }, - } - }.ToPB(); + auto current = MakeCurrent(); bool success = CompleteFromTag(current); Y_UNUSED(success); diff --git a/ydb/core/driver_lib/version/version.h b/ydb/core/driver_lib/version/version.h index 1ecf76cb9e28..a18b2ad0cb5b 100644 --- a/ydb/core/driver_lib/version/version.h +++ b/ydb/core/driver_lib/version/version.h @@ -141,6 +141,8 @@ class TCompatibilityInfo { bool CompleteFromTag(NKikimrConfig::TCurrentCompatibilityInfo& current); + static NKikimrConfig::TCurrentCompatibilityInfo MakeCurrent(); + NKikimrConfig::TStoredCompatibilityInfo MakeStored(TComponentId componentId) const; NKikimrConfig::TStoredCompatibilityInfo MakeStored(TComponentId componentId, const NKikimrConfig::TCurrentCompatibilityInfo* current) const; diff --git a/ydb/core/mind/bscontroller/ut_selfheal/ya.make b/ydb/core/mind/bscontroller/ut_selfheal/ya.make index c3b4ba285713..1189fc7e7025 100644 --- a/ydb/core/mind/bscontroller/ut_selfheal/ya.make +++ b/ydb/core/mind/bscontroller/ut_selfheal/ya.make @@ -16,6 +16,7 @@ SRCS( ) PEERDIR( + ydb/apps/version ydb/core/blobstorage/dsproxy/mock ydb/core/blobstorage/pdisk/mock ydb/core/mind/bscontroller diff --git a/ydb/core/testlib/actors/ya.make b/ydb/core/testlib/actors/ya.make index fc27aa01c236..25f814605794 100644 --- a/ydb/core/testlib/actors/ya.make +++ b/ydb/core/testlib/actors/ya.make @@ -5,6 +5,7 @@ SRCS( ) PEERDIR( + ydb/apps/version ydb/library/actors/testlib library/cpp/testing/unittest ydb/core/base diff --git a/ydb/core/testlib/ya.make b/ydb/core/testlib/ya.make index e7a93b69ae78..009636936e28 100644 --- a/ydb/core/testlib/ya.make +++ b/ydb/core/testlib/ya.make @@ -22,6 +22,7 @@ SRCS( ) PEERDIR( + ydb/apps/version ydb/library/actors/core ydb/library/actors/interconnect ydb/library/grpc/client From d9f28806396272fdf28200612a5ddbbad02e60ee Mon Sep 17 00:00:00 2001 From: Vasily Gerasimov Date: Tue, 12 Mar 2024 14:51:01 +0100 Subject: [PATCH 069/117] Fix script feature flag test in 24-1 (#2655) --- ydb/core/kqp/proxy_service/kqp_proxy_ut.cpp | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/ydb/core/kqp/proxy_service/kqp_proxy_ut.cpp b/ydb/core/kqp/proxy_service/kqp_proxy_ut.cpp index 3e090a42c665..e88af0455f22 100644 --- a/ydb/core/kqp/proxy_service/kqp_proxy_ut.cpp +++ b/ydb/core/kqp/proxy_service/kqp_proxy_ut.cpp @@ -492,8 +492,8 @@ Y_UNIT_TEST_SUITE(KqpProxy) { Y_UNIT_TEST(ExecuteScriptFailsWithoutFeatureFlag) { NKikimrConfig::TAppConfig appConfig; + appConfig.MutableFeatureFlags()->SetEnableScriptExecutionOperations(false); NYdb::TKikimrWithGrpcAndRootSchema server(appConfig); - appConfig.MutableFeatureFlags()->SetEnableScriptExecutionOperations(false); // default server.Server_->GetRuntime()->SetLogPriority(NKikimrServices::KQP_PROXY, NActors::NLog::PRI_DEBUG); ui16 grpc = server.GetPort(); From b3004c6f27edd14464f53dedf69e9adb72a1ddc0 Mon Sep 17 00:00:00 2001 From: Vitalii Gridnev Date: Tue, 12 Mar 2024 22:11:49 +0300 Subject: [PATCH 070/117] simplify query service enable (#2676) --- ydb/core/driver_lib/run/run.cpp | 4 ++++ 1 file changed, 4 insertions(+) diff --git a/ydb/core/driver_lib/run/run.cpp b/ydb/core/driver_lib/run/run.cpp index f75eb3c765e9..03b8ce3c2a20 100644 --- a/ydb/core/driver_lib/run/run.cpp +++ b/ydb/core/driver_lib/run/run.cpp @@ -584,6 +584,10 @@ void TKikimrRunner::InitializeGRpc(const TKikimrRunConfig& runConfig) { TServiceCfg hasKeyValue = services.empty(); names["keyvalue"] = &hasKeyValue; + if (hasTableService || hasYql) { + hasQueryService = true; + } + std::unordered_set enabled; for (const auto& name : services) { enabled.insert(name); From c205eed26b56bb90a835be4cb93c68716efae355 Mon Sep 17 00:00:00 2001 From: Daniil Demin Date: Wed, 13 Mar 2024 11:39:12 +0300 Subject: [PATCH 071/117] Use empty parsing context to build view's select in CREATE VIEW statement (#2049) (#2595) Based on: #2049 KIKIMR-20891 CREATE VIEW statement parses (and validates) the select statement saved in the view. It should be parsed in a context isolated from the statements executed before the CREATE VIEW statement (we haven't decided yet on the exact scope of the context of the view's select statement, see [KIKIMR-20656](https://st.yandex-team.ru/KIKIMR-20656)). It is pretty obvious that one should be able to execute the following statement in one go ("one go" = one press of a "run" button in YDB UI): ```sql -- create view NecessaryInnerView with (security_invoker = true) as select 1; -- create view ContextTestingView with (security_invoker = true) as select * from `/local/NecessaryInnerView`; -- where `/local/...` is your cluster name drop view ContextTestingView; create view ContextTestingView with (security_invoker = true) as select * from `/local/NecessaryInnerView`; ``` However, executing both drop view and create view in one go currently produces and error: ``` DropObject is not yet implemented for intent determination transformer ``` which indicates that the context of the inner query: ```sql select * from `/local/NecessaryInnerView` ``` is polluted by the previous: ```sql drop view ContextTestingView; ``` statement. This problem is fixed by using an empty parsing context for parsing view's inner select statement during handling of CREATE VIEW statement. --- ydb/core/kqp/ut/view/view_ut.cpp | 18 +++++++++ ydb/library/yql/sql/v1/sql_translation.cpp | 43 ++++++++++++++++------ 2 files changed, 49 insertions(+), 12 deletions(-) diff --git a/ydb/core/kqp/ut/view/view_ut.cpp b/ydb/core/kqp/ut/view/view_ut.cpp index cfd6adf5c654..3a74e319bef7 100644 --- a/ydb/core/kqp/ut/view/view_ut.cpp +++ b/ydb/core/kqp/ut/view/view_ut.cpp @@ -316,6 +316,24 @@ Y_UNIT_TEST_SUITE(TKQPViewTest) { UNIT_ASSERT(dropResult.GetIssues().ToString().Contains("Error: Path does not exist")); } } + + Y_UNIT_TEST(ContextPollution) { + TKikimrRunner kikimr(TKikimrSettings().SetWithSampleTables(false)); + EnableViewsFeatureFlag(kikimr); + auto session = kikimr.GetTableClient().CreateSession().GetValueSync().GetSession(); + + ExecuteDataDefinitionQuery(session, R"( + CREATE VIEW InnerView WITH (security_invoker = TRUE) AS SELECT 1; + )"); + ExecuteDataDefinitionQuery(session, R"( + CREATE VIEW OuterView WITH (security_invoker = TRUE) AS SELECT * FROM InnerView; + )"); + + ExecuteDataDefinitionQuery(session, R"( + DROP VIEW OuterView; + CREATE VIEW OuterView WITH (security_invoker = TRUE) AS SELECT * FROM InnerView; + )"); + } } Y_UNIT_TEST_SUITE(TSelectFromViewTest) { diff --git a/ydb/library/yql/sql/v1/sql_translation.cpp b/ydb/library/yql/sql/v1/sql_translation.cpp index 073dd5e07397..aaef357bd06c 100644 --- a/ydb/library/yql/sql/v1/sql_translation.cpp +++ b/ydb/library/yql/sql/v1/sql_translation.cpp @@ -53,6 +53,33 @@ TString CollectTokens(const TRule_select_stmt& selectStatement) { return tokenCollector.Tokens; } +NSQLTranslation::TTranslationSettings CreateViewTranslationSettings(const NSQLTranslation::TTranslationSettings& base) { + NSQLTranslation::TTranslationSettings settings; + + settings.ClusterMapping = base.ClusterMapping; + settings.Mode = NSQLTranslation::ESqlMode::LIMITED_VIEW; + + return settings; +} + +TNodePtr BuildViewSelect(const TRule_select_stmt& query, TContext& ctx) { + const auto viewTranslationSettings = CreateViewTranslationSettings(ctx.Settings); + TContext viewParsingContext(viewTranslationSettings, {}, ctx.Issues); + TSqlSelect select(viewParsingContext, viewTranslationSettings.Mode); + TPosition pos; + auto source = select.Build(query, pos); + if (!source) { + return nullptr; + } + return BuildSelectResult( + pos, + std::move(source), + false, + false, + viewParsingContext.Scoped + ); +} + } namespace NSQLTranslationV1 { @@ -4484,19 +4511,11 @@ bool TSqlTranslation::ParseViewQuery(std::map& features, const TString queryText = CollectTokens(query); features["query_text"] = {Ctx.Pos(), queryText}; - { - TSqlSelect select(Ctx, Mode); - TPosition pos; - auto source = select.Build(query, pos); - if (!source) { - return false; - } - features["query_ast"] = {BuildSelectResult(pos, - std::move(source), - false, - false, - Ctx.Scoped), Ctx}; + const auto viewSelect = BuildViewSelect(query, Ctx); + if (!viewSelect) { + return false; } + features["query_ast"] = {viewSelect, Ctx}; return true; } From a510fe8463d318d17a7fa3f921284995e495d4c7 Mon Sep 17 00:00:00 2001 From: Nikolay Shestakov Date: Thu, 14 Mar 2024 13:06:41 +0500 Subject: [PATCH 072/117] Fix Verify in WriteSessionActor (#2651) (#2700) --- ydb/services/deprecated/persqueue_v0/grpc_pq_actor.h | 2 ++ .../deprecated/persqueue_v0/grpc_pq_write_actor.cpp | 12 ++++++++++-- .../persqueue_v1/actors/write_session_actor.h | 2 ++ .../persqueue_v1/actors/write_session_actor.ipp | 9 ++++++++- 4 files changed, 22 insertions(+), 3 deletions(-) diff --git a/ydb/services/deprecated/persqueue_v0/grpc_pq_actor.h b/ydb/services/deprecated/persqueue_v0/grpc_pq_actor.h index 0d5e472ca443..cb1ca35ecd86 100644 --- a/ydb/services/deprecated/persqueue_v0/grpc_pq_actor.h +++ b/ydb/services/deprecated/persqueue_v0/grpc_pq_actor.h @@ -554,6 +554,8 @@ class TWriteSessionActor : public NActors::TActorBootstrapped { diff --git a/ydb/services/deprecated/persqueue_v0/grpc_pq_write_actor.cpp b/ydb/services/deprecated/persqueue_v0/grpc_pq_write_actor.cpp index e29b4bc4f304..6172305476af 100644 --- a/ydb/services/deprecated/persqueue_v0/grpc_pq_write_actor.cpp +++ b/ydb/services/deprecated/persqueue_v0/grpc_pq_write_actor.cpp @@ -310,7 +310,10 @@ void TWriteSessionActor::SetupCounters(const TString& cloudId, const TString& db void TWriteSessionActor::Handle(TEvDescribeTopicsResponse::TPtr& ev, const TActorContext& ctx) { - Y_ABORT_UNLESS(State == ES_WAIT_SCHEME || State == ES_INITED); + if (State != ES_WAIT_SCHEME && State != ES_INITED) { + return CloseSession("erroneous internal state", NPersQueue::NErrorCode::ERROR, ctx); + } + auto& res = ev->Get()->Result; Y_ABORT_UNLESS(res->ResultSet.size() == 1); @@ -503,6 +506,11 @@ void TWriteSessionActor::ProceedPartition(const ui32 partition, const TActorCont } void TWriteSessionActor::CloseSession(const TString& errorReason, const NPersQueue::NErrorCode::EErrorCode errorCode, const NActors::TActorContext& ctx) { + if (SessionClosed) { + return; + } + SessionClosed = true; + if (errorCode != NPersQueue::NErrorCode::OK) { if (InternalErrorCode(errorCode)) { SLIErrors.Inc(); @@ -865,7 +873,7 @@ void TWriteSessionActor::LogSession(const TActorContext& ctx) { void TWriteSessionActor::HandleWakeup(const TActorContext& ctx) { if (State != ES_INITED) { - return; + return CloseSession("erroneous internal state", NPersQueue::NErrorCode::ERROR, ctx); } auto now = ctx.Now(); diff --git a/ydb/services/persqueue_v1/actors/write_session_actor.h b/ydb/services/persqueue_v1/actors/write_session_actor.h index 2d69db971d7f..17c47aab7837 100644 --- a/ydb/services/persqueue_v1/actors/write_session_actor.h +++ b/ydb/services/persqueue_v1/actors/write_session_actor.h @@ -271,6 +271,8 @@ class TWriteSessionActor TActorId PartitionWriterCache; TActorId PartitionChooser; + + bool SessionClosed = false; }; } diff --git a/ydb/services/persqueue_v1/actors/write_session_actor.ipp b/ydb/services/persqueue_v1/actors/write_session_actor.ipp index b76ab8fb24a7..825e342b7ead 100644 --- a/ydb/services/persqueue_v1/actors/write_session_actor.ipp +++ b/ydb/services/persqueue_v1/actors/write_session_actor.ipp @@ -724,6 +724,10 @@ void TWriteSessionActor::DestroyPartitionWriterCache(const template void TWriteSessionActor::CloseSession(const TString& errorReason, const PersQueue::ErrorCode::ErrorCode errorCode, const NActors::TActorContext& ctx) { + if (SessionClosed) { + return; + } + SessionClosed = true; if (errorCode != PersQueue::ErrorCode::OK) { @@ -1503,7 +1507,10 @@ void TWriteSessionActor::Handle(TEvents::TEvWakeup::TPtr& template void TWriteSessionActor::RecheckACL(const TActorContext& ctx) { - Y_ABORT_UNLESS(State == ES_INITED); + if (State != ES_INITED) { + LOG_ERROR_S(ctx, NKikimrServices::PQ_WRITE_PROXY, "WriteSessionActor state is wrong. Actual state '" << (int)State << "'"); + return CloseSession("erroneous internal state", PersQueue::ErrorCode::ERROR, ctx); + } auto now = ctx.Now(); From 9986dce991b9c838a2d12513577d8bb83f034679 Mon Sep 17 00:00:00 2001 From: Nikolay Shestakov Date: Thu, 14 Mar 2024 18:53:58 +0500 Subject: [PATCH 073/117] Fixing PartitionChooserActors leaks (#2742) (#2750) --- .../writer/partition_chooser_impl__abstract_chooser_actor.h | 4 ++-- 1 file changed, 2 insertions(+), 2 deletions(-) diff --git a/ydb/core/persqueue/writer/partition_chooser_impl__abstract_chooser_actor.h b/ydb/core/persqueue/writer/partition_chooser_impl__abstract_chooser_actor.h index 4b385f779cda..0e975c6cec67 100644 --- a/ydb/core/persqueue/writer/partition_chooser_impl__abstract_chooser_actor.h +++ b/ydb/core/persqueue/writer/partition_chooser_impl__abstract_chooser_actor.h @@ -207,7 +207,7 @@ class TAbstractPartitionChooserActor: public TActorBootstrapped { TRACE_EVENT(NKikimrServices::PQ_PARTITION_CHOOSER); switch (ev->GetTypeRewrite()) { HFunc(NKqp::TEvKqp::TEvQueryResponse, HandleUpdate); - sFunc(TEvents::TEvPoison, ScheduleStop); + SFunc(TEvents::TEvPoison, TThis::Die); } } @@ -237,7 +237,7 @@ class TAbstractPartitionChooserActor: public TActorBootstrapped { HFunc(NKikimr::TEvPQ::TEvCheckPartitionStatusResponse, Handle); HFunc(TEvTabletPipe::TEvClientConnected, HandleOwnership); HFunc(TEvTabletPipe::TEvClientDestroyed, HandleOwnership); - sFunc(TEvents::TEvPoison, ScheduleStop); + SFunc(TEvents::TEvPoison, TThis::Die); } } From c1ad21b74e691d78479b7be23c41d9dfd187ae88 Mon Sep 17 00:00:00 2001 From: Sergey Belyakov Date: Thu, 14 Mar 2024 19:33:33 +0300 Subject: [PATCH 074/117] Fix PEERDIRs (#2754) --- ydb/core/blobstorage/ut_pdiskfit/pdiskfit/ya.make | 1 + ydb/core/blobstorage/ut_pdiskfit/ut/ya.make | 1 + ydb/core/blobstorage/ut_testshard/ya.make | 1 + ydb/core/blobstorage/vdisk/syncer/ut/ya.make | 1 + ydb/core/blobstorage/vdisk/syncer/ya.make | 1 - 5 files changed, 4 insertions(+), 1 deletion(-) diff --git a/ydb/core/blobstorage/ut_pdiskfit/pdiskfit/ya.make b/ydb/core/blobstorage/ut_pdiskfit/pdiskfit/ya.make index 3f1ae9920495..ef98e816685e 100644 --- a/ydb/core/blobstorage/ut_pdiskfit/pdiskfit/ya.make +++ b/ydb/core/blobstorage/ut_pdiskfit/pdiskfit/ya.make @@ -6,6 +6,7 @@ IF (OS_LINUX) ) PEERDIR( + ydb/apps/version library/cpp/getopt library/cpp/string_utils/parse_size ydb/core/blobstorage diff --git a/ydb/core/blobstorage/ut_pdiskfit/ut/ya.make b/ydb/core/blobstorage/ut_pdiskfit/ut/ya.make index b4e9ff9707ba..31b328c8a37f 100644 --- a/ydb/core/blobstorage/ut_pdiskfit/ut/ya.make +++ b/ydb/core/blobstorage/ut_pdiskfit/ut/ya.make @@ -16,6 +16,7 @@ IF (OS_LINUX AND NOT WITH_VALGRIND) ENDIF () PEERDIR( + ydb/apps/version ydb/core/blobstorage ydb/core/blobstorage/ut_pdiskfit/lib ) diff --git a/ydb/core/blobstorage/ut_testshard/ya.make b/ydb/core/blobstorage/ut_testshard/ya.make index e1c6adef761d..47409b20d301 100644 --- a/ydb/core/blobstorage/ut_testshard/ya.make +++ b/ydb/core/blobstorage/ut_testshard/ya.make @@ -12,6 +12,7 @@ UNITTEST() ) PEERDIR( + ydb/apps/version ydb/core/base ydb/core/blob_depot ydb/core/blobstorage/backpressure diff --git a/ydb/core/blobstorage/vdisk/syncer/ut/ya.make b/ydb/core/blobstorage/vdisk/syncer/ut/ya.make index 8844b2aeafd0..21f122b246d4 100644 --- a/ydb/core/blobstorage/vdisk/syncer/ut/ya.make +++ b/ydb/core/blobstorage/vdisk/syncer/ut/ya.make @@ -7,6 +7,7 @@ TIMEOUT(600) SIZE(MEDIUM) PEERDIR( + ydb/apps/version library/cpp/getopt library/cpp/svnversion ydb/core/base diff --git a/ydb/core/blobstorage/vdisk/syncer/ya.make b/ydb/core/blobstorage/vdisk/syncer/ya.make index 176da08e58e0..fae14c758326 100644 --- a/ydb/core/blobstorage/vdisk/syncer/ya.make +++ b/ydb/core/blobstorage/vdisk/syncer/ya.make @@ -1,7 +1,6 @@ LIBRARY() PEERDIR( - ydb/apps/version ydb/library/actors/core ydb/library/actors/interconnect library/cpp/monlib/service/pages From 6d4a423c0770ffddb4f7e69491c8d14a936362f3 Mon Sep 17 00:00:00 2001 From: Innokentii Mokin Date: Fri, 15 Mar 2024 11:41:16 +0300 Subject: [PATCH 075/117] 24-1: backport ydb#2397 add allow/deny lists to configs dispatcher (#2790) --- ydb/core/cms/cms_ut_common.cpp | 8 +- ydb/core/cms/console/configs_dispatcher.cpp | 131 ++++++++++-------- ydb/core/cms/console/configs_dispatcher.h | 30 +++- .../run/kikimr_services_initializers.cpp | 13 +- ydb/core/testlib/tenant_runtime.cpp | 7 +- ydb/core/testlib/test_client.cpp | 5 +- 6 files changed, 128 insertions(+), 66 deletions(-) diff --git a/ydb/core/cms/cms_ut_common.cpp b/ydb/core/cms/cms_ut_common.cpp index ab8843330d19..876bde9982ef 100644 --- a/ydb/core/cms/cms_ut_common.cpp +++ b/ydb/core/cms/cms_ut_common.cpp @@ -486,7 +486,13 @@ static void SetupServices(TTestActorRuntime &runtime, const TTestEnvOpts &option NKikimrConfig::TAppConfig appConfig; appConfig.MutableBootstrapConfig()->CopyFrom(TFakeNodeWhiteboardService::BootstrapConfig); runtime.AddLocalService(MakeConfigsDispatcherID(runtime.GetNodeId(0)), - TActorSetupCmd(CreateConfigsDispatcher(appConfig, {}), TMailboxType::Simple, 0), 0); + TActorSetupCmd(CreateConfigsDispatcher( + NKikimr::NConsole::TConfigsDispatcherInitInfo { + .InitialConfig = appConfig, + }), + TMailboxType::Simple, + 0), + 0); runtime.Initialize(app.Unwrap()); auto dnsConfig = new TDynamicNameserviceConfig(); diff --git a/ydb/core/cms/console/configs_dispatcher.cpp b/ydb/core/cms/console/configs_dispatcher.cpp index bd6b40d2edf8..d1834fe1018d 100644 --- a/ydb/core/cms/console/configs_dispatcher.cpp +++ b/ydb/core/cms/console/configs_dispatcher.cpp @@ -133,12 +133,7 @@ class TConfigsDispatcher : public TActorBootstrapped { return NKikimrServices::TActivity::CONFIGS_DISPATCHER_ACTOR; } - TConfigsDispatcher( - const NKikimrConfig::TAppConfig &config, - const TMap &labels, - const NKikimrConfig::TAppConfig &initialCmsConfig, - const NKikimrConfig::TAppConfig &initialCmsYamlConfig, - const THashMap &configInitInfo); + TConfigsDispatcher(const TConfigsDispatcherInitInfo& initInfo); void Bootstrap(); @@ -163,6 +158,8 @@ class TConfigsDispatcher : public TActorBootstrapped { NKikimrConfig::TAppConfig ParseYamlProtoConfig(); + TDynBitMap FilterKinds(const TDynBitMap& in); + void Handle(NMon::TEvHttpInfo::TPtr &ev); void Handle(TEvInterconnect::TEvNodesInfo::TPtr &ev); void Handle(TEvConsole::TEvConfigSubscriptionNotification::TPtr &ev); @@ -230,12 +227,11 @@ class TConfigsDispatcher : public TActorBootstrapped { private: - TMap Labels; - const NKikimrConfig::TAppConfig InitialConfig; + const TMap Labels; + const std::variant ItemsServeRules; + const NKikimrConfig::TAppConfig BaseConfig; NKikimrConfig::TAppConfig CurrentConfig; - const NKikimrConfig::TAppConfig InitialCmsConfig; - const NKikimrConfig::TAppConfig InitialCmsYamlConfig; - const THashMap ConfigInitInfo; + const std::optional DebugInfo; ui64 NextRequestCookie; TVector HttpRequests; TActorId CommonSubscriptionClient; @@ -255,21 +251,14 @@ class TConfigsDispatcher : public TActorBootstrapped { }; -TConfigsDispatcher::TConfigsDispatcher( - const NKikimrConfig::TAppConfig &config, - const TMap &labels, - const NKikimrConfig::TAppConfig &initialCmsConfig, - const NKikimrConfig::TAppConfig &initialCmsYamlConfig, - const THashMap &configInitInfo) - : Labels(labels) - , InitialConfig(config) - , CurrentConfig(config) - , InitialCmsConfig(initialCmsConfig) - , InitialCmsYamlConfig(initialCmsYamlConfig) - , ConfigInitInfo(configInitInfo) +TConfigsDispatcher::TConfigsDispatcher(const TConfigsDispatcherInitInfo& initInfo) + : Labels(initInfo.Labels) + , ItemsServeRules(initInfo.ItemsServeRules) + , BaseConfig(initInfo.InitialConfig) + , CurrentConfig(initInfo.InitialConfig) + , DebugInfo(initInfo.DebugInfo) , NextRequestCookie(Now().GetValue()) -{ -} +{} void TConfigsDispatcher::Bootstrap() { @@ -400,9 +389,12 @@ void TConfigsDispatcher::ReplyMonJson(TActorId mailbox) { response.InsertValue("yaml_config", YamlConfig); response.InsertValue("resolved_json_config", NJson::ReadJsonFastTree(ResolvedJsonConfig, true)); response.InsertValue("current_json_config", NJson::ReadJsonFastTree(NProtobufJson::Proto2Json(CurrentConfig, NYamlConfig::GetProto2JsonConfig()), true)); - response.InsertValue("initial_json_config", NJson::ReadJsonFastTree(NProtobufJson::Proto2Json(InitialConfig, NYamlConfig::GetProto2JsonConfig()), true)); - response.InsertValue("initial_cms_json_config", NJson::ReadJsonFastTree(NProtobufJson::Proto2Json(InitialCmsConfig, NYamlConfig::GetProto2JsonConfig()), true)); - response.InsertValue("initial_cms_yaml_json_config", NJson::ReadJsonFastTree(NProtobufJson::Proto2Json(InitialCmsYamlConfig, NYamlConfig::GetProto2JsonConfig()), true)); + + if (DebugInfo) { + response.InsertValue("initial_json_config", NJson::ReadJsonFastTree(NProtobufJson::Proto2Json(DebugInfo->StaticConfig, NYamlConfig::GetProto2JsonConfig()), true)); + response.InsertValue("initial_cms_json_config", NJson::ReadJsonFastTree(NProtobufJson::Proto2Json(DebugInfo->OldDynConfig, NYamlConfig::GetProto2JsonConfig()), true)); + response.InsertValue("initial_cms_yaml_json_config", NJson::ReadJsonFastTree(NProtobufJson::Proto2Json(DebugInfo->NewDynConfig, NYamlConfig::GetProto2JsonConfig()), true)); + } NJson::WriteJson(&str, &response, {}); @@ -419,6 +411,29 @@ void TConfigsDispatcher::Handle(TEvConsole::TEvConfigNotificationRequest::TPtr & Send(ev->Sender, resp.Release(), 0, ev->Cookie); } + +TDynBitMap TConfigsDispatcher::FilterKinds(const TDynBitMap& in) { + TDynBitMap out; + + if (const auto* denyList = std::get_if(&ItemsServeRules)) { + Y_FOR_EACH_BIT(kind, in) { + if (!denyList->Items.contains(kind)) { + out.Set(kind); + } + } + } else if (const auto* allowList = std::get_if(&ItemsServeRules)) { + Y_FOR_EACH_BIT(kind, in) { + if (allowList->Items.contains(kind)) { + out.Set(kind); + } + } + } else { + out = in; + } + + return out; +} + void TConfigsDispatcher::Handle(TEvInterconnect::TEvNodesInfo::TPtr &ev) { Y_UNUSED(ev); @@ -494,14 +509,14 @@ void TConfigsDispatcher::Handle(TEvInterconnect::TEvNodesInfo::TPtr &ev) str << "Coloring: \"config not set\"," << " \"config set in dynamic config\", \"config set in static config\"" << Endl; str << "" << Endl; - NHttp::OutputRichConfigHTML(str, InitialConfig, YamlProtoConfig, CurrentConfig, DYNAMIC_KINDS, NON_YAML_KINDS, YamlConfigEnabled); + NHttp::OutputRichConfigHTML(str, BaseConfig, YamlProtoConfig, CurrentConfig, DYNAMIC_KINDS, NON_YAML_KINDS, YamlConfigEnabled); } str << "
" << Endl; COLLAPSED_REF_CONTENT("effective-startup-config", "Effective startup config") { str << "
" << Endl; str << "Some of these configs may be overwritten by dynamic ones." << Endl; str << "
" << Endl; - NHttp::OutputConfigHTML(str, InitialConfig); + NHttp::OutputConfigHTML(str, BaseConfig); } str << "
" << Endl; COLLAPSED_REF_CONTENT("effective-dynamic-config", "Effective dynamic config") { @@ -510,10 +525,10 @@ void TConfigsDispatcher::Handle(TEvInterconnect::TEvNodesInfo::TPtr &ev) str << "" << Endl; NKikimrConfig::TAppConfig trunc; if (YamlConfigEnabled) { - ReplaceConfigItems(YamlProtoConfig, trunc, KindsToBitMap(DYNAMIC_KINDS), InitialConfig); - ReplaceConfigItems(CurrentConfig, trunc, KindsToBitMap(NON_YAML_KINDS), trunc, false); + ReplaceConfigItems(YamlProtoConfig, trunc, FilterKinds(KindsToBitMap(DYNAMIC_KINDS)), BaseConfig); + ReplaceConfigItems(CurrentConfig, trunc, FilterKinds(KindsToBitMap(NON_YAML_KINDS)), trunc, false); } else { - ReplaceConfigItems(CurrentConfig, trunc, KindsToBitMap(DYNAMIC_KINDS), InitialConfig); + ReplaceConfigItems(CurrentConfig, trunc, FilterKinds(KindsToBitMap(DYNAMIC_KINDS)), BaseConfig); } NHttp::OutputConfigHTML(str, trunc); } @@ -521,7 +536,15 @@ void TConfigsDispatcher::Handle(TEvInterconnect::TEvNodesInfo::TPtr &ev) COLLAPSED_REF_CONTENT("debug-info", "Debug info") { DIV_CLASS("tab-left") { COLLAPSED_REF_CONTENT("effective-config-debug-info", "Effective config debug info") { - NHttp::OutputConfigDebugInfoHTML(str, InitialConfig, YamlProtoConfig, CurrentConfig, ConfigInitInfo, DYNAMIC_KINDS, NON_YAML_KINDS, YamlConfigEnabled); + NHttp::OutputConfigDebugInfoHTML( + str, + BaseConfig, + YamlProtoConfig, + CurrentConfig, + {DebugInfo ? DebugInfo->InitInfo : THashMap{}}, + DYNAMIC_KINDS, + NON_YAML_KINDS, + YamlConfigEnabled); } str << "
" << Endl; COLLAPSED_REF_CONTENT("state", "State") { @@ -651,15 +674,17 @@ void TConfigsDispatcher::Handle(TEvInterconnect::TEvNodesInfo::TPtr &ev) } str << "
" << Endl; COLLAPSED_REF_CONTENT("initial-config", "Initial config") { - NHttp::OutputConfigHTML(str, InitialConfig); + NHttp::OutputConfigHTML(str, BaseConfig); } - str << "
" << Endl; - COLLAPSED_REF_CONTENT("initial-cms-config", "Initial CMS config") { - NHttp::OutputConfigHTML(str, InitialCmsConfig); - } - str << "
" << Endl; - COLLAPSED_REF_CONTENT("initial-cms-yaml-config", "Initial CMS YAML config") { - NHttp::OutputConfigHTML(str, InitialCmsYamlConfig); + if (DebugInfo) { + str << "
" << Endl; + COLLAPSED_REF_CONTENT("initial-cms-config", "Initial CMS config") { + NHttp::OutputConfigHTML(str, DebugInfo->OldDynConfig); + } + str << "
" << Endl; + COLLAPSED_REF_CONTENT("initial-cms-yaml-config", "Initial CMS YAML config") { + NHttp::OutputConfigHTML(str, DebugInfo->NewDynConfig); + } } } } @@ -742,7 +767,7 @@ void TConfigsDispatcher::Handle(TEvConsole::TEvConfigSubscriptionNotification::T bool hasAffectedKinds = false; if (subscription->Yaml && YamlConfigEnabled) { - ReplaceConfigItems(YamlProtoConfig, trunc, subscription->Kinds, InitialConfig); + ReplaceConfigItems(YamlProtoConfig, trunc, FilterKinds(subscription->Kinds), BaseConfig); } else { Y_FOR_EACH_BIT(kind, kinds) { if (affectedKinds.contains(kind)) { @@ -755,7 +780,7 @@ void TConfigsDispatcher::Handle(TEvConsole::TEvConfigSubscriptionNotification::T continue; } - ReplaceConfigItems(ev->Get()->Record.GetConfig(), trunc, kinds, InitialConfig); + ReplaceConfigItems(ev->Get()->Record.GetConfig(), trunc, FilterKinds(kinds), BaseConfig); } if (hasAffectedKinds || !CompareConfigs(subscription->CurrentConfig.Config, trunc) || CurrentStateFunc() == &TThis::StateInit) { @@ -820,9 +845,9 @@ void TConfigsDispatcher::Handle(TEvConfigsDispatcher::TEvGetConfigRequest::TPtr auto trunc = std::make_shared(); auto kinds = KindsToBitMap(ev->Get()->ConfigItemKinds); if (YamlConfigEnabled && yamlKinds) { - ReplaceConfigItems(YamlProtoConfig, *trunc, kinds, InitialConfig); + ReplaceConfigItems(YamlProtoConfig, *trunc, FilterKinds(kinds), BaseConfig); } else { - ReplaceConfigItems(CurrentConfig, *trunc, kinds, InitialConfig); + ReplaceConfigItems(CurrentConfig, *trunc, FilterKinds(kinds), BaseConfig); } resp->Config = trunc; @@ -893,9 +918,9 @@ void TConfigsDispatcher::Handle(TEvConfigsDispatcher::TEvSetConfigSubscriptionRe subscription->UpdateInProcess = MakeHolder(); NKikimrConfig::TAppConfig trunc; if (YamlConfigEnabled) { - ReplaceConfigItems(YamlProtoConfig, trunc, kinds, InitialConfig); + ReplaceConfigItems(YamlProtoConfig, trunc, FilterKinds(kinds), BaseConfig); } else { - ReplaceConfigItems(CurrentConfig, trunc, kinds, InitialConfig); + ReplaceConfigItems(CurrentConfig, trunc, FilterKinds(kinds), BaseConfig); } subscription->UpdateInProcess->Record.MutableConfig()->CopyFrom(trunc); Y_FOR_EACH_BIT(kind, kinds) { @@ -997,14 +1022,8 @@ void TConfigsDispatcher::Handle(TEvConsole::TEvGetNodeLabelsRequest::TPtr &ev) { Send(ev->Sender, Response.Release()); } -IActor *CreateConfigsDispatcher( - const NKikimrConfig::TAppConfig &config, - const TMap &labels, - const NKikimrConfig::TAppConfig &initialCmsConfig, - const NKikimrConfig::TAppConfig &initialCmsYamlConfig, - const THashMap &configInitInfo) -{ - return new TConfigsDispatcher(config, labels, initialCmsConfig, initialCmsYamlConfig, configInitInfo); +IActor *CreateConfigsDispatcher(const TConfigsDispatcherInitInfo& initInfo) { + return new TConfigsDispatcher(initInfo); } } // namespace NKikimr::NConsole diff --git a/ydb/core/cms/console/configs_dispatcher.h b/ydb/core/cms/console/configs_dispatcher.h index b771a8a72529..e3034f932522 100644 --- a/ydb/core/cms/console/configs_dispatcher.h +++ b/ydb/core/cms/console/configs_dispatcher.h @@ -5,6 +5,7 @@ #include #include +#include namespace NKikimr::NConsole { @@ -107,17 +108,34 @@ struct TEvConfigsDispatcher { }; }; +struct TDenyList { + std::set Items; +}; + +struct TAllowList { + std::set Items; +}; + +struct TDebugInfo { + NKikimrConfig::TAppConfig StaticConfig; + NKikimrConfig::TAppConfig OldDynConfig; + NKikimrConfig::TAppConfig NewDynConfig; + THashMap InitInfo; +}; + +struct TConfigsDispatcherInitInfo { + NKikimrConfig::TAppConfig InitialConfig; + TMap Labels; + std::variant ItemsServeRules; + std::optional DebugInfo; +}; + /** * Initial config is used to initilize Configs Dispatcher. All received configs * are compared to the current one and notifications are not sent to local * subscribers if there is no config modification detected. */ -IActor *CreateConfigsDispatcher( - const NKikimrConfig::TAppConfig &config, - const TMap &labels, - const NKikimrConfig::TAppConfig &initialCmsConfig = {}, - const NKikimrConfig::TAppConfig &initialCmsYamlConfig = {}, - const THashMap &configInitInfo = {}); +IActor *CreateConfigsDispatcher(const TConfigsDispatcherInitInfo& initInfo); inline TActorId MakeConfigsDispatcherID(ui32 node = 0) { char x[12] = { 'c', 'o', 'n', 'f', 'i', 'g', 's', 'd', 'i', 's', 'p' }; diff --git a/ydb/core/driver_lib/run/kikimr_services_initializers.cpp b/ydb/core/driver_lib/run/kikimr_services_initializers.cpp index 38da10016654..0dae3013e17b 100644 --- a/ydb/core/driver_lib/run/kikimr_services_initializers.cpp +++ b/ydb/core/driver_lib/run/kikimr_services_initializers.cpp @@ -2381,7 +2381,18 @@ TConfigsDispatcherInitializer::TConfigsDispatcherInitializer(const TKikimrRunCon } void TConfigsDispatcherInitializer::InitializeServices(NActors::TActorSystemSetup* setup, const NKikimr::TAppData* appData) { - IActor* actor = NConsole::CreateConfigsDispatcher(Config, Labels, InitialCmsConfig, InitialCmsYamlConfig, ConfigInitInfo); + NKikimr::NConsole::TConfigsDispatcherInitInfo initInfo { + .InitialConfig = Config, + .Labels = Labels, + .ItemsServeRules = std::monostate{}, + .DebugInfo = NKikimr::NConsole::TDebugInfo { + .StaticConfig = Config, + .OldDynConfig = InitialCmsConfig, + .NewDynConfig = InitialCmsYamlConfig, + .InitInfo = ConfigInitInfo, + }, + }; + IActor* actor = NConsole::CreateConfigsDispatcher(initInfo); setup->LocalServices.push_back(std::pair( NConsole::MakeConfigsDispatcherID(NodeId), TActorSetupCmd(actor, TMailboxType::HTSwap, appData->UserPoolId))); diff --git a/ydb/core/testlib/tenant_runtime.cpp b/ydb/core/testlib/tenant_runtime.cpp index 88ba8b75905c..3f1d14f4a977 100644 --- a/ydb/core/testlib/tenant_runtime.cpp +++ b/ydb/core/testlib/tenant_runtime.cpp @@ -1034,7 +1034,12 @@ void TTenantTestRuntime::Setup(bool createTenantPools) labels[label.GetName()] = label.GetValue(); } labels.emplace("node_id", ToString(i)); - auto aid = Register(CreateConfigsDispatcher(Extension, labels)); + auto aid = Register(CreateConfigsDispatcher( + NKikimr::NConsole::TConfigsDispatcherInitInfo { + .InitialConfig = Extension, + .Labels = labels, + } + )); EnableScheduleForActor(aid, true); RegisterService(MakeConfigsDispatcherID(GetNodeId(0)), aid, 0); } diff --git a/ydb/core/testlib/test_client.cpp b/ydb/core/testlib/test_client.cpp index b4c35f7375ac..978d3e3b1f97 100644 --- a/ydb/core/testlib/test_client.cpp +++ b/ydb/core/testlib/test_client.cpp @@ -739,7 +739,10 @@ namespace Tests { if (!initial.HasImmediateControlsConfig()) { initial.MutableImmediateControlsConfig()->CopyFrom(Settings->Controls); } - auto *dispatcher = NConsole::CreateConfigsDispatcher(initial, {}); + auto *dispatcher = NConsole::CreateConfigsDispatcher( + NKikimr::NConsole::TConfigsDispatcherInitInfo { + .InitialConfig = initial, + }); auto aid = Runtime->Register(dispatcher, nodeIdx, appData.SystemPoolId, TMailboxType::Revolving, 0); Runtime->RegisterService(NConsole::MakeConfigsDispatcherID(Runtime->GetNodeId(nodeIdx)), aid, nodeIdx); } From cceacdc648fed60fee9f438beba8ddc9007438f9 Mon Sep 17 00:00:00 2001 From: Aleksei Borzenkov Date: Fri, 15 Mar 2024 16:16:50 +0300 Subject: [PATCH 076/117] 24-1: Fix use-after-free when debug logging read errors (#2816) --- ydb/core/tx/datashard/datashard__read_iterator.cpp | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/ydb/core/tx/datashard/datashard__read_iterator.cpp b/ydb/core/tx/datashard/datashard__read_iterator.cpp index 928592a56959..2eb034c485a0 100644 --- a/ydb/core/tx/datashard/datashard__read_iterator.cpp +++ b/ydb/core/tx/datashard/datashard__read_iterator.cpp @@ -2490,9 +2490,9 @@ class TDataShard::TTxReadContinue : public NTabletFlatExecutor::TTransactionBase if (record.HasStatus()) { record.SetSeqNo(state.SeqNo + 1); record.SetReadId(readId.ReadId); - Self->SendImmediateReadResult(request->Reader, Result.release(), 0, state.SessionId); LOG_DEBUG_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " read iterator# " << readId << " TTxReadContinue::Execute() finished with error, aborting: " << record.DebugString()); + Self->SendImmediateReadResult(request->Reader, Result.release(), 0, state.SessionId); state.Request->ReadSpan.EndError("Finished with error"); Self->DeleteReadIterator(it); From 53c016c5112a8d076364ad90d7e062a8e906faa0 Mon Sep 17 00:00:00 2001 From: Alexander Petrukhin Date: Fri, 15 Mar 2024 20:32:19 +0300 Subject: [PATCH 077/117] [cms] add version to Node in Maintenance API (#2788) (#2796) --- ydb/core/cms/api_adapters.cpp | 1 + ydb/public/api/protos/draft/ydb_maintenance.proto | 3 +++ 2 files changed, 4 insertions(+) diff --git a/ydb/core/cms/api_adapters.cpp b/ydb/core/cms/api_adapters.cpp index 18fe27185554..55572dbb9931 100644 --- a/ydb/core/cms/api_adapters.cpp +++ b/ydb/core/cms/api_adapters.cpp @@ -163,6 +163,7 @@ class TListClusterNodes: public TAdapterActor< out.set_host(in.Host); out.set_port(in.IcPort); out.set_state(ConvertNodeState(in.State)); + out.set_version(in.Version); *out.mutable_start_time() = TimeUtil::MicrosecondsToTimestamp(in.StartTime.GetValue()); auto& location = *out.mutable_location(); diff --git a/ydb/public/api/protos/draft/ydb_maintenance.proto b/ydb/public/api/protos/draft/ydb_maintenance.proto index 8dc461221314..c37356b98527 100644 --- a/ydb/public/api/protos/draft/ydb_maintenance.proto +++ b/ydb/public/api/protos/draft/ydb_maintenance.proto @@ -43,6 +43,9 @@ message Node { } // start_time defines time when node was registered in cms. google.protobuf.Timestamp start_time = 8; + // version defines YDB version for current Node. + // For example, 'ydb-stable-24-1'. + string version = 9; } message ListClusterNodesRequest { From 9edd75732ea4d2cf8210f31b1a5f8f94360160ed Mon Sep 17 00:00:00 2001 From: Aleksei Borzenkov Date: Sat, 16 Mar 2024 21:03:25 +0300 Subject: [PATCH 078/117] 24-1: Fix missing locks on read iterator empty result elision. Fixes #2765. (#2839) --- .../tx/datashard/datashard__read_iterator.cpp | 4 + .../datashard/datashard_ut_read_iterator.cpp | 78 +++++++++++++++++++ 2 files changed, 82 insertions(+) diff --git a/ydb/core/tx/datashard/datashard__read_iterator.cpp b/ydb/core/tx/datashard/datashard__read_iterator.cpp index 2eb034c485a0..bb4fbe8de801 100644 --- a/ydb/core/tx/datashard/datashard__read_iterator.cpp +++ b/ydb/core/tx/datashard/datashard__read_iterator.cpp @@ -665,6 +665,10 @@ class TReader { } } + if (record.TxLocksSize() > 0 || record.BrokenTxLocksSize() > 0) { + useful = true; + } + Self->IncCounter(COUNTER_READ_ITERATOR_ROWS_READ, RowsRead); if (!isKeysRequest) { Self->IncCounter(COUNTER_ENGINE_HOST_SELECT_RANGE_ROW_SKIPS, DeletedRowSkips); diff --git a/ydb/core/tx/datashard/datashard_ut_read_iterator.cpp b/ydb/core/tx/datashard/datashard_ut_read_iterator.cpp index cd3889c58d3c..876f58415ad0 100644 --- a/ydb/core/tx/datashard/datashard_ut_read_iterator.cpp +++ b/ydb/core/tx/datashard/datashard_ut_read_iterator.cpp @@ -21,6 +21,7 @@ namespace NKikimr { using namespace NKikimr::NDataShard; +using namespace NKikimr::NDataShard::NKqpHelpers; using namespace NSchemeShard; using namespace Tests; @@ -3689,6 +3690,83 @@ Y_UNIT_TEST_SUITE(DataShardReadIteratorPageFaults) { // We should be able to drop table WaitTxNotification(server, AsyncDropTable(server, sender, "/Root", "table-1")); } + + Y_UNIT_TEST(LocksNotLostOnPageFault) { + TPortManager pm; + NFake::TCaches caches; + caches.Shared = 1 /* bytes */; + TServerSettings serverSettings(pm.GetPort(2134)); + serverSettings.SetDomainName("Root") + .SetUseRealThreads(false) + .SetCacheParams(caches); + TServer::TPtr server = new TServer(serverSettings); + + auto& runtime = *server->GetRuntime(); + auto sender = runtime.AllocateEdgeActor(); + + runtime.SetLogPriority(NKikimrServices::TX_DATASHARD, NLog::PRI_TRACE); + + InitRoot(server, sender); + + TDisableDataShardLogBatching disableDataShardLogBatching; + + // Use a policy that forces very small page sizes, effectively making each row on its own page + NLocalDb::TCompactionPolicyPtr policy = NLocalDb::CreateDefaultTablePolicy(); + policy->MinDataPageSize = 1; + + auto opts = TShardedTableOptions() + .Columns({{"key", "Int32", true, false}, + {"index", "Int32", true, false}, + {"value", "Int32", false, false}}) + .Policy(policy.Get()) + .ExecutorCacheSize(1 /* byte */); + auto [shards, tableId] = CreateShardedTable(server, sender, "/Root", "table-1", opts); + + ExecSQL(server, sender, "UPSERT INTO `/Root/table-1` (key, index, value) VALUES (1, 0, 10), (3, 0, 30), (5, 0, 50), (7, 0, 70), (9, 0, 90);"); + runtime.SimulateSleep(TDuration::Seconds(1)); + + const auto shard1 = shards.at(0); + CompactTable(runtime, shard1, tableId, false); + RebootTablet(runtime, shard1, sender); + runtime.SimulateSleep(TDuration::Seconds(1)); + + // Start a write transaction that has uncommitted write to key (2, 0) + // This is because read iterator measures "work" in processed/skipped rows, so we have to give it something + TString writeSessionId, writeTxId; + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleBegin(runtime, writeSessionId, writeTxId, R"( + UPSERT INTO `/Root/table-1` (key, index, value) VALUES (2, 0, 20), (4, 0, 40); + + SELECT key, index, value FROM `/Root/table-1` + WHERE key = 2 + ORDER BY key, index; + )"), + "{ items { int32_value: 2 } items { int32_value: 0 } items { int32_value: 20 } }"); + + // Start a read transaction with several range read in a specific order + // The first two prefixes don't exist (nothing committed yet) + // The other two prefixes are supposed to page fault + TString sessionId, txId; + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleBegin(runtime, sessionId, txId, R"( + SELECT key, index, value FROM `/Root/table-1` + WHERE key IN (2, 4, 7, 9) + ORDER BY key, index; + )"), + "{ items { int32_value: 7 } items { int32_value: 0 } items { int32_value: 70 } }, " + "{ items { int32_value: 9 } items { int32_value: 0 } items { int32_value: 90 } }"); + + // Commit the first transaction, it must succeed + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleCommit(runtime, writeSessionId, writeTxId, "SELECT 1;"), + "{ items { int32_value: 1 } }"); + + // Commit the second transaction with a new upsert, it must not succeed + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleCommit(runtime, sessionId, txId, + "UPSERT INTO `/Root/table-1` (key, index, value) VALUES (2, 0, 22);"), + "ERROR: ABORTED"); + } } } // namespace NKikimr From bba277c51687e63154c00b5acc46e5a52fa1dfaa Mon Sep 17 00:00:00 2001 From: Alexander Rutkovsky Date: Mon, 18 Mar 2024 09:19:30 +0300 Subject: [PATCH 079/117] Fix put impl class (#2829) (#2853) --- .../dsproxy/dsproxy_blackboard.cpp | 71 ++++-------- .../blobstorage/dsproxy/dsproxy_blackboard.h | 30 ++--- ydb/core/blobstorage/dsproxy/dsproxy_put.cpp | 35 +++--- .../blobstorage/dsproxy/dsproxy_put_impl.cpp | 104 +++++++----------- .../blobstorage/dsproxy/dsproxy_put_impl.h | 44 ++------ .../blobstorage/dsproxy/ut/dsproxy_put_ut.cpp | 10 +- .../dsproxy/ut_strategy/strategy_ut.cpp | 2 +- 7 files changed, 108 insertions(+), 188 deletions(-) diff --git a/ydb/core/blobstorage/dsproxy/dsproxy_blackboard.cpp b/ydb/core/blobstorage/dsproxy/dsproxy_blackboard.cpp index 97706a1b6f13..6df5e4ce8698 100644 --- a/ydb/core/blobstorage/dsproxy/dsproxy_blackboard.cpp +++ b/ydb/core/blobstorage/dsproxy/dsproxy_blackboard.cpp @@ -48,12 +48,6 @@ void TBlobState::AddPartToPut(ui32 partIdx, TRope&& partData) { IsChanged = true; } -void TBlobState::MarkBlobReadyToPut(ui8 blobIdx) { - Y_ABORT_UNLESS(WholeSituation == ESituation::Unknown || WholeSituation == ESituation::Present); - BlobIdx = blobIdx; - IsChanged = true; -} - bool TBlobState::Restore(const TBlobStorageGroupInfo &info) { const TIntervalVec fullBlobInterval(0, Id.BlobSize()); const TIntervalSet here = Whole.Here(); @@ -227,7 +221,7 @@ TString TBlobState::ToString() const { for (ui32 i = 0; i < Disks.size(); ++i) { str << Endl << " Disks[" << i << "]# " << Disks[i].ToString() << Endl; } - str << " BlobIdx# " << (ui32)BlobIdx << Endl; + str << " BlobIdx# " << BlobIdx << Endl; str << "}"; return str.Str(); } @@ -304,7 +298,7 @@ void TGroupDiskRequests::AddGet(ui32 diskOrderNumber, const TLogoBlobID &id, ui3 } void TGroupDiskRequests::AddPut(ui32 diskOrderNumber, const TLogoBlobID &id, TRope buffer, - TDiskPutRequest::EPutReason putReason, bool isHandoff, ui8 blobIdx) { + TDiskPutRequest::EPutReason putReason, bool isHandoff, size_t blobIdx) { PutsPending.emplace_back(diskOrderNumber, id, buffer, putReason, isHandoff, blobIdx); } @@ -340,20 +334,6 @@ void TBlackboard::AddPartToPut(const TLogoBlobID &id, ui32 partIdx, TRope&& part (*this)[id].AddPartToPut(partIdx, std::move(partData)); } -void TBlackboard::MarkBlobReadyToPut(const TLogoBlobID &id, ui8 blobIdx) { - Y_ABORT_UNLESS(bool(id)); - Y_ABORT_UNLESS(id.PartId() == 0); - Y_ABORT_UNLESS(id.BlobSize() != 0); - (*this)[id].MarkBlobReadyToPut(blobIdx); -} - -void TBlackboard::MoveBlobStateToDone(const TLogoBlobID &id) { - Y_ABORT_UNLESS(bool(id)); - Y_ABORT_UNLESS(id.PartId() == 0); - Y_ABORT_UNLESS(id.BlobSize() != 0); - DoneBlobStates.insert(BlobStates.extract(id)); -} - void TBlackboard::AddPutOkResponse(const TLogoBlobID &id, ui32 orderNumber) { Y_ABORT_UNLESS(bool(id)); Y_ABORT_UNLESS(id.PartId() != 0); @@ -390,8 +370,7 @@ void TBlackboard::AddErrorResponse(const TLogoBlobID &id, ui32 orderNumber) { } EStrategyOutcome TBlackboard::RunStrategies(TLogContext &logCtx, const TStackVec& s, - TBatchedVec *finished, const TBlobStorageGroupInfo::TGroupVDisks *expired) { - TString errorReason; + TBatchedVec *finished, const TBlobStorageGroupInfo::TGroupVDisks *expired) { for (auto it = BlobStates.begin(); it != BlobStates.end(); ) { auto& blob = it->second; if (!std::exchange(blob.IsChanged, false)) { @@ -401,6 +380,7 @@ EStrategyOutcome TBlackboard::RunStrategies(TLogContext &logCtx, const TStackVec // recalculate blob outcome if it is not yet determined NKikimrProto::EReplyStatus status = NKikimrProto::OK; + TString errorReason; for (IStrategy *strategy : s) { switch (auto res = strategy->Process(logCtx, blob, *Info, *this, GroupDiskRequests)) { case EStrategyOutcome::IN_PROGRESS: @@ -408,16 +388,11 @@ EStrategyOutcome TBlackboard::RunStrategies(TLogContext &logCtx, const TStackVec break; case EStrategyOutcome::ERROR: - if (IsAllRequestsTogether) { + if (!finished) { return res; } - if (errorReason) { - errorReason += " && "; - errorReason += res.ErrorReason; - } else { - errorReason = res.ErrorReason; - } status = NKikimrProto::ERROR; + errorReason = std::move(res.ErrorReason); break; case EStrategyOutcome::DONE: @@ -431,26 +406,25 @@ EStrategyOutcome TBlackboard::RunStrategies(TLogContext &logCtx, const TStackVec status = NKikimrProto::UNKNOWN; } if (status != NKikimrProto::UNKNOWN) { + if (finished) { // we are operating on independent blobs + finished->push_back(TFinishedBlob{ + blob.BlobIdx, + status, + std::move(errorReason), + }); + } const auto [doneIt, inserted, node] = DoneBlobStates.insert(BlobStates.extract(it++)); Y_ABORT_UNLESS(inserted); - if (!IsAllRequestsTogether) { - blob.Status = status; - if (finished) { - finished->push_back(&*doneIt); - } - } } else { ++it; } } - EStrategyOutcome outcome(BlobStates.empty() ? EStrategyOutcome::DONE : EStrategyOutcome::IN_PROGRESS); - outcome.ErrorReason = std::move(errorReason); - return outcome; + return BlobStates.empty() ? EStrategyOutcome::DONE : EStrategyOutcome::IN_PROGRESS; } EStrategyOutcome TBlackboard::RunStrategy(TLogContext &logCtx, const IStrategy& s, - TBatchedVec *finished, const TBlobStorageGroupInfo::TGroupVDisks *expired) { + TBatchedVec *finished, const TBlobStorageGroupInfo::TGroupVDisks *expired) { return RunStrategies(logCtx, {const_cast(&s)}, finished, expired); } @@ -464,8 +438,7 @@ TBlobState& TBlackboard::GetState(const TLogoBlobID &id) { << " blobId# " << fullId << " BlackBoard# " << ToString()); } - TBlobState &state = it->second; - return state; + return it->second; } ssize_t TBlackboard::AddPartMap(const TLogoBlobID &id, ui32 diskOrderNumber, ui32 requestIndex) { @@ -512,8 +485,12 @@ void TBlackboard::GetWorstPredictedDelaysNs(const TBlobStorageGroupInfo &info, T } } -void TBlackboard::RegisterBlobForPut(const TLogoBlobID& id) { - (*this)[id]; +void TBlackboard::RegisterBlobForPut(const TLogoBlobID& id, size_t blobIdx) { + const auto [it, inserted] = BlobStates.try_emplace(id); + Y_ABORT_UNLESS(inserted); + TBlobState& state = it->second; + state.Init(id, *Info); + state.BlobIdx = blobIdx; } TBlobState& TBlackboard::operator [](const TLogoBlobID& id) { @@ -559,9 +536,7 @@ void TBlackboard::InvalidatePartStates(ui32 orderNumber) { const TVDiskID vdiskId = Info->GetVDiskId(orderNumber); for (auto& [id, state] : BlobStates) { if (const ui32 diskIdx = Info->GetIdxInSubgroup(vdiskId, id.Hash()); diskIdx != Info->Type.BlobSubgroupSize()) { - TBlobState::TDisk& disk = state.Disks[diskIdx]; - for (ui32 partIdx = 0; partIdx < disk.DiskParts.size(); ++partIdx) { - TBlobState::TDiskPart& part = disk.DiskParts[partIdx]; + for (TBlobState::TDiskPart& part : state.Disks[diskIdx].DiskParts) { if (part.Situation == TBlobState::ESituation::Present) { part.Situation = TBlobState::ESituation::Unknown; if (state.WholeSituation == TBlobState::ESituation::Present) { diff --git a/ydb/core/blobstorage/dsproxy/dsproxy_blackboard.h b/ydb/core/blobstorage/dsproxy/dsproxy_blackboard.h index c128a013e507..84dc4780c9a5 100644 --- a/ydb/core/blobstorage/dsproxy/dsproxy_blackboard.h +++ b/ydb/core/blobstorage/dsproxy/dsproxy_blackboard.h @@ -81,14 +81,12 @@ struct TBlobState { TStackVec Parts; TStackVec Disks; TVector PartMap; - NKikimrProto::EReplyStatus Status = NKikimrProto::UNKNOWN; - ui8 BlobIdx; + size_t BlobIdx; bool IsChanged = false; void Init(const TLogoBlobID &id, const TBlobStorageGroupInfo &Info); void AddNeeded(ui64 begin, ui64 size); void AddPartToPut(ui32 partIdx, TRope&& partData); - void MarkBlobReadyToPut(ui8 blobIdx = 0); bool Restore(const TBlobStorageGroupInfo &info); void AddResponseData(const TBlobStorageGroupInfo &info, const TLogoBlobID &id, ui32 diskIdxInSubring, ui32 shift, TRope&& data); @@ -133,9 +131,9 @@ struct TDiskPutRequest { TRope Buffer; EPutReason Reason; bool IsHandoff; - ui8 BlobIdx; + size_t BlobIdx; - TDiskPutRequest(ui32 orderNumber, const TLogoBlobID &id, TRope buffer, EPutReason reason, bool isHandoff, ui8 blobIdx) + TDiskPutRequest(ui32 orderNumber, const TLogoBlobID &id, TRope buffer, EPutReason reason, bool isHandoff, size_t blobIdx) : OrderNumber(orderNumber) , Id(id) , Buffer(std::move(buffer)) @@ -152,7 +150,7 @@ struct TGroupDiskRequests { void AddGet(ui32 diskOrderNumber, const TLogoBlobID &id, const TIntervalSet &intervalSet); void AddGet(ui32 diskOrderNumber, const TLogoBlobID &id, ui32 shift, ui32 size); void AddPut(ui32 diskOrderNumber, const TLogoBlobID &id, TRope buffer, - TDiskPutRequest::EPutReason putReason, bool isHandoff, ui8 blobIdx); + TDiskPutRequest::EPutReason putReason, bool isHandoff, size_t blobIdx); }; struct TBlackboard; @@ -170,6 +168,12 @@ struct TBlackboard { AccelerationModeSkipMarked }; + struct TFinishedBlob { + size_t BlobIdx; + NKikimrProto::EReplyStatus Status; + TString ErrorReason; + }; + using TBlobStates = TMap; TBlobStates BlobStates; TBlobStates DoneBlobStates; @@ -179,31 +183,27 @@ struct TBlackboard { EAccelerationMode AccelerationMode; const NKikimrBlobStorage::EPutHandleClass PutHandleClass; const NKikimrBlobStorage::EGetHandleClass GetHandleClass; - const bool IsAllRequestsTogether; TBlackboard(const TIntrusivePtr &info, const TIntrusivePtr &groupQueues, - NKikimrBlobStorage::EPutHandleClass putHandleClass, NKikimrBlobStorage::EGetHandleClass getHandleClass, - bool isAllRequestsTogether = true) + NKikimrBlobStorage::EPutHandleClass putHandleClass, NKikimrBlobStorage::EGetHandleClass getHandleClass) : Info(info) , GroupQueues(groupQueues) , AccelerationMode(AccelerationModeSkipOneSlowest) , PutHandleClass(putHandleClass) , GetHandleClass(getHandleClass) - , IsAllRequestsTogether(isAllRequestsTogether) {} void AddNeeded(const TLogoBlobID &id, ui32 inShift, ui32 inSize); void AddPartToPut(const TLogoBlobID &id, ui32 partIdx, TRope&& partData); - void MarkBlobReadyToPut(const TLogoBlobID &id, ui8 blobIdx = 0); - void MoveBlobStateToDone(const TLogoBlobID &id); void AddResponseData(const TLogoBlobID &id, ui32 orderNumber, ui32 shift, TRope&& data); void AddPutOkResponse(const TLogoBlobID &id, ui32 orderNumber); void AddNoDataResponse(const TLogoBlobID &id, ui32 orderNumber); void AddErrorResponse(const TLogoBlobID &id, ui32 orderNumber); void AddNotYetResponse(const TLogoBlobID &id, ui32 orderNumber); + EStrategyOutcome RunStrategies(TLogContext& logCtx, const TStackVec& strategies, - TBatchedVec *finished = nullptr, const TBlobStorageGroupInfo::TGroupVDisks *expired = nullptr); - EStrategyOutcome RunStrategy(TLogContext &logCtx, const IStrategy& s, TBatchedVec *finished = nullptr, + TBatchedVec *finished = nullptr, const TBlobStorageGroupInfo::TGroupVDisks *expired = nullptr); + EStrategyOutcome RunStrategy(TLogContext &logCtx, const IStrategy& s, TBatchedVec *finished = nullptr, const TBlobStorageGroupInfo::TGroupVDisks *expired = nullptr); TBlobState& GetState(const TLogoBlobID &id); ssize_t AddPartMap(const TLogoBlobID &id, ui32 diskOrderNumber, ui32 requestIndex); @@ -221,7 +221,7 @@ struct TBlackboard { void InvalidatePartStates(ui32 orderNumber); - void RegisterBlobForPut(const TLogoBlobID& id); + void RegisterBlobForPut(const TLogoBlobID& id, size_t blobIdx); TBlobState& operator [](const TLogoBlobID& id); }; diff --git a/ydb/core/blobstorage/dsproxy/dsproxy_put.cpp b/ydb/core/blobstorage/dsproxy/dsproxy_put.cpp index a092e45872a7..4f815af5a8d9 100644 --- a/ydb/core/blobstorage/dsproxy/dsproxy_put.cpp +++ b/ydb/core/blobstorage/dsproxy/dsproxy_put.cpp @@ -103,11 +103,11 @@ class TBlobStorageGroupPutRequest : public TBlobStorageGroupRequestActorNodeMon->AccelerateEvVMultiPutCount : Mon->NodeMon->AccelerateEvVPutCount) += v.size(); } @@ -210,9 +208,7 @@ class TBlobStorageGroupPutRequest : public TBlobStorageGroupRequestActorGet()); @@ -351,7 +347,7 @@ class TBlobStorageGroupPutRequest : public TBlobStorageGroupRequestActor putResult, ui64 blobIdx) { + void SendReply(std::unique_ptr putResult, size_t blobIdx) { NKikimrProto::EReplyStatus status = putResult->Status; A_LOG_LOG_S(false, status == NKikimrProto::OK ? NLog::PRI_INFO : NLog::PRI_NOTICE, "BPP21", "SendReply putResult# " << putResult->ToString() << " ResponsesSent# " << ResponsesSent @@ -449,7 +445,7 @@ class TBlobStorageGroupPutRequest : public TBlobStorageGroupRequestActorGetTypeRewrite(); diff --git a/ydb/core/blobstorage/dsproxy/dsproxy_put_impl.cpp b/ydb/core/blobstorage/dsproxy/dsproxy_put_impl.cpp index 81f56bed5363..3049ab1a039b 100644 --- a/ydb/core/blobstorage/dsproxy/dsproxy_put_impl.cpp +++ b/ydb/core/blobstorage/dsproxy/dsproxy_put_impl.cpp @@ -11,22 +11,44 @@ namespace NKikimr { using TPutResultVec = TPutImpl::TPutResultVec; -void TPutImpl::RunStrategies(TLogContext &logCtx, TPutResultVec &outPutResults, const TBlobStorageGroupInfo::TGroupVDisks& expired) { +void TPutImpl::RunStrategies(TLogContext &logCtx, TPutResultVec &outPutResults, + const TBlobStorageGroupInfo::TGroupVDisks& expired, bool accelerate) { + if (accelerate) { + ChangeAll(); + } + switch (Info->Type.GetErasure()) { case TBlobStorageGroupType::ErasureMirror3dc: - return RunStrategy(logCtx, TPut3dcStrategy(Tactic, EnableRequestMod3x3ForMinLatecy), outPutResults, expired); + return accelerate + ? RunStrategy(logCtx, TAcceleratePut3dcStrategy(Tactic, EnableRequestMod3x3ForMinLatecy), outPutResults, expired) + : RunStrategy(logCtx, TPut3dcStrategy(Tactic, EnableRequestMod3x3ForMinLatecy), outPutResults, expired); case TBlobStorageGroupType::ErasureMirror3of4: - return RunStrategy(logCtx, TPut3of4Strategy(Tactic), outPutResults, expired); + return accelerate + ? RunStrategy(logCtx, TPut3of4Strategy(Tactic, true), outPutResults, expired) + : RunStrategy(logCtx, TPut3of4Strategy(Tactic), outPutResults, expired); default: - return RunStrategy(logCtx, TRestoreStrategy(), outPutResults, expired); + return accelerate + ? RunStrategy(logCtx, TAcceleratePutStrategy(), outPutResults, expired) + : RunStrategy(logCtx, TRestoreStrategy(), outPutResults, expired); } } void TPutImpl::RunStrategy(TLogContext &logCtx, const IStrategy& strategy, TPutResultVec &outPutResults, const TBlobStorageGroupInfo::TGroupVDisks& expired) { - TBatchedVec finished; + Y_VERIFY_S(Blackboard.BlobStates.size(), "State# " << DumpFullState()); + TBatchedVec finished; const EStrategyOutcome outcome = Blackboard.RunStrategy(logCtx, strategy, &finished, &expired); - PrepareReply(logCtx, outcome.ErrorReason, finished, outPutResults); + for (const TBlackboard::TFinishedBlob& item : finished) { + Y_ABORT_UNLESS(item.BlobIdx < Blobs.size()); + Y_ABORT_UNLESS(!IsDone[item.BlobIdx]); + PrepareOneReply(item.Status, item.BlobIdx, logCtx, item.ErrorReason, outPutResults); + Y_VERIFY_S(IsDone[item.BlobIdx], "State# " << DumpFullState()); + } + if (outcome == EStrategyOutcome::DONE) { + for (const auto& done : IsDone) { + Y_VERIFY_S(done, "finished.size# " << finished.size() << " State# " << DumpFullState()); + } + } } NLog::EPriority GetPriorityForReply(TAtomicLogPriorityMuteChecker &checker, @@ -40,62 +62,23 @@ NLog::EPriority GetPriorityForReply(TAtomicLogPriorityMuteCheckerGroupID, - ApproximateFreeSpaceShare)); - outPutResults.back().second->ErrorReason = errorReason; - NLog::EPriority priority = GetPriorityForReply(Info->PutErrorMuteChecker, status); - A_LOG_LOG_SX(logCtx, true, priority, "BPP12", "Result# " << outPutResults.back().second->Print(false)); - MarkBlobAsSent(blobIdx); + if (!std::exchange(IsDone[blobIdx], true)) { + auto ev = std::make_unique(status, Blobs[blobIdx].BlobId, StatusFlags, + Info->GroupID, ApproximateFreeSpaceShare); + ev->ErrorReason = std::move(errorReason); + const NLog::EPriority priority = GetPriorityForReply(Info->PutErrorMuteChecker, status); + A_LOG_LOG_SX(logCtx, true, priority, "BPP12", "Result# " << ev->Print(false)); + outPutResults.emplace_back(blobIdx, std::move(ev)); } } void TPutImpl::PrepareReply(NKikimrProto::EReplyStatus status, TLogContext &logCtx, TString errorReason, TPutResultVec &outPutResults) { A_LOG_DEBUG_SX(logCtx, "BPP34", "PrepareReply status# " << status << " errorReason# " << errorReason); - for (ui64 idx = 0; idx < Blobs.size(); ++idx) { - if (IsDone[idx]) { - A_LOG_DEBUG_SX(logCtx, "BPP35", "blob# " << Blobs[idx].ToString() << - " idx# " << idx << " is sent, skipped"); - continue; - } - - outPutResults.emplace_back(idx, new TEvBlobStorage::TEvPutResult(status, Blobs[idx].BlobId, StatusFlags, - Info->GroupID, ApproximateFreeSpaceShare)); - outPutResults.back().second->ErrorReason = errorReason; - - NLog::EPriority priority = GetPriorityForReply(Info->PutErrorMuteChecker, status); - A_LOG_LOG_SX(logCtx, true, priority, "BPP38", - "PrepareReply Result# " << outPutResults.back().second->Print(false)); - - if (IsInitialized) { - MarkBlobAsSent(idx); - } - } -} - -void TPutImpl::PrepareReply(TLogContext &logCtx, TString errorReason, - TBatchedVec& finished, TPutResultVec &outPutResults) { - A_LOG_DEBUG_SX(logCtx, "BPP36", "PrepareReply errorReason# " << errorReason); - Y_ABORT_UNLESS(IsInitialized); - for (auto item : finished) { - auto &[blobId, state] = *item; - const ui64 idx = state.BlobIdx; - Y_ABORT_UNLESS(blobId == Blobs[idx].BlobId, "BlobIdx# %" PRIu64 " BlobState# %s Blackboard# %s", - idx, state.ToString().c_str(), Blackboard.ToString().c_str()); - Y_ABORT_UNLESS(!IsDone[idx]); - Y_ABORT_UNLESS(state.Status != NKikimrProto::UNKNOWN); - outPutResults.emplace_back(idx, new TEvBlobStorage::TEvPutResult(state.Status, blobId, StatusFlags, - Info->GroupID, ApproximateFreeSpaceShare)); - outPutResults.back().second->ErrorReason = errorReason; - - NLog::EPriority priority = GetPriorityForReply(Info->PutErrorMuteChecker, state.Status); - A_LOG_LOG_SX(logCtx, true, priority, "BPP37", - "PrepareReply Result# " << outPutResults.back().second->Print(false)); - MarkBlobAsSent(idx); + for (size_t blobIdx = 0; blobIdx < Blobs.size(); ++blobIdx) { + PrepareOneReply(status, blobIdx, logCtx, errorReason, outPutResults); } } @@ -125,7 +108,7 @@ TString TPutImpl::DumpFullState() const { str << Endl; str << " Blobs# " << Blobs.ToString(); str << Endl; - str << "IsDone# " << IsDone.ToString(); + str << " IsDone# " << IsDone.ToString(); str << Endl; str << " HandoffPartsSent# " << HandoffPartsSent; str << Endl; @@ -143,15 +126,6 @@ TString TPutImpl::DumpFullState() const { return str.Str(); } -bool TPutImpl::MarkBlobAsSent(ui64 idx) { - Y_ABORT_UNLESS(idx < Blobs.size()); - Y_ABORT_UNLESS(!IsDone[idx]); - Blackboard.MoveBlobStateToDone(Blobs[idx].BlobId); - IsDone[idx] = true; - DoneBlobs++; - return true; -} - }//NKikimr Y_DECLARE_OUT_SPEC(, NKikimr::TPutImpl::TBlobInfo, stream, value) { diff --git a/ydb/core/blobstorage/dsproxy/dsproxy_put_impl.h b/ydb/core/blobstorage/dsproxy/dsproxy_put_impl.h index 5c499eda22ab..b15b864837aa 100644 --- a/ydb/core/blobstorage/dsproxy/dsproxy_put_impl.h +++ b/ydb/core/blobstorage/dsproxy/dsproxy_put_impl.h @@ -43,8 +43,6 @@ class TPutImpl { bool AtLeastOneResponseWasNotOk = false; bool EnableRequestMod3x3ForMinLatecy = false; - ui64 DoneBlobs = 0; - const TEvBlobStorage::TEvPut::ETactic Tactic; struct TBlobInfo { @@ -99,8 +97,6 @@ class TPutImpl { friend class TBlobStorageGroupPutRequest; - bool IsInitialized = false; - friend void ::Out(IOutputStream&, const TBlobInfo&); public: @@ -109,7 +105,7 @@ class TPutImpl { bool enableRequestMod3x3ForMinLatecy, TActorId recipient, ui64 cookie, NWilson::TTraceId traceId) : Deadline(ev->Deadline) , Info(info) - , Blackboard(info, state, ev->HandleClass, NKikimrBlobStorage::EGetHandleClass::AsyncRead, false) + , Blackboard(info, state, ev->HandleClass, NKikimrBlobStorage::EGetHandleClass::AsyncRead) , IsDone(1) , WrittenBeyondBarrier(1) , StatusFlags(0) @@ -133,7 +129,7 @@ class TPutImpl { bool enableRequestMod3x3ForMinLatecy) : Deadline(TInstant::Zero()) , Info(info) - , Blackboard(info, state, putHandleClass, NKikimrBlobStorage::EGetHandleClass::AsyncRead, false) + , Blackboard(info, state, putHandleClass, NKikimrBlobStorage::EGetHandleClass::AsyncRead) , IsDone(events.size()) , WrittenBeyondBarrier(events.size()) , StatusFlags(0) @@ -175,47 +171,26 @@ class TPutImpl { Y_VERIFY_S(partSets.size() == Blobs.size(), "partSets.size# " << partSets.size() << " Blobs.size# " << Blobs.size()); const ui32 totalParts = Info->Type.TotalPartCount(); - for (ui64 blobIdx = 0; blobIdx < Blobs.size(); ++blobIdx) { + for (size_t blobIdx = 0; blobIdx < Blobs.size(); ++blobIdx) { TBlobInfo& blob = Blobs[blobIdx]; - Blackboard.RegisterBlobForPut(blob.BlobId); + Blackboard.RegisterBlobForPut(blob.BlobId, blobIdx); for (ui32 i = 0; i < totalParts; ++i) { if (Info->Type.PartSize(TLogoBlobID(blob.BlobId, i + 1))) { Blackboard.AddPartToPut(blob.BlobId, i, TRope(partSets[blobIdx][i])); } } - Blackboard.MarkBlobReadyToPut(blob.BlobId, blobIdx); } - IsInitialized = true; } void PrepareReply(NKikimrProto::EReplyStatus status, TLogContext &logCtx, TString errorReason, TPutResultVec &outPutResults); - void PrepareReply(TLogContext &logCtx, TString errorReason, TBatchedVec& finished, - TPutResultVec &outPutResults); - void PrepareOneReply(NKikimrProto::EReplyStatus status, TLogoBlobID blobId, ui64 blobIdx, TLogContext &logCtx, + void PrepareOneReply(NKikimrProto::EReplyStatus status, size_t blobIdx, TLogContext &logCtx, TString errorReason, TPutResultVec &outPutResults); ui64 GetTimeToAccelerateNs(TLogContext &logCtx); - void Accelerate(TLogContext &logCtx) { - Blackboard.ChangeAll(); - switch (Info->Type.GetErasure()) { - case TBlobStorageGroupType::ErasureMirror3dc: - Blackboard.RunStrategy(logCtx, TAcceleratePut3dcStrategy(Tactic, EnableRequestMod3x3ForMinLatecy)); - break; - case TBlobStorageGroupType::ErasureMirror3of4: - Blackboard.RunStrategy(logCtx, TPut3of4Strategy(Tactic, true)); - break; - default: - Blackboard.RunStrategy(logCtx, TAcceleratePutStrategy()); - break; - } - } - TString DumpFullState() const; - bool MarkBlobAsSent(ui64 blobIdx); - TString ToString() const; void InvalidatePartStates(ui32 orderNumber) { @@ -226,8 +201,8 @@ class TPutImpl { Blackboard.ChangeAll(); } - void Step(TLogContext &logCtx, TPutResultVec& putResults, const TBlobStorageGroupInfo::TGroupVDisks& expired) { - RunStrategies(logCtx, putResults, expired); + void Step(TLogContext &logCtx, TPutResultVec& putResults, const TBlobStorageGroupInfo::TGroupVDisks& expired, bool accelerate) { + RunStrategies(logCtx, putResults, expired, accelerate); } TDeque GeneratePutRequests() { @@ -299,7 +274,8 @@ class TPutImpl { } protected: - void RunStrategies(TLogContext &logCtx, TPutResultVec &outPutResults, const TBlobStorageGroupInfo::TGroupVDisks& expired); + void RunStrategies(TLogContext &logCtx, TPutResultVec &outPutResults, const TBlobStorageGroupInfo::TGroupVDisks& expired, + bool accelerate); void RunStrategy(TLogContext &logCtx, const IStrategy& strategy, TPutResultVec &outPutResults, const TBlobStorageGroupInfo::TGroupVDisks& expired); @@ -339,7 +315,7 @@ class TPutImpl { void ProcessResponseCommonPart(TProtobuf& record) { Y_ABORT_UNLESS(record.HasStatus()); const NKikimrProto::EReplyStatus status = record.GetStatus(); - Y_ABORT_UNLESS(status != NKikimrProto::BLOCKED && status != NKikimrProto::RACE && status != NKikimrProto::DEADLINE); + Y_ABORT_UNLESS(status != NKikimrProto::RACE); if (record.HasStatusFlags()) { StatusFlags.Merge(record.GetStatusFlags()); } diff --git a/ydb/core/blobstorage/dsproxy/ut/dsproxy_put_ut.cpp b/ydb/core/blobstorage/dsproxy/ut/dsproxy_put_ut.cpp index 09dca39bb5fd..2af3baccace5 100644 --- a/ydb/core/blobstorage/dsproxy/ut/dsproxy_put_ut.cpp +++ b/ydb/core/blobstorage/dsproxy/ut/dsproxy_put_ut.cpp @@ -76,7 +76,7 @@ void TestPutMaxPartCountOnHandoff(TErasureType::EErasureSpecies erasureSpecies) TPutImpl::TPutResultVec putResults; putImpl.GenerateInitialRequests(logCtx, partSetSingleton); - putImpl.Step(logCtx, putResults, {&group.GetInfo()->GetTopology()}); + putImpl.Step(logCtx, putResults, {&group.GetInfo()->GetTopology()}, false); auto vPuts = putImpl.GeneratePutRequests(); group.SetError(0, NKikimrProto::ERROR); @@ -119,7 +119,7 @@ void TestPutMaxPartCountOnHandoff(TErasureType::EErasureSpecies erasureSpecies) vPutResult.MakeError(status, TString(), vPut.Record); putImpl.ProcessResponse(vPutResult); - putImpl.Step(logCtx, putResults, {&group.GetInfo()->GetTopology()}); + putImpl.Step(logCtx, putResults, {&group.GetInfo()->GetTopology()}, false); auto nextVPuts = putImpl.GeneratePutRequests(); if (putResults.size()) { @@ -273,7 +273,7 @@ struct TTestPutAllOk { } std::visit([&](auto &ev) { putImpl.ProcessResponse(*ev); }, vPutResults[resIdx]); - putImpl.Step(LogCtx, putResults, &Group.GetInfo()->GetTopology()); + putImpl.Step(LogCtx, putResults, &Group.GetInfo()->GetTopology(), false); auto vPuts = putImpl.GeneratePutRequests(); if (putResults.size() == BlobCount) { break; @@ -309,7 +309,7 @@ struct TTestPutAllOk { } putImpl->GenerateInitialRequests(LogCtx, PartSets); - putImpl->Step(LogCtx, putResults, &Group.GetInfo()->GetTopology()); + putImpl->Step(LogCtx, putResults, &Group.GetInfo()->GetTopology(), false); auto vPuts = putImpl->GeneratePutRequests(); UNIT_ASSERT(vPuts.size() == 6 || !IsVPut); TDeque vPutResults; @@ -367,7 +367,7 @@ Y_UNIT_TEST(TestMirror3dcWith3x3MinLatencyMod) { ErasureSplit((TErasureType::ECrcMode)blobId.CrcMode(), env.Info->Type, TRope(encryptedData), partSetSingleton[0]); putImpl.GenerateInitialRequests(logCtx, partSetSingleton); TPutImpl::TPutResultVec putResults; - putImpl.Step(logCtx, putResults, &env.Info->GetTopology()); + putImpl.Step(logCtx, putResults, &env.Info->GetTopology(), false); auto vPuts = putImpl.GeneratePutRequests(); UNIT_ASSERT_VALUES_EQUAL(vPuts.size(), 9); diff --git a/ydb/core/blobstorage/dsproxy/ut_strategy/strategy_ut.cpp b/ydb/core/blobstorage/dsproxy/ut_strategy/strategy_ut.cpp index 8b77cc4ee6b8..64ace509dd63 100644 --- a/ydb/core/blobstorage/dsproxy/ut_strategy/strategy_ut.cpp +++ b/ydb/core/blobstorage/dsproxy/ut_strategy/strategy_ut.cpp @@ -105,7 +105,7 @@ void RunStrategyTest(TBlobStorageGroupType type) { TLogoBlobID id(1'000'000'000, 1, 1, 0, data.size(), 0); std::vector parts(type.TotalPartCount()); ErasureSplit(TBlobStorageGroupType::CrcModeNone, type, TRope(data), parts); - blackboard.RegisterBlobForPut(id); + blackboard.RegisterBlobForPut(id, 0); for (ui32 i = 0; i < parts.size(); ++i) { blackboard.AddPartToPut(id, i, TRope(parts[i])); } From 5ac0c0bae8db72dc920313783fde15ed113b0e54 Mon Sep 17 00:00:00 2001 From: Aleksandr Dmitriev Date: Mon, 18 Mar 2024 14:39:28 +0300 Subject: [PATCH 080/117] skip metrics without name label instead of crashing KIKIMR-21198 (#2883) --- library/cpp/monlib/encode/prometheus/prometheus_encoder.cpp | 6 +++--- 1 file changed, 3 insertions(+), 3 deletions(-) diff --git a/library/cpp/monlib/encode/prometheus/prometheus_encoder.cpp b/library/cpp/monlib/encode/prometheus/prometheus_encoder.cpp index f3015c48bc29..8083221b63d0 100644 --- a/library/cpp/monlib/encode/prometheus/prometheus_encoder.cpp +++ b/library/cpp/monlib/encode/prometheus/prometheus_encoder.cpp @@ -370,9 +370,9 @@ namespace NMonitoring { } TMaybe nameLabel = MetricState_.Labels.Extract(MetricNameLabel_); - Y_ENSURE(nameLabel, - "labels " << MetricState_.Labels << - " does not contain label '" << MetricNameLabel_ << '\''); + if (!nameLabel) { + return; + } const TString& metricName = ToString(nameLabel->Value()); if (MetricState_.Type != EMetricType::DSUMMARY) { From 0aaa317160ab6c381779d0383d7ef67ba66ef333 Mon Sep 17 00:00:00 2001 From: azevaykin <145343289+azevaykin@users.noreply.github.com> Date: Mon, 18 Mar 2024 15:49:31 +0300 Subject: [PATCH 081/117] Call ProposeQueue.Ack for canceled txs (#2826) --- ydb/core/tx/datashard/datashard.cpp | 4 ++-- 1 file changed, 2 insertions(+), 2 deletions(-) diff --git a/ydb/core/tx/datashard/datashard.cpp b/ydb/core/tx/datashard/datashard.cpp index 6b10f4632c76..314060536c8e 100644 --- a/ydb/core/tx/datashard/datashard.cpp +++ b/ydb/core/tx/datashard/datashard.cpp @@ -2952,13 +2952,13 @@ void TDataShard::Handle(TEvPrivate::TEvDelayedProposeTransaction::TPtr &ev, cons kind, TabletID(), txId, NKikimrTxDataShard::TEvProposeTransactionResult::CANCELLED); ctx.Send(target, result, 0, cookie); - return; + break; } case NEvents::TDataEvents::TEvWrite::EventType: { auto* msg = item.Event->Get(); auto result = NEvents::TDataEvents::TEvWriteResult::BuildError(TabletID(), msg->GetTxId(), NKikimrDataEvents::TEvWriteResult::STATUS_CANCELLED, "Canceled"); ctx.Send(target, result.release(), 0, cookie); - return; + break; } default: Y_FAIL_S("Unexpected event type " << item.Event->GetTypeRewrite()); From ccfeb7a5c1b73cba28cb75e8298b9d948954a1c6 Mon Sep 17 00:00:00 2001 From: Maxim Gorbunov Date: Mon, 18 Mar 2024 13:22:26 +0000 Subject: [PATCH 082/117] Update CMakeLists --- ydb/apps/CMakeLists.txt | 1 + ydb/apps/version/CMakeLists.darwin-arm64.txt | 18 ++++++++++++++++++ ydb/apps/version/CMakeLists.darwin-x86_64.txt | 18 ++++++++++++++++++ ydb/apps/version/CMakeLists.linux-aarch64.txt | 19 +++++++++++++++++++ ydb/apps/version/CMakeLists.linux-x86_64.txt | 19 +++++++++++++++++++ ydb/apps/version/CMakeLists.txt | 19 +++++++++++++++++++ .../version/CMakeLists.windows-x86_64.txt | 18 ++++++++++++++++++ ydb/apps/ydbd/CMakeLists.darwin-arm64.txt | 1 + ydb/apps/ydbd/CMakeLists.darwin-x86_64.txt | 1 + ydb/apps/ydbd/CMakeLists.linux-aarch64.txt | 1 + ydb/apps/ydbd/CMakeLists.linux-x86_64.txt | 1 + ydb/apps/ydbd/CMakeLists.windows-x86_64.txt | 1 + .../ut/CMakeLists.darwin-arm64.txt | 1 + .../ut/CMakeLists.darwin-x86_64.txt | 1 + .../ut/CMakeLists.linux-aarch64.txt | 1 + .../ut/CMakeLists.linux-x86_64.txt | 1 + .../ut/CMakeLists.windows-x86_64.txt | 1 + .../incrhuge/ut/CMakeLists.darwin-arm64.txt | 1 + .../incrhuge/ut/CMakeLists.darwin-x86_64.txt | 1 + .../incrhuge/ut/CMakeLists.linux-aarch64.txt | 1 + .../incrhuge/ut/CMakeLists.linux-x86_64.txt | 1 + .../incrhuge/ut/CMakeLists.windows-x86_64.txt | 1 + .../lib/CMakeLists.darwin-arm64.txt | 1 + .../lib/CMakeLists.darwin-x86_64.txt | 1 + .../lib/CMakeLists.linux-aarch64.txt | 1 + .../lib/CMakeLists.linux-x86_64.txt | 1 + .../lib/CMakeLists.windows-x86_64.txt | 1 + .../ut_group/CMakeLists.darwin-arm64.txt | 1 + .../ut_group/CMakeLists.darwin-x86_64.txt | 1 + .../ut_group/CMakeLists.linux-aarch64.txt | 1 + .../ut_group/CMakeLists.linux-x86_64.txt | 1 + .../ut_group/CMakeLists.windows-x86_64.txt | 1 + .../ut_mirror3of4/CMakeLists.darwin-arm64.txt | 1 + .../CMakeLists.darwin-x86_64.txt | 1 + .../CMakeLists.linux-aarch64.txt | 1 + .../ut_mirror3of4/CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../pdiskfit/CMakeLists.linux-aarch64.txt | 1 + .../pdiskfit/CMakeLists.linux-x86_64.txt | 1 + .../ut/CMakeLists.linux-aarch64.txt | 1 + .../ut/CMakeLists.linux-x86_64.txt | 1 + .../ut_testshard/CMakeLists.darwin-arm64.txt | 1 + .../ut_testshard/CMakeLists.darwin-x86_64.txt | 1 + .../ut_testshard/CMakeLists.linux-aarch64.txt | 1 + .../ut_testshard/CMakeLists.linux-x86_64.txt | 1 + .../CMakeLists.windows-x86_64.txt | 1 + .../ut_vdisk/CMakeLists.darwin-arm64.txt | 1 + .../ut_vdisk/CMakeLists.darwin-x86_64.txt | 1 + .../ut_vdisk/CMakeLists.linux-aarch64.txt | 1 + .../ut_vdisk/CMakeLists.linux-x86_64.txt | 1 + .../ut_vdisk/CMakeLists.windows-x86_64.txt | 1 + .../ut_vdisk2/CMakeLists.darwin-arm64.txt | 1 + .../ut_vdisk2/CMakeLists.darwin-x86_64.txt | 1 + .../ut_vdisk2/CMakeLists.linux-aarch64.txt | 1 + .../ut_vdisk2/CMakeLists.linux-x86_64.txt | 1 + .../ut_vdisk2/CMakeLists.windows-x86_64.txt | 1 + .../syncer/ut/CMakeLists.darwin-arm64.txt | 1 + .../syncer/ut/CMakeLists.darwin-x86_64.txt | 1 + .../syncer/ut/CMakeLists.linux-aarch64.txt | 1 + .../syncer/ut/CMakeLists.linux-x86_64.txt | 1 + .../syncer/ut/CMakeLists.windows-x86_64.txt | 1 + .../version/ut/CMakeLists.darwin-arm64.txt | 1 + .../version/ut/CMakeLists.darwin-x86_64.txt | 1 + .../version/ut/CMakeLists.linux-aarch64.txt | 1 + .../version/ut/CMakeLists.linux-x86_64.txt | 1 + .../version/ut/CMakeLists.windows-x86_64.txt | 1 + .../ut_selfheal/CMakeLists.darwin-arm64.txt | 1 + .../ut_selfheal/CMakeLists.darwin-x86_64.txt | 1 + .../ut_selfheal/CMakeLists.linux-aarch64.txt | 1 + .../ut_selfheal/CMakeLists.linux-x86_64.txt | 1 + .../ut_selfheal/CMakeLists.windows-x86_64.txt | 1 + ydb/core/testlib/CMakeLists.darwin-arm64.txt | 1 + ydb/core/testlib/CMakeLists.darwin-x86_64.txt | 1 + ydb/core/testlib/CMakeLists.linux-aarch64.txt | 1 + ydb/core/testlib/CMakeLists.linux-x86_64.txt | 1 + .../testlib/CMakeLists.windows-x86_64.txt | 1 + .../actors/CMakeLists.darwin-arm64.txt | 1 + .../actors/CMakeLists.darwin-x86_64.txt | 1 + .../actors/CMakeLists.linux-aarch64.txt | 1 + .../actors/CMakeLists.linux-x86_64.txt | 1 + .../actors/CMakeLists.windows-x86_64.txt | 1 + 81 files changed, 186 insertions(+) create mode 100644 ydb/apps/version/CMakeLists.darwin-arm64.txt create mode 100644 ydb/apps/version/CMakeLists.darwin-x86_64.txt create mode 100644 ydb/apps/version/CMakeLists.linux-aarch64.txt create mode 100644 ydb/apps/version/CMakeLists.linux-x86_64.txt create mode 100644 ydb/apps/version/CMakeLists.txt create mode 100644 ydb/apps/version/CMakeLists.windows-x86_64.txt diff --git a/ydb/apps/CMakeLists.txt b/ydb/apps/CMakeLists.txt index e1c6d2181e21..08df7dd2187e 100644 --- a/ydb/apps/CMakeLists.txt +++ b/ydb/apps/CMakeLists.txt @@ -7,5 +7,6 @@ add_subdirectory(pgwire) +add_subdirectory(version) add_subdirectory(ydb) add_subdirectory(ydbd) diff --git a/ydb/apps/version/CMakeLists.darwin-arm64.txt b/ydb/apps/version/CMakeLists.darwin-arm64.txt new file mode 100644 index 000000000000..ce969ee15772 --- /dev/null +++ b/ydb/apps/version/CMakeLists.darwin-arm64.txt @@ -0,0 +1,18 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(version_definition) +target_link_libraries(version_definition PUBLIC + contrib-libs-cxxsupp + yutil + version +) +target_sources(version_definition PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/apps/version/version_definition.cpp +) diff --git a/ydb/apps/version/CMakeLists.darwin-x86_64.txt b/ydb/apps/version/CMakeLists.darwin-x86_64.txt new file mode 100644 index 000000000000..ce969ee15772 --- /dev/null +++ b/ydb/apps/version/CMakeLists.darwin-x86_64.txt @@ -0,0 +1,18 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(version_definition) +target_link_libraries(version_definition PUBLIC + contrib-libs-cxxsupp + yutil + version +) +target_sources(version_definition PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/apps/version/version_definition.cpp +) diff --git a/ydb/apps/version/CMakeLists.linux-aarch64.txt b/ydb/apps/version/CMakeLists.linux-aarch64.txt new file mode 100644 index 000000000000..bca854e1db0f --- /dev/null +++ b/ydb/apps/version/CMakeLists.linux-aarch64.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(version_definition) +target_link_libraries(version_definition PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + version +) +target_sources(version_definition PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/apps/version/version_definition.cpp +) diff --git a/ydb/apps/version/CMakeLists.linux-x86_64.txt b/ydb/apps/version/CMakeLists.linux-x86_64.txt new file mode 100644 index 000000000000..bca854e1db0f --- /dev/null +++ b/ydb/apps/version/CMakeLists.linux-x86_64.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(version_definition) +target_link_libraries(version_definition PUBLIC + contrib-libs-linux-headers + contrib-libs-cxxsupp + yutil + version +) +target_sources(version_definition PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/apps/version/version_definition.cpp +) diff --git a/ydb/apps/version/CMakeLists.txt b/ydb/apps/version/CMakeLists.txt new file mode 100644 index 000000000000..d863ebd18067 --- /dev/null +++ b/ydb/apps/version/CMakeLists.txt @@ -0,0 +1,19 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + +if (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Linux" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "aarch64" AND NOT HAVE_CUDA) + include(CMakeLists.linux-aarch64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "x86_64") + include(CMakeLists.darwin-x86_64.txt) +elseif (CMAKE_SYSTEM_NAME STREQUAL "Darwin" AND CMAKE_SYSTEM_PROCESSOR STREQUAL "arm64") + include(CMakeLists.darwin-arm64.txt) +elseif (WIN32 AND CMAKE_SYSTEM_PROCESSOR STREQUAL "AMD64" AND NOT HAVE_CUDA) + include(CMakeLists.windows-x86_64.txt) +endif() diff --git a/ydb/apps/version/CMakeLists.windows-x86_64.txt b/ydb/apps/version/CMakeLists.windows-x86_64.txt new file mode 100644 index 000000000000..ce969ee15772 --- /dev/null +++ b/ydb/apps/version/CMakeLists.windows-x86_64.txt @@ -0,0 +1,18 @@ + +# This file was generated by the build system used internally in the Yandex monorepo. +# Only simple modifications are allowed (adding source-files to targets, adding simple properties +# like target_include_directories). These modifications will be ported to original +# ya.make files by maintainers. Any complex modifications which can't be ported back to the +# original buildsystem will not be accepted. + + + +add_library(version_definition) +target_link_libraries(version_definition PUBLIC + contrib-libs-cxxsupp + yutil + version +) +target_sources(version_definition PRIVATE + ${CMAKE_SOURCE_DIR}/ydb/apps/version/version_definition.cpp +) diff --git a/ydb/apps/ydbd/CMakeLists.darwin-arm64.txt b/ydb/apps/ydbd/CMakeLists.darwin-arm64.txt index 55cb758927dd..e9139a985617 100644 --- a/ydb/apps/ydbd/CMakeLists.darwin-arm64.txt +++ b/ydb/apps/ydbd/CMakeLists.darwin-arm64.txt @@ -14,6 +14,7 @@ target_compile_options(ydbd PRIVATE target_link_libraries(ydbd PUBLIC contrib-libs-cxxsupp yutil + version_definition run ydb-core-protos ydb-core-security diff --git a/ydb/apps/ydbd/CMakeLists.darwin-x86_64.txt b/ydb/apps/ydbd/CMakeLists.darwin-x86_64.txt index c14caccd9816..1d6341727d76 100644 --- a/ydb/apps/ydbd/CMakeLists.darwin-x86_64.txt +++ b/ydb/apps/ydbd/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,7 @@ target_link_libraries(ydbd PUBLIC yutil library-cpp-cpuid_check udfs-common-hyperscan + version_definition run ydb-core-protos ydb-core-security diff --git a/ydb/apps/ydbd/CMakeLists.linux-aarch64.txt b/ydb/apps/ydbd/CMakeLists.linux-aarch64.txt index 39d8a56655d5..1cecfe06897d 100644 --- a/ydb/apps/ydbd/CMakeLists.linux-aarch64.txt +++ b/ydb/apps/ydbd/CMakeLists.linux-aarch64.txt @@ -15,6 +15,7 @@ target_link_libraries(ydbd PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + version_definition run ydb-core-protos ydb-core-security diff --git a/ydb/apps/ydbd/CMakeLists.linux-x86_64.txt b/ydb/apps/ydbd/CMakeLists.linux-x86_64.txt index c1e2d6955ed2..dd34e31acbb1 100644 --- a/ydb/apps/ydbd/CMakeLists.linux-x86_64.txt +++ b/ydb/apps/ydbd/CMakeLists.linux-x86_64.txt @@ -17,6 +17,7 @@ target_link_libraries(ydbd PUBLIC yutil library-cpp-cpuid_check hyperscan_udf + version_definition run ydb-core-protos ydb-core-security diff --git a/ydb/apps/ydbd/CMakeLists.windows-x86_64.txt b/ydb/apps/ydbd/CMakeLists.windows-x86_64.txt index 92044a6688cf..2e7334f4eb8f 100644 --- a/ydb/apps/ydbd/CMakeLists.windows-x86_64.txt +++ b/ydb/apps/ydbd/CMakeLists.windows-x86_64.txt @@ -17,6 +17,7 @@ target_link_libraries(ydbd PUBLIC yutil library-cpp-cpuid_check udfs-common-hyperscan + version_definition run ydb-core-protos ydb-core-security diff --git a/ydb/core/actorlib_impl/ut/CMakeLists.darwin-arm64.txt b/ydb/core/actorlib_impl/ut/CMakeLists.darwin-arm64.txt index b23f1701861d..8cf38ba69fb3 100644 --- a/ydb/core/actorlib_impl/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/actorlib_impl/ut/CMakeLists.darwin-arm64.txt @@ -19,6 +19,7 @@ target_link_libraries(ydb-core-actorlib_impl-ut PUBLIC yutil cpp-testing-unittest_main ydb-core-actorlib_impl + version_definition library-actors-core library-actors-interconnect library-cpp-getopt diff --git a/ydb/core/actorlib_impl/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/actorlib_impl/ut/CMakeLists.darwin-x86_64.txt index 97b02c598742..089fb719b212 100644 --- a/ydb/core/actorlib_impl/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/actorlib_impl/ut/CMakeLists.darwin-x86_64.txt @@ -20,6 +20,7 @@ target_link_libraries(ydb-core-actorlib_impl-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main ydb-core-actorlib_impl + version_definition library-actors-core library-actors-interconnect library-cpp-getopt diff --git a/ydb/core/actorlib_impl/ut/CMakeLists.linux-aarch64.txt b/ydb/core/actorlib_impl/ut/CMakeLists.linux-aarch64.txt index 8884fae6ef3e..5b399007a656 100644 --- a/ydb/core/actorlib_impl/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/actorlib_impl/ut/CMakeLists.linux-aarch64.txt @@ -20,6 +20,7 @@ target_link_libraries(ydb-core-actorlib_impl-ut PUBLIC yutil cpp-testing-unittest_main ydb-core-actorlib_impl + version_definition library-actors-core library-actors-interconnect library-cpp-getopt diff --git a/ydb/core/actorlib_impl/ut/CMakeLists.linux-x86_64.txt b/ydb/core/actorlib_impl/ut/CMakeLists.linux-x86_64.txt index cc8f189feba3..cec69ce080fd 100644 --- a/ydb/core/actorlib_impl/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/actorlib_impl/ut/CMakeLists.linux-x86_64.txt @@ -21,6 +21,7 @@ target_link_libraries(ydb-core-actorlib_impl-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main ydb-core-actorlib_impl + version_definition library-actors-core library-actors-interconnect library-cpp-getopt diff --git a/ydb/core/actorlib_impl/ut/CMakeLists.windows-x86_64.txt b/ydb/core/actorlib_impl/ut/CMakeLists.windows-x86_64.txt index cc5c27df7c96..dfcd699fb474 100644 --- a/ydb/core/actorlib_impl/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/actorlib_impl/ut/CMakeLists.windows-x86_64.txt @@ -20,6 +20,7 @@ target_link_libraries(ydb-core-actorlib_impl-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main ydb-core-actorlib_impl + version_definition library-actors-core library-actors-interconnect library-cpp-getopt diff --git a/ydb/core/blobstorage/incrhuge/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/incrhuge/ut/CMakeLists.darwin-arm64.txt index 6f2136d8d1d8..51b840c6a43a 100644 --- a/ydb/core/blobstorage/incrhuge/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/incrhuge/ut/CMakeLists.darwin-arm64.txt @@ -12,6 +12,7 @@ target_link_libraries(ydb-core-blobstorage-incrhuge-ut PUBLIC contrib-libs-cxxsupp yutil cpp-testing-unittest_main + version_definition library-actors-protos ydb-core-blobstorage core-blobstorage-incrhuge diff --git a/ydb/core/blobstorage/incrhuge/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/incrhuge/ut/CMakeLists.darwin-x86_64.txt index 832140620685..f0293a9024ff 100644 --- a/ydb/core/blobstorage/incrhuge/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/incrhuge/ut/CMakeLists.darwin-x86_64.txt @@ -13,6 +13,7 @@ target_link_libraries(ydb-core-blobstorage-incrhuge-ut PUBLIC yutil library-cpp-cpuid_check cpp-testing-unittest_main + version_definition library-actors-protos ydb-core-blobstorage core-blobstorage-incrhuge diff --git a/ydb/core/blobstorage/incrhuge/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/incrhuge/ut/CMakeLists.linux-aarch64.txt index 0966d091dc40..4b62e15a07c2 100644 --- a/ydb/core/blobstorage/incrhuge/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/incrhuge/ut/CMakeLists.linux-aarch64.txt @@ -13,6 +13,7 @@ target_link_libraries(ydb-core-blobstorage-incrhuge-ut PUBLIC contrib-libs-cxxsupp yutil cpp-testing-unittest_main + version_definition library-actors-protos ydb-core-blobstorage core-blobstorage-incrhuge diff --git a/ydb/core/blobstorage/incrhuge/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/incrhuge/ut/CMakeLists.linux-x86_64.txt index 88ae35a5387f..1b632fce1e63 100644 --- a/ydb/core/blobstorage/incrhuge/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/incrhuge/ut/CMakeLists.linux-x86_64.txt @@ -14,6 +14,7 @@ target_link_libraries(ydb-core-blobstorage-incrhuge-ut PUBLIC yutil library-cpp-cpuid_check cpp-testing-unittest_main + version_definition library-actors-protos ydb-core-blobstorage core-blobstorage-incrhuge diff --git a/ydb/core/blobstorage/incrhuge/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/incrhuge/ut/CMakeLists.windows-x86_64.txt index c81f9ff136bf..264ff4621bdf 100644 --- a/ydb/core/blobstorage/incrhuge/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/incrhuge/ut/CMakeLists.windows-x86_64.txt @@ -13,6 +13,7 @@ target_link_libraries(ydb-core-blobstorage-incrhuge-ut PUBLIC yutil library-cpp-cpuid_check cpp-testing-unittest_main + version_definition library-actors-protos ydb-core-blobstorage core-blobstorage-incrhuge diff --git a/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.darwin-arm64.txt index 5e5bdff5c9c6..60160019c364 100644 --- a/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.darwin-arm64.txt @@ -13,6 +13,7 @@ target_link_libraries(blobstorage-ut_blobstorage-lib PUBLIC yutil cpp-digest-md5 cpp-testing-unittest + version_definition ydb-core-base ydb-core-blob_depot core-blobstorage-backpressure diff --git a/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.darwin-x86_64.txt index 5e5bdff5c9c6..60160019c364 100644 --- a/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.darwin-x86_64.txt @@ -13,6 +13,7 @@ target_link_libraries(blobstorage-ut_blobstorage-lib PUBLIC yutil cpp-digest-md5 cpp-testing-unittest + version_definition ydb-core-base ydb-core-blob_depot core-blobstorage-backpressure diff --git a/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.linux-aarch64.txt index be9f296fefb5..26965076f973 100644 --- a/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.linux-aarch64.txt @@ -14,6 +14,7 @@ target_link_libraries(blobstorage-ut_blobstorage-lib PUBLIC yutil cpp-digest-md5 cpp-testing-unittest + version_definition ydb-core-base ydb-core-blob_depot core-blobstorage-backpressure diff --git a/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.linux-x86_64.txt index be9f296fefb5..26965076f973 100644 --- a/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.linux-x86_64.txt @@ -14,6 +14,7 @@ target_link_libraries(blobstorage-ut_blobstorage-lib PUBLIC yutil cpp-digest-md5 cpp-testing-unittest + version_definition ydb-core-base ydb-core-blob_depot core-blobstorage-backpressure diff --git a/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.windows-x86_64.txt index 5e5bdff5c9c6..60160019c364 100644 --- a/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_blobstorage/lib/CMakeLists.windows-x86_64.txt @@ -13,6 +13,7 @@ target_link_libraries(blobstorage-ut_blobstorage-lib PUBLIC yutil cpp-digest-md5 cpp-testing-unittest + version_definition ydb-core-base ydb-core-blob_depot core-blobstorage-backpressure diff --git a/ydb/core/blobstorage/ut_group/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_group/CMakeLists.darwin-arm64.txt index 353b5cf2d3de..ac67abed5452 100644 --- a/ydb/core/blobstorage/ut_group/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_group/CMakeLists.darwin-arm64.txt @@ -12,6 +12,7 @@ target_link_libraries(ydb-core-blobstorage-ut_group PUBLIC contrib-libs-cxxsupp yutil cpp-testing-unittest_main + version_definition actors-interconnect-mock cpp-testing-unittest core-blobstorage-crypto diff --git a/ydb/core/blobstorage/ut_group/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_group/CMakeLists.darwin-x86_64.txt index 6312ab3ac606..e0c4daf3fe72 100644 --- a/ydb/core/blobstorage/ut_group/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_group/CMakeLists.darwin-x86_64.txt @@ -13,6 +13,7 @@ target_link_libraries(ydb-core-blobstorage-ut_group PUBLIC yutil library-cpp-cpuid_check cpp-testing-unittest_main + version_definition actors-interconnect-mock cpp-testing-unittest core-blobstorage-crypto diff --git a/ydb/core/blobstorage/ut_group/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_group/CMakeLists.linux-aarch64.txt index 746f31afd9b7..8aee02b36535 100644 --- a/ydb/core/blobstorage/ut_group/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_group/CMakeLists.linux-aarch64.txt @@ -13,6 +13,7 @@ target_link_libraries(ydb-core-blobstorage-ut_group PUBLIC contrib-libs-cxxsupp yutil cpp-testing-unittest_main + version_definition actors-interconnect-mock cpp-testing-unittest core-blobstorage-crypto diff --git a/ydb/core/blobstorage/ut_group/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_group/CMakeLists.linux-x86_64.txt index 9d161e135ce8..a050e4a489be 100644 --- a/ydb/core/blobstorage/ut_group/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_group/CMakeLists.linux-x86_64.txt @@ -14,6 +14,7 @@ target_link_libraries(ydb-core-blobstorage-ut_group PUBLIC yutil library-cpp-cpuid_check cpp-testing-unittest_main + version_definition actors-interconnect-mock cpp-testing-unittest core-blobstorage-crypto diff --git a/ydb/core/blobstorage/ut_group/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_group/CMakeLists.windows-x86_64.txt index 2d97bd8714b7..f47b37d786a1 100644 --- a/ydb/core/blobstorage/ut_group/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_group/CMakeLists.windows-x86_64.txt @@ -13,6 +13,7 @@ target_link_libraries(ydb-core-blobstorage-ut_group PUBLIC yutil library-cpp-cpuid_check cpp-testing-unittest_main + version_definition actors-interconnect-mock cpp-testing-unittest core-blobstorage-crypto diff --git a/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.darwin-arm64.txt index cd619388db4d..4c7cad058acb 100644 --- a/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.darwin-arm64.txt @@ -12,6 +12,7 @@ target_link_libraries(ydb-core-blobstorage-ut_mirror3of4 PUBLIC contrib-libs-cxxsupp yutil cpp-testing-unittest_main + version_definition actors-interconnect-mock cpp-testing-unittest core-blobstorage-backpressure diff --git a/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.darwin-x86_64.txt index 23d89529f7cc..ce6f8ca30e0f 100644 --- a/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.darwin-x86_64.txt @@ -13,6 +13,7 @@ target_link_libraries(ydb-core-blobstorage-ut_mirror3of4 PUBLIC yutil library-cpp-cpuid_check cpp-testing-unittest_main + version_definition actors-interconnect-mock cpp-testing-unittest core-blobstorage-backpressure diff --git a/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.linux-aarch64.txt index e6a8877d5f34..dc13b4d1f416 100644 --- a/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.linux-aarch64.txt @@ -13,6 +13,7 @@ target_link_libraries(ydb-core-blobstorage-ut_mirror3of4 PUBLIC contrib-libs-cxxsupp yutil cpp-testing-unittest_main + version_definition actors-interconnect-mock cpp-testing-unittest core-blobstorage-backpressure diff --git a/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.linux-x86_64.txt index 9f496b5c44c0..a696701b1d63 100644 --- a/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.linux-x86_64.txt @@ -14,6 +14,7 @@ target_link_libraries(ydb-core-blobstorage-ut_mirror3of4 PUBLIC yutil library-cpp-cpuid_check cpp-testing-unittest_main + version_definition actors-interconnect-mock cpp-testing-unittest core-blobstorage-backpressure diff --git a/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.windows-x86_64.txt index 37faed49d804..01fde9d224d7 100644 --- a/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_mirror3of4/CMakeLists.windows-x86_64.txt @@ -13,6 +13,7 @@ target_link_libraries(ydb-core-blobstorage-ut_mirror3of4 PUBLIC yutil library-cpp-cpuid_check cpp-testing-unittest_main + version_definition actors-interconnect-mock cpp-testing-unittest core-blobstorage-backpressure diff --git a/ydb/core/blobstorage/ut_pdiskfit/pdiskfit/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_pdiskfit/pdiskfit/CMakeLists.linux-aarch64.txt index c4f854dfecec..aed8d4e44586 100644 --- a/ydb/core/blobstorage/ut_pdiskfit/pdiskfit/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_pdiskfit/pdiskfit/CMakeLists.linux-aarch64.txt @@ -12,6 +12,7 @@ target_link_libraries(pdiskfit PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + version_definition library-cpp-getopt cpp-string_utils-parse_size ydb-core-blobstorage diff --git a/ydb/core/blobstorage/ut_pdiskfit/pdiskfit/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_pdiskfit/pdiskfit/CMakeLists.linux-x86_64.txt index ff3d93d99608..25dd867af41f 100644 --- a/ydb/core/blobstorage/ut_pdiskfit/pdiskfit/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_pdiskfit/pdiskfit/CMakeLists.linux-x86_64.txt @@ -13,6 +13,7 @@ target_link_libraries(pdiskfit PUBLIC contrib-libs-cxxsupp yutil library-cpp-cpuid_check + version_definition library-cpp-getopt cpp-string_utils-parse_size ydb-core-blobstorage diff --git a/ydb/core/blobstorage/ut_pdiskfit/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_pdiskfit/ut/CMakeLists.linux-aarch64.txt index 629ca9bf1cd2..6a6dce60f5a0 100644 --- a/ydb/core/blobstorage/ut_pdiskfit/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_pdiskfit/ut/CMakeLists.linux-aarch64.txt @@ -13,6 +13,7 @@ target_link_libraries(ydb-core-blobstorage-ut_pdiskfit-ut PUBLIC contrib-libs-cxxsupp yutil cpp-testing-unittest_main + version_definition ydb-core-blobstorage blobstorage-ut_pdiskfit-lib ) diff --git a/ydb/core/blobstorage/ut_pdiskfit/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_pdiskfit/ut/CMakeLists.linux-x86_64.txt index ea899890610e..5b779405228d 100644 --- a/ydb/core/blobstorage/ut_pdiskfit/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_pdiskfit/ut/CMakeLists.linux-x86_64.txt @@ -14,6 +14,7 @@ target_link_libraries(ydb-core-blobstorage-ut_pdiskfit-ut PUBLIC yutil library-cpp-cpuid_check cpp-testing-unittest_main + version_definition ydb-core-blobstorage blobstorage-ut_pdiskfit-lib ) diff --git a/ydb/core/blobstorage/ut_testshard/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_testshard/CMakeLists.darwin-arm64.txt index 46b220972149..19b8a576735e 100644 --- a/ydb/core/blobstorage/ut_testshard/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_testshard/CMakeLists.darwin-arm64.txt @@ -12,6 +12,7 @@ target_link_libraries(ydb-core-blobstorage-ut_testshard PUBLIC contrib-libs-cxxsupp yutil cpp-testing-unittest_main + version_definition ydb-core-base ydb-core-blob_depot core-blobstorage-backpressure diff --git a/ydb/core/blobstorage/ut_testshard/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_testshard/CMakeLists.darwin-x86_64.txt index 5c635e0b11b3..972e7c84ccaa 100644 --- a/ydb/core/blobstorage/ut_testshard/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_testshard/CMakeLists.darwin-x86_64.txt @@ -13,6 +13,7 @@ target_link_libraries(ydb-core-blobstorage-ut_testshard PUBLIC yutil library-cpp-cpuid_check cpp-testing-unittest_main + version_definition ydb-core-base ydb-core-blob_depot core-blobstorage-backpressure diff --git a/ydb/core/blobstorage/ut_testshard/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_testshard/CMakeLists.linux-aarch64.txt index 13632cba37ce..59ed90704881 100644 --- a/ydb/core/blobstorage/ut_testshard/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_testshard/CMakeLists.linux-aarch64.txt @@ -13,6 +13,7 @@ target_link_libraries(ydb-core-blobstorage-ut_testshard PUBLIC contrib-libs-cxxsupp yutil cpp-testing-unittest_main + version_definition ydb-core-base ydb-core-blob_depot core-blobstorage-backpressure diff --git a/ydb/core/blobstorage/ut_testshard/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_testshard/CMakeLists.linux-x86_64.txt index 9e02e5a34a5b..1d86546dcea5 100644 --- a/ydb/core/blobstorage/ut_testshard/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_testshard/CMakeLists.linux-x86_64.txt @@ -14,6 +14,7 @@ target_link_libraries(ydb-core-blobstorage-ut_testshard PUBLIC yutil library-cpp-cpuid_check cpp-testing-unittest_main + version_definition ydb-core-base ydb-core-blob_depot core-blobstorage-backpressure diff --git a/ydb/core/blobstorage/ut_testshard/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_testshard/CMakeLists.windows-x86_64.txt index 0fd1655f0b30..e1748212ae74 100644 --- a/ydb/core/blobstorage/ut_testshard/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_testshard/CMakeLists.windows-x86_64.txt @@ -13,6 +13,7 @@ target_link_libraries(ydb-core-blobstorage-ut_testshard PUBLIC yutil library-cpp-cpuid_check cpp-testing-unittest_main + version_definition ydb-core-base ydb-core-blob_depot core-blobstorage-backpressure diff --git a/ydb/core/blobstorage/ut_vdisk/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_vdisk/CMakeLists.darwin-arm64.txt index 84b2321057db..fe3bd0df4a23 100644 --- a/ydb/core/blobstorage/ut_vdisk/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_vdisk/CMakeLists.darwin-arm64.txt @@ -20,6 +20,7 @@ target_link_libraries(ydb-core-blobstorage-ut_vdisk PUBLIC yutil cpp-testing-unittest_main ydb-core-blobstorage + version_definition library-actors-protos library-cpp-codecs ydb-core-base diff --git a/ydb/core/blobstorage/ut_vdisk/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_vdisk/CMakeLists.darwin-x86_64.txt index 0c581b6e4f34..2b13c91661e2 100644 --- a/ydb/core/blobstorage/ut_vdisk/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_vdisk/CMakeLists.darwin-x86_64.txt @@ -21,6 +21,7 @@ target_link_libraries(ydb-core-blobstorage-ut_vdisk PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main ydb-core-blobstorage + version_definition library-actors-protos library-cpp-codecs ydb-core-base diff --git a/ydb/core/blobstorage/ut_vdisk/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_vdisk/CMakeLists.linux-aarch64.txt index 2260e8b0bcb1..30f3761dce83 100644 --- a/ydb/core/blobstorage/ut_vdisk/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_vdisk/CMakeLists.linux-aarch64.txt @@ -21,6 +21,7 @@ target_link_libraries(ydb-core-blobstorage-ut_vdisk PUBLIC yutil cpp-testing-unittest_main ydb-core-blobstorage + version_definition library-actors-protos library-cpp-codecs ydb-core-base diff --git a/ydb/core/blobstorage/ut_vdisk/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_vdisk/CMakeLists.linux-x86_64.txt index 9d8dbd248282..c350eb55659e 100644 --- a/ydb/core/blobstorage/ut_vdisk/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_vdisk/CMakeLists.linux-x86_64.txt @@ -22,6 +22,7 @@ target_link_libraries(ydb-core-blobstorage-ut_vdisk PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main ydb-core-blobstorage + version_definition library-actors-protos library-cpp-codecs ydb-core-base diff --git a/ydb/core/blobstorage/ut_vdisk/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_vdisk/CMakeLists.windows-x86_64.txt index 7a391ae50e24..284a5a11ac12 100644 --- a/ydb/core/blobstorage/ut_vdisk/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_vdisk/CMakeLists.windows-x86_64.txt @@ -21,6 +21,7 @@ target_link_libraries(ydb-core-blobstorage-ut_vdisk PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main ydb-core-blobstorage + version_definition library-actors-protos library-cpp-codecs ydb-core-base diff --git a/ydb/core/blobstorage/ut_vdisk2/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/ut_vdisk2/CMakeLists.darwin-arm64.txt index ca0fee8a8348..3f16b18c6b95 100644 --- a/ydb/core/blobstorage/ut_vdisk2/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/ut_vdisk2/CMakeLists.darwin-arm64.txt @@ -12,6 +12,7 @@ target_link_libraries(ydb-core-blobstorage-ut_vdisk2 PUBLIC contrib-libs-cxxsupp yutil cpp-testing-unittest_main + version_definition cpp-testing-unittest core-blobstorage-backpressure core-blobstorage-groupinfo diff --git a/ydb/core/blobstorage/ut_vdisk2/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/ut_vdisk2/CMakeLists.darwin-x86_64.txt index 0a4fdd94186d..a163d72935b2 100644 --- a/ydb/core/blobstorage/ut_vdisk2/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/ut_vdisk2/CMakeLists.darwin-x86_64.txt @@ -13,6 +13,7 @@ target_link_libraries(ydb-core-blobstorage-ut_vdisk2 PUBLIC yutil library-cpp-cpuid_check cpp-testing-unittest_main + version_definition cpp-testing-unittest core-blobstorage-backpressure core-blobstorage-groupinfo diff --git a/ydb/core/blobstorage/ut_vdisk2/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/ut_vdisk2/CMakeLists.linux-aarch64.txt index 137fc6d3b9af..767d418c4ebf 100644 --- a/ydb/core/blobstorage/ut_vdisk2/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/ut_vdisk2/CMakeLists.linux-aarch64.txt @@ -13,6 +13,7 @@ target_link_libraries(ydb-core-blobstorage-ut_vdisk2 PUBLIC contrib-libs-cxxsupp yutil cpp-testing-unittest_main + version_definition cpp-testing-unittest core-blobstorage-backpressure core-blobstorage-groupinfo diff --git a/ydb/core/blobstorage/ut_vdisk2/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/ut_vdisk2/CMakeLists.linux-x86_64.txt index dff8445d7de9..b6cfc5355922 100644 --- a/ydb/core/blobstorage/ut_vdisk2/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/ut_vdisk2/CMakeLists.linux-x86_64.txt @@ -14,6 +14,7 @@ target_link_libraries(ydb-core-blobstorage-ut_vdisk2 PUBLIC yutil library-cpp-cpuid_check cpp-testing-unittest_main + version_definition cpp-testing-unittest core-blobstorage-backpressure core-blobstorage-groupinfo diff --git a/ydb/core/blobstorage/ut_vdisk2/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/ut_vdisk2/CMakeLists.windows-x86_64.txt index b4109c6cb45b..19ffd0ac9b8f 100644 --- a/ydb/core/blobstorage/ut_vdisk2/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/ut_vdisk2/CMakeLists.windows-x86_64.txt @@ -13,6 +13,7 @@ target_link_libraries(ydb-core-blobstorage-ut_vdisk2 PUBLIC yutil library-cpp-cpuid_check cpp-testing-unittest_main + version_definition cpp-testing-unittest core-blobstorage-backpressure core-blobstorage-groupinfo diff --git a/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.darwin-arm64.txt b/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.darwin-arm64.txt index 7c716b4a5553..578fa0238b10 100644 --- a/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.darwin-arm64.txt @@ -16,6 +16,7 @@ target_link_libraries(ydb-core-blobstorage-vdisk-syncer-ut PUBLIC yutil cpp-testing-unittest_main blobstorage-vdisk-syncer + version_definition library-cpp-getopt library-cpp-svnversion ydb-core-base diff --git a/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.darwin-x86_64.txt index 75256f3af926..a4157f2d94fe 100644 --- a/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.darwin-x86_64.txt @@ -17,6 +17,7 @@ target_link_libraries(ydb-core-blobstorage-vdisk-syncer-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main blobstorage-vdisk-syncer + version_definition library-cpp-getopt library-cpp-svnversion ydb-core-base diff --git a/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.linux-aarch64.txt b/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.linux-aarch64.txt index f4f1ee69f448..cfee695d7895 100644 --- a/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.linux-aarch64.txt @@ -17,6 +17,7 @@ target_link_libraries(ydb-core-blobstorage-vdisk-syncer-ut PUBLIC yutil cpp-testing-unittest_main blobstorage-vdisk-syncer + version_definition library-cpp-getopt library-cpp-svnversion ydb-core-base diff --git a/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.linux-x86_64.txt b/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.linux-x86_64.txt index 996ac0bd9406..8ce55a24c606 100644 --- a/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.linux-x86_64.txt @@ -18,6 +18,7 @@ target_link_libraries(ydb-core-blobstorage-vdisk-syncer-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main blobstorage-vdisk-syncer + version_definition library-cpp-getopt library-cpp-svnversion ydb-core-base diff --git a/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.windows-x86_64.txt b/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.windows-x86_64.txt index 657e7e41f3c3..8eb0e7465a02 100644 --- a/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/blobstorage/vdisk/syncer/ut/CMakeLists.windows-x86_64.txt @@ -17,6 +17,7 @@ target_link_libraries(ydb-core-blobstorage-vdisk-syncer-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main blobstorage-vdisk-syncer + version_definition library-cpp-getopt library-cpp-svnversion ydb-core-base diff --git a/ydb/core/driver_lib/version/ut/CMakeLists.darwin-arm64.txt b/ydb/core/driver_lib/version/ut/CMakeLists.darwin-arm64.txt index 923cb8c2f35a..340107041898 100644 --- a/ydb/core/driver_lib/version/ut/CMakeLists.darwin-arm64.txt +++ b/ydb/core/driver_lib/version/ut/CMakeLists.darwin-arm64.txt @@ -16,6 +16,7 @@ target_link_libraries(ydb-core-driver_lib-version-ut PUBLIC yutil cpp-testing-unittest_main version + version_definition ) target_link_options(ydb-core-driver_lib-version-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 diff --git a/ydb/core/driver_lib/version/ut/CMakeLists.darwin-x86_64.txt b/ydb/core/driver_lib/version/ut/CMakeLists.darwin-x86_64.txt index ff98a9080641..11879a5ca99b 100644 --- a/ydb/core/driver_lib/version/ut/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/driver_lib/version/ut/CMakeLists.darwin-x86_64.txt @@ -17,6 +17,7 @@ target_link_libraries(ydb-core-driver_lib-version-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main version + version_definition ) target_link_options(ydb-core-driver_lib-version-ut PRIVATE -Wl,-platform_version,macos,11.0,11.0 diff --git a/ydb/core/driver_lib/version/ut/CMakeLists.linux-aarch64.txt b/ydb/core/driver_lib/version/ut/CMakeLists.linux-aarch64.txt index 3ecb12cd4036..c2f3a1a268e1 100644 --- a/ydb/core/driver_lib/version/ut/CMakeLists.linux-aarch64.txt +++ b/ydb/core/driver_lib/version/ut/CMakeLists.linux-aarch64.txt @@ -17,6 +17,7 @@ target_link_libraries(ydb-core-driver_lib-version-ut PUBLIC yutil cpp-testing-unittest_main version + version_definition ) target_link_options(ydb-core-driver_lib-version-ut PRIVATE -ldl diff --git a/ydb/core/driver_lib/version/ut/CMakeLists.linux-x86_64.txt b/ydb/core/driver_lib/version/ut/CMakeLists.linux-x86_64.txt index 999ad8804d32..6b89d73255c3 100644 --- a/ydb/core/driver_lib/version/ut/CMakeLists.linux-x86_64.txt +++ b/ydb/core/driver_lib/version/ut/CMakeLists.linux-x86_64.txt @@ -18,6 +18,7 @@ target_link_libraries(ydb-core-driver_lib-version-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main version + version_definition ) target_link_options(ydb-core-driver_lib-version-ut PRIVATE -ldl diff --git a/ydb/core/driver_lib/version/ut/CMakeLists.windows-x86_64.txt b/ydb/core/driver_lib/version/ut/CMakeLists.windows-x86_64.txt index f611bebb0fcc..5d3d9db541e7 100644 --- a/ydb/core/driver_lib/version/ut/CMakeLists.windows-x86_64.txt +++ b/ydb/core/driver_lib/version/ut/CMakeLists.windows-x86_64.txt @@ -17,6 +17,7 @@ target_link_libraries(ydb-core-driver_lib-version-ut PUBLIC library-cpp-cpuid_check cpp-testing-unittest_main version + version_definition ) target_sources(ydb-core-driver_lib-version-ut PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/driver_lib/version/ut/version_ut.cpp diff --git a/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.darwin-arm64.txt b/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.darwin-arm64.txt index a58014c2f253..681c447ff2b1 100644 --- a/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.darwin-arm64.txt +++ b/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.darwin-arm64.txt @@ -15,6 +15,7 @@ target_link_libraries(ydb-core-mind-bscontroller-ut_selfheal PUBLIC contrib-libs-cxxsupp yutil cpp-testing-unittest_main + version_definition blobstorage-dsproxy-mock blobstorage-pdisk-mock core-mind-bscontroller diff --git a/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.darwin-x86_64.txt b/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.darwin-x86_64.txt index 556785ce5eec..a971d8b38b01 100644 --- a/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.darwin-x86_64.txt @@ -16,6 +16,7 @@ target_link_libraries(ydb-core-mind-bscontroller-ut_selfheal PUBLIC yutil library-cpp-cpuid_check cpp-testing-unittest_main + version_definition blobstorage-dsproxy-mock blobstorage-pdisk-mock core-mind-bscontroller diff --git a/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.linux-aarch64.txt b/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.linux-aarch64.txt index e70a88c2eace..573524420487 100644 --- a/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.linux-aarch64.txt +++ b/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.linux-aarch64.txt @@ -16,6 +16,7 @@ target_link_libraries(ydb-core-mind-bscontroller-ut_selfheal PUBLIC contrib-libs-cxxsupp yutil cpp-testing-unittest_main + version_definition blobstorage-dsproxy-mock blobstorage-pdisk-mock core-mind-bscontroller diff --git a/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.linux-x86_64.txt b/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.linux-x86_64.txt index 85bda2ed3f1a..e919aa17cbc2 100644 --- a/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.linux-x86_64.txt +++ b/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.linux-x86_64.txt @@ -17,6 +17,7 @@ target_link_libraries(ydb-core-mind-bscontroller-ut_selfheal PUBLIC yutil library-cpp-cpuid_check cpp-testing-unittest_main + version_definition blobstorage-dsproxy-mock blobstorage-pdisk-mock core-mind-bscontroller diff --git a/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.windows-x86_64.txt b/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.windows-x86_64.txt index 8b59fa168205..3b6a02137fe6 100644 --- a/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.windows-x86_64.txt +++ b/ydb/core/mind/bscontroller/ut_selfheal/CMakeLists.windows-x86_64.txt @@ -16,6 +16,7 @@ target_link_libraries(ydb-core-mind-bscontroller-ut_selfheal PUBLIC yutil library-cpp-cpuid_check cpp-testing-unittest_main + version_definition blobstorage-dsproxy-mock blobstorage-pdisk-mock core-mind-bscontroller diff --git a/ydb/core/testlib/CMakeLists.darwin-arm64.txt b/ydb/core/testlib/CMakeLists.darwin-arm64.txt index d234d9d9e6a0..887f4f370184 100644 --- a/ydb/core/testlib/CMakeLists.darwin-arm64.txt +++ b/ydb/core/testlib/CMakeLists.darwin-arm64.txt @@ -18,6 +18,7 @@ target_compile_options(ydb-core-testlib PRIVATE target_link_libraries(ydb-core-testlib PUBLIC contrib-libs-cxxsupp yutil + version_definition library-actors-core library-actors-interconnect library-grpc-client diff --git a/ydb/core/testlib/CMakeLists.darwin-x86_64.txt b/ydb/core/testlib/CMakeLists.darwin-x86_64.txt index d234d9d9e6a0..887f4f370184 100644 --- a/ydb/core/testlib/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/testlib/CMakeLists.darwin-x86_64.txt @@ -18,6 +18,7 @@ target_compile_options(ydb-core-testlib PRIVATE target_link_libraries(ydb-core-testlib PUBLIC contrib-libs-cxxsupp yutil + version_definition library-actors-core library-actors-interconnect library-grpc-client diff --git a/ydb/core/testlib/CMakeLists.linux-aarch64.txt b/ydb/core/testlib/CMakeLists.linux-aarch64.txt index f5e108c012be..0a6dcd6d400c 100644 --- a/ydb/core/testlib/CMakeLists.linux-aarch64.txt +++ b/ydb/core/testlib/CMakeLists.linux-aarch64.txt @@ -19,6 +19,7 @@ target_link_libraries(ydb-core-testlib PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + version_definition library-actors-core library-actors-interconnect library-grpc-client diff --git a/ydb/core/testlib/CMakeLists.linux-x86_64.txt b/ydb/core/testlib/CMakeLists.linux-x86_64.txt index f5e108c012be..0a6dcd6d400c 100644 --- a/ydb/core/testlib/CMakeLists.linux-x86_64.txt +++ b/ydb/core/testlib/CMakeLists.linux-x86_64.txt @@ -19,6 +19,7 @@ target_link_libraries(ydb-core-testlib PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + version_definition library-actors-core library-actors-interconnect library-grpc-client diff --git a/ydb/core/testlib/CMakeLists.windows-x86_64.txt b/ydb/core/testlib/CMakeLists.windows-x86_64.txt index d234d9d9e6a0..887f4f370184 100644 --- a/ydb/core/testlib/CMakeLists.windows-x86_64.txt +++ b/ydb/core/testlib/CMakeLists.windows-x86_64.txt @@ -18,6 +18,7 @@ target_compile_options(ydb-core-testlib PRIVATE target_link_libraries(ydb-core-testlib PUBLIC contrib-libs-cxxsupp yutil + version_definition library-actors-core library-actors-interconnect library-grpc-client diff --git a/ydb/core/testlib/actors/CMakeLists.darwin-arm64.txt b/ydb/core/testlib/actors/CMakeLists.darwin-arm64.txt index 652256b272aa..559ad8cb1896 100644 --- a/ydb/core/testlib/actors/CMakeLists.darwin-arm64.txt +++ b/ydb/core/testlib/actors/CMakeLists.darwin-arm64.txt @@ -12,6 +12,7 @@ add_library(core-testlib-actors) target_link_libraries(core-testlib-actors PUBLIC contrib-libs-cxxsupp yutil + version_definition library-actors-testlib cpp-testing-unittest ydb-core-base diff --git a/ydb/core/testlib/actors/CMakeLists.darwin-x86_64.txt b/ydb/core/testlib/actors/CMakeLists.darwin-x86_64.txt index 652256b272aa..559ad8cb1896 100644 --- a/ydb/core/testlib/actors/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/testlib/actors/CMakeLists.darwin-x86_64.txt @@ -12,6 +12,7 @@ add_library(core-testlib-actors) target_link_libraries(core-testlib-actors PUBLIC contrib-libs-cxxsupp yutil + version_definition library-actors-testlib cpp-testing-unittest ydb-core-base diff --git a/ydb/core/testlib/actors/CMakeLists.linux-aarch64.txt b/ydb/core/testlib/actors/CMakeLists.linux-aarch64.txt index 3aa61780092e..296b9c055c85 100644 --- a/ydb/core/testlib/actors/CMakeLists.linux-aarch64.txt +++ b/ydb/core/testlib/actors/CMakeLists.linux-aarch64.txt @@ -13,6 +13,7 @@ target_link_libraries(core-testlib-actors PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + version_definition library-actors-testlib cpp-testing-unittest ydb-core-base diff --git a/ydb/core/testlib/actors/CMakeLists.linux-x86_64.txt b/ydb/core/testlib/actors/CMakeLists.linux-x86_64.txt index 3aa61780092e..296b9c055c85 100644 --- a/ydb/core/testlib/actors/CMakeLists.linux-x86_64.txt +++ b/ydb/core/testlib/actors/CMakeLists.linux-x86_64.txt @@ -13,6 +13,7 @@ target_link_libraries(core-testlib-actors PUBLIC contrib-libs-linux-headers contrib-libs-cxxsupp yutil + version_definition library-actors-testlib cpp-testing-unittest ydb-core-base diff --git a/ydb/core/testlib/actors/CMakeLists.windows-x86_64.txt b/ydb/core/testlib/actors/CMakeLists.windows-x86_64.txt index 652256b272aa..559ad8cb1896 100644 --- a/ydb/core/testlib/actors/CMakeLists.windows-x86_64.txt +++ b/ydb/core/testlib/actors/CMakeLists.windows-x86_64.txt @@ -12,6 +12,7 @@ add_library(core-testlib-actors) target_link_libraries(core-testlib-actors PUBLIC contrib-libs-cxxsupp yutil + version_definition library-actors-testlib cpp-testing-unittest ydb-core-base From 45a24af215720ef7206d1462d8fbfb4b35383860 Mon Sep 17 00:00:00 2001 From: Alexander Petrukhin Date: Mon, 18 Mar 2024 21:57:19 +0300 Subject: [PATCH 083/117] [grpc_server] improve logs on server shutdown (#2910) (#2911) --- ydb/library/grpc/server/grpc_server.cpp | 7 +++++-- 1 file changed, 5 insertions(+), 2 deletions(-) diff --git a/ydb/library/grpc/server/grpc_server.cpp b/ydb/library/grpc/server/grpc_server.cpp index b39a4f8b5de7..ffd236c22d04 100644 --- a/ydb/library/grpc/server/grpc_server.cpp +++ b/ydb/library/grpc/server/grpc_server.cpp @@ -210,13 +210,16 @@ void TGRpcServer::Stop() { break; auto spent = (TInstant::Now() - now).SecondsFloat(); - if (attempt % 300 == 0) { + if ((attempt + 1) % 300 == 0) { // don't log too much Cerr << "GRpc shutdown warning: left infly: " << infly << ", spent: " << spent << " sec" << Endl; } - if (!unsafe && spent > Options_.GRpcShutdownDeadline.SecondsFloat()) + if (!unsafe && spent > Options_.GRpcShutdownDeadline.SecondsFloat()) { + Cerr << "GRpc shutdown warning: failed to shutdown all connections, left infly: " << infly << ", spent: " << spent << " sec" + << Endl; break; + } Sleep(TDuration::MilliSeconds(10)); } From 7e50ccf384eba18be497079f417e03e6f42d7031 Mon Sep 17 00:00:00 2001 From: Vitalii Gridnev Date: Tue, 19 Mar 2024 13:44:43 +0300 Subject: [PATCH 084/117] Merge query service fixes to stable 24 1 (#2930) Co-authored-by: Daniil Cherednik Co-authored-by: spuchin --- .../grpc_services/query/rpc_execute_query.cpp | 2 +- .../kqp/executer_actor/kqp_data_executer.cpp | 12 +- ydb/core/kqp/executer_actor/kqp_executer.h | 10 +- .../kqp/executer_actor/kqp_executer_impl.cpp | 4 +- .../kqp/executer_actor/kqp_executer_impl.h | 26 +++- .../kqp/executer_actor/kqp_executer_stats.cpp | 11 +- .../kqp/executer_actor/kqp_executer_stats.h | 1 + .../executer_actor/kqp_literal_executer.cpp | 4 +- .../kqp/executer_actor/kqp_result_channel.cpp | 8 +- .../executer_actor/kqp_scheme_executer.cpp | 4 +- ydb/core/kqp/executer_actor/ya.make | 4 + ydb/core/kqp/provider/yql_kikimr_type_ann.cpp | 1 + .../kqp/proxy_service/kqp_proxy_service.cpp | 2 +- ydb/core/kqp/query_data/kqp_query_data.cpp | 10 +- ydb/core/kqp/query_data/kqp_query_data.h | 4 +- ydb/core/kqp/runtime/kqp_read_actor.cpp | 37 +++-- .../kqp/session_actor/kqp_session_actor.cpp | 14 +- ydb/core/kqp/ut/query/kqp_limits_ut.cpp | 47 ++++++ ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp | 2 +- ydb/core/kqp/ut/service/kqp_qs_queries_ut.cpp | 139 ++++++++++++++---- 20 files changed, 266 insertions(+), 76 deletions(-) diff --git a/ydb/core/grpc_services/query/rpc_execute_query.cpp b/ydb/core/grpc_services/query/rpc_execute_query.cpp index 3e642b39167c..6865cb8379e5 100644 --- a/ydb/core/grpc_services/query/rpc_execute_query.cpp +++ b/ydb/core/grpc_services/query/rpc_execute_query.cpp @@ -289,7 +289,7 @@ class TExecuteQueryRPC : public TActorBootstrapped { false, // keepSession false, // useCancelAfter syntax, - true); + true); // trailing support if (!ctx.Send(NKqp::MakeKqpProxyID(ctx.SelfID.NodeId()), ev.Release())) { NYql::TIssues issues; diff --git a/ydb/core/kqp/executer_actor/kqp_data_executer.cpp b/ydb/core/kqp/executer_actor/kqp_data_executer.cpp index 15fe364f8d25..4ff23bfa0165 100644 --- a/ydb/core/kqp/executer_actor/kqp_data_executer.cpp +++ b/ydb/core/kqp/executer_actor/kqp_data_executer.cpp @@ -278,8 +278,16 @@ class TKqpDataExecuter : public TKqpExecuterBaseGetByteSize(); if (resultSize > (int)ReplySizeLimit) { - TString message = TStringBuilder() << "Query result size limit exceeded. (" - << resultSize << " > " << ReplySizeLimit << ")"; + TString message; + if (ResponseEv->TxResults.size() == 1 && !ResponseEv->TxResults[0].QueryResultIndex.Defined()) { + message = TStringBuilder() << "Intermediate data materialization exceeded size limit" + << " (" << resultSize << " > " << ReplySizeLimit << ")." + << " This usually happens when trying to write large amounts of data or to perform lookup" + << " by big collection of keys in single query. Consider using smaller batches of data."; + } else { + message = TStringBuilder() << "Query result size limit exceeded. (" + << resultSize << " > " << ReplySizeLimit << ")"; + } auto issue = YqlIssue({}, TIssuesIds::KIKIMR_RESULT_UNAVAILABLE, message); ReplyErrorAndDie(Ydb::StatusIds::PRECONDITION_FAILED, issue); diff --git a/ydb/core/kqp/executer_actor/kqp_executer.h b/ydb/core/kqp/executer_actor/kqp_executer.h index 242c64027224..d0d2105276c4 100644 --- a/ydb/core/kqp/executer_actor/kqp_executer.h +++ b/ydb/core/kqp/executer_actor/kqp_executer.h @@ -28,8 +28,16 @@ struct TEvKqpExecuter { ui64 ResultRowsCount = 0; ui64 ResultRowsBytes = 0; - explicit TEvTxResponse(TTxAllocatorState::TPtr allocState) + enum class EExecutionType { + Data, + Scan, + Scheme, + Literal, + } ExecutionType; + + TEvTxResponse(TTxAllocatorState::TPtr allocState, EExecutionType type) : AllocState(std::move(allocState)) + , ExecutionType(type) {} ~TEvTxResponse(); diff --git a/ydb/core/kqp/executer_actor/kqp_executer_impl.cpp b/ydb/core/kqp/executer_actor/kqp_executer_impl.cpp index f43e2ad845b6..5975a8ac4e2e 100644 --- a/ydb/core/kqp/executer_actor/kqp_executer_impl.cpp +++ b/ydb/core/kqp/executer_actor/kqp_executer_impl.cpp @@ -96,7 +96,9 @@ IActor* CreateKqpExecuter(IKqpGateway::TExecPhysicalRequest&& request, const TSt for (auto& tx : request.Transactions) { if (txsType) { YQL_ENSURE(*txsType == tx.Body->GetType(), "Mixed physical tx types in executer."); - YQL_ENSURE(*txsType == NKqpProto::TKqpPhyTx::TYPE_DATA, "Cannot execute multiple non-data physical txs."); + YQL_ENSURE((*txsType == NKqpProto::TKqpPhyTx::TYPE_DATA) + || (*txsType == NKqpProto::TKqpPhyTx::TYPE_GENERIC), + "Cannot execute multiple non-data physical txs."); } else { txsType = tx.Body->GetType(); } diff --git a/ydb/core/kqp/executer_actor/kqp_executer_impl.h b/ydb/core/kqp/executer_actor/kqp_executer_impl.h index fc944349ea13..f0706f346a95 100644 --- a/ydb/core/kqp/executer_actor/kqp_executer_impl.h +++ b/ydb/core/kqp/executer_actor/kqp_executer_impl.h @@ -64,12 +64,10 @@ namespace NKqp { #define LOG_E(stream) LOG_ERROR_S(*TlsActivationContext, NKikimrServices::KQP_EXECUTER, "ActorId: " << SelfId() << " TxId: " << TxId << ". " << "Ctx: " << *GetUserRequestContext() << ". " << stream) #define LOG_C(stream) LOG_CRIT_S(*TlsActivationContext, NKikimrServices::KQP_EXECUTER, "ActorId: " << SelfId() << " TxId: " << TxId << ". " << "Ctx: " << *GetUserRequestContext() << ". " << stream) -enum class EExecType { - Data, - Scan -}; +using EExecType = TEvKqpExecuter::TEvTxResponse::EExecutionType; const ui64 MaxTaskSize = 48_MB; +constexpr ui64 PotentialUnsigned64OverflowLimit = (std::numeric_limits::max() >> 1); std::pair SerializeKqpTasksParametersForOlap(const TStageInfo& stageInfo, const TTask& task); @@ -114,6 +112,7 @@ struct TEvPrivate { template class TKqpExecuterBase : public TActorBootstrapped { + static_assert(ExecType == EExecType::Data || ExecType == EExecType::Scan); public: TKqpExecuterBase(IKqpGateway::TExecPhysicalRequest&& request, const TString& database, const TIntrusiveConstPtr& userToken, @@ -140,7 +139,7 @@ class TKqpExecuterBase : public TActorBootstrapped { TasksGraph.GetMeta().Database = Database; TasksGraph.GetMeta().ChannelTransportVersion = chanTransportVersion; TasksGraph.GetMeta().UserRequestContext = userRequestContext; - ResponseEv = std::make_unique(Request.TxAlloc); + ResponseEv = std::make_unique(Request.TxAlloc, ExecType); ResponseEv->Orbit = std::move(Request.Orbit); Stats = std::make_unique(Request.StatsMode, &TasksGraph, ResponseEv->Record.MutableResponse()->MutableResult()->MutableStats()); @@ -360,7 +359,7 @@ class TKqpExecuterBase : public TActorBootstrapped { ui64 seqNo = ev->Get()->Record.GetSeqNo(); i64 freeSpace = ev->Get()->Record.GetFreeSpace(); - LOG_ERROR_S(*NActors::TlsActivationContext, NKikimrServices::KQP_EXECUTER, "TxId: " << TxId + LOG_DEBUG_S(*NActors::TlsActivationContext, NKikimrServices::KQP_EXECUTER, "TxId: " << TxId << ", send ack to channelId: " << channelId << ", seqNo: " << seqNo << ", enough: " << ev->Get()->Record.GetEnough() @@ -798,6 +797,9 @@ class TKqpExecuterBase : public TActorBootstrapped { auto ru = NRuCalc::CalcRequestUnit(consumption); + YQL_ENSURE(consumption.ReadIOStat.Rows < PotentialUnsigned64OverflowLimit); + YQL_ENSURE(ru < PotentialUnsigned64OverflowLimit); + // Some heuristic to reduce overprice due to round part stats if (ru <= 100 && !force) return; @@ -1661,6 +1663,10 @@ class TKqpExecuterBase : public TActorBootstrapped { } void AbortExecutionAndDie(TActorId abortSender, NYql::NDqProto::StatusIds::StatusCode status, const TString& message) { + if (AlreadyReplied) { + return; + } + LOG_E("Abort execution: " << NYql::NDqProto::StatusIds_StatusCode_Name(status) << "," << message); if (ExecuterSpan) { ExecuterSpan.EndError(TStringBuilder() << NYql::NDqProto::StatusIds_StatusCode_Name(status)); @@ -1674,6 +1680,7 @@ class TKqpExecuterBase : public TActorBootstrapped { this->Send(Target, abortEv.Release()); } + AlreadyReplied = true; LOG_E("Sending timeout response to: " << Target); this->Send(Target, ResponseEv.release()); @@ -1685,6 +1692,10 @@ class TKqpExecuterBase : public TActorBootstrapped { virtual void ReplyErrorAndDie(Ydb::StatusIds::StatusCode status, google::protobuf::RepeatedPtrField* issues) { + if (AlreadyReplied) { + return; + } + if (Planner) { for (auto computeActor : Planner->GetPendingComputeActors()) { LOG_D("terminate compute actor " << computeActor.first); @@ -1694,6 +1705,7 @@ class TKqpExecuterBase : public TActorBootstrapped { } } + AlreadyReplied = true; auto& response = *ResponseEv->Record.MutableResponse(); response.SetStatus(status); @@ -1907,6 +1919,8 @@ class TKqpExecuterBase : public TActorBootstrapped { THashMap ResultChannelToComputeActor; THashMap> SourceScanStageIdToParititions; + bool AlreadyReplied = false; + private: static constexpr TDuration ResourceUsageUpdateInterval = TDuration::MilliSeconds(100); }; diff --git a/ydb/core/kqp/executer_actor/kqp_executer_stats.cpp b/ydb/core/kqp/executer_actor/kqp_executer_stats.cpp index 34633516825a..2c67d66cbe38 100644 --- a/ydb/core/kqp/executer_actor/kqp_executer_stats.cpp +++ b/ydb/core/kqp/executer_actor/kqp_executer_stats.cpp @@ -746,7 +746,7 @@ void TQueryExecutionStats::ExportExecStats(NYql::NDqProto::TDqExecutionStats& st for (auto& p2 : p.second.Egress) { ExportAggAsyncBufferStats(p2.second, (*stageStats.MutableEgress())[p2.first]); } - } + } } void TQueryExecutionStats::Finish() { @@ -761,7 +761,7 @@ void TQueryExecutionStats::Finish() { Result->SetDurationUs(FinishTs.MicroSeconds() - StartTs.MicroSeconds()); // Result->Result* feilds are (temporary?) commented out in proto due to lack of use - // + // // Result->SetResultBytes(ResultBytes); // Result->SetResultRows(ResultRows); @@ -838,6 +838,11 @@ void TProgressStatEntry::Out(IOutputStream& o) const { } void TProgressStat::Set(const NDqProto::TDqComputeActorStats& stats) { + if (Cur.Defined) { + Cur = TEntry(); + } + + Cur.Defined = true; Cur.ComputeTime += TDuration::MicroSeconds(stats.GetCpuTimeUs()); for (auto& task : stats.GetTasks()) { for (auto& table: task.GetTables()) { @@ -848,7 +853,7 @@ void TProgressStat::Set(const NDqProto::TDqComputeActorStats& stats) { } TProgressStat::TEntry TProgressStat::GetLastUsage() const { - return Cur - Total; + return Cur.Defined ? Cur - Total : Cur; } void TProgressStat::Update() { diff --git a/ydb/core/kqp/executer_actor/kqp_executer_stats.h b/ydb/core/kqp/executer_actor/kqp_executer_stats.h index bea43d882dab..b078a6ca7e64 100644 --- a/ydb/core/kqp/executer_actor/kqp_executer_stats.h +++ b/ydb/core/kqp/executer_actor/kqp_executer_stats.h @@ -191,6 +191,7 @@ struct TTableStat { struct TProgressStatEntry { TDuration ComputeTime; TTableStat ReadIOStat; + bool Defined = false; TProgressStatEntry& operator+=(const TProgressStatEntry& rhs); diff --git a/ydb/core/kqp/executer_actor/kqp_literal_executer.cpp b/ydb/core/kqp/executer_actor/kqp_literal_executer.cpp index 6c2df7106680..3c50ede68766 100644 --- a/ydb/core/kqp/executer_actor/kqp_literal_executer.cpp +++ b/ydb/core/kqp/executer_actor/kqp_literal_executer.cpp @@ -79,7 +79,9 @@ class TKqpLiteralExecuter { , LiteralExecuterSpan(TWilsonKqp::LiteralExecuter, std::move(Request.TraceId), "LiteralExecuter") , UserRequestContext(userRequestContext) { - ResponseEv = std::make_unique(Request.TxAlloc); + ResponseEv = std::make_unique( + Request.TxAlloc, TEvKqpExecuter::TEvTxResponse::EExecutionType::Literal); + ResponseEv->Orbit = std::move(Request.Orbit); Stats = std::make_unique(Request.StatsMode, &TasksGraph, ResponseEv->Record.MutableResponse()->MutableResult()->MutableStats()); diff --git a/ydb/core/kqp/executer_actor/kqp_result_channel.cpp b/ydb/core/kqp/executer_actor/kqp_result_channel.cpp index 3d3d9d00d199..c71efa06082a 100644 --- a/ydb/core/kqp/executer_actor/kqp_result_channel.cpp +++ b/ydb/core/kqp/executer_actor/kqp_result_channel.cpp @@ -56,6 +56,8 @@ class TResultCommonChannelProxy : public NActors::TActor(NYql::NDqProto::StatusIds::INTERNAL_ERROR, msg); + auto evAbort = MakeHolder(code, msg); Send(Executer, evAbort.Release()); Become(&TResultCommonChannelProxy::DeadState); @@ -112,7 +114,7 @@ class TResultCommonChannelProxy : public NActors::TActorGetTypeRewrite()) { hFunc(TEvents::TEvPoison, HandlePoison); } - + } catch(const yexception& ex) { InternalError(ex.what()); } diff --git a/ydb/core/kqp/executer_actor/kqp_scheme_executer.cpp b/ydb/core/kqp/executer_actor/kqp_scheme_executer.cpp index 26dc514af23b..9ed5fceef0d3 100644 --- a/ydb/core/kqp/executer_actor/kqp_scheme_executer.cpp +++ b/ydb/core/kqp/executer_actor/kqp_scheme_executer.cpp @@ -69,7 +69,9 @@ class TKqpSchemeExecuter : public TActorBootstrapped { YQL_ENSURE(PhyTx); YQL_ENSURE(PhyTx->GetType() == NKqpProto::TKqpPhyTx::TYPE_SCHEME); - ResponseEv = std::make_unique(nullptr); + ResponseEv = std::make_unique( + nullptr, + TEvKqpExecuter::TEvTxResponse::EExecutionType::Scheme); } void StartBuildOperation() { diff --git a/ydb/core/kqp/executer_actor/ya.make b/ydb/core/kqp/executer_actor/ya.make index 7a7cee3e675e..9cb7618afb0d 100644 --- a/ydb/core/kqp/executer_actor/ya.make +++ b/ydb/core/kqp/executer_actor/ya.make @@ -42,6 +42,10 @@ PEERDIR( ydb/library/yql/providers/common/http_gateway ) +GENERATE_ENUM_SERIALIZATION( + kqp_executer.h +) + YQL_LAST_ABI_VERSION() END() diff --git a/ydb/core/kqp/provider/yql_kikimr_type_ann.cpp b/ydb/core/kqp/provider/yql_kikimr_type_ann.cpp index 527cc1dce28e..9204f469758d 100644 --- a/ydb/core/kqp/provider/yql_kikimr_type_ann.cpp +++ b/ydb/core/kqp/provider/yql_kikimr_type_ann.cpp @@ -887,6 +887,7 @@ virtual TStatus HandleCreateTable(TKiCreateTable create, TExprContext& ctx) over columnMeta.DefaultFromSequence = "_serial_column_" + columnMeta.Name; columnMeta.SetDefaultFromSequence(); + columnMeta.NotNull = true; } else if (constraint.Name().Value() == "not_null") { columnMeta.NotNull = true; } diff --git a/ydb/core/kqp/proxy_service/kqp_proxy_service.cpp b/ydb/core/kqp/proxy_service/kqp_proxy_service.cpp index f19e2e74e82d..8755961afbf8 100644 --- a/ydb/core/kqp/proxy_service/kqp_proxy_service.cpp +++ b/ydb/core/kqp/proxy_service/kqp_proxy_service.cpp @@ -863,7 +863,7 @@ class TKqpProxyService : public TActorBootstrapped { } const TKqpSessionInfo* info = LocalSessions->FindPtr(proxyRequest->SessionId); - if (info) { + if (info && !info->AttachedRpcId) { LocalSessions->StartIdleCheck(info, GetSessionIdleDuration()); } diff --git a/ydb/core/kqp/query_data/kqp_query_data.cpp b/ydb/core/kqp/query_data/kqp_query_data.cpp index c0bf8e338ed0..7debbaf9da02 100644 --- a/ydb/core/kqp/query_data/kqp_query_data.cpp +++ b/ydb/core/kqp/query_data/kqp_query_data.cpp @@ -77,14 +77,12 @@ Ydb::ResultSet* TKqpExecuterTxResult::GetYdb(google::protobuf::Arena* arena, TMa return ydbResult; } -Ydb::ResultSet* TKqpExecuterTxResult::GetTrailingYdb(google::protobuf::Arena* arena) { +Ydb::ResultSet* TKqpExecuterTxResult::ExtractTrailingYdb(google::protobuf::Arena* arena) { if (!HasTrailingResult) return nullptr; Ydb::ResultSet* ydbResult = google::protobuf::Arena::CreateMessage(arena); - if (TrailingResult.rows().size() > 0) { - ydbResult->Swap(&TrailingResult); - } + ydbResult->Swap(&TrailingResult); return ydbResult; } @@ -237,10 +235,10 @@ NKikimrMiniKQL::TResult* TQueryData::GetMkqlTxResult(const NKqpProto::TKqpPhyRes return TxResults[txIndex][resultIndex].GetMkql(arena); } -Ydb::ResultSet* TQueryData::GetTrailingTxResult(const NKqpProto::TKqpPhyResultBinding& rb, google::protobuf::Arena* arena) { +Ydb::ResultSet* TQueryData::ExtractTrailingTxResult(const NKqpProto::TKqpPhyResultBinding& rb, google::protobuf::Arena* arena) { auto txIndex = rb.GetTxResultBinding().GetTxIndex(); auto resultIndex = rb.GetTxResultBinding().GetResultIndex(); - return TxResults[txIndex][resultIndex].GetTrailingYdb(arena); + return TxResults[txIndex][resultIndex].ExtractTrailingYdb(arena); } diff --git a/ydb/core/kqp/query_data/kqp_query_data.h b/ydb/core/kqp/query_data/kqp_query_data.h index ca8e772d5bda..9c380c090965 100644 --- a/ydb/core/kqp/query_data/kqp_query_data.h +++ b/ydb/core/kqp/query_data/kqp_query_data.h @@ -100,7 +100,7 @@ struct TKqpExecuterTxResult { NKikimrMiniKQL::TResult* GetMkql(google::protobuf::Arena* arena); NKikimrMiniKQL::TResult GetMkql(); Ydb::ResultSet* GetYdb(google::protobuf::Arena* arena, TMaybe rowsLimitPerWrite); - Ydb::ResultSet* GetTrailingYdb(google::protobuf::Arena* arena); + Ydb::ResultSet* ExtractTrailingYdb(google::protobuf::Arena* arena); void FillMkql(NKikimrMiniKQL::TResult* mkqlResult); void FillYdb(Ydb::ResultSet* ydbResult, TMaybe rowsLimitPerWrite); @@ -253,7 +253,7 @@ class TQueryData : NMiniKQL::ITerminator { TTypedUnboxedValue GetTxResult(ui32 txIndex, ui32 resultIndex); NKikimrMiniKQL::TResult* GetMkqlTxResult(const NKqpProto::TKqpPhyResultBinding& rb, google::protobuf::Arena* arena); Ydb::ResultSet* GetYdbTxResult(const NKqpProto::TKqpPhyResultBinding& rb, google::protobuf::Arena* arena, TMaybe rowsLimitPerWrite); - Ydb::ResultSet* GetTrailingTxResult(const NKqpProto::TKqpPhyResultBinding& rb, google::protobuf::Arena* arena); + Ydb::ResultSet* ExtractTrailingTxResult(const NKqpProto::TKqpPhyResultBinding& rb, google::protobuf::Arena* arena); std::pair GetInternalBindingValue(const NKqpProto::TKqpPhyParamBinding& paramBinding); TTypedUnboxedValue& GetParameterUnboxedValue(const TString& name); diff --git a/ydb/core/kqp/runtime/kqp_read_actor.cpp b/ydb/core/kqp/runtime/kqp_read_actor.cpp index 22f1bf9bcfc9..1b69097b7b48 100644 --- a/ydb/core/kqp/runtime/kqp_read_actor.cpp +++ b/ydb/core/kqp/runtime/kqp_read_actor.cpp @@ -1136,7 +1136,7 @@ class TKqpReadActor : public TActorBootstrapped, public NYql::NDq NMiniKQL::WriteColumnValuesFromArrow(editAccessors, NMiniKQL::TBatchDataAccessor(result->Get()->GetArrowBatch()), columnIndex, resultColumnIndex, column.TypeInfo) ); if (column.NotNull) { - std::shared_ptr columnSharedPtr = result->Get()->GetArrowBatch()->column(columnIndex); + std::shared_ptr columnSharedPtr = result->Get()->GetArrowBatch()->column(columnIndex); bool gotNullValue = false; for (ui64 rowIndex = 0; rowIndex < result->Get()->GetRowsCount(); ++rowIndex) { if (columnSharedPtr->IsNull(rowIndex)) { @@ -1181,9 +1181,14 @@ class TKqpReadActor : public TActorBootstrapped, public NYql::NDq } NMiniKQL::TBytesStatistics PackCells(TResult& handle, i64& freeSpace) { - auto& [shardId, result, batch, _, packed] = handle; + auto& [shardId, result, batch, processedRows, packed] = handle; NMiniKQL::TBytesStatistics stats; batch->reserve(batch->size()); + CA_LOG_D(TStringBuilder() << "enter pack cells method " + << " shardId: " << shardId + << " processedRows: " << processedRows + << " packed rows: " << packed + << " freeSpace: " << freeSpace); for (size_t rowIndex = packed; rowIndex < result->Get()->GetRowsCount(); ++rowIndex) { const auto& row = result->Get()->GetCells(rowIndex); @@ -1225,6 +1230,12 @@ class TKqpReadActor : public TActorBootstrapped, public NYql::NDq break; } } + + CA_LOG_D(TStringBuilder() << "exit pack cells method " + << " shardId: " << shardId + << " processedRows: " << processedRows + << " packed rows: " << packed + << " freeSpace: " << freeSpace); return stats; } @@ -1246,7 +1257,9 @@ class TKqpReadActor : public TActorBootstrapped, public NYql::NDq YQL_ENSURE(!resultBatch.IsWide(), "Wide stream is not supported"); - CA_LOG_D(TStringBuilder() << " enter getasyncinputdata results size " << Results.size()); + CA_LOG_D(TStringBuilder() << " enter getasyncinputdata results size " << Results.size() + << ", freeSpace " << freeSpace); + ui64 bytes = 0; while (!Results.empty()) { auto& result = Results.front(); @@ -1255,14 +1268,15 @@ class TKqpReadActor : public TActorBootstrapped, public NYql::NDq auto& msg = *result.ReadResult->Get(); if (!batch.Defined()) { batch.ConstructInPlace(); - switch (msg.Record.GetResultFormat()) { - case NKikimrDataEvents::FORMAT_ARROW: - BytesStats.AddStatistics(PackArrow(result, freeSpace)); - break; - case NKikimrDataEvents::FORMAT_UNSPECIFIED: - case NKikimrDataEvents::FORMAT_CELLVEC: - BytesStats.AddStatistics(PackCells(result, freeSpace)); - } + } + + switch (msg.Record.GetResultFormat()) { + case NKikimrDataEvents::FORMAT_ARROW: + BytesStats.AddStatistics(PackArrow(result, freeSpace)); + break; + case NKikimrDataEvents::FORMAT_UNSPECIFIED: + case NKikimrDataEvents::FORMAT_CELLVEC: + BytesStats.AddStatistics(PackCells(result, freeSpace)); } auto id = result.ReadResult->Get()->Record.GetReadId(); @@ -1334,6 +1348,7 @@ class TKqpReadActor : public TActorBootstrapped, public NYql::NDq CA_LOG_D(TStringBuilder() << "returned async data" << " processed rows " << ProcessedRowCount + << " left freeSpace " << freeSpace << " received rows " << ReceivedRowCount << " running reads " << RunningReads() << " pending shards " << PendingShards.Size() diff --git a/ydb/core/kqp/session_actor/kqp_session_actor.cpp b/ydb/core/kqp/session_actor/kqp_session_actor.cpp index 1b285ba738e6..2d43845429eb 100644 --- a/ydb/core/kqp/session_actor/kqp_session_actor.cpp +++ b/ydb/core/kqp/session_actor/kqp_session_actor.cpp @@ -1268,7 +1268,10 @@ class TKqpSessionActor : public TActorBootstrapped { ExecuterId = TActorId{}; if (response->GetStatus() != Ydb::StatusIds::SUCCESS) { - LOG_D("TEvTxResponse has non-success status, CurrentTx: " << QueryState->CurrentTx); + const auto executionType = ev->ExecutionType; + + LOG_D("TEvTxResponse has non-success status, CurrentTx: " << QueryState->CurrentTx + << " ExecutionType: " << executionType); auto status = response->GetStatus(); TIssues issues; @@ -1280,11 +1283,14 @@ class TKqpSessionActor : public TActorBootstrapped { case Ydb::StatusIds::INTERNAL_ERROR: InvalidateQuery(); issues.AddIssue(YqlIssue(TPosition(), TIssuesIds::KIKIMR_QUERY_INVALIDATED, - TStringBuilder() << "Query invalidated on scheme/internal error.")); + TStringBuilder() << "Query invalidated on scheme/internal error during " + << executionType << " execution")); // SCHEME_ERROR during execution is a soft (retriable) error, we abort query execution, // invalidate query cache, and return ABORTED as retriable status. - if (status == Ydb::StatusIds::SCHEME_ERROR) { + if (status == Ydb::StatusIds::SCHEME_ERROR && + executionType != TEvKqpExecuter::TEvTxResponse::EExecutionType::Scheme) + { status = Ydb::StatusIds::ABORTED; } @@ -1581,7 +1587,7 @@ class TKqpSessionActor : public TActorBootstrapped { size_t trailingResultsCount = 0; for (size_t i = 0; i < phyQuery.ResultBindingsSize(); ++i) { if (QueryState->IsStreamResult()) { - auto ydbResult = QueryState->QueryData->GetTrailingTxResult( + auto ydbResult = QueryState->QueryData->ExtractTrailingTxResult( phyQuery.GetResultBindings(i), response->GetArena()); if (ydbResult) { diff --git a/ydb/core/kqp/ut/query/kqp_limits_ut.cpp b/ydb/core/kqp/ut/query/kqp_limits_ut.cpp index 2b0218e43e7b..bca5187d1607 100644 --- a/ydb/core/kqp/ut/query/kqp_limits_ut.cpp +++ b/ydb/core/kqp/ut/query/kqp_limits_ut.cpp @@ -17,6 +17,35 @@ namespace { } Y_UNIT_TEST_SUITE(KqpLimits) { + Y_UNIT_TEST(QSReplySizeEnsureMemoryLimits) { + TKikimrRunner kikimr; + CreateLargeTable(kikimr, 1'000, 100, 1'000, 1'000); + + auto db = kikimr.GetQueryClient(); + + TControlWrapper mkqlInitialMemoryLimit; + TControlWrapper mkqlMaxMemoryLimit; + + mkqlInitialMemoryLimit = kikimr.GetTestServer().GetRuntime()->GetAppData().Icb->RegisterSharedControl( + mkqlInitialMemoryLimit, "KqpSession.MkqlInitialMemoryLimit"); + mkqlMaxMemoryLimit = kikimr.GetTestServer().GetRuntime()->GetAppData().Icb->RegisterSharedControl( + mkqlMaxMemoryLimit, "KqpSession.MkqlMaxMemoryLimit"); + + mkqlInitialMemoryLimit = 1_KB; + mkqlMaxMemoryLimit = 1_KB; + + auto result = db.ExecuteQuery(R"( + UPSERT INTO KeyValue2 + SELECT + KeyText AS Key, + DataText AS Value + FROM `/Root/LargeTable`; + )", NQuery::TTxControl::BeginTx().CommitTx()).ExtractValueSync(); + result.GetIssues().PrintTo(Cerr); + UNIT_ASSERT_VALUES_EQUAL(result.GetStatus(), EStatus::PRECONDITION_FAILED); + UNIT_ASSERT(!to_lower(result.GetIssues().ToString()).Contains("query result")); + } + Y_UNIT_TEST(KqpMkqlMemoryLimitException) { TKikimrRunner kikimr; CreateLargeTable(kikimr, 10, 10, 1'000'000, 1); @@ -1033,6 +1062,24 @@ Y_UNIT_TEST_SUITE(KqpLimits) { last = current; } } + + Y_UNIT_TEST(QSReplySize) { + TKikimrRunner kikimr; + CreateLargeTable(kikimr, 10'000, 100, 1'000, 1'000); + + auto db = kikimr.GetQueryClient(); + + auto result = db.ExecuteQuery(R"( + UPSERT INTO KeyValue2 + SELECT + KeyText AS Key, + DataText AS Value + FROM `/Root/LargeTable`; + )", NQuery::TTxControl::BeginTx().CommitTx()).ExtractValueSync(); + result.GetIssues().PrintTo(Cerr); + UNIT_ASSERT_VALUES_EQUAL(result.GetStatus(), EStatus::PRECONDITION_FAILED); + UNIT_ASSERT(!to_lower(result.GetIssues().ToString()).Contains("query result")); + } } } // namespace NKqp diff --git a/ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp b/ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp index 71ff6bc7da91..6fbb7319009d 100644 --- a/ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp +++ b/ydb/core/kqp/ut/scheme/kqp_constraints_ut.cpp @@ -256,7 +256,7 @@ Y_UNIT_TEST_SUITE(KqpConstraints) { result.GetIssues().ToString()); CompareYson(R"( [ - [[1];["New"]] + [1;["New"]] ] )", NYdb::FormatResultSetYson(result.GetResultSet(0))); diff --git a/ydb/core/kqp/ut/service/kqp_qs_queries_ut.cpp b/ydb/core/kqp/ut/service/kqp_qs_queries_ut.cpp index dbcc2dcf8b09..aa8009bcacab 100644 --- a/ydb/core/kqp/ut/service/kqp_qs_queries_ut.cpp +++ b/ydb/core/kqp/ut/service/kqp_qs_queries_ut.cpp @@ -140,26 +140,55 @@ Y_UNIT_TEST_SUITE(KqpQueryService) { auto kikimr = DefaultKikimrRunner(); auto db = kikimr.GetQueryClient(); - auto it = db.StreamExecuteQuery(R"( - SELECT Key, Value2 FROM TwoShard WHERE Value2 > 0; - )", TTxControl::BeginTx().CommitTx()).ExtractValueSync(); - UNIT_ASSERT_C(it.IsSuccess(), it.GetIssues().ToString()); + { + auto it = db.StreamExecuteQuery(R"( + SELECT Key, Value2 FROM TwoShard WHERE Value2 > 0; + )", TTxControl::BeginTx().CommitTx()).ExtractValueSync(); + UNIT_ASSERT_C(it.IsSuccess(), it.GetIssues().ToString()); + + ui64 count = 0; + for (;;) { + auto streamPart = it.ReadNext().GetValueSync(); + if (!streamPart.IsSuccess()) { + UNIT_ASSERT_C(streamPart.EOS(), streamPart.GetIssues().ToString()); + break; + } - ui64 count = 0; - for (;;) { - auto streamPart = it.ReadNext().GetValueSync(); - if (!streamPart.IsSuccess()) { - UNIT_ASSERT_C(streamPart.EOS(), streamPart.GetIssues().ToString()); - break; + if (streamPart.HasResultSet()) { + auto resultSet = streamPart.ExtractResultSet(); + count += resultSet.RowsCount(); + } } - if (streamPart.HasResultSet()) { - auto resultSet = streamPart.ExtractResultSet(); - count += resultSet.RowsCount(); - } + UNIT_ASSERT_VALUES_EQUAL(count, 2); } - UNIT_ASSERT_VALUES_EQUAL(count, 2); + { + auto it = db.StreamExecuteQuery(R"( + SELECT Key, Value2 FROM TwoShard WHERE false ORDER BY Key > 0; + )", TTxControl::BeginTx().CommitTx()).ExtractValueSync(); + UNIT_ASSERT_C(it.IsSuccess(), it.GetIssues().ToString()); + + ui32 rsCount = 0; + ui32 columns = 0; + for (;;) { + auto streamPart = it.ReadNext().GetValueSync(); + if (!streamPart.IsSuccess()) { + UNIT_ASSERT_C(streamPart.EOS(), streamPart.GetIssues().ToString()); + break; + } + + if (streamPart.HasResultSet()) { + auto resultSet = streamPart.ExtractResultSet(); + columns = resultSet.ColumnsCount(); + CompareYson(R"([])", FormatResultSetYson(resultSet)); + rsCount++; + } + } + + UNIT_ASSERT_VALUES_EQUAL(rsCount, 1); + UNIT_ASSERT_VALUES_EQUAL(columns, 2); + } } void CheckQueryResult(TExecuteQueryResult result) { @@ -242,27 +271,60 @@ Y_UNIT_TEST_SUITE(KqpQueryService) { UNIT_ASSERT_VALUES_EQUAL_C(sessionResult.GetStatus(), EStatus::SUCCESS, sessionResult.GetIssues().ToString()); auto session = sessionResult.GetSession(); - const TString query = "UPDATE TwoShard SET Value2 = 0"; - auto result = session.ExecuteQuery(query, TTxControl::BeginTx()).ExtractValueSync(); - UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, result.GetIssues().ToString()); - auto transaction = result.GetTransaction(); - UNIT_ASSERT(transaction->IsActive()); + { + const TString query = "UPDATE TwoShard SET Value2 = 0"; + auto result = session.ExecuteQuery(query, TTxControl::BeginTx()).ExtractValueSync(); + UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, result.GetIssues().ToString()); + auto transaction = result.GetTransaction(); + UNIT_ASSERT(transaction->IsActive()); - auto checkResult = [&](TString expected) { - auto selectRes = db.ExecuteQuery( - "SELECT * FROM TwoShard ORDER BY Key", - TTxControl::BeginTx().CommitTx() - ).ExtractValueSync(); + auto checkResult = [&](TString expected) { + auto selectRes = db.ExecuteQuery( + "SELECT * FROM TwoShard ORDER BY Key", + TTxControl::BeginTx().CommitTx() + ).ExtractValueSync(); - UNIT_ASSERT_C(selectRes.IsSuccess(), selectRes.GetIssues().ToString()); - CompareYson(expected, FormatResultSetYson(selectRes.GetResultSet(0))); - }; - checkResult(R"([[[1u];["One"];[-1]];[[2u];["Two"];[0]];[[3u];["Three"];[1]];[[4000000001u];["BigOne"];[-1]];[[4000000002u];["BigTwo"];[0]];[[4000000003u];["BigThree"];[1]]])"); + UNIT_ASSERT_C(selectRes.IsSuccess(), selectRes.GetIssues().ToString()); + CompareYson(expected, FormatResultSetYson(selectRes.GetResultSet(0))); + }; + checkResult(R"([[[1u];["One"];[-1]];[[2u];["Two"];[0]];[[3u];["Three"];[1]];[[4000000001u];["BigOne"];[-1]];[[4000000002u];["BigTwo"];[0]];[[4000000003u];["BigThree"];[1]]])"); - auto txRes = transaction->Commit().GetValueSync(); - UNIT_ASSERT_VALUES_EQUAL_C(txRes.GetStatus(), EStatus::SUCCESS, txRes.GetIssues().ToString()); + auto txRes = transaction->Commit().GetValueSync(); + UNIT_ASSERT_VALUES_EQUAL_C(txRes.GetStatus(), EStatus::SUCCESS, txRes.GetIssues().ToString()); - checkResult(R"([[[1u];["One"];[0]];[[2u];["Two"];[0]];[[3u];["Three"];[0]];[[4000000001u];["BigOne"];[0]];[[4000000002u];["BigTwo"];[0]];[[4000000003u];["BigThree"];[0]]])"); + checkResult(R"([[[1u];["One"];[0]];[[2u];["Two"];[0]];[[3u];["Three"];[0]];[[4000000001u];["BigOne"];[0]];[[4000000002u];["BigTwo"];[0]];[[4000000003u];["BigThree"];[0]]])"); + } + + { + const TString query = "UPDATE TwoShard SET Value2 = 1"; + auto result = session.ExecuteQuery(query, TTxControl::BeginTx()).ExtractValueSync(); + UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SUCCESS, result.GetIssues().ToString()); + auto transaction = result.GetTransaction(); + UNIT_ASSERT(transaction->IsActive()); + + const TString query2 = "UPDATE KeyValue SET Value = 'Vic'"; + auto result2 = session.ExecuteQuery(query2, TTxControl::Tx(transaction->GetId())).ExtractValueSync(); + UNIT_ASSERT_VALUES_EQUAL_C(result2.GetStatus(), EStatus::SUCCESS, result2.GetIssues().ToString()); + auto transaction2 = result2.GetTransaction(); + UNIT_ASSERT(transaction2->IsActive()); + + auto checkResult = [&](TString table, TString expected) { + auto selectRes = db.ExecuteQuery( + Sprintf("SELECT * FROM %s ORDER BY Key", table.data()), + TTxControl::BeginTx().CommitTx() + ).ExtractValueSync(); + + UNIT_ASSERT_C(selectRes.IsSuccess(), selectRes.GetIssues().ToString()); + CompareYson(expected, FormatResultSetYson(selectRes.GetResultSet(0))); + }; + checkResult("TwoShard", R"([[[1u];["One"];[0]];[[2u];["Two"];[0]];[[3u];["Three"];[0]];[[4000000001u];["BigOne"];[0]];[[4000000002u];["BigTwo"];[0]];[[4000000003u];["BigThree"];[0]]])"); + checkResult("KeyValue", R"([[[1u];["One"]];[[2u];["Two"]]])"); + auto txRes = transaction->Commit().GetValueSync(); + UNIT_ASSERT_VALUES_EQUAL_C(txRes.GetStatus(), EStatus::SUCCESS, txRes.GetIssues().ToString()); + + checkResult("KeyValue", R"([[[1u];["Vic"]];[[2u];["Vic"]]])"); + checkResult("TwoShard", R"([[[1u];["One"];[1]];[[2u];["Two"];[1]];[[3u];["Three"];[1]];[[4000000001u];["BigOne"];[1]];[[4000000002u];["BigTwo"];[1]];[[4000000003u];["BigThree"];[1]]])"); + } } Y_UNIT_TEST(ExecuteQueryInteractiveTxCommitWithQuery) { @@ -367,6 +429,19 @@ Y_UNIT_TEST_SUITE(KqpQueryService) { } } + Y_UNIT_TEST(ExecuteDDLStatusCodeSchemeError) { + TKikimrRunner kikimr(NKqp::TKikimrSettings().SetWithSampleTables(false)); + { + auto db = kikimr.GetQueryClient(); + auto result = db.ExecuteQuery(R"( + CREATE TABLE unsupported_TzTimestamp (key Int32, payload TzTimestamp, primary key(key)))", + TTxControl::NoTx() + ).GetValueSync(); + + UNIT_ASSERT_VALUES_EQUAL_C(result.GetStatus(), EStatus::SCHEME_ERROR, result.GetIssues().ToString()); + } + } + Y_UNIT_TEST(ExecuteQueryScalar) { auto kikimr = DefaultKikimrRunner(); auto db = kikimr.GetQueryClient(); From 8d1f4fa6a17d461042bb7267d3e7f7dcbe107e62 Mon Sep 17 00:00:00 2001 From: Alexander Rutkovsky Date: Wed, 20 Mar 2024 18:56:17 +0300 Subject: [PATCH 085/117] Fix BlobDepot interaction with group mapper in mirror-3-dc mode (#3006) --- .../groupinfo/blobstorage_groupinfo_blobmap.cpp | 12 +++++++----- 1 file changed, 7 insertions(+), 5 deletions(-) diff --git a/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_blobmap.cpp b/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_blobmap.cpp index 75eba136ce44..013622e1b3ab 100644 --- a/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_blobmap.cpp +++ b/ydb/core/blobstorage/groupinfo/blobstorage_groupinfo_blobmap.cpp @@ -165,12 +165,14 @@ namespace NKikimr { TMirror3dcMapper(const TBlobStorageGroupInfo::TTopology *topology) : Topology(topology) , NumFailRealms(Topology->FailRealms.size()) - , NumFailDomainsPerFailRealm(Topology->FailRealms[0].FailDomains.size()) - , NumVDisksPerFailDomain(Topology->FailRealms[0].FailDomains[0].VDisks.size()) + , NumFailDomainsPerFailRealm(NumFailRealms ? Topology->FailRealms[0].FailDomains.size() : 0) + , NumVDisksPerFailDomain(NumFailDomainsPerFailRealm ? Topology->FailRealms[0].FailDomains[0].VDisks.size() : 0) { - Y_ABORT_UNLESS(NumFailRealms >= NumFailRealmsInSubgroup && - NumFailDomainsPerFailRealm >= NumFailDomainsPerFailRealmInSubgroup, - "mirror-3-dc group tolopogy is invalid: %s", topology->ToString().data()); + if (NumFailRealms && NumFailDomainsPerFailRealm && NumVDisksPerFailDomain) { + Y_ABORT_UNLESS(NumFailRealms >= NumFailRealmsInSubgroup && + NumFailDomainsPerFailRealm >= NumFailDomainsPerFailRealmInSubgroup, + "mirror-3-dc group tolopogy is invalid: %s", topology->ToString().data()); + } } void PickSubgroup(ui32 hash, TBlobStorageGroupInfo::TOrderNums &orderNums) override final { From fe6d594e5496a5ce8beab43866ac46f0aa6c48a5 Mon Sep 17 00:00:00 2001 From: Alexander Rutkovsky Date: Thu, 21 Mar 2024 17:33:25 +0300 Subject: [PATCH 086/117] Fix NodeWarden caching error (#3014) --- ydb/core/blobstorage/nodewarden/node_warden_resource.cpp | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/ydb/core/blobstorage/nodewarden/node_warden_resource.cpp b/ydb/core/blobstorage/nodewarden/node_warden_resource.cpp index a8b811f517bd..044c6c2e1ee9 100644 --- a/ydb/core/blobstorage/nodewarden/node_warden_resource.cpp +++ b/ydb/core/blobstorage/nodewarden/node_warden_resource.cpp @@ -95,7 +95,7 @@ void TNodeWarden::Handle(TEvNodeWardenStorageConfig::TPtr ev) { ev->Get()->Config->Swap(&StorageConfig); if (StorageConfig.HasBlobStorageConfig()) { if (const auto& bsConfig = StorageConfig.GetBlobStorageConfig(); bsConfig.HasServiceSet()) { - ApplyServiceSet(bsConfig.GetServiceSet(), true, false, true); + ApplyServiceSet(bsConfig.GetServiceSet(), true, false, false); } } for (const TActorId& subscriber : StorageConfigSubscribers) { From 112be1a6cecab2ea795a4ca3096372f01d9707fc Mon Sep 17 00:00:00 2001 From: Aleksei Borzenkov Date: Fri, 22 Mar 2024 13:36:34 +0300 Subject: [PATCH 087/117] 24-1: Fix read iterator local snapshot consistency. Fixes #2885. (#3074) --- ydb/core/tx/datashard/datashard.cpp | 6 + .../tx/datashard/datashard__read_iterator.cpp | 222 +++++----- .../tx/datashard/datashard_dep_tracker.cpp | 8 +- ydb/core/tx/datashard/datashard_pipeline.cpp | 2 + .../tx/datashard/datashard_ut_common_kqp.h | 8 +- .../datashard/datashard_ut_read_iterator.cpp | 397 ++++++++++++++++++ ydb/core/tx/datashard/operation.cpp | 34 ++ ydb/core/tx/datashard/operation.h | 6 + ydb/core/tx/datashard/read_iterator.h | 4 +- 9 files changed, 575 insertions(+), 112 deletions(-) diff --git a/ydb/core/tx/datashard/datashard.cpp b/ydb/core/tx/datashard/datashard.cpp index 314060536c8e..ce98a47b6599 100644 --- a/ydb/core/tx/datashard/datashard.cpp +++ b/ydb/core/tx/datashard/datashard.cpp @@ -2107,6 +2107,12 @@ TDataShard::TPromotePostExecuteEdges TDataShard::PromoteImmediatePostExecuteEdge << " promoting UnprotectedReadEdge to " << version); SnapshotManager.PromoteUnprotectedReadEdge(version); + // Make sure pending distributed transactions are marked incomplete, + // since we just protected up to and including version from writes, + // we need to make sure new immediate conflicting writes are blocked + // and don't perform writes with out-of-order versions. + res.HadWrites |= Pipeline.MarkPlannedLogicallyIncompleteUpTo(version, txc); + // We want to promote the complete edge when protected reads are // used or when we're already writing something anyway. if (res.HadWrites) { diff --git a/ydb/core/tx/datashard/datashard__read_iterator.cpp b/ydb/core/tx/datashard/datashard__read_iterator.cpp index bb4fbe8de801..2c2cff174e9d 100644 --- a/ydb/core/tx/datashard/datashard__read_iterator.cpp +++ b/ydb/core/tx/datashard/datashard__read_iterator.cpp @@ -1074,8 +1074,7 @@ const NHPTimer::STime TReader::MaxCyclesPerIteration = class TDataShard::TReadOperation : public TOperation, public IReadOperation { TDataShard* Self; - TActorId Sender; - std::shared_ptr Request; + TReadIteratorId ReadId; NMiniKQL::IEngineFlat::TValidationInfo ValidationInfo; @@ -1091,11 +1090,10 @@ class TDataShard::TReadOperation : public TOperation, public IReadOperation { static constexpr ui32 Flags = NTxDataShard::TTxFlags::ReadOnly | NTxDataShard::TTxFlags::Immediate; public: - TReadOperation(TDataShard* ds, TInstant receivedAt, ui64 tieBreakerIndex, TEvDataShard::TEvRead::TPtr ev) + TReadOperation(TDataShard* ds, TInstant receivedAt, ui64 tieBreakerIndex, const TReadIteratorId& readId) : TOperation(TBasicOpInfo(EOperationKind::ReadTx, Flags, 0, receivedAt, tieBreakerIndex)) , Self(ds) - , Sender(ev->Sender) - , Request(ev->Release().Release()) + , ReadId(readId) {} void BuildExecutionPlan(bool loaded) override @@ -1117,14 +1115,13 @@ class TDataShard::TReadOperation : public TOperation, public IReadOperation { } EExecutionStatus Execute(TTransactionContext& txc, const TActorContext& ctx) override { - TReadIteratorId readId(Sender, Request->Record.GetReadId()); - auto it = Self->ReadIterators.find(readId); - if (it == Self->ReadIterators.end()) { + auto readIt = Self->ReadIterators.find(ReadId); + if (readIt == Self->ReadIterators.end()) { // iterator has been aborted return EExecutionStatus::DelayComplete; } - Y_ABORT_UNLESS(it->second); - auto& state = *it->second; + Y_ABORT_UNLESS(readIt->second); + auto& state = *readIt->second; if (Result->Record.HasStatus()) { // error happened on check phase @@ -1133,9 +1130,11 @@ class TDataShard::TReadOperation : public TOperation, public IReadOperation { Y_ABORT_UNLESS(state.State == TReadIteratorState::EState::Executing); + auto* request = state.Request; + ++ExecuteCount; LOG_TRACE_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " Execute read# " << ExecuteCount - << ", request: " << Request->Record); + << ", request: " << request->Record); switch (Self->State) { case TShardState::Ready: @@ -1248,8 +1247,8 @@ class TDataShard::TReadOperation : public TOperation, public IReadOperation { } } - state.LockId = state.Request->Record.GetLockTxId(); - state.LockNodeId = state.Request->Record.GetLockNodeId(); + state.LockId = request->Record.GetLockTxId(); + state.LockNodeId = request->Record.GetLockNodeId(); TDataShardLocksDb locksDb(*Self, txc); TSetupSysLocks guardLocks(state.LockId, state.LockNodeId, *Self, &locksDb); @@ -1309,22 +1308,37 @@ class TDataShard::TReadOperation : public TOperation, public IReadOperation { state.IsHeadRead = false; if (!Self->IsFollower()) { + TRowVersion unreadableEdge = Self->Pipeline.GetUnreadableEdge(); + if (state.ReadVersion >= unreadableEdge) { + // This version is unreadable in repeatable read mode at the moment, we have to wait + // We actually have to completely destroy current state and start from scratch + LWTRACK(ReadWaitSnapshot, request->Orbit, state.ReadVersion.Step, state.ReadVersion.TxId); + Self->Pipeline.AddWaitingReadIterator(state.ReadVersion, std::move(state.Ev), ctx); + Self->DeleteReadIterator(readIt); + + // Make sure we rollback everything (on a slim chance there are any changes) + if (txc.DB.HasChanges()) { + txc.DB.RollbackChanges(); + } + + // This unit will remove current operation from the pipeline when we return + Abort(EExecutionUnitKind::CompletedOperations); + + return EExecutionStatus::Executed; + } + // Switch to repeatable read at the same version SetMvccSnapshot(state.ReadVersion, /* isRepeatable */ true); - TStepOrder order(state.ReadVersion.Step, state.ReadVersion.TxId); - const auto& plannedOps = Self->Pipeline.GetActivePlannedOps(); - auto it = plannedOps.lower_bound(order); - if (it != plannedOps.end() && it->first == order) { - if (!it->second->IsReadOnly()) { - // we need to wait this op - AddDependency(it->second); + // We may have had repeatable read conflicts, promote them + PromoteRepeatableReadConflicts(); - // Make sure current incomplete result will not be sent - Result = MakeEvReadResult(ctx.SelfID.NodeId()); + // Having runtime conflicts now means we have to wait and restart + if (HasRuntimeConflicts()) { + // Make sure current incomplete result will not be sent + Result = MakeEvReadResult(ctx.SelfID.NodeId()); - return EExecutionStatus::Continue; - } + return EExecutionStatus::Continue; } } else { auto [followerEdge, followerRepeatable] = Self->GetSnapshotManager().GetFollowerReadEdge(); @@ -1378,8 +1392,7 @@ class TDataShard::TReadOperation : public TOperation, public IReadOperation { } void CheckRequestAndInit(TTransactionContext& txc, const TActorContext& ctx) override { - TReadIteratorId readId(Sender, Request->Record.GetReadId()); - auto it = Self->ReadIterators.find(readId); + auto it = Self->ReadIterators.find(ReadId); if (it == Self->ReadIterators.end()) { // iterator has been aborted return; @@ -1390,7 +1403,8 @@ class TDataShard::TReadOperation : public TOperation, public IReadOperation { Result = MakeEvReadResult(ctx.SelfID.NodeId()); - const auto& record = Request->Record; + auto* request = state.Request; + const auto& record = request->Record; if (record.HasMaxRows()) state.Quota.Rows = record.GetMaxRows(); @@ -1409,7 +1423,7 @@ class TDataShard::TReadOperation : public TOperation, public IReadOperation { state.Reverse = record.GetReverse(); if (state.Reverse) { - state.FirstUnprocessedQuery = Request->Keys.size() + Request->Ranges.size() - 1; + state.FirstUnprocessedQuery = request->Keys.size() + request->Ranges.size() - 1; } // Note: some checks already performed in TTxReadViaPipeline::Execute @@ -1459,10 +1473,10 @@ class TDataShard::TReadOperation : public TOperation, public IReadOperation { } // Make ranges in the new 'any' form compatible with the old '+inf' form - for (size_t i = 0; i < Request->Ranges.size(); ++i) { - auto& range = Request->Ranges[i]; + for (size_t i = 0; i < request->Ranges.size(); ++i) { + auto& range = request->Ranges[i]; auto& keyFrom = range.From; - auto& keyTo = Request->Ranges[i].To; + auto& keyTo = request->Ranges[i].To; if (range.FromInclusive && keyFrom.GetCells().size() != TableInfo.KeyColumnCount) { keyFrom = ExtendWithNulls(keyFrom, TableInfo.KeyColumnCount); @@ -1474,16 +1488,16 @@ class TDataShard::TReadOperation : public TOperation, public IReadOperation { } // Make prefixes in the new 'any' form compatible with the old '+inf' form - for (size_t i = 0; i < Request->Keys.size(); ++i) { - const auto& key = Request->Keys[i]; + for (size_t i = 0; i < request->Keys.size(); ++i) { + const auto& key = request->Keys[i]; if (key.GetCells().size() == TableInfo.KeyColumnCount) continue; - if (state.Keys.size() != Request->Keys.size()) { - state.Keys.resize(Request->Keys.size()); + if (state.Keys.size() != request->Keys.size()) { + state.Keys.resize(request->Keys.size()); } - // we can safely use cells referencing original Request->Keys[x], + // we can safely use cells referencing original request->Keys[x], // because request will live until the end state.Keys[i] = ExtendWithNulls(key, TableInfo.KeyColumnCount); } @@ -1503,7 +1517,6 @@ class TDataShard::TReadOperation : public TOperation, public IReadOperation { state.Columns.push_back(col); } - state.Request = Request; state.State = TReadIteratorState::EState::Executing; Y_ASSERT(Result); @@ -1521,29 +1534,29 @@ class TDataShard::TReadOperation : public TOperation, public IReadOperation { return; ResultSent = true; - TReadIteratorId readId(Sender, Request->Record.GetReadId()); - auto it = Self->ReadIterators.find(readId); + auto it = Self->ReadIterators.find(ReadId); if (it == Self->ReadIterators.end()) { // the one who removed the iterator should have replied to user - LOG_TRACE_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " read iterator# " << readId + LOG_TRACE_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " read iterator# " << ReadId << " has been invalidated before TReadOperation::SendResult()"); return; } Y_ABORT_UNLESS(it->second); auto& state = *it->second; + auto* request = state.Request; if (!Result) { - LOG_DEBUG_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " read iterator# " << readId + LOG_DEBUG_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " read iterator# " << ReadId << " TReadOperation::Execute() finished without Result, aborting"); Result = MakeEvReadResult(ctx.SelfID.NodeId()); SetStatusError(Result->Record, Ydb::StatusIds::ABORTED, TStringBuilder() << "Iterator aborted" << " (shard# " << Self->TabletID() << " node# " << ctx.SelfID.NodeId() << " state# " << DatashardStateName(Self->State) << ")"); - Result->Record.SetReadId(readId.ReadId); - Self->SendImmediateReadResult(Sender, Result.release(), 0, state.SessionId); + Result->Record.SetReadId(ReadId.ReadId); + Self->SendImmediateReadResult(ReadId.Sender, Result.release(), 0, state.SessionId); - Request->ReadSpan.EndError("Iterator aborted"); + request->ReadSpan.EndError("Iterator aborted"); Self->DeleteReadIterator(it); return; } @@ -1557,13 +1570,13 @@ class TDataShard::TReadOperation : public TOperation, public IReadOperation { // error happened and status set auto& record = Result->Record; if (record.HasStatus()) { - record.SetReadId(readId.ReadId); + record.SetReadId(ReadId.ReadId); record.SetSeqNo(state.SeqNo + 1); - LOG_DEBUG_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " read iterator# " << readId + LOG_DEBUG_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " read iterator# " << ReadId << " TReadOperation::Execute() finished with error, aborting: " << record.DebugString()); - Self->SendImmediateReadResult(Sender, Result.release(), 0, state.SessionId); + Self->SendImmediateReadResult(ReadId.Sender, Result.release(), 0, state.SessionId); - Request->ReadSpan.EndError("Finished with error"); + request->ReadSpan.EndError("Finished with error"); Self->DeleteReadIterator(it); return; } @@ -1571,7 +1584,7 @@ class TDataShard::TReadOperation : public TOperation, public IReadOperation { Y_ASSERT(Reader); Y_ASSERT(BlockBuilder); - LOG_TRACE_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " read iterator# " << readId + LOG_TRACE_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " read iterator# " << ReadId << " sends rowCount# " << Reader->GetRowsRead() << ", bytes# " << Reader->GetBytesRead() << ", quota rows left# " << (state.Quota.Rows - Reader->GetRowsRead()) << ", quota bytes left# " << (state.Quota.Bytes - Reader->GetBytesRead()) @@ -1587,29 +1600,29 @@ class TDataShard::TReadOperation : public TOperation, public IReadOperation { if (!gSkipReadIteratorResultFailPoint.Check(Self->TabletID())) { LWTRACK(ReadSendResult, state.Orbit); - Self->SendImmediateReadResult(Sender, Result.release(), 0, state.SessionId); + Self->SendImmediateReadResult(ReadId.Sender, Result.release(), 0, state.SessionId); } } void Complete(const TActorContext& ctx) override { - TReadIteratorId readId(Sender, Request->Record.GetReadId()); - auto it = Self->ReadIterators.find(readId); + auto it = Self->ReadIterators.find(ReadId); if (it == Self->ReadIterators.end()) { // the one who removed the iterator should have reply to user - LOG_DEBUG_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " read iterator# " << readId + LOG_DEBUG_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " read iterator# " << ReadId << " has been invalidated before TReadOperation::Complete()"); return; } auto& state = *it->second; + auto* request = state.Request; - LOG_TRACE_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " Complete read# " << state.ReadId + LOG_TRACE_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " Complete read# " << ReadId << " after executionsCount# " << ExecuteCount); SendResult(ctx); - it = Self->ReadIterators.find(readId); + it = Self->ReadIterators.find(ReadId); if (it == Self->ReadIterators.end()) { - // We sent an error and delete iterator + // We sent an error and deleted iterator return; } @@ -1621,17 +1634,17 @@ class TDataShard::TReadOperation : public TOperation, public IReadOperation { if (!state.IsExhausted()) { ctx.Send( Self->SelfId(), - new TEvDataShard::TEvReadContinue(Sender, Request->Record.GetReadId())); + new TEvDataShard::TEvReadContinue(ReadId.Sender, ReadId.ReadId)); } else { Self->IncCounter(COUNTER_READ_ITERATORS_EXHAUSTED_COUNT); LOG_DEBUG_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() - << " read iterator# " << readId << " exhausted"); + << " read iterator# " << ReadId << " exhausted"); } } else { - LOG_TRACE_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " read iterator# " << readId + LOG_TRACE_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " read iterator# " << ReadId << " finished in read"); - Request->ReadSpan.EndOk(); + request->ReadSpan.EndOk(); Self->DeleteReadIterator(it); } } @@ -1874,7 +1887,6 @@ class TDataShard::TReadOperation : public TOperation, public IReadOperation { }; class TDataShard::TTxReadViaPipeline : public NTabletFlatExecutor::TTransactionBase { - TEvDataShard::TEvRead::TPtr Ev; TReadIteratorId ReadId; // When we need to reply with an error @@ -1885,10 +1897,9 @@ class TDataShard::TTxReadViaPipeline : public NTabletFlatExecutor::TTransactionB bool WaitComplete = false; public: - TTxReadViaPipeline(TDataShard* ds, TEvDataShard::TEvRead::TPtr ev, NWilson::TTraceId &&traceId) + TTxReadViaPipeline(TDataShard* ds, const TReadIteratorId& readId, NWilson::TTraceId &&traceId) : TBase(ds, std::move(traceId)) - , Ev(std::move(ev)) - , ReadId(Ev->Sender, Ev->Get()->Record.GetReadId()) + , ReadId(readId) {} TTxType GetTxType() const override { return TXTYPE_READ; } @@ -1920,22 +1931,23 @@ class TDataShard::TTxReadViaPipeline : public NTabletFlatExecutor::TTransactionB // iterator already aborted return true; } + auto& state = *readIt->second; ReplyError( Ydb::StatusIds::INTERNAL_ERROR, TStringBuilder() << "Failed to sync follower: " << errMessage << " (shard# " << Self->TabletID() << " node# " << ctx.SelfID.NodeId() << " state# " << DatashardStateName(Self->State) << ")", ctx.SelfID.NodeId(), - Ev->Get()->ReadSpan); + state.Request->ReadSpan); return true; } } - if (Ev) { + if (!Op) { // We must perform some initialization in transaction (e.g. after a follower sync), but before the operation is built Y_ABORT_UNLESS(readIt != Self->ReadIterators.end()); Y_ABORT_UNLESS(readIt->second); auto& state = *readIt->second; - auto* request = Ev->Get(); + auto* request = state.Request; const auto& record = request->Record; NWilson::TSpan &readSpan = request->ReadSpan; @@ -2043,7 +2055,7 @@ class TDataShard::TTxReadViaPipeline : public NTabletFlatExecutor::TTransactionB TRowVersion unreadableEdge = Self->Pipeline.GetUnreadableEdge(); if (state.ReadVersion >= unreadableEdge) { LWTRACK(ReadWaitSnapshot, request->Orbit, state.ReadVersion.Step, state.ReadVersion.TxId); - Self->Pipeline.AddWaitingReadIterator(state.ReadVersion, std::move(Ev), ctx); + Self->Pipeline.AddWaitingReadIterator(state.ReadVersion, std::move(state.Ev), ctx); Self->DeleteReadIterator(readIt); return true; } @@ -2119,7 +2131,7 @@ class TDataShard::TTxReadViaPipeline : public NTabletFlatExecutor::TTransactionB } const ui64 tieBreaker = Self->NextTieBreakerIndex++; - Op = new TReadOperation(Self, ctx.Now(), tieBreaker, Ev); + Op = new TReadOperation(Self, ctx.Now(), tieBreaker, ReadId); Op->BuildExecutionPlan(false); Self->Pipeline.GetExecutionUnit(Op->GetCurrentUnit()).AddOperation(Op); @@ -2133,7 +2145,6 @@ class TDataShard::TTxReadViaPipeline : public NTabletFlatExecutor::TTransactionB Op->SetUsingSnapshotFlag(); } - Ev = nullptr; Op->IncrementInProgress(); } @@ -2238,7 +2249,7 @@ class TDataShard::TTxReadViaPipeline : public NTabletFlatExecutor::TTransactionB }; class TDataShard::TTxReadContinue : public NTabletFlatExecutor::TTransactionBase { - TEvDataShard::TEvReadContinue::TPtr Ev; + TReadIteratorId ReadId; std::unique_ptr Result; std::unique_ptr BlockBuilder; @@ -2247,9 +2258,9 @@ class TDataShard::TTxReadContinue : public NTabletFlatExecutor::TTransactionBase bool DelayedResult = false; public: - TTxReadContinue(TDataShard* ds, TEvDataShard::TEvReadContinue::TPtr ev, NWilson::TTraceId &&traceId) + TTxReadContinue(TDataShard* ds, const TReadIteratorId& readId, NWilson::TTraceId &&traceId) : TBase(ds, std::move(traceId)) - , Ev(ev) + , ReadId(readId) {} // note that intentionally the same as TEvRead @@ -2260,20 +2271,18 @@ class TDataShard::TTxReadContinue : public NTabletFlatExecutor::TTransactionBase // 1. Since TTxReadContinue scheduled, shard was ready. // 2. If shards changes the state, it must cancel iterators and we will // not find our readId ReadIterators. - TReadIteratorId readId(Ev->Get()->Reader, Ev->Get()->ReadId); - auto it = Self->ReadIterators.find(readId); + auto it = Self->ReadIterators.find(ReadId); if (it == Self->ReadIterators.end()) { // read has been aborted - LOG_TRACE_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " ReadContinue for reader# " - << Ev->Get()->Reader << ", readId# " << Ev->Get()->ReadId << " didn't found state"); + LOG_TRACE_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " ReadContinue for iterator# " << ReadId + << " didn't find state"); return true; } Y_ASSERT(it->second); auto& state = *it->second; - LOG_TRACE_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " ReadContinue for reader# " - << Ev->Get()->Reader << ", readId# " << Ev->Get()->ReadId + LOG_TRACE_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " ReadContinue for iterator# " << ReadId << ", firstUnprocessedQuery# " << state.FirstUnprocessedQuery); Result = MakeEvReadResult(ctx.SelfID.NodeId()); @@ -2368,7 +2377,7 @@ class TDataShard::TTxReadContinue : public NTabletFlatExecutor::TTransactionBase Y_ASSERT(Result); LOG_TRACE_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() - << " ReadContinue: reader# " << Ev->Get()->Reader << ", readId# " << Ev->Get()->ReadId + << " ReadContinue: iterator# " << ReadId << ", FirstUnprocessedQuery# " << state.FirstUnprocessedQuery); TDataShardLocksDb locksDb(*Self, txc); @@ -2388,7 +2397,7 @@ class TDataShard::TTxReadContinue : public NTabletFlatExecutor::TTransactionBase Self->WaitVolatileDependenciesThenSend( Reader->GetVolatileReadDependencies(), Self->SelfId(), - std::make_unique(Ev->Get()->Reader, Ev->Get()->ReadId)); + std::make_unique(ReadId.Sender, ReadId.ReadId)); return true; } @@ -2411,9 +2420,7 @@ class TDataShard::TTxReadContinue : public NTabletFlatExecutor::TTransactionBase } void ApplyLocks(const TActorContext& ctx) { - const auto* request = Ev->Get(); - TReadIteratorId readId(request->Reader, request->ReadId); - auto it = Self->ReadIterators.find(readId); + auto it = Self->ReadIterators.find(ReadId); Y_ABORT_UNLESS(it != Self->ReadIterators.end()); Y_ABORT_UNLESS(it->second); auto& state = *it->second; @@ -2449,7 +2456,7 @@ class TDataShard::TTxReadContinue : public NTabletFlatExecutor::TTransactionBase addLock->SetSchemeShard(state.PathId.OwnerId); addLock->SetPathId(state.PathId.LocalPathId); - LOG_DEBUG_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " read iterator# " << readId + LOG_DEBUG_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " read iterator# " << ReadId << " TTxReadContinue::Execute() found broken lock# " << state.Lock->GetLockId()); // A broken write lock means we are reading inconsistent results and must abort @@ -2468,21 +2475,19 @@ class TDataShard::TTxReadContinue : public NTabletFlatExecutor::TTransactionBase } void SendResult(const TActorContext& ctx) { - auto* request = Ev->Get(); - TReadIteratorId readId(request->Reader, request->ReadId); - auto it = Self->ReadIterators.find(readId); + auto it = Self->ReadIterators.find(ReadId); Y_ABORT_UNLESS(it != Self->ReadIterators.end()); Y_ABORT_UNLESS(it->second); auto& state = *it->second; if (!Result) { - LOG_DEBUG_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " read iterator# " << readId + LOG_DEBUG_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " read iterator# " << ReadId << " TTxReadContinue::Execute() finished without Result, aborting"); Result = MakeEvReadResult(ctx.SelfID.NodeId()); SetStatusError(Result->Record, Ydb::StatusIds::ABORTED, "Iterator aborted"); - Result->Record.SetReadId(readId.ReadId); - Self->SendImmediateReadResult(request->Reader, Result.release(), 0, state.SessionId); + Result->Record.SetReadId(ReadId.ReadId); + Self->SendImmediateReadResult(ReadId.Sender, Result.release(), 0, state.SessionId); state.Request->ReadSpan.EndError("Iterator aborted"); Self->DeleteReadIterator(it); @@ -2493,10 +2498,10 @@ class TDataShard::TTxReadContinue : public NTabletFlatExecutor::TTransactionBase auto& record = Result->Record; if (record.HasStatus()) { record.SetSeqNo(state.SeqNo + 1); - record.SetReadId(readId.ReadId); - LOG_DEBUG_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " read iterator# " << readId + record.SetReadId(ReadId.ReadId); + LOG_DEBUG_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " read iterator# " << ReadId << " TTxReadContinue::Execute() finished with error, aborting: " << record.DebugString()); - Self->SendImmediateReadResult(request->Reader, Result.release(), 0, state.SessionId); + Self->SendImmediateReadResult(ReadId.Sender, Result.release(), 0, state.SessionId); state.Request->ReadSpan.EndError("Finished with error"); Self->DeleteReadIterator(it); @@ -2506,7 +2511,7 @@ class TDataShard::TTxReadContinue : public NTabletFlatExecutor::TTransactionBase Y_ASSERT(Reader); Y_ASSERT(BlockBuilder); - LOG_TRACE_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " readContinue iterator# " << readId + LOG_TRACE_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " readContinue iterator# " << ReadId << " sends rowCount# " << Reader->GetRowsRead() << ", bytes# " << Reader->GetBytesRead() << ", quota rows left# " << (state.Quota.Rows - Reader->GetRowsRead()) << ", quota bytes left# " << (state.Quota.Bytes - Reader->GetBytesRead()) @@ -2518,7 +2523,7 @@ class TDataShard::TTxReadContinue : public NTabletFlatExecutor::TTransactionBase bool useful = Reader->FillResult(*Result, state); if (useful) { LWTRACK(ReadSendResult, state.Orbit); - Self->SendImmediateReadResult(request->Reader, Result.release(), 0, state.SessionId); + Self->SendImmediateReadResult(ReadId.Sender, Result.release(), 0, state.SessionId); } if (Reader->HasUnreadQueries()) { @@ -2528,14 +2533,14 @@ class TDataShard::TTxReadContinue : public NTabletFlatExecutor::TTransactionBase if (!state.IsExhausted()) { ctx.Send( Self->SelfId(), - new TEvDataShard::TEvReadContinue(request->Reader, request->ReadId)); + new TEvDataShard::TEvReadContinue(ReadId.Sender, ReadId.ReadId)); } else { Self->IncCounter(COUNTER_READ_ITERATORS_EXHAUSTED_COUNT); LOG_DEBUG_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() - << " read iterator# " << readId << " exhausted"); + << " read iterator# " << ReadId << " exhausted"); } } else { - LOG_DEBUG_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " read iterator# " << readId + LOG_DEBUG_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " read iterator# " << ReadId << " finished in ReadContinue"); state.Request->ReadSpan.EndOk(); @@ -2698,16 +2703,21 @@ void TDataShard::Handle(TEvDataShard::TEvRead::TPtr& ev, const TActorContext& ct sessionId = ev->InterconnectSession; } - ReadIterators.emplace( + auto pr = ReadIterators.emplace( readId, new TReadIteratorState( readId, TPathId(record.GetTableId().GetOwnerId(), record.GetTableId().GetTableId()), sessionId, readVersion, isHeadRead, AppData()->MonotonicTimeProvider->Now(), std::move(request->Orbit))); + Y_ABORT_UNLESS(pr.second); + + auto& state = *pr.first->second; + state.Ev = std::move(ev); + state.Request = request; SetCounter(COUNTER_READ_ITERATORS_COUNT, ReadIterators.size()); - Executor()->Execute(new TTxReadViaPipeline(this, ev, request->ReadSpan.GetTraceId()), ctx); + Executor()->Execute(new TTxReadViaPipeline(this, readId, request->ReadSpan.GetTraceId()), ctx); } void TDataShard::Handle(TEvDataShard::TEvReadContinue::TPtr& ev, const TActorContext& ctx) { @@ -2716,8 +2726,8 @@ void TDataShard::Handle(TEvDataShard::TEvReadContinue::TPtr& ev, const TActorCon if (Y_UNLIKELY(it == ReadIterators.end())) { return; } - - Executor()->Execute(new TTxReadContinue(this, ev, it->second->Request->ReadSpan.GetTraceId()), ctx); + + Executor()->Execute(new TTxReadContinue(this, readId, it->second->Request->ReadSpan.GetTraceId()), ctx); } void TDataShard::Handle(TEvDataShard::TEvReadAck::TPtr& ev, const TActorContext& ctx) { @@ -2835,9 +2845,7 @@ void TDataShard::Handle(TEvDataShard::TEvReadCancel::TPtr& ev, const TActorConte LWTRACK(ReadCancel, state->Orbit); - if (state->Request) { - state->Request->ReadSpan.EndError("Cancelled"); - } + state->Request->ReadSpan.EndError("Cancelled"); DeleteReadIterator(it); } @@ -2860,6 +2868,7 @@ void TDataShard::CancelReadIterators(Ydb::StatusIds::StatusCode code, const TStr result->Record.SetSeqNo(state->SeqNo + 1); SendViaSession(state->SessionId, readIteratorId.Sender, SelfId(), result.release()); + state->Request->ReadSpan.EndError("Cancelled"); } ReadIterators.clear(); @@ -2913,6 +2922,7 @@ void TDataShard::ReadIteratorsOnNodeDisconnected(const TActorId& sessionId, cons ++exhaustedCount; } + state->Request->ReadSpan.EndError("Disconnected"); ReadIterators.erase(it); } diff --git a/ydb/core/tx/datashard/datashard_dep_tracker.cpp b/ydb/core/tx/datashard/datashard_dep_tracker.cpp index a5874bdf6a3b..cbc79414ca93 100644 --- a/ydb/core/tx/datashard/datashard_dep_tracker.cpp +++ b/ydb/core/tx/datashard/datashard_dep_tracker.cpp @@ -46,8 +46,8 @@ namespace { return a.GetStep() < b.Step || (a.GetStep() == b.Step && a.GetTxId() < b.TxId); } - bool IsLessEqual(const TOperation& a, const TRowVersion& b) { - return a.GetStep() < b.Step || (a.GetStep() == b.Step && a.GetTxId() <= b.TxId); + bool IsEqual(const TOperation& a, const TRowVersion& b) { + return a.GetStep() == b.Step && a.GetTxId() == b.TxId; } } @@ -799,8 +799,10 @@ void TDependencyTracker::TMvccDependencyTrackingLogic::AddOperation(const TOpera Y_ABORT_UNLESS(!conflict.IsImmediate()); if (snapshot.IsMax()) { conflict.AddImmediateConflict(op); - } else if (snapshotRepeatable ? IsLessEqual(conflict, snapshot) : IsLess(conflict, snapshot)) { + } else if (IsLess(conflict, snapshot)) { op->AddDependency(&conflict); + } else if (IsEqual(conflict, snapshot)) { + op->AddRepeatableReadConflict(&conflict); } }; diff --git a/ydb/core/tx/datashard/datashard_pipeline.cpp b/ydb/core/tx/datashard/datashard_pipeline.cpp index 1e0c3353c9af..f993241ab68f 100644 --- a/ydb/core/tx/datashard/datashard_pipeline.cpp +++ b/ydb/core/tx/datashard/datashard_pipeline.cpp @@ -38,6 +38,7 @@ TPipeline::~TPipeline() pr.second->ClearSpecialDependencies(); pr.second->ClearPlannedConflicts(); pr.second->ClearImmediateConflicts(); + pr.second->ClearRepeatableReadConflicts(); } } @@ -487,6 +488,7 @@ void TPipeline::UnblockNormalDependencies(const TOperation::TPtr &op) op->ClearDependencies(); op->ClearPlannedConflicts(); op->ClearImmediateConflicts(); + op->ClearRepeatableReadConflicts(); DepTracker.RemoveOperation(op); } diff --git a/ydb/core/tx/datashard/datashard_ut_common_kqp.h b/ydb/core/tx/datashard/datashard_ut_common_kqp.h index de0e2ef7a24d..1ca7c1396ebe 100644 --- a/ydb/core/tx/datashard/datashard_ut_common_kqp.h +++ b/ydb/core/tx/datashard/datashard_ut_common_kqp.h @@ -208,9 +208,13 @@ namespace NKqpHelpers { return FormatResult(result); } - inline TString KqpSimpleCommit(TTestActorRuntime& runtime, const TString& sessionId, const TString& txId, const TString& query) { + inline auto KqpSimpleSendCommit(TTestActorRuntime& runtime, const TString& sessionId, const TString& txId, const TString& query) { Y_ABORT_UNLESS(!txId.empty(), "commit on empty transaction"); - auto response = AwaitResponse(runtime, SendRequest(runtime, MakeSimpleRequestRPC(query, sessionId, txId, true /* commitTx */))); + return SendRequest(runtime, MakeSimpleRequestRPC(query, sessionId, txId, true /* commitTx */)); + } + + inline TString KqpSimpleCommit(TTestActorRuntime& runtime, const TString& sessionId, const TString& txId, const TString& query) { + auto response = AwaitResponse(runtime, KqpSimpleSendCommit(runtime, sessionId, txId, query)); if (response.operation().status() != Ydb::StatusIds::SUCCESS) { return TStringBuilder() << "ERROR: " << response.operation().status(); } diff --git a/ydb/core/tx/datashard/datashard_ut_read_iterator.cpp b/ydb/core/tx/datashard/datashard_ut_read_iterator.cpp index 876f58415ad0..c2b2febb0067 100644 --- a/ydb/core/tx/datashard/datashard_ut_read_iterator.cpp +++ b/ydb/core/tx/datashard/datashard_ut_read_iterator.cpp @@ -3769,4 +3769,401 @@ Y_UNIT_TEST_SUITE(DataShardReadIteratorPageFaults) { } } +Y_UNIT_TEST_SUITE(DataShardReadIteratorConsistency) { + + Y_UNIT_TEST(LocalSnapshotReadWithPlanQueueRace) { + TPortManager pm; + TServerSettings serverSettings(pm.GetPort(2134)); + serverSettings.SetDomainName("Root") + .SetUseRealThreads(false); + TServer::TPtr server = new TServer(serverSettings); + + auto& runtime = *server->GetRuntime(); + auto sender = runtime.AllocateEdgeActor(); + + runtime.SetLogPriority(NKikimrServices::TX_DATASHARD, NLog::PRI_TRACE); + + InitRoot(server, sender); + + TDisableDataShardLogBatching disableDataShardLogBatching; + + auto [shards, tableId] = CreateShardedTable(server, sender, "/Root", "table-1", 1); + CreateShardedTable(server, sender, "/Root", "table-2", 1); + + auto shardActor = ResolveTablet(runtime, shards.at(0)); + + ExecSQL(server, sender, "UPSERT INTO `/Root/table-1` (key, value) VALUES (1, 10), (3, 30), (5, 50), (7, 70), (9, 90);"); + ExecSQL(server, sender, "UPSERT INTO `/Root/table-2` (key, value) VALUES (2, 20), (4, 40), (6, 60), (8, 80);"); + + std::vector reads; + auto captureReads = runtime.AddObserver([&](TEvDataShard::TEvRead::TPtr& ev) { + if (ev->GetRecipientRewrite() == shardActor) { + Cerr << "... captured TEvRead for " << shardActor << Endl; + reads.push_back(std::move(ev)); + } + }); + + std::vector plans; + auto capturePlans = runtime.AddObserver([&](TEvTxProcessing::TEvPlanStep::TPtr& ev) { + if (ev->GetRecipientRewrite() == shardActor) { + Cerr << "... captured TEvPlanStep for " << shardActor << Endl; + plans.push_back(std::move(ev)); + } + }); + + auto readFuture = KqpSimpleSend(runtime, R"( + SELECT * FROM `/Root/table-1` ORDER BY key; + )"); + + auto upsertFuture = KqpSimpleSend(runtime, R"( + UPSERT INTO `/Root/table-1` SELECT * FROM `/Root/table-2`; + )"); + + WaitFor(runtime, [&]{ return reads.size() > 0 && plans.size() > 0; }, "read and plan"); + + captureReads.Remove(); + capturePlans.Remove(); + + TRowVersion lastTx; + for (auto& ev : plans) { + auto* msg = ev->Get(); + for (auto& tx : msg->Record.GetTransactions()) { + // Remember the last transaction in the plan + lastTx = TRowVersion(msg->Record.GetStep(), tx.GetTxId()); + } + runtime.Send(ev.Release(), 0, true); + } + plans.clear(); + + for (auto& ev : reads) { + auto* msg = ev->Get(); + // We expect it to be an immediate read + UNIT_ASSERT_C(!msg->Record.HasSnapshot(), msg->Record.DebugString()); + // Limit each chunk to just 2 rows + // This will force it to sleep and read in repeatable snapshot mode + msg->Record.SetMaxRowsInResult(2); + // Message must be immediate after plan in the mailbox + runtime.Send(ev.Release(), 0, true); + } + reads.clear(); + + std::vector readContinues; + auto captureReadContinues = runtime.AddObserver([&](TEvDataShard::TEvReadContinue::TPtr& ev) { + if (ev->GetRecipientRewrite() == shardActor) { + Cerr << "... captured TEvReadContinue for " << shardActor << Endl; + readContinues.push_back(std::move(ev)); + } + }); + + UNIT_ASSERT_VALUES_EQUAL( + FormatResult(AwaitResponse(runtime, std::move(upsertFuture))), + ""); + + captureReadContinues.Remove(); + for (auto& ev : readContinues) { + runtime.Send(ev.Release(), 0, true); + } + readContinues.clear(); + + UNIT_ASSERT_VALUES_EQUAL( + FormatResult(AwaitResponse(runtime, std::move(readFuture))), + // Technically result without 2, 4, 6 and 8 is possible + // In practice we will never block writes because of unfinished reads + "{ items { uint32_value: 1 } items { uint32_value: 10 } }, " + "{ items { uint32_value: 2 } items { uint32_value: 20 } }, " + "{ items { uint32_value: 3 } items { uint32_value: 30 } }, " + "{ items { uint32_value: 4 } items { uint32_value: 40 } }, " + "{ items { uint32_value: 5 } items { uint32_value: 50 } }, " + "{ items { uint32_value: 6 } items { uint32_value: 60 } }, " + "{ items { uint32_value: 7 } items { uint32_value: 70 } }, " + "{ items { uint32_value: 8 } items { uint32_value: 80 } }, " + "{ items { uint32_value: 9 } items { uint32_value: 90 } }"); + } + + Y_UNIT_TEST(LocalSnapshotReadHasRequiredDependencies) { + TPortManager pm; + TServerSettings serverSettings(pm.GetPort(2134)); + serverSettings.SetDomainName("Root") + .SetUseRealThreads(false) + // We need to block transactions with readsets + .SetEnableDataShardVolatileTransactions(false); + TServer::TPtr server = new TServer(serverSettings); + + auto& runtime = *server->GetRuntime(); + auto sender = runtime.AllocateEdgeActor(); + + runtime.SetLogPriority(NKikimrServices::TX_DATASHARD, NLog::PRI_TRACE); + + InitRoot(server, sender); + + TDisableDataShardLogBatching disableDataShardLogBatching; + + auto [shards, tableId] = CreateShardedTable(server, sender, "/Root", "table-1", 1); + CreateShardedTable(server, sender, "/Root", "table-2", 1); + + auto shardActor = ResolveTablet(runtime, shards.at(0)); + + ExecSQL(server, sender, "UPSERT INTO `/Root/table-1` (key, value) VALUES (1, 10), (3, 30), (5, 50), (7, 70);"); + ExecSQL(server, sender, "UPSERT INTO `/Root/table-2` (key, value) VALUES (2, 20), (4, 40), (6, 60);"); + + std::vector readsets; + auto captureReadSets = runtime.AddObserver([&](TEvTxProcessing::TEvReadSet::TPtr& ev) { + if (ev->GetRecipientRewrite() == shardActor) { + Cerr << "... captured readset for " << ev->GetRecipientRewrite() << Endl; + readsets.push_back(std::move(ev)); + } + }); + + // Block while writing to some keys + auto upsertFuture = KqpSimpleSend(runtime, R"( + UPSERT INTO `/Root/table-1` SELECT * FROM `/Root/table-2`; + )"); + + WaitFor(runtime, [&]{ return readsets.size() > 0; }, "readset"); + + captureReadSets.Remove(); + + auto modifyReads = runtime.AddObserver([&](TEvDataShard::TEvRead::TPtr& ev) { + if (ev->GetRecipientRewrite() == shardActor) { + Cerr << "... modifying TEvRead for " << shardActor << Endl; + auto* msg = ev->Get(); + // We expect it to be an immediate read + UNIT_ASSERT_C(!msg->Record.HasSnapshot(), msg->Record.DebugString()); + // Limit each chunk to just 2 rows + // This will force it to sleep and read in repeatable snapshot mode + msg->Record.SetMaxRowsInResult(2); + } + }); + + // Read all rows, including currently undecided keys + auto readFuture = KqpSimpleSend(runtime, R"( + SELECT * FROM `/Root/table-1` + WHERE key <= 5 + ORDER BY key; + )"); + + // Give read a chance to finish incorrectly + runtime.SimulateSleep(TDuration::Seconds(1)); + + for (auto& ev : readsets) { + runtime.Send(ev.Release(), 0, true); + } + readsets.clear(); + + UNIT_ASSERT_VALUES_EQUAL( + FormatResult(AwaitResponse(runtime, std::move(upsertFuture))), + ""); + + // We must have observed all rows at the given repeatable snapshot + UNIT_ASSERT_VALUES_EQUAL( + FormatResult(AwaitResponse(runtime, std::move(readFuture))), + "{ items { uint32_value: 1 } items { uint32_value: 10 } }, " + "{ items { uint32_value: 2 } items { uint32_value: 20 } }, " + "{ items { uint32_value: 3 } items { uint32_value: 30 } }, " + "{ items { uint32_value: 4 } items { uint32_value: 40 } }, " + "{ items { uint32_value: 5 } items { uint32_value: 50 } }"); + } + + Y_UNIT_TEST(LocalSnapshotReadNoUnnecessaryDependencies) { + TPortManager pm; + TServerSettings serverSettings(pm.GetPort(2134)); + serverSettings.SetDomainName("Root") + .SetUseRealThreads(false) + // We need to block transactions with readsets + .SetEnableDataShardVolatileTransactions(false); + TServer::TPtr server = new TServer(serverSettings); + + auto& runtime = *server->GetRuntime(); + auto sender = runtime.AllocateEdgeActor(); + + runtime.SetLogPriority(NKikimrServices::TX_DATASHARD, NLog::PRI_TRACE); + + InitRoot(server, sender); + + TDisableDataShardLogBatching disableDataShardLogBatching; + + auto [shards, tableId] = CreateShardedTable(server, sender, "/Root", "table-1", 1); + CreateShardedTable(server, sender, "/Root", "table-2", 1); + + auto shardActor = ResolveTablet(runtime, shards.at(0)); + + ExecSQL(server, sender, "UPSERT INTO `/Root/table-1` (key, value) VALUES (1, 10), (3, 30), (5, 50), (7, 70);"); + ExecSQL(server, sender, "UPSERT INTO `/Root/table-2` (key, value) VALUES (2, 20), (4, 40), (6, 60);"); + + std::vector readsets; + auto captureReadSets = runtime.AddObserver([&](TEvTxProcessing::TEvReadSet::TPtr& ev) { + if (ev->GetRecipientRewrite() == shardActor) { + Cerr << "... captured readset for " << ev->GetRecipientRewrite() << Endl; + readsets.push_back(std::move(ev)); + } + }); + + // Block while writing to key 2 + auto upsertFuture = KqpSimpleSend(runtime, R"( + UPSERT INTO `/Root/table-1` SELECT * FROM `/Root/table-2` WHERE key = 2; + )"); + + WaitFor(runtime, [&]{ return readsets.size() > 0; }, "readset"); + + captureReadSets.Remove(); + + auto modifyReads = runtime.AddObserver([&](TEvDataShard::TEvRead::TPtr& ev) { + if (ev->GetRecipientRewrite() == shardActor) { + Cerr << "... modifying TEvRead for " << shardActor << Endl; + auto* msg = ev->Get(); + // We expect it to be an immediate read + UNIT_ASSERT_C(!msg->Record.HasSnapshot(), msg->Record.DebugString()); + // Limit each chunk to just 2 rows + // This will force it to sleep and read in repeatable snapshot mode + msg->Record.SetMaxRowsInResult(2); + } + }); + + // Read all rows, not including currently undecided keys + auto readFuture = KqpSimpleSend(runtime, R"( + SELECT * FROM `/Root/table-1` + WHERE key >= 3 + ORDER BY key; + )"); + + // Read must complete without waiting for the above upsert to finish + UNIT_ASSERT_VALUES_EQUAL( + FormatResult(AwaitResponse(runtime, std::move(readFuture))), + "{ items { uint32_value: 3 } items { uint32_value: 30 } }, " + "{ items { uint32_value: 5 } items { uint32_value: 50 } }, " + "{ items { uint32_value: 7 } items { uint32_value: 70 } }"); + + for (auto& ev : readsets) { + runtime.Send(ev.Release(), 0, true); + } + readsets.clear(); + + UNIT_ASSERT_VALUES_EQUAL( + FormatResult(AwaitResponse(runtime, std::move(upsertFuture))), + ""); + } + + Y_UNIT_TEST(LocalSnapshotReadWithConcurrentWrites) { + TPortManager pm; + TServerSettings serverSettings(pm.GetPort(2134)); + serverSettings.SetDomainName("Root") + .SetUseRealThreads(false) + // We need to block transactions with readsets + .SetEnableDataShardVolatileTransactions(false); + TServer::TPtr server = new TServer(serverSettings); + + auto& runtime = *server->GetRuntime(); + auto sender = runtime.AllocateEdgeActor(); + + runtime.SetLogPriority(NKikimrServices::TX_DATASHARD, NLog::PRI_TRACE); + + InitRoot(server, sender); + + TDisableDataShardLogBatching disableDataShardLogBatching; + + auto [shards, tableId] = CreateShardedTable(server, sender, "/Root", "table-1", 1); + CreateShardedTable(server, sender, "/Root", "table-2", 1); + + auto shardActor = ResolveTablet(runtime, shards.at(0)); + + ExecSQL(server, sender, "UPSERT INTO `/Root/table-1` (key, value) VALUES (1, 10), (3, 30), (5, 50), (7, 70);"); + ExecSQL(server, sender, "UPSERT INTO `/Root/table-2` (key, value) VALUES (2, 20), (4, 40), (6, 60);"); + + std::vector readsets; + auto captureReadSets = runtime.AddObserver([&](TEvTxProcessing::TEvReadSet::TPtr& ev) { + if (ev->GetRecipientRewrite() == shardActor) { + Cerr << "... captured readset for " << ev->GetRecipientRewrite() << Endl; + readsets.push_back(std::move(ev)); + } + }); + + // The first upsert needs to block while writing to key 2 + auto upsertFuture1 = KqpSimpleSend(runtime, R"( + UPSERT INTO `/Root/table-1` SELECT * FROM `/Root/table-2` WHERE key = 2; + )"); + + WaitFor(runtime, [&]{ return readsets.size() > 0; }, "readset"); + + captureReadSets.Remove(); + + TRowVersion txVersion = TRowVersion::Min(); + auto observePlanSteps = runtime.AddObserver([&](TEvTxProcessing::TEvPlanStep::TPtr& ev) { + if (ev->GetRecipientRewrite() == shardActor) { + auto* msg = ev->Get(); + for (const auto& tx : msg->Record.GetTransactions()) { + txVersion = TRowVersion(msg->Record.GetStep(), tx.GetTxId()); + Cerr << "... observed plan for tx " << txVersion << Endl; + } + } + }); + + // Start a transaction that reads from key 3 + TString sessionId, txId; + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleBegin(runtime, sessionId, txId, R"( + SELECT key, value FROM `/Root/table-1` WHERE key = 3; + )"), + "{ items { uint32_value: 3 } items { uint32_value: 30 } }"); + + // The second upsert should be ready to execute, but blocked by write-write conflict on key 2 + // Note we also read from key 3, so that later only one transaction may survive + auto upsertFuture2 = KqpSimpleSend(runtime, R"( + SELECT key, value FROM `/Root/table-1` WHERE key = 3; + $rows = ( + SELECT key, value FROM `/Root/table-2` WHERE key = 4 + UNION ALL + SELECT 2u AS key, 21u AS value + UNION ALL + SELECT 3u AS key, 31u AS value + ); + UPSERT INTO `/Root/table-1` SELECT * FROM $rows; + )"); + + WaitFor(runtime, [&]{ return txVersion != TRowVersion::Min(); }, "plan step"); + + observePlanSteps.Remove(); + auto forceSnapshotRead = runtime.AddObserver([&](TEvDataShard::TEvRead::TPtr& ev) { + if (ev->GetRecipientRewrite() == shardActor) { + auto* msg = ev->Get(); + if (!msg->Record.HasSnapshot()) { + Cerr << "... forcing read snapshot " << txVersion << Endl; + msg->Record.MutableSnapshot()->SetStep(txVersion.Step); + msg->Record.MutableSnapshot()->SetTxId(txVersion.TxId); + } + } + }); + + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleExec(runtime, R"( + SELECT key, value FROM `/Root/table-1` + WHERE key >= 5 + ORDER BY key; + )"), + "{ items { uint32_value: 5 } items { uint32_value: 50 } }, " + "{ items { uint32_value: 7 } items { uint32_value: 70 } }"); + + auto commitFuture = KqpSimpleSendCommit(runtime, sessionId, txId, R"( + UPSERT INTO `/Root/table-1` (key, value) VALUES (3, 32); + )"); + + // Give it all a chance to complete + runtime.SimulateSleep(TDuration::Seconds(1)); + + // Unblock readsets + for (auto& ev : readsets) { + runtime.Send(ev.Release(), 0, true); + } + readsets.clear(); + + auto result1 = FormatResult(AwaitResponse(runtime, std::move(upsertFuture2))); + auto result2 = FormatResult(AwaitResponse(runtime, std::move(commitFuture))); + + UNIT_ASSERT_C( + result1 == "ERROR: ABORTED" || result2 == "ERROR: ABORTED", + "result1: " << result1 << ", " + "result2: " << result2); + } + +} + } // namespace NKikimr diff --git a/ydb/core/tx/datashard/operation.cpp b/ydb/core/tx/datashard/operation.cpp index f1779c24bf91..9de4faa6bb17 100644 --- a/ydb/core/tx/datashard/operation.cpp +++ b/ydb/core/tx/datashard/operation.cpp @@ -183,6 +183,40 @@ void TOperation::ClearImmediateConflicts() { ImmediateConflicts.clear(); } +void TOperation::AddRepeatableReadConflict(const TOperation::TPtr &op) { + Y_ABORT_UNLESS(this != op.Get()); + Y_DEBUG_ABORT_UNLESS(IsImmediate()); + Y_DEBUG_ABORT_UNLESS(!op->IsImmediate()); + + if (IsMvccSnapshotRepeatable()) { + AddDependency(this); + return; + } + + if (RepeatableReadConflicts.insert(op).second) { + op->RepeatableReadConflicts.insert(this); + } +} + +void TOperation::PromoteRepeatableReadConflicts() { + Y_ABORT_UNLESS(IsImmediate()); + + for (auto& op : RepeatableReadConflicts) { + Y_DEBUG_ABORT_UNLESS(op->RepeatableReadConflicts.contains(this)); + op->RepeatableReadConflicts.erase(this); + AddDependency(op); + } + RepeatableReadConflicts.clear(); +} + +void TOperation::ClearRepeatableReadConflicts() { + for (auto& op : RepeatableReadConflicts) { + Y_DEBUG_ABORT_UNLESS(op->RepeatableReadConflicts.contains(this)); + op->RepeatableReadConflicts.erase(this); + } + RepeatableReadConflicts.clear(); +} + void TOperation::AddVolatileDependency(ui64 txId) { VolatileDependencies.insert(txId); } diff --git a/ydb/core/tx/datashard/operation.h b/ydb/core/tx/datashard/operation.h index 8cffc801f97b..6c963da09a32 100644 --- a/ydb/core/tx/datashard/operation.h +++ b/ydb/core/tx/datashard/operation.h @@ -686,6 +686,7 @@ class TOperation const absl::flat_hash_set> &GetSpecialDependencies() const { return SpecialDependencies; } const absl::flat_hash_set> &GetPlannedConflicts() const { return PlannedConflicts; } const absl::flat_hash_set> &GetImmediateConflicts() const { return ImmediateConflicts; } + const absl::flat_hash_set> &GetRepeatableReadConflicts() const { return RepeatableReadConflicts; } const absl::flat_hash_set &GetVolatileDependencies() const { return VolatileDependencies; } bool HasVolatileDependencies() const { return !VolatileDependencies.empty(); } bool GetVolatileDependenciesAborted() const { return VolatileDependenciesAborted; } @@ -703,6 +704,10 @@ class TOperation void ClearSpecialDependents(); void ClearSpecialDependencies(); + void AddRepeatableReadConflict(const TOperation::TPtr &op); + void PromoteRepeatableReadConflicts(); + void ClearRepeatableReadConflicts(); + void AddVolatileDependency(ui64 txId); void RemoveVolatileDependency(ui64 txId, bool success); void ClearVolatileDependenciesAborted() { VolatileDependenciesAborted = false; } @@ -892,6 +897,7 @@ class TOperation absl::flat_hash_set> SpecialDependencies; absl::flat_hash_set> PlannedConflicts; absl::flat_hash_set> ImmediateConflicts; + absl::flat_hash_set> RepeatableReadConflicts; absl::flat_hash_set VolatileDependencies; bool VolatileDependenciesAborted = false; TVector ExecutionPlan; diff --git a/ydb/core/tx/datashard/read_iterator.h b/ydb/core/tx/datashard/read_iterator.h index 3ce26ec01220..71f853f9795c 100644 --- a/ydb/core/tx/datashard/read_iterator.h +++ b/ydb/core/tx/datashard/read_iterator.h @@ -179,7 +179,9 @@ struct TReadIteratorState { bool Reverse = false; - std::shared_ptr Request; + // The original event handle + TEvDataShard::TEvRead::TPtr Ev; + TEvDataShard::TEvRead* Request = nullptr; // parallel to Request->Keys, but real data only in indices, // where in Request->Keys we have key prefix (here we have properly extended one). From 9a7d761eea207b5e32081671e20b3803c7e711f2 Mon Sep 17 00:00:00 2001 From: Maxim Gorbunov Date: Mon, 25 Mar 2024 12:07:31 +0000 Subject: [PATCH 088/117] Update CMakeLists --- .../kqp/executer_actor/CMakeLists.darwin-arm64.txt | 12 ++++++++++++ .../kqp/executer_actor/CMakeLists.darwin-x86_64.txt | 12 ++++++++++++ .../kqp/executer_actor/CMakeLists.linux-aarch64.txt | 12 ++++++++++++ .../kqp/executer_actor/CMakeLists.linux-x86_64.txt | 12 ++++++++++++ .../kqp/executer_actor/CMakeLists.windows-x86_64.txt | 12 ++++++++++++ 5 files changed, 60 insertions(+) diff --git a/ydb/core/kqp/executer_actor/CMakeLists.darwin-arm64.txt b/ydb/core/kqp/executer_actor/CMakeLists.darwin-arm64.txt index 2fbf94276ed8..da6983426576 100644 --- a/ydb/core/kqp/executer_actor/CMakeLists.darwin-arm64.txt +++ b/ydb/core/kqp/executer_actor/CMakeLists.darwin-arm64.txt @@ -7,6 +7,12 @@ add_subdirectory(ut) +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) add_library(core-kqp-executer_actor) target_compile_options(core-kqp-executer_actor PRIVATE @@ -36,6 +42,7 @@ target_link_libraries(core-kqp-executer_actor PUBLIC yql-dq-runtime yql-dq-tasks providers-common-http_gateway + tools-enum_parser-enum_serialization_runtime ) target_sources(core-kqp-executer_actor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/executer_actor/kqp_data_executer.cpp @@ -54,3 +61,8 @@ target_sources(core-kqp-executer_actor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/executer_actor/kqp_tasks_graph.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/executer_actor/kqp_tasks_validate.cpp ) +generate_enum_serilization(core-kqp-executer_actor + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/executer_actor/kqp_executer.h + INCLUDE_HEADERS + ydb/core/kqp/executer_actor/kqp_executer.h +) diff --git a/ydb/core/kqp/executer_actor/CMakeLists.darwin-x86_64.txt b/ydb/core/kqp/executer_actor/CMakeLists.darwin-x86_64.txt index 2fbf94276ed8..da6983426576 100644 --- a/ydb/core/kqp/executer_actor/CMakeLists.darwin-x86_64.txt +++ b/ydb/core/kqp/executer_actor/CMakeLists.darwin-x86_64.txt @@ -7,6 +7,12 @@ add_subdirectory(ut) +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) add_library(core-kqp-executer_actor) target_compile_options(core-kqp-executer_actor PRIVATE @@ -36,6 +42,7 @@ target_link_libraries(core-kqp-executer_actor PUBLIC yql-dq-runtime yql-dq-tasks providers-common-http_gateway + tools-enum_parser-enum_serialization_runtime ) target_sources(core-kqp-executer_actor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/executer_actor/kqp_data_executer.cpp @@ -54,3 +61,8 @@ target_sources(core-kqp-executer_actor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/executer_actor/kqp_tasks_graph.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/executer_actor/kqp_tasks_validate.cpp ) +generate_enum_serilization(core-kqp-executer_actor + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/executer_actor/kqp_executer.h + INCLUDE_HEADERS + ydb/core/kqp/executer_actor/kqp_executer.h +) diff --git a/ydb/core/kqp/executer_actor/CMakeLists.linux-aarch64.txt b/ydb/core/kqp/executer_actor/CMakeLists.linux-aarch64.txt index f1cda212730a..4ec8af24234b 100644 --- a/ydb/core/kqp/executer_actor/CMakeLists.linux-aarch64.txt +++ b/ydb/core/kqp/executer_actor/CMakeLists.linux-aarch64.txt @@ -7,6 +7,12 @@ add_subdirectory(ut) +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) add_library(core-kqp-executer_actor) target_compile_options(core-kqp-executer_actor PRIVATE @@ -37,6 +43,7 @@ target_link_libraries(core-kqp-executer_actor PUBLIC yql-dq-runtime yql-dq-tasks providers-common-http_gateway + tools-enum_parser-enum_serialization_runtime ) target_sources(core-kqp-executer_actor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/executer_actor/kqp_data_executer.cpp @@ -55,3 +62,8 @@ target_sources(core-kqp-executer_actor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/executer_actor/kqp_tasks_graph.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/executer_actor/kqp_tasks_validate.cpp ) +generate_enum_serilization(core-kqp-executer_actor + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/executer_actor/kqp_executer.h + INCLUDE_HEADERS + ydb/core/kqp/executer_actor/kqp_executer.h +) diff --git a/ydb/core/kqp/executer_actor/CMakeLists.linux-x86_64.txt b/ydb/core/kqp/executer_actor/CMakeLists.linux-x86_64.txt index f1cda212730a..4ec8af24234b 100644 --- a/ydb/core/kqp/executer_actor/CMakeLists.linux-x86_64.txt +++ b/ydb/core/kqp/executer_actor/CMakeLists.linux-x86_64.txt @@ -7,6 +7,12 @@ add_subdirectory(ut) +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) add_library(core-kqp-executer_actor) target_compile_options(core-kqp-executer_actor PRIVATE @@ -37,6 +43,7 @@ target_link_libraries(core-kqp-executer_actor PUBLIC yql-dq-runtime yql-dq-tasks providers-common-http_gateway + tools-enum_parser-enum_serialization_runtime ) target_sources(core-kqp-executer_actor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/executer_actor/kqp_data_executer.cpp @@ -55,3 +62,8 @@ target_sources(core-kqp-executer_actor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/executer_actor/kqp_tasks_graph.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/executer_actor/kqp_tasks_validate.cpp ) +generate_enum_serilization(core-kqp-executer_actor + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/executer_actor/kqp_executer.h + INCLUDE_HEADERS + ydb/core/kqp/executer_actor/kqp_executer.h +) diff --git a/ydb/core/kqp/executer_actor/CMakeLists.windows-x86_64.txt b/ydb/core/kqp/executer_actor/CMakeLists.windows-x86_64.txt index 2fbf94276ed8..da6983426576 100644 --- a/ydb/core/kqp/executer_actor/CMakeLists.windows-x86_64.txt +++ b/ydb/core/kqp/executer_actor/CMakeLists.windows-x86_64.txt @@ -7,6 +7,12 @@ add_subdirectory(ut) +get_built_tool_path( + TOOL_enum_parser_bin + TOOL_enum_parser_dependency + tools/enum_parser/enum_parser + enum_parser +) add_library(core-kqp-executer_actor) target_compile_options(core-kqp-executer_actor PRIVATE @@ -36,6 +42,7 @@ target_link_libraries(core-kqp-executer_actor PUBLIC yql-dq-runtime yql-dq-tasks providers-common-http_gateway + tools-enum_parser-enum_serialization_runtime ) target_sources(core-kqp-executer_actor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/executer_actor/kqp_data_executer.cpp @@ -54,3 +61,8 @@ target_sources(core-kqp-executer_actor PRIVATE ${CMAKE_SOURCE_DIR}/ydb/core/kqp/executer_actor/kqp_tasks_graph.cpp ${CMAKE_SOURCE_DIR}/ydb/core/kqp/executer_actor/kqp_tasks_validate.cpp ) +generate_enum_serilization(core-kqp-executer_actor + ${CMAKE_SOURCE_DIR}/ydb/core/kqp/executer_actor/kqp_executer.h + INCLUDE_HEADERS + ydb/core/kqp/executer_actor/kqp_executer.h +) From 7023b135089898d672eb0e8fac4f4c5c2c0c36b1 Mon Sep 17 00:00:00 2001 From: Alexander Petrukhin Date: Mon, 25 Mar 2024 21:06:14 +0300 Subject: [PATCH 089/117] [kqp] improve logging on KQP shutdown (#2927) (#2929) --- ydb/core/kqp/common/shutdown/controller.cpp | 4 ++++ 1 file changed, 4 insertions(+) diff --git a/ydb/core/kqp/common/shutdown/controller.cpp b/ydb/core/kqp/common/shutdown/controller.cpp index a6c1bd609e20..6113308df884 100644 --- a/ydb/core/kqp/common/shutdown/controller.cpp +++ b/ydb/core/kqp/common/shutdown/controller.cpp @@ -40,6 +40,10 @@ void TKqpShutdownController::Stop() { ++iteration; spent = (TInstant::Now() - startedAt).SecondsFloat(); } + if (!ShutdownState_->ShutdownComplete()) { + Cerr << "Failed to gracefully shutdown KQP after " << timeout.Seconds() << " seconds: spent " << spent << " seconds, "; + Cerr << ShutdownState_->GetPendingSessions() << " sessions to shutdown left" << Endl; + } } } // namespace NKikimr::NKqp From 6fbfd4a5488e67e5d8faf35df5b4545419fbfa7b Mon Sep 17 00:00:00 2001 From: Aleksei Borzenkov Date: Tue, 26 Mar 2024 18:52:08 +0300 Subject: [PATCH 090/117] 24-1: Fix race between table merge and borrowed gc compaction. Fixes #3154. (#3165) --- ydb/core/tx/datashard/datashard_split_dst.cpp | 81 +++++++----- .../tx/datashard/datashard_ut_common_kqp.h | 28 ++++ .../tx/datashard/datashard_ut_snapshot.cpp | 124 ++++++++++++++++++ 3 files changed, 200 insertions(+), 33 deletions(-) diff --git a/ydb/core/tx/datashard/datashard_split_dst.cpp b/ydb/core/tx/datashard/datashard_split_dst.cpp index d78ca11ccf2c..c55038394253 100644 --- a/ydb/core/tx/datashard/datashard_split_dst.cpp +++ b/ydb/core/tx/datashard/datashard_split_dst.cpp @@ -120,13 +120,11 @@ class TDataShard::TTxInitSplitMergeDestination : public NTabletFlatExecutor::TTr class TDataShard::TTxSplitTransferSnapshot : public NTabletFlatExecutor::TTransactionBase { private: TEvDataShard::TEvSplitTransferSnapshot::TPtr Ev; - bool LastSnapshotReceived; public: TTxSplitTransferSnapshot(TDataShard* ds, TEvDataShard::TEvSplitTransferSnapshot::TPtr& ev) : NTabletFlatExecutor::TTransactionBase(ds) , Ev(ev) - , LastSnapshotReceived(false) {} TTxType GetTxType() const override { return TXTYPE_SPLIT_TRANSFER_SNAPSHOT; } @@ -257,8 +255,6 @@ class TDataShard::TTxSplitTransferSnapshot : public NTabletFlatExecutor::TTransa } if (Self->ReceiveSnapshotsFrom.empty()) { - LastSnapshotReceived = true; - const auto minVersion = mvcc ? Self->GetSnapshotManager().GetLowWatermark() : Self->GetSnapshotManager().GetMinWriteVersion(); @@ -295,6 +291,12 @@ class TDataShard::TTxSplitTransferSnapshot : public NTabletFlatExecutor::TTransa // Note: we persist Ready, but keep current state in memory until Complete Self->SetPersistState(TShardState::Ready, txc); Self->State = TShardState::SplitDstReceivingSnapshot; + + // Schedule a new transaction that will move shard to the Ready state + // and finish initialization. This new transaction is guaranteed to + // wait until async LoanTable above is complete and new parts are + // fully merged into the table. + Self->Execute(new TTxLastSnapshotReceived(Self)); } return true; @@ -307,39 +309,52 @@ class TDataShard::TTxSplitTransferSnapshot : public NTabletFlatExecutor::TTransa LOG_DEBUG_S(ctx, NKikimrServices::TX_DATASHARD, Self->TabletID() << " ack snapshot OpId " << opId); ctx.Send(ackTo, new TEvDataShard::TEvSplitTransferSnapshotAck(opId, Self->TabletID())); + } - // Note: we skip init in an unlikely event of state resetting between Execute and Complete - if (LastSnapshotReceived && Self->State == TShardState::SplitDstReceivingSnapshot) { - // We have received all the data, finish shard initialization - // Note: previously we used TxInit, however received system tables - // have been empty for years now, and since pipes are still open we - // may receive requests between TxInit loading the Ready state and - // its Complete method initializing everything properly. Instead - // necessary steps are repeated here. - Self->State = TShardState::Ready; - - // We are already in StateWork, but we need to repeat many steps now that we are Ready - Self->SwitchToWork(ctx); - - // We can send the registration request now that we are ready - Self->SendRegistrationRequestTimeCast(ctx); - - // Initialize snapshot expiration queue with current context time - Self->GetSnapshotManager().InitExpireQueue(ctx.Now()); - if (Self->GetSnapshotManager().HasExpiringSnapshots()) { - Self->PlanCleanup(ctx); - } + class TTxLastSnapshotReceived : public NTabletFlatExecutor::TTransactionBase { + public: + TTxLastSnapshotReceived(TDataShard* self) + : TTransactionBase(self) + {} - // Initialize change senders - Self->KillChangeSender(ctx); - Self->CreateChangeSender(ctx); - Self->MaybeActivateChangeSender(ctx); - Self->EmitHeartbeats(); + bool Execute(TTransactionContext&, const TActorContext&) override { + return true; + } - // Switch mvcc state if needed - Self->CheckMvccStateChangeCanStart(ctx); + void Complete(const TActorContext& ctx) override { + // Note: we skip init in an unlikely event of state resetting before reaching Complete + if (Self->State == TShardState::SplitDstReceivingSnapshot) { + // We have received all the data, finish shard initialization + // Note: previously we used TxInit, however received system tables + // have been empty for years now, and since pipes are still open we + // may receive requests between TxInit loading the Ready state and + // its Complete method initializing everything properly. Instead + // necessary steps are repeated here. + Self->State = TShardState::Ready; + + // We are already in StateWork, but we need to repeat many steps now that we are Ready + Self->SwitchToWork(ctx); + + // We can send the registration request now that we are ready + Self->SendRegistrationRequestTimeCast(ctx); + + // Initialize snapshot expiration queue with current context time + Self->GetSnapshotManager().InitExpireQueue(ctx.Now()); + if (Self->GetSnapshotManager().HasExpiringSnapshots()) { + Self->PlanCleanup(ctx); + } + + // Initialize change senders + Self->KillChangeSender(ctx); + Self->CreateChangeSender(ctx); + Self->MaybeActivateChangeSender(ctx); + Self->EmitHeartbeats(); + + // Switch mvcc state if needed + Self->CheckMvccStateChangeCanStart(ctx); + } } - } + }; }; class TDataShard::TTxSplitReplicationSourceOffsets : public NTabletFlatExecutor::TTransactionBase { diff --git a/ydb/core/tx/datashard/datashard_ut_common_kqp.h b/ydb/core/tx/datashard/datashard_ut_common_kqp.h index 1ca7c1396ebe..61b189a860c4 100644 --- a/ydb/core/tx/datashard/datashard_ut_common_kqp.h +++ b/ydb/core/tx/datashard/datashard_ut_common_kqp.h @@ -11,6 +11,9 @@ namespace NKqpHelpers { using TEvExecuteDataQueryRequest = NKikimr::NGRpcService::TGrpcRequestOperationCall; + using TEvExecuteSchemeQueryRequest = NKikimr::NGRpcService::TGrpcRequestOperationCall; + using TEvCreateSessionRequest = NKikimr::NGRpcService::TGrpcRequestOperationCall; @@ -224,6 +227,31 @@ namespace NKqpHelpers { return FormatResult(result); } + inline Ydb::Table::ExecuteSchemeQueryRequest MakeSchemeRequestRPC( + const TString& sql, const TString& sessionId) + { + Ydb::Table::ExecuteSchemeQueryRequest request; + request.set_session_id(sessionId); + request.set_yql_text(sql); + return request; + } + + inline NThreading::TFuture SendRequest( + TTestActorRuntime& runtime, Ydb::Table::ExecuteSchemeQueryRequest&& request, const TString& database = {}) + { + return NRpcService::DoLocalRpc( + std::move(request), database, /* token */ "", runtime.GetActorSystem(0)); + } + + inline TString KqpSchemeExec(TTestActorRuntime& runtime, const TString& query) { + TString sessionId = CreateSessionRPC(runtime); + auto response = AwaitResponse(runtime, SendRequest(runtime, MakeSchemeRequestRPC(query, sessionId))); + if (response.operation().status() != Ydb::StatusIds::SUCCESS) { + return TStringBuilder() << "ERROR: " << response.operation().status(); + } + return "SUCCESS"; + } + } // namespace NKqpHelpers } // namespace NDataShard } // namespace NKikimr diff --git a/ydb/core/tx/datashard/datashard_ut_snapshot.cpp b/ydb/core/tx/datashard/datashard_ut_snapshot.cpp index 486c88502e0e..51da5d32d2ff 100644 --- a/ydb/core/tx/datashard/datashard_ut_snapshot.cpp +++ b/ydb/core/tx/datashard/datashard_ut_snapshot.cpp @@ -4551,6 +4551,130 @@ Y_UNIT_TEST_SUITE(DataShardSnapshots) { } } + void CompactBorrowed(TTestActorRuntime& runtime, ui64 shardId, const TTableId& tableId) { + auto msg = MakeHolder(tableId.PathId); + auto sender = runtime.AllocateEdgeActor(); + runtime.SendToPipe(shardId, sender, msg.Release(), 0, GetPipeConfigWithRetries()); + runtime.GrabEdgeEventRethrow(sender); + } + + Y_UNIT_TEST(PostMergeNotCompactedTooEarly) { + TPortManager pm; + TServerSettings serverSettings(pm.GetPort(2134)); + serverSettings.SetDomainName("Root") + .SetUseRealThreads(false) + .SetDomainPlanResolution(100); + + Tests::TServer::TPtr server = new TServer(serverSettings); + auto &runtime = *server->GetRuntime(); + auto sender = runtime.AllocateEdgeActor(); + + runtime.SetLogPriority(NKikimrServices::TX_DATASHARD, NLog::PRI_TRACE); + + InitRoot(server, sender); + + TDisableDataShardLogBatching disableDataShardLogBatching; + + KqpSchemeExec(runtime, R"( + CREATE TABLE `/Root/table` (key int, value bytes, PRIMARY KEY (key)) + WITH (AUTO_PARTITIONING_MIN_PARTITIONS_COUNT = 1, + PARTITION_AT_KEYS = (5)); + )"); + + const auto shards = GetTableShards(server, sender, "/Root/table"); + UNIT_ASSERT_VALUES_EQUAL(shards.size(), 2u); + const auto tableId = ResolveTableId(server, sender, "/Root/table"); + + for (int i = 0; i < 20; ++i) { + Cerr << "... upserting key " << i << Endl; + auto query = Sprintf(R"( + UPSERT INTO `/Root/table` (key, value) VALUES (%d, '%s'); + )", i, TString(128 * 1024, 'x').c_str()); + ExecSQL(server, sender, query); + if (i >= 5) { + Cerr << "... compacting shard " << shards.at(1) << Endl; + CompactTable(runtime, shards.at(1), tableId, false); + } else if (i == 4) { + Cerr << "... compacting shard " << shards.at(0) << Endl; + CompactTable(runtime, shards.at(0), tableId, false); + } + } + + // Read (and snapshot) current data, so it doesn't go away on compaction + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleExec(runtime, "SELECT COUNT(*) FROM `/Root/table`;"), + "{ items { uint64_value: 20 } }"); + + // Delete all the data in shard 0, this is small and will stay in memtable + // But when borrowed dst compaction will have pressure to compact it all + ExecSQL(server, sender, "DELETE FROM `/Root/table` WHERE key < 5"); + + std::vector snapshots; + auto captureSnapshots = runtime.AddObserver( + [&](TEvDataShard::TEvSplitTransferSnapshot::TPtr& ev) { + auto* msg = ev->Get(); + Cerr << "... captured snapshot from " << msg->Record.GetSrcTabletId() << Endl; + snapshots.emplace_back(ev.Release()); + }); + + Cerr << "... merging table" << Endl; + SetSplitMergePartCountLimit(server->GetRuntime(), -1); + ui64 txId = AsyncMergeTable(server, sender, "/Root/table", shards); + Cerr << "... started merge " << txId << Endl; + WaitFor(runtime, [&]{ return snapshots.size() >= 2; }, "both src tablet snapshots"); + + std::vector gets; + auto captureGets = runtime.AddObserver( + [&](TEvBlobStorage::TEvGet::TPtr& ev) { + auto* msg = ev->Get(); + if (msg->Queries[0].Id.TabletID() == shards.at(1)) { + Cerr << "... blocking blob get of " << msg->Queries[0].Id << Endl; + gets.emplace_back(ev.Release()); + } + }); + + // Release snapshot for shard 0 then shard 1 + captureSnapshots.Remove(); + Cerr << "... unlocking snapshots from tablet " << shards.at(0) << Endl; + for (auto& ev : snapshots) { + if (ev && ev->Get()->Record.GetSrcTabletId() == shards.at(0)) { + runtime.Send(ev.Release(), 0, true); + } + } + Cerr << "... unblocking snapshots from tablet " << shards.at(1) << Endl; + for (auto& ev : snapshots) { + if (ev && ev->Get()->Record.GetSrcTabletId() == shards.at(1)) { + runtime.Send(ev.Release(), 0, true); + } + } + + // Let it commit above snapshots and incorrectly compact after the first one is loaded and merged + runtime.SimulateSleep(TDuration::Seconds(1)); + UNIT_ASSERT(gets.size() > 0); + + Cerr << "... unblocking blob gets" << Endl; + captureGets.Remove(); + for (auto& ev : gets) { + runtime.Send(ev.Release(), 0, true); + } + + // Let it finish loading the second snapshot + runtime.SimulateSleep(TDuration::Seconds(1)); + + // Wait for merge to complete and start a borrowed compaction + // When bug is present it will cause newly compacted to part to have epoch larger than previously compacted + WaitTxNotification(server, sender, txId); + const auto merged = GetTableShards(server, sender, "/Root/table"); + UNIT_ASSERT_VALUES_EQUAL(merged.size(), 1u); + Cerr << "... compacting borrowed parts in shard " << merged.at(0) << Endl; + CompactBorrowed(runtime, merged.at(0), tableId); + + // Validate we have an expected number of rows + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleExec(runtime, "SELECT COUNT(*) FROM `/Root/table`;"), + "{ items { uint64_value: 15 } }"); + } + } } // namespace NKikimr From d563efb6696c07d8e224e0f5bd1467b3eeeecdf2 Mon Sep 17 00:00:00 2001 From: ildar-khisambeev Date: Tue, 26 Mar 2024 23:10:01 +0300 Subject: [PATCH 091/117] Cherry pick fix leak (#3167) Co-authored-by: Oleg Doronin --- .github/config/muted_ya.txt | 4 --- ydb/core/persqueue/ut/mirrorer_ut.cpp | 1 - .../ydb_persqueue_core/impl/read_session.cpp | 2 ++ .../ydb_persqueue_core/impl/read_session.h | 31 ++++++++++++++++++- .../ydb_persqueue_core/impl/read_session.ipp | 9 ++++++ .../client/ydb_topic/impl/read_session.cpp | 2 ++ 6 files changed, 43 insertions(+), 6 deletions(-) diff --git a/.github/config/muted_ya.txt b/.github/config/muted_ya.txt index 97770b38528e..6d4ded2774d2 100644 --- a/.github/config/muted_ya.txt +++ b/.github/config/muted_ya.txt @@ -14,10 +14,6 @@ ydb/core/client/ut TClientTest.ReadFromFollower ydb/core/client/ut TFlatTest.AutoSplitMergeQueue ydb/core/cms/ut_sentinel TSentinelTests.BSControllerCantChangeStatus ydb/core/debug_tools/ut OperationLog.ConcurrentWrites -ydb/core/persqueue/ut [31/40]* -ydb/core/persqueue/ut TopicSplitMerge.PartitionSplit -ydb/core/persqueue/ut TPersQueueMirrorer.TestBasicRemote -ydb/core/persqueue/ut TPQTest.TestDirectReadHappyWay ydb/core/quoter/ut QuoterWithKesusTest.PrefetchCoefficient ydb/core/kafka_proxy/ut KafkaProtocol.CreatePartitionsScenario ydb/core/kafka_proxy/ut KafkaProtocol.ProduceScenario diff --git a/ydb/core/persqueue/ut/mirrorer_ut.cpp b/ydb/core/persqueue/ut/mirrorer_ut.cpp index 0790f673a133..08f1af2c66e6 100644 --- a/ydb/core/persqueue/ut/mirrorer_ut.cpp +++ b/ydb/core/persqueue/ut/mirrorer_ut.cpp @@ -251,7 +251,6 @@ Y_UNIT_TEST_SUITE(TPersQueueMirrorer) { } } } - } Y_UNIT_TEST(ValidStartStream) { diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session.cpp b/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session.cpp index 12d7e86b53cb..13a5517ff6c2 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session.cpp +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session.cpp @@ -57,6 +57,8 @@ TReadSession::TReadSession(const TReadSessionSettings& settings, } TReadSession::~TReadSession() { + Close(TDuration::Zero()); + { TDeferredActions deferred; NYql::TIssues issues; diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session.h b/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session.h index 93b23a5749a2..49f40cf3a704 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session.h +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session.h @@ -518,6 +518,11 @@ class TRawPartitionStreamEventQueue { (NotReady.empty() ? Ready : NotReady).pop_back(); } + void clear() noexcept { + NotReady.clear(); + Ready.clear(); + } + void SignalReadyEvents(TIntrusivePtr> stream, TReadSessionEventsQueue& queue, TDeferredActions& deferred); @@ -539,6 +544,7 @@ class TRawPartitionStreamEventQueue { TUserRetrievedEventsInfoAccumulator& accumulator, std::deque>& queue); +private: std::deque> Ready; std::deque> NotReady; }; @@ -719,6 +725,14 @@ class TPartitionStreamImpl : public TAPartitionStream { void DeleteNotReadyTail(TDeferredActions& deferred); + void ClearQueue() noexcept { + EventsQueue.clear(); + } + + TRawPartitionStreamEventQueue ExtractQueue() noexcept { + return std::move(EventsQueue); + } + static void GetDataEventImpl(TIntrusivePtr> partitionStream, size_t& maxEventsCount, size_t& maxByteSize, @@ -776,14 +790,27 @@ class TReadSessionEventsQueue: public TBaseSessionEventsQueue& event, TDeferredActions& deferred) { TWaiter waiter; + TVector> deferredDelete; with_lock (TParent::Mutex) { - if (TParent::Closed) + if (TParent::Closed) { return false; + } + deferredDelete.reserve(TParent::Events.size()); + while (!TParent::Events.empty()) { + auto& event = TParent::Events.front(); + if (!event.IsEmpty()) { + deferredDelete.push_back(event.PartitionStream->ExtractQueue()); + } + TParent::Events.pop(); + } TParent::CloseEvent = event; TParent::Closed = true; waiter = TWaiter(TParent::Waiter.ExtractPromise(), this); } + // Delayed deletion is necessary to avoid deadlock with PushEvent + deferredDelete.clear(); + TReadSessionEventInfo info(event); ApplyHandler(info, deferred); deferred.DeferSignalWaiter(std::move(waiter)); @@ -959,6 +986,8 @@ class TSingleClusterReadSessionImpl : public NPersQueue::TEnableSelfContext* partitionStream, TMaybe readOffset, TMaybe commitOffset); void ConfirmPartitionStreamDestroy(TPartitionStreamImpl* partitionStream); diff --git a/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session.ipp b/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session.ipp index d04d5fd843ed..c973b0441eef 100644 --- a/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session.ipp +++ b/ydb/public/sdk/cpp/client/ydb_persqueue_core/impl/read_session.ipp @@ -225,6 +225,14 @@ void TRawPartitionStreamEventQueue::DeleteNotReadyTail(TDe //////////////////////////////////////////////////////////////////////////////////////////////////////////////////////// // TSingleClusterReadSessionImpl +template +TSingleClusterReadSessionImpl::~TSingleClusterReadSessionImpl() { + for (auto&& [_, partitionStream] : PartitionStreams) { + partitionStream->ClearQueue(); + } +} + + template TStringBuilder TSingleClusterReadSessionImpl::GetLogPrefix() const { return TStringBuilder() << GetDatabaseLogPrefix(Database) << "[" << SessionId << "] [" << ClusterName << "] "; @@ -1057,6 +1065,7 @@ inline void TSingleClusterReadSessionImpl::OnReadDoneImpl( PartitionStreams[partitionStream->GetAssignId()]; if (currentPartitionStream) { CookieMapping.RemoveMapping(currentPartitionStream->GetPartitionStreamId()); + bool pushRes = EventsQueue->PushEvent( currentPartitionStream, TReadSessionEvent::TPartitionStreamClosedEvent( diff --git a/ydb/public/sdk/cpp/client/ydb_topic/impl/read_session.cpp b/ydb/public/sdk/cpp/client/ydb_topic/impl/read_session.cpp index 949abf9ab11c..92fd3b210fe1 100644 --- a/ydb/public/sdk/cpp/client/ydb_topic/impl/read_session.cpp +++ b/ydb/public/sdk/cpp/client/ydb_topic/impl/read_session.cpp @@ -34,6 +34,8 @@ TReadSession::TReadSession(const TReadSessionSettings& settings, } TReadSession::~TReadSession() { + Close(TDuration::Zero()); + Abort(EStatus::ABORTED, "Aborted"); ClearAllEvents(); From a762c7687c324ef6c2e3cf6ec5ea696b9657d682 Mon Sep 17 00:00:00 2001 From: Jornydb Date: Wed, 27 Mar 2024 11:45:18 +0300 Subject: [PATCH 092/117] Update datastreams_proxy supported codec (#2687) --- ydb/services/datastreams/datastreams_proxy.cpp | 1 - 1 file changed, 1 deletion(-) diff --git a/ydb/services/datastreams/datastreams_proxy.cpp b/ydb/services/datastreams/datastreams_proxy.cpp index 8b2e373acf28..11289cb4a001 100644 --- a/ydb/services/datastreams/datastreams_proxy.cpp +++ b/ydb/services/datastreams/datastreams_proxy.cpp @@ -121,7 +121,6 @@ namespace NKikimr::NDataStreams::V1 { topicRequest.mutable_retention_period()->set_seconds( TDuration::Hours(DEFAULT_STREAM_DAY_RETENTION).Seconds()); } - topicRequest.mutable_supported_codecs()->add_codecs(Ydb::Topic::CODEC_RAW); topicRequest.set_partition_write_speed_bytes_per_second( PartitionWriteSpeedInBytesPerSec(GetProtoRequest()->write_quota_kb_per_sec())); topicRequest.set_partition_write_burst_bytes( From 93f4928056fa72481307650f33342b6583d21c7b Mon Sep 17 00:00:00 2001 From: Vitalii Gridnev Date: Fri, 29 Mar 2024 19:55:54 +0300 Subject: [PATCH 093/117] fix query service enable order (#3312) --- ydb/core/driver_lib/run/run.cpp | 8 ++++---- 1 file changed, 4 insertions(+), 4 deletions(-) diff --git a/ydb/core/driver_lib/run/run.cpp b/ydb/core/driver_lib/run/run.cpp index 03b8ce3c2a20..bfd467224554 100644 --- a/ydb/core/driver_lib/run/run.cpp +++ b/ydb/core/driver_lib/run/run.cpp @@ -584,10 +584,6 @@ void TKikimrRunner::InitializeGRpc(const TKikimrRunConfig& runConfig) { TServiceCfg hasKeyValue = services.empty(); names["keyvalue"] = &hasKeyValue; - if (hasTableService || hasYql) { - hasQueryService = true; - } - std::unordered_set enabled; for (const auto& name : services) { enabled.insert(name); @@ -641,6 +637,10 @@ void TKikimrRunner::InitializeGRpc(const TKikimrRunConfig& runConfig) { hasImport = true; } + if (hasTableService || hasYql) { + hasQueryService = true; + } + // Enable RL for all services if enabled list is empty if (rlServicesEnabled.empty()) { for (auto& [name, cfg] : names) { From bb2692a8f8742c77f8785c4107ba8adc38a76b17 Mon Sep 17 00:00:00 2001 From: Vitalii Gridnev Date: Fri, 29 Mar 2024 20:33:51 +0300 Subject: [PATCH 094/117] disable oob transport (#3314) --- ydb/core/protos/table_service_config.proto | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/ydb/core/protos/table_service_config.proto b/ydb/core/protos/table_service_config.proto index 1bb2f32f8ef3..92fd3d3b1681 100644 --- a/ydb/core/protos/table_service_config.proto +++ b/ydb/core/protos/table_service_config.proto @@ -256,7 +256,7 @@ message TTableServiceConfig { CTV_OOB_PICKLE_1_0 = 1; } - optional EChannelTransportVersion ChannelTransportVersion = 46 [default = CTV_OOB_PICKLE_1_0]; + optional EChannelTransportVersion ChannelTransportVersion = 46 [default = CTV_UV_PICKLE_1_0]; enum EIndexAutoChooseMode { DISABLED = 0; From da40f7220709c519cc5ef8aaea6b0f1139a43473 Mon Sep 17 00:00:00 2001 From: Ilnaz Nizametdinov Date: Mon, 1 Apr 2024 13:51:38 +0300 Subject: [PATCH 095/117] Get rid of pedantic check (#3342) --- .../tx/datashard/execute_distributed_erase_tx_unit.cpp | 9 +++++---- 1 file changed, 5 insertions(+), 4 deletions(-) diff --git a/ydb/core/tx/datashard/execute_distributed_erase_tx_unit.cpp b/ydb/core/tx/datashard/execute_distributed_erase_tx_unit.cpp index 1c1a8be5e81b..ab6f553e5b20 100644 --- a/ydb/core/tx/datashard/execute_distributed_erase_tx_unit.cpp +++ b/ydb/core/tx/datashard/execute_distributed_erase_tx_unit.cpp @@ -91,11 +91,12 @@ class TExecuteDistributedEraseTxUnit : public TExecutionUnit { for (const auto& rs : readSets) { NKikimrTxDataShard::TDistributedEraseRS body; Y_ABORT_UNLESS(body.ParseFromArray(rs.Body.data(), rs.Body.size())); - Y_ABORT_UNLESS(presentRows.contains(rs.Origin)); - const bool ok = Execute(txc, request, presentRows.at(rs.Origin), - DeserializeBitMap(body.GetConfirmedRows()), writeVersion, op->GetGlobalTxId()); - Y_ABORT_UNLESS(ok); + + auto confirmedRows = DeserializeBitMap(body.GetConfirmedRows()); + if (!Execute(txc, request, presentRows.at(rs.Origin), confirmedRows, writeVersion, op->GetGlobalTxId())) { + return EExecutionStatus::Restart; + } } } From 70508571d12575a66d84027754322c681385ffc5 Mon Sep 17 00:00:00 2001 From: kruall Date: Tue, 2 Apr 2024 14:58:45 +0300 Subject: [PATCH 096/117] Send unsubcribe in viewer (#3371) --- ydb/core/viewer/counters_hosts.h | 70 ++++++++++++++++++++------------ ydb/core/viewer/json_vdisk_req.h | 19 +++++++-- 2 files changed, 59 insertions(+), 30 deletions(-) diff --git a/ydb/core/viewer/counters_hosts.h b/ydb/core/viewer/counters_hosts.h index 9a65349aae2d..2232f16b00ba 100644 --- a/ydb/core/viewer/counters_hosts.h +++ b/ydb/core/viewer/counters_hosts.h @@ -16,10 +16,13 @@ using namespace NActors; using namespace NNodeWhiteboard; class TCountersHostsList : public TActorBootstrapped { + using TBase = TActorBootstrapped; + IViewer* Viewer; NMon::TEvHttpInfo::TPtr Event; THolder NodesInfo; TMap> NodesResponses; + THashSet TcpProxies; ui32 NodesRequested = 0; ui32 NodesReceived = 0; bool StaticNodesOnly = false; @@ -35,47 +38,48 @@ class TCountersHostsList : public TActorBootstrapped { , Event(ev) {} - void Bootstrap(const TActorContext& ctx) { + void Bootstrap() { const auto& params(Event->Get()->Request.GetParams()); StaticNodesOnly = FromStringWithDefault(params.Get("static_only"), StaticNodesOnly); DynamicNodesOnly = FromStringWithDefault(params.Get("dynamic_only"), DynamicNodesOnly); const TActorId nameserviceId = GetNameserviceActorId(); - ctx.Send(nameserviceId, new TEvInterconnect::TEvListNodes()); - ctx.Schedule(TDuration::Seconds(10), new TEvents::TEvWakeup()); + Send(nameserviceId, new TEvInterconnect::TEvListNodes()); + Schedule(TDuration::Seconds(10), new TEvents::TEvWakeup()); Become(&TThis::StateRequestedList); } STFUNC(StateRequestedList) { switch (ev->GetTypeRewrite()) { - HFunc(TEvInterconnect::TEvNodesInfo, Handle); - CFunc(TEvents::TSystem::Wakeup, Timeout); + hFunc(TEvInterconnect::TEvNodesInfo, Handle); + cFunc(TEvents::TSystem::Wakeup, Timeout); } } STFUNC(StateRequestedSysInfo) { switch (ev->GetTypeRewrite()) { - HFunc(TEvWhiteboard::TEvSystemStateResponse, Handle); - HFunc(TEvents::TEvUndelivered, Undelivered); - HFunc(TEvInterconnect::TEvNodeDisconnected, Disconnected); - CFunc(TEvents::TSystem::Wakeup, Timeout); + hFunc(TEvWhiteboard::TEvSystemStateResponse, Handle); + hFunc(TEvents::TEvUndelivered, Undelivered); + hFunc(TEvInterconnect::TEvNodeDisconnected, Disconnected); + hFunc(TEvInterconnect::TEvNodeConnected, Connected); + cFunc(TEvents::TSystem::Wakeup, Timeout); } } - void SendRequest(ui32 nodeId, const TActorContext& ctx) { + void SendRequest(ui32 nodeId) { TActorId whiteboardServiceId = MakeNodeWhiteboardServiceId(nodeId); THolder request = MakeHolder(); - ctx.Send(whiteboardServiceId, request.Release(), IEventHandle::FlagTrackDelivery | IEventHandle::FlagSubscribeOnSession, nodeId); - ++NodesRequested; + Send(whiteboardServiceId, request.Release(), IEventHandle::FlagTrackDelivery | IEventHandle::FlagSubscribeOnSession, nodeId); + NodesRequested++; } - void NodeStateInfoReceived(const TActorContext& ctx) { + void NodeStateInfoReceived() { ++NodesReceived; if (NodesRequested == NodesReceived) { - ReplyAndDie(ctx); + ReplyAndDie(); } } - void Handle(TEvInterconnect::TEvNodesInfo::TPtr& ev, const TActorContext& ctx) { + void Handle(TEvInterconnect::TEvNodesInfo::TPtr& ev) { NodesInfo = ev->Release(); ui32 minAllowedNodeId = std::numeric_limits::min(); ui32 maxAllowedNodeId = std::numeric_limits::max(); @@ -90,33 +94,38 @@ class TCountersHostsList : public TActorBootstrapped { } for (const auto& nodeInfo : NodesInfo->Nodes) { if (nodeInfo.NodeId >= minAllowedNodeId && nodeInfo.NodeId <= maxAllowedNodeId) { - SendRequest(nodeInfo.NodeId, ctx); + SendRequest(nodeInfo.NodeId); } } Become(&TThis::StateRequestedSysInfo); } - void Handle(TEvWhiteboard::TEvSystemStateResponse::TPtr& ev, const TActorContext& ctx) { + void Handle(TEvWhiteboard::TEvSystemStateResponse::TPtr& ev) { ui64 nodeId = ev.Get()->Cookie; NodesResponses[nodeId] = ev->Release(); - NodeStateInfoReceived(ctx); + NodeStateInfoReceived(); } - void Undelivered(TEvents::TEvUndelivered::TPtr& ev, const TActorContext& ctx) { + void Undelivered(TEvents::TEvUndelivered::TPtr& ev) { ui32 nodeId = ev.Get()->Cookie; if (NodesResponses.emplace(nodeId, nullptr).second) { - NodeStateInfoReceived(ctx); + NodeStateInfoReceived(); } } - void Disconnected(TEvInterconnect::TEvNodeDisconnected::TPtr& ev, const TActorContext& ctx) { + void Disconnected(TEvInterconnect::TEvNodeDisconnected::TPtr& ev) { ui32 nodeId = ev->Get()->NodeId; + TcpProxies.erase(ev->Sender); if (NodesResponses.emplace(nodeId, nullptr).second) { - NodeStateInfoReceived(ctx); + NodeStateInfoReceived(); } } - void ReplyAndDie(const TActorContext& ctx) { + void Connected(TEvInterconnect::TEvNodeConnected::TPtr& ev) { + TcpProxies.insert(ev->Sender); + } + + void ReplyAndDie() { TStringStream text; for (const auto& [nodeId, sysInfo] : NodesResponses) { if (sysInfo) { @@ -147,12 +156,19 @@ class TCountersHostsList : public TActorBootstrapped { } } } - ctx.Send(Event->Sender, new NMon::TEvHttpInfoRes(Viewer->GetHTTPOKTEXT(Event->Get()) + text.Str(), 0, NMon::IEvHttpInfoRes::EContentType::Custom)); - Die(ctx); + Send(Event->Sender, new NMon::TEvHttpInfoRes(Viewer->GetHTTPOKTEXT(Event->Get()) + text.Str(), 0, NMon::IEvHttpInfoRes::EContentType::Custom)); + PassAway(); + } + + void PassAway() { + for (auto &tcpPorxy: TcpProxies) { + Send(tcpPorxy, new TEvents::TEvUnsubscribe); + } + TBase::PassAway(); } - void Timeout(const TActorContext &ctx) { - ReplyAndDie(ctx); + void Timeout() { + ReplyAndDie(); } }; diff --git a/ydb/core/viewer/json_vdisk_req.h b/ydb/core/viewer/json_vdisk_req.h index 61b805d9a498..28459d510b56 100644 --- a/ydb/core/viewer/json_vdisk_req.h +++ b/ydb/core/viewer/json_vdisk_req.h @@ -60,6 +60,8 @@ class TJsonVDiskRequest : public TViewerPipeClient TcpProxyId; + public: static constexpr NKikimrServices::TActivity::EType ActorActivityType() { return NKikimrServices::TActivity::VIEWER_HANDLER; @@ -111,6 +113,7 @@ class TJsonVDiskRequest : public TViewerPipeClientSender; + } + void Disconnected() { + TcpProxyId = {}; if (!RetryRequest()) { TBase::RequestDone(); } @@ -170,6 +178,13 @@ class TJsonVDiskRequest : public TViewerPipeClientSend(*TcpProxyId, new TEvents::TEvUnsubscribe); + } + TBase::PassAway(); + } + void ReplyAndPassAway(const TString &error = "") { try { TStringStream json; @@ -182,10 +197,8 @@ class TJsonVDiskRequest : public TViewerPipeClient From d547c4c50a53a4a4f562d92d2b4d936da8924ca8 Mon Sep 17 00:00:00 2001 From: Alexander Petrukhin Date: Tue, 2 Apr 2024 21:37:35 +0300 Subject: [PATCH 097/117] Reduce severity of some health check issues (#3067) (#3176) --- ydb/core/health_check/health_check.cpp | 14 +++++--------- 1 file changed, 5 insertions(+), 9 deletions(-) diff --git a/ydb/core/health_check/health_check.cpp b/ydb/core/health_check/health_check.cpp index a127d271e60f..c0e407f01933 100644 --- a/ydb/core/health_check/health_check.cpp +++ b/ydb/core/health_check/health_check.cpp @@ -1140,19 +1140,15 @@ class TSelfCheckRequest : public TActorBootstrapped { static void Check(TSelfCheckContext& context, const NKikimrWhiteboard::TSystemStateInfo::TPoolStats& poolStats) { if (poolStats.name() == "System" || poolStats.name() == "IC" || poolStats.name() == "IO") { if (poolStats.usage() >= 0.99) { - context.ReportStatus(Ydb::Monitoring::StatusFlag::RED, "Pool usage over 99%", ETags::OverloadState); + context.ReportStatus(Ydb::Monitoring::StatusFlag::ORANGE, "Pool usage is over than 99%", ETags::OverloadState); } else if (poolStats.usage() >= 0.95) { - context.ReportStatus(Ydb::Monitoring::StatusFlag::ORANGE, "Pool usage over 95%", ETags::OverloadState); - } else if (poolStats.usage() >= 0.90) { - context.ReportStatus(Ydb::Monitoring::StatusFlag::YELLOW, "Pool usage over 90%", ETags::OverloadState); + context.ReportStatus(Ydb::Monitoring::StatusFlag::YELLOW, "Pool usage is over than 95%", ETags::OverloadState); } else { context.ReportStatus(Ydb::Monitoring::StatusFlag::GREEN); } } else { if (poolStats.usage() >= 0.99) { - context.ReportStatus(Ydb::Monitoring::StatusFlag::ORANGE, "Pool usage over 99%", ETags::OverloadState); - } else if (poolStats.usage() >= 0.95) { - context.ReportStatus(Ydb::Monitoring::StatusFlag::YELLOW, "Pool usage over 95%", ETags::OverloadState); + context.ReportStatus(Ydb::Monitoring::StatusFlag::YELLOW, "Pool usage is over than 99%", ETags::OverloadState); } else { context.ReportStatus(Ydb::Monitoring::StatusFlag::GREEN); } @@ -1222,7 +1218,7 @@ class TSelfCheckRequest : public TActorBootstrapped { break; case TNodeTabletState::ETabletState::RestartsTooOften: computeTabletStatus.set_state("RESTARTS_TOO_OFTEN"); - tabletContext.ReportStatus(Ydb::Monitoring::StatusFlag::RED, "Tablets are restarting too often", ETags::TabletState); + tabletContext.ReportStatus(Ydb::Monitoring::StatusFlag::ORANGE, "Tablets are restarting too often", ETags::TabletState); break; case TNodeTabletState::ETabletState::Dead: computeTabletStatus.set_state("DEAD"); @@ -1261,7 +1257,7 @@ class TSelfCheckRequest : public TActorBootstrapped { TSelfCheckContext rrContext(&context, "NODE_UPTIME"); if (databaseState.NodeRestartsPerPeriod[nodeId] >= 30) { - rrContext.ReportStatus(Ydb::Monitoring::StatusFlag::RED, "Node is restarting too often", ETags::Uptime); + rrContext.ReportStatus(Ydb::Monitoring::StatusFlag::ORANGE, "Node is restarting too often", ETags::Uptime); } else if (databaseState.NodeRestartsPerPeriod[nodeId] >= 10) { rrContext.ReportStatus(Ydb::Monitoring::StatusFlag::YELLOW, "The number of node restarts has increased", ETags::Uptime); } else { From 2631f5b0696cf14959922b74cfa05d0ab52da2e5 Mon Sep 17 00:00:00 2001 From: Vitalii Gridnev Date: Wed, 3 Apr 2024 11:34:26 +0300 Subject: [PATCH 098/117] fix bug: limit retries in starting state (#3398) --- ydb/core/kqp/compute_actor/kqp_scan_fetcher_actor.cpp | 8 ++++++++ 1 file changed, 8 insertions(+) diff --git a/ydb/core/kqp/compute_actor/kqp_scan_fetcher_actor.cpp b/ydb/core/kqp/compute_actor/kqp_scan_fetcher_actor.cpp index da29486bd7d5..5d29c47c9260 100644 --- a/ydb/core/kqp/compute_actor/kqp_scan_fetcher_actor.cpp +++ b/ydb/core/kqp/compute_actor/kqp_scan_fetcher_actor.cpp @@ -154,6 +154,14 @@ void TKqpScanFetcherActor::HandleExecute(TEvKqpCompute::TEvScanError::TPtr& ev) } if (state->State == EShardState::Starting) { + ++TotalRetries; + if (TotalRetries >= MAX_TOTAL_SHARD_RETRIES) { + CA_LOG_E("TKqpScanFetcherActor: broken tablet for this request " << state->TabletId + << ", retries limit exceeded (" << state->TotalRetries << "/" << TotalRetries << ")"); + SendGlobalFail(NDqProto::COMPUTE_STATE_FAILURE, YdbStatusToDqStatus(status), issues); + return PassAway(); + } + if (FindSchemeErrorInIssues(status, issues)) { return EnqueueResolveShard(state); } From c301eca874c20bb42226aa7a64e067f3fa51dc85 Mon Sep 17 00:00:00 2001 From: vporyadke Date: Wed, 3 Apr 2024 20:00:05 +0200 Subject: [PATCH 099/117] disable db metadata cache (#3444) --- ydb/core/driver_lib/run/config.h | 1 + 1 file changed, 1 insertion(+) diff --git a/ydb/core/driver_lib/run/config.h b/ydb/core/driver_lib/run/config.h index 2cd944329a68..ae040faa9e2c 100644 --- a/ydb/core/driver_lib/run/config.h +++ b/ydb/core/driver_lib/run/config.h @@ -125,6 +125,7 @@ union TBasicKikimrServicesMask { TBasicKikimrServicesMask() { EnableAll(); + EnableDatabaseMetadataCache = false; } }; From 9acd57994ae3dfb9ee2fe7dbb10f52284198a338 Mon Sep 17 00:00:00 2001 From: Nikolay Shestakov Date: Fri, 5 Apr 2024 20:31:29 +0500 Subject: [PATCH 100/117] Decrease default value of SharedCacheSizeMb to 1024 (#3421) --- ydb/core/protos/node_limits.proto | 3 +-- 1 file changed, 1 insertion(+), 2 deletions(-) diff --git a/ydb/core/protos/node_limits.proto b/ydb/core/protos/node_limits.proto index 5aaf8c6fdaf8..ef067d578c48 100644 --- a/ydb/core/protos/node_limits.proto +++ b/ydb/core/protos/node_limits.proto @@ -3,10 +3,9 @@ option java_package = "ru.yandex.kikimr.proto"; message TNodeLimitsConfig { message TPersQueueNodeConfig { - optional uint64 SharedCacheSizeMb = 1 [default = 8192]; + optional uint64 SharedCacheSizeMb = 1 [default = 1024]; optional uint32 CacheKeepTimeSec = 2 [default = 10]; } optional TPersQueueNodeConfig PersQueueNodeConfig = 1; } - From b6a279dc928be6b36748c27ba33f4af55bc30766 Mon Sep 17 00:00:00 2001 From: niksaveliev Date: Mon, 8 Apr 2024 11:29:01 +0500 Subject: [PATCH 101/117] Kafka balance fixes to 24 1 (#3537) --- .../actors/kafka_read_session_actor.cpp | 25 ++++++++++--------- 1 file changed, 13 insertions(+), 12 deletions(-) diff --git a/ydb/core/kafka_proxy/actors/kafka_read_session_actor.cpp b/ydb/core/kafka_proxy/actors/kafka_read_session_actor.cpp index cd3f6dd7d674..a1886ca53752 100644 --- a/ydb/core/kafka_proxy/actors/kafka_read_session_actor.cpp +++ b/ydb/core/kafka_proxy/actors/kafka_read_session_actor.cpp @@ -36,11 +36,10 @@ void TKafkaReadSessionActor::HandleWakeup(TEvKafka::TEvWakeup::TPtr, const TActo return; } - for (auto& topicToPartitions: NewPartitionsToLockOnTime) { - auto& partitions = topicToPartitions.second; + for (auto& [topicName, partitions]: NewPartitionsToLockOnTime) { for (auto partitionsIt = partitions.begin(); partitionsIt != partitions.end(); ) { if (partitionsIt->LockOn <= ctx.Now()) { - TopicPartitions[topicToPartitions.first].ToLock.emplace(partitionsIt->PartitionId); + TopicPartitions[topicName].ToLock.emplace(partitionsIt->PartitionId); NeedRebalance = true; partitionsIt = partitions.erase(partitionsIt); } else { @@ -408,6 +407,8 @@ void TKafkaReadSessionActor::HandlePipeDestroyed(TEvTabletPipe::TEvClientDestroy } void TKafkaReadSessionActor::ProcessBalancerDead(ui64 tabletId, const TActorContext& ctx) { + NewPartitionsToLockOnTime.clear(); + for (auto& [topicName, topicInfo] : TopicsInfo) { if (topicInfo.TabletID == tabletId) { auto partitionsIt = TopicPartitions.find(topicName); @@ -579,8 +580,7 @@ void TKafkaReadSessionActor::HandleReleasePartition(TEvPersQueue::TEvReleasePart auto newPartitionsToLockCount = newPartitionsToLockIt == NewPartitionsToLockOnTime.end() ? 0 : newPartitionsToLockIt->second.size(); auto topicPartitionsIt = TopicPartitions.find(pathIt->second->GetInternalName()); - Y_ABORT_UNLESS(topicPartitionsIt != TopicPartitions.end()); - Y_ABORT_UNLESS(record.GetCount() <= topicPartitionsIt->second.ToLock.size() + topicPartitionsIt->second.ReadingNow.size() + newPartitionsToLockCount); + Y_ABORT_UNLESS(record.GetCount() <= (topicPartitionsIt.IsEnd() ? 0 : topicPartitionsIt->second.ToLock.size() + topicPartitionsIt->second.ReadingNow.size()) + newPartitionsToLockCount); for (ui32 c = 0; c < record.GetCount(); ++c) { // if some partition not locked yet, then release it without rebalance @@ -599,18 +599,19 @@ void TKafkaReadSessionActor::HandleReleasePartition(TEvPersQueue::TEvReleasePart } NeedRebalance = true; - size_t partitionToReleaseIndex = 0; - size_t i = 0; + ui32 partitionToRelease = 0; + ui32 i = 0; - for (size_t partIndex = 0; partIndex < topicPartitionsIt->second.ReadingNow.size(); partIndex++) { - if (!topicPartitionsIt->second.ToRelease.contains(partIndex) && (group == 0 || partIndex + 1 == group)) { + for (auto curPartition : topicPartitionsIt->second.ReadingNow) { + if (!topicPartitionsIt->second.ToRelease.contains(curPartition) && (group == 0 || curPartition + 1 == group)) { ++i; - if (rand() % i == 0) { // will lead to 1/n probability for each of n partitions - partitionToReleaseIndex = partIndex; + if (rand() % i == 0) { + partitionToRelease = curPartition; } } } - topicPartitionsIt->second.ToRelease.emplace(partitionToReleaseIndex); + + topicPartitionsIt->second.ToRelease.emplace(partitionToRelease); } } From d14df371eccf952f4fdee844985b205022e18db1 Mon Sep 17 00:00:00 2001 From: Aleksei Borzenkov Date: Mon, 8 Apr 2024 12:04:46 +0300 Subject: [PATCH 102/117] 24-1: Fix a race between mediator state and pipeline restoring active transactions (#3378) --- ydb/core/tx/datashard/datashard.cpp | 54 +++-- ydb/core/tx/datashard/datashard_impl.h | 5 +- ydb/core/tx/datashard/datashard_pipeline.cpp | 30 ++- .../tx/datashard/datashard_ut_snapshot.cpp | 221 ++++++++++++++++++ 4 files changed, 288 insertions(+), 22 deletions(-) diff --git a/ydb/core/tx/datashard/datashard.cpp b/ydb/core/tx/datashard/datashard.cpp index ce98a47b6599..12bc7e28e7cb 100644 --- a/ydb/core/tx/datashard/datashard.cpp +++ b/ydb/core/tx/datashard/datashard.cpp @@ -2318,6 +2318,31 @@ void TDataShard::SendAfterMediatorStepActivate(ui64 mediatorStep, const TActorCo EmitHeartbeats(); } +class TDataShard::TTxMediatorStateRestored : public TTransactionBase { +public: + TTxMediatorStateRestored(TDataShard* self, ui64 readStep, ui64 observedStep) + : TTransactionBase(self) + , ReadStep(readStep) + , ObservedStep(observedStep) + {} + + bool Execute(TTransactionContext& txc, const TActorContext&) override { + Y_ABORT_UNLESS(Self->MediatorStateRestoreTxPending); + Self->MediatorStateRestoreTxPending = false; + + Self->FinishMediatorStateRestore(txc, ReadStep, ObservedStep); + return true; + } + + void Complete(const TActorContext&) override { + // nothing + } + +private: + const ui64 ReadStep; + const ui64 ObservedStep; +}; + void TDataShard::CheckMediatorStateRestored() { if (!MediatorStateWaiting || !RegistrationSended || @@ -2325,16 +2350,11 @@ void TDataShard::CheckMediatorStateRestored() { CoordinatorSubscriptionsPending > 0 && CoordinatorPrevReadStepMax == Max()) { // We are not waiting or not ready to make a decision - if (MediatorStateWaiting && - MediatorTimeCastEntry && - CoordinatorPrevReadStepMax == Max() && - !MediatorStateBackupInitiated) - { - // It is possible we don't have coordinators with new protocol support - // Use a backup plan of acquiring a read snapshot for restoring the read step - Schedule(TDuration::MilliSeconds(50), new TEvPrivate::TEvMediatorRestoreBackup); - MediatorStateBackupInitiated = true; - } + return; + } + + if (MediatorStateRestoreTxPending) { + // We already made a decision and are waiting for transaction to execute return; } @@ -2372,6 +2392,13 @@ void TDataShard::CheckMediatorStateRestored() { return; } + MediatorStateRestoreTxPending = true; + Execute(new TTxMediatorStateRestored(this, readStep, observedStep)); +} + +void TDataShard::FinishMediatorStateRestore(TTransactionContext& txc, ui64 readStep, ui64 observedStep) { + Y_ABORT_UNLESS(MediatorStateWaiting); + // Using the inferred last read step we restore the pessimistic unprotected // read edge. Note we only need to do so if there have actually been any // unprotected reads in this datashard history. We also need to make sure @@ -2386,6 +2413,8 @@ void TDataShard::CheckMediatorStateRestored() { const TRowVersion edge = Max(lastReadEdge, preImmediateWriteEdge); LOG_TRACE_S(*TlsActivationContext, NKikimrServices::TX_DATASHARD, "CheckMediatorStateRestored at " << TabletID() << " promoting UnprotectedReadEdge to " << edge); + Pipeline.MarkPlannedLogicallyCompleteUpTo(edge, txc); + Pipeline.MarkPlannedLogicallyIncompleteUpTo(edge, txc); SnapshotManager.PromoteUnprotectedReadEdge(edge); } @@ -3289,10 +3318,7 @@ void TDataShard::Handle(TEvMediatorTimecast::TEvNotifyPlanStep::TPtr& ev, const } void TDataShard::Handle(TEvPrivate::TEvMediatorRestoreBackup::TPtr&, const TActorContext&) { - if (MediatorStateWaiting && CoordinatorPrevReadStepMax == Max()) { - // We are still waiting for new protol coordinator state - // TODO: send an old snapshot request to coordinators - } + Y_ABORT("This code path was always no-op and no longer used"); } bool TDataShard::WaitPlanStep(ui64 step) { diff --git a/ydb/core/tx/datashard/datashard_impl.h b/ydb/core/tx/datashard/datashard_impl.h index 7720260dce60..b277cfe1ef43 100644 --- a/ydb/core/tx/datashard/datashard_impl.h +++ b/ydb/core/tx/datashard/datashard_impl.h @@ -247,6 +247,8 @@ class TDataShard class TTxHandleSafeKqpScan; class TTxHandleSafeBuildIndexScan; + class TTxMediatorStateRestored; + ITransaction *CreateTxMonitoring(TDataShard *self, NMon::TEvRemoteHttpInfo::TPtr ev); ITransaction *CreateTxGetInfo(TDataShard *self, @@ -1947,6 +1949,7 @@ class TDataShard void SendAfterMediatorStepActivate(ui64 mediatorStep, const TActorContext& ctx); void CheckMediatorStateRestored(); + void FinishMediatorStateRestore(TTransactionContext&, ui64, ui64); void FillExecutionStats(const TExecutionProfile& execProfile, TEvDataShard::TEvProposeTransactionResult& result) const; @@ -2613,7 +2616,7 @@ class TDataShard TVector> MediatorStateWaitingMsgs; bool MediatorStateWaiting = false; - bool MediatorStateBackupInitiated = false; + bool MediatorStateRestoreTxPending = false; bool IcbRegistered = false; diff --git a/ydb/core/tx/datashard/datashard_pipeline.cpp b/ydb/core/tx/datashard/datashard_pipeline.cpp index f993241ab68f..15cfdc4c88f7 100644 --- a/ydb/core/tx/datashard/datashard_pipeline.cpp +++ b/ydb/core/tx/datashard/datashard_pipeline.cpp @@ -401,13 +401,25 @@ void TPipeline::AddActiveOp(TOperation::TPtr op) if (Self->IsMvccEnabled()) { TStepOrder stepOrder = op->GetStepOrder(); TRowVersion version(stepOrder.Step, stepOrder.TxId); - TRowVersion completeEdge = Max( - Self->SnapshotManager.GetCompleteEdge(), - Self->SnapshotManager.GetUnprotectedReadEdge()); - if (version <= completeEdge) { - op->SetFlag(TTxFlags::BlockingImmediateOps); - } else if (version <= Self->SnapshotManager.GetIncompleteEdge()) { - op->SetFlag(TTxFlags::BlockingImmediateWrites); + if (version <= Self->SnapshotManager.GetCompleteEdge() || + version < Self->SnapshotManager.GetImmediateWriteEdge() || + version < Self->SnapshotManager.GetUnprotectedReadEdge()) + { + // This transaction would have been marked as logically complete + if (!op->HasFlag(TTxFlags::BlockingImmediateOps)) { + LOG_TRACE_S(*TlsActivationContext, NKikimrServices::TX_DATASHARD, + "Adding BlockingImmediateOps for op " << *op << " at " << Self->TabletID()); + op->SetFlag(TTxFlags::BlockingImmediateOps); + } + } else if (version <= Self->SnapshotManager.GetIncompleteEdge() || + version <= Self->SnapshotManager.GetUnprotectedReadEdge()) + { + // This transaction would have been marked as logically incomplete + if (!op->HasFlag(TTxFlags::BlockingImmediateWrites)) { + LOG_TRACE_S(*TlsActivationContext, NKikimrServices::TX_DATASHARD, + "Adding BlockingImmediateWrites for op " << *op << " at " << Self->TabletID()); + op->SetFlag(TTxFlags::BlockingImmediateWrites); + } } } auto pr = ActivePlannedOps.emplace(op->GetStepOrder(), op); @@ -415,10 +427,14 @@ void TPipeline::AddActiveOp(TOperation::TPtr op) Y_ABORT_UNLESS(pr.first == std::prev(ActivePlannedOps.end()), "AddActiveOp must always add transactions in order"); bool isComplete = op->HasFlag(TTxFlags::BlockingImmediateOps); if (ActivePlannedOpsLogicallyCompleteEnd == ActivePlannedOps.end() && !isComplete) { + LOG_TRACE_S(*TlsActivationContext, NKikimrServices::TX_DATASHARD, + "Operation " << *op << " is the new logically complete end at " << Self->TabletID()); ActivePlannedOpsLogicallyCompleteEnd = pr.first; } bool isIncomplete = isComplete || op->HasFlag(TTxFlags::BlockingImmediateWrites); if (ActivePlannedOpsLogicallyIncompleteEnd == ActivePlannedOps.end() && !isIncomplete) { + LOG_TRACE_S(*TlsActivationContext, NKikimrServices::TX_DATASHARD, + "Operation " << *op << " is the new logically incomplete end at " << Self->TabletID()); ActivePlannedOpsLogicallyIncompleteEnd = pr.first; } } diff --git a/ydb/core/tx/datashard/datashard_ut_snapshot.cpp b/ydb/core/tx/datashard/datashard_ut_snapshot.cpp index 51da5d32d2ff..ea3c67b171e7 100644 --- a/ydb/core/tx/datashard/datashard_ut_snapshot.cpp +++ b/ydb/core/tx/datashard/datashard_ut_snapshot.cpp @@ -4675,6 +4675,227 @@ Y_UNIT_TEST_SUITE(DataShardSnapshots) { "{ items { uint64_value: 15 } }"); } + Y_UNIT_TEST(PipelineAndMediatorRestoreRace) { + TPortManager pm; + TServerSettings serverSettings(pm.GetPort(2134)); + serverSettings.SetDomainName("Root") + .SetUseRealThreads(false) + .SetDomainPlanResolution(100) + .SetEnableDataShardVolatileTransactions(false); + + Tests::TServer::TPtr server = new TServer(serverSettings); + auto &runtime = *server->GetRuntime(); + auto sender = runtime.AllocateEdgeActor(); + + runtime.SetLogPriority(NKikimrServices::TX_DATASHARD, NLog::PRI_TRACE); + + InitRoot(server, sender); + + TDisableDataShardLogBatching disableDataShardLogBatching; + + UNIT_ASSERT_VALUES_EQUAL( + KqpSchemeExec(runtime, R"( + CREATE TABLE `/Root/table1` (key int, value int, PRIMARY KEY (key)); + CREATE TABLE `/Root/table2` (key int, value int, PRIMARY KEY (key)); + )"), + "SUCCESS"); + + const auto shards1 = GetTableShards(server, sender, "/Root/table1"); + UNIT_ASSERT_VALUES_EQUAL(shards1.size(), 1u); + + // Upsert initial data + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleExec(runtime, R"( + UPSERT INTO `/Root/table1` (key, value) VALUES (1, 10); + UPSERT INTO `/Root/table2` (key, value) VALUES (2, 20); + )"), + ""); + + // Make sure shards have unprotected reads enabled + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleExec(runtime, R"( + SELECT key, value FROM `/Root/table1` + UNION ALL + SELECT key, value FROM `/Root/table2` + ORDER BY key; + )"), + "{ items { int32_value: 1 } items { int32_value: 10 } }, " + "{ items { int32_value: 2 } items { int32_value: 20 } }"); + + std::vector readsets; + auto blockReadSets = runtime.AddObserver( + [&](TEvTxProcessing::TEvReadSet::TPtr& ev) { + auto* msg = ev->Get(); + Cerr << "... blocking readset for " << msg->Record.GetTabletDest() << Endl; + readsets.push_back(std::move(ev)); + }); + + size_t planSteps = 0; + auto observePlanSteps = runtime.AddObserver( + [&](TEvTxProcessing::TEvPlanStep::TPtr& ev) { + auto* msg = ev->Get(); + Cerr << "... observed plan step " << msg->Record.GetStep() << " for " << msg->Record.GetTabletID() << Endl; + ++planSteps; + }); + + // Create a "staircase" of transactions at different steps + + // Upsert1 will have outgoing readsets from both shards + Cerr << "... sending upsert1" << Endl; + auto upsert1 = KqpSimpleSend(runtime, R"( + SELECT key, value FROM `/Root/table1` WHERE key = 1; + SELECT key, value FROM `/Root/table2` WHERE key = 2; + UPSERT INTO `/Root/table1` (key, value) VALUES (3, 30), (5, 50); + UPSERT INTO `/Root/table2` (key, value) VALUES (4, 40); + )"); + WaitFor(runtime, [&]{ return planSteps >= 2; }, "upsert1 plan step"); + UNIT_ASSERT_VALUES_EQUAL(planSteps, 2u); + WaitFor(runtime, [&]{ return readsets.size() >= 2; }, "upsert1 readsets"); + UNIT_ASSERT_VALUES_EQUAL(readsets.size(), 2u); + + // Upsert2 will be blocked by dependencies (key 5) at table1, but not table2 + Cerr << "... sending upsert2" << Endl; + auto upsert2 = KqpSimpleSend(runtime, R"( + SELECT key, value FROM `/Root/table2` WHERE key = 2; + UPSERT INTO `/Root/table1` (key, value) VALUES (5, 55), (7, 70); + )"); + WaitFor(runtime, [&]{ return planSteps >= 4; }, "upsert2 plan step"); + UNIT_ASSERT_VALUES_EQUAL(planSteps, 4u); + WaitFor(runtime, [&]{ return readsets.size() >= 3; }, "upsert2 readset from table2"); + UNIT_ASSERT_VALUES_EQUAL(readsets.size(), 3u); + + // Upsert3 will be blocked by dependencies (key 7) at table1, but not table2 + Cerr << "... sending upsert3" << Endl; + auto upsert3 = KqpSimpleSend(runtime, R"( + SELECT key, value FROM `/Root/table2` WHERE key = 2; + UPSERT INTO `/Root/table1` (key, value) VALUES (7, 77), (9, 90); + )"); + WaitFor(runtime, [&]{ return planSteps >= 6; }, "upsert3 plan step"); + UNIT_ASSERT_VALUES_EQUAL(planSteps, 6u); + WaitFor(runtime, [&]{ return readsets.size() >= 4; }, "upsert3 readset from table2"); + UNIT_ASSERT_VALUES_EQUAL(readsets.size(), 4u); + + // Sleep a little to make sure everything is persisted at table1 and mediator time advanced + runtime.SimulateSleep(TDuration::MilliSeconds(200)); + + // Now restart table1 shard while blocking mediator timecast registration + std::vector registrations; + auto blockRegistrations = runtime.AddObserver( + [&](TEvMediatorTimecast::TEvRegisterTabletResult::TPtr& ev) { + Cerr << "... blocking timecast registration result for " << ev->GetRecipientRewrite() << Endl; + registrations.push_back(std::move(ev)); + }); + + // ... waiting for the new tablet actor booting + TActorId shardActor; + auto waitBoot = runtime.AddObserver( + [&](TEvTablet::TEvBoot::TPtr& ev) { + auto* msg = ev->Get(); + if (msg->TabletID == shards1.at(0)) { + shardActor = ev->GetRecipientRewrite(); + Cerr << "... booting " << msg->TabletID << " with actor " << shardActor << Endl; + } + }); + + // ... and blocking progress transactions + size_t allowProgress = 0; + std::vector> blockedProgress; + auto blockProgress = runtime.AddObserver([&](TAutoPtr& ev) { + if (shardActor && + ev->GetRecipientRewrite() == shardActor && + ev->GetTypeRewrite() == EventSpaceBegin(TKikimrEvents::ES_PRIVATE) + 0 /* EvProgressTransaction */) + { + if (allowProgress > 0) { + Cerr << "... allowing EvProgressTransaction for " << ev->GetRecipientRewrite() << Endl; + --allowProgress; + } else { + Cerr << "... blocking EvProgressTransaction for " << ev->GetRecipientRewrite() << Endl; + blockedProgress.push_back(std::move(ev)); + } + } + }); + + Cerr << "... rebooting " << shards1.at(0) << Endl; + GracefulRestartTablet(runtime, shards1.at(0), sender); + + WaitFor(runtime, [&]{ return registrations.size() >= 1; }, "timecast registration"); + UNIT_ASSERT_VALUES_EQUAL(registrations.size(), 1u); + + WaitFor(runtime, [&]{ return readsets.size() >= 8; }, "readsets resent"); + UNIT_ASSERT_VALUES_EQUAL(readsets.size(), 8u); + + // We need to unblock two transactions + // The first is already marked incomplete + // The second will be added to the pipeline, but blocked by dependencies + for (int i = 0; i < 2; ++i) { + WaitFor(runtime, [&]{ return blockedProgress.size() >= 1; }, "blocked progress"); + UNIT_ASSERT_VALUES_EQUAL(blockedProgress.size(), 1); + + Cerr << "... unblocking a single progress tx" << Endl; + allowProgress += blockedProgress.size(); + for (auto& ev : blockedProgress) { + runtime.Send(ev.Release(), 0, true); + } + blockedProgress.clear(); + } + + WaitFor(runtime, [&]{ return blockedProgress.size() >= 1; }, "blocked progress"); + UNIT_ASSERT_VALUES_EQUAL(blockedProgress.size(), 1); + + runtime.SimulateSleep(TDuration::MilliSeconds(1)); + + Cerr << "... unblocking timecast registration" << Endl; + blockRegistrations.Remove(); + for (auto& ev : registrations) { + runtime.Send(ev.Release(), 0, true); + } + + runtime.SimulateSleep(TDuration::MilliSeconds(200)); + + // Unblock the final transaction + // It's going to be before the restored worst-case unprotected read edge + // However because it's no the complete/incomplete tail it will not update lists properly + Cerr << "... unblocking final progress tx" << Endl; + blockProgress.Remove(); + for (auto& ev : blockedProgress) { + runtime.Send(ev.Release(), 0, true); + } + blockedProgress.clear(); + + runtime.SimulateSleep(TDuration::MilliSeconds(1)); + + // Perform snapshot read that will try to mark all pending transactions as logically complete/incomplete + UNIT_ASSERT_VALUES_EQUAL( + KqpSimpleExec(runtime, R"( + SELECT key, value FROM `/Root/table1` WHERE key = 1 + UNION ALL + SELECT key, value FROM `/Root/table2` WHERE key = 2 + ORDER BY key; + )"), + "{ items { int32_value: 1 } items { int32_value: 10 } }, " + "{ items { int32_value: 2 } items { int32_value: 20 } }"); + + Cerr << "... unblocking readsets" << Endl; + blockReadSets.Remove(); + for (auto& ev : readsets) { + runtime.Send(ev.Release(), 0, true); + } + readsets.clear(); + + UNIT_ASSERT_VALUES_EQUAL( + FormatResult(AwaitResponse(runtime, std::move(upsert1))), + "{ items { int32_value: 1 } items { int32_value: 10 } }\n" + "{ items { int32_value: 2 } items { int32_value: 20 } }"); + + UNIT_ASSERT_VALUES_EQUAL( + FormatResult(AwaitResponse(runtime, std::move(upsert2))), + "{ items { int32_value: 2 } items { int32_value: 20 } }"); + + UNIT_ASSERT_VALUES_EQUAL( + FormatResult(AwaitResponse(runtime, std::move(upsert3))), + "{ items { int32_value: 2 } items { int32_value: 20 } }"); + } + } } // namespace NKikimr From 295aafda229bcf7d117b2563df7ff43dcde0c5a2 Mon Sep 17 00:00:00 2001 From: qrort <31865255+qrort@users.noreply.github.com> Date: Mon, 8 Apr 2024 14:49:08 +0300 Subject: [PATCH 103/117] KIKIMR-18545: do not set not_null for default values (#3512) (#3548) --- ydb/core/kqp/ut/opt/kqp_not_null_ut.cpp | 22 ++++++++++++++----- .../tx/schemeshard/ut_export/ut_export.cpp | 2 -- ydb/core/ydb_convert/table_description.cpp | 10 +++++---- ydb/services/ydb/ydb_ut.cpp | 4 ---- 4 files changed, 22 insertions(+), 16 deletions(-) diff --git a/ydb/core/kqp/ut/opt/kqp_not_null_ut.cpp b/ydb/core/kqp/ut/opt/kqp_not_null_ut.cpp index 01a3c9bdb215..5252d6f1e6de 100644 --- a/ydb/core/kqp/ut/opt/kqp_not_null_ut.cpp +++ b/ydb/core/kqp/ut/opt/kqp_not_null_ut.cpp @@ -1966,8 +1966,8 @@ Y_UNIT_TEST_SUITE(KqpNotNullColumns) { {"Value3", "Pg('pgint2','',21,0,0)"} }; - const THashMap columnNullability = { - {"Key1", true}, + const THashMap columnNonNullability = { + {"Key1", false}, {"Key2", false}, {"Value1", false}, {"Value2", false}, @@ -1977,7 +1977,12 @@ Y_UNIT_TEST_SUITE(KqpNotNullColumns) { const auto& columns = describeTableResult.GetTableDescription().GetTableColumns(); for (const auto& column : columns) { UNIT_ASSERT_VALUES_EQUAL_C(column.Type.ToString(), columnTypes.at(column.Name), column.Name); - UNIT_ASSERT_VALUES_EQUAL_C(column.NotNull.value(), columnNullability.at(column.Name), column.Name); + bool isNotNull = columnNonNullability.at(column.Name); + if (isNotNull) { + UNIT_ASSERT_VALUES_EQUAL_C(column.NotNull.value(), true, column.Name); + } else { + UNIT_ASSERT_C(!column.NotNull.has_value() || !column.NotNull.value(), column.Name); + } } } @@ -1997,16 +2002,21 @@ Y_UNIT_TEST_SUITE(KqpNotNullColumns) { } auto describeTableResult = session.DescribeTable("/Root/NotNullCheck").GetValueSync(); UNIT_ASSERT_C(describeTableResult.IsSuccess(), describeTableResult.GetIssues().ToString()); - const THashMap columnNullability = { + const THashMap columnNonNullability = { {"1", false}, - {"2", true}, + {"2", false}, {"3", false}, {"4", true}, }; const auto& columns = describeTableResult.GetTableDescription().GetTableColumns(); for (const auto& column : columns) { - UNIT_ASSERT_VALUES_EQUAL_C(column.NotNull.value(), columnNullability.at(column.Name), column.Name); + bool isNotNull = columnNonNullability.at(column.Name); + if (isNotNull) { + UNIT_ASSERT_VALUES_EQUAL_C(column.NotNull.value(), true, column.Name); + } else { + UNIT_ASSERT_C(!column.NotNull.has_value() || !column.NotNull.value(), column.Name); + } } { diff --git a/ydb/core/tx/schemeshard/ut_export/ut_export.cpp b/ydb/core/tx/schemeshard/ut_export/ut_export.cpp index ef35341e5769..936010729a87 100644 --- a/ydb/core/tx/schemeshard/ut_export/ut_export.cpp +++ b/ydb/core/tx/schemeshard/ut_export/ut_export.cpp @@ -364,7 +364,6 @@ Y_UNIT_TEST_SUITE(TExportToS3Tests) { } } } - not_null: false from_literal { type { optional_type { @@ -389,7 +388,6 @@ columns { } } } - not_null: false from_literal { type { optional_type { diff --git a/ydb/core/ydb_convert/table_description.cpp b/ydb/core/ydb_convert/table_description.cpp index 7912606b9214..e9350f2733f6 100644 --- a/ydb/core/ydb_convert/table_description.cpp +++ b/ydb/core/ydb_convert/table_description.cpp @@ -367,13 +367,15 @@ static Ydb::Type* AddColumn(Ydb::Table::ColumnMeta* newColumn, const TColumn& co pg->set_oid(NPg::PgTypeIdFromTypeDesc(typeDesc)); pg->set_typlen(0); pg->set_typmod(0); + if (column.GetNotNull()) { + newColumn->set_not_null(column.GetNotNull()); + } } else { NYql::NProto::TypeIds protoType; if (!NYql::NProto::TypeIds_Parse(column.GetType(), &protoType)) { throw NYql::TErrorException(NKikimrIssues::TIssuesIds::DEFAULT_ERROR) << "Got invalid type: " << column.GetType() << " for column: " << column.GetName(); } - if (column.GetNotNull()) { columnType = newColumn->mutable_type(); } else { @@ -389,7 +391,6 @@ static Ydb::Type* AddColumn(Ydb::Table::ColumnMeta* newColumn, const TColumn& co NMiniKQL::ExportPrimitiveTypeToProto(protoType, *columnType); } } - newColumn->set_not_null(column.GetNotNull()); return columnType; } @@ -407,13 +408,15 @@ Ydb::Type* AddColumn(Ydb::Table::ColumnMeta pg->set_oid(NPg::PgTypeIdFromTypeDesc(typeDesc)); pg->set_typlen(0); pg->set_typmod(0); + if (column.GetNotNull()) { + newColumn->set_not_null(column.GetNotNull()); + } } else { NYql::NProto::TypeIds protoType; if (!NYql::NProto::TypeIds_Parse(column.GetType(), &protoType)) { throw NYql::TErrorException(NKikimrIssues::TIssuesIds::DEFAULT_ERROR) << "Got invalid type: " << column.GetType() << " for column: " << column.GetName(); } - if (column.GetNotNull()) { columnType = newColumn->mutable_type(); } else { @@ -429,7 +432,6 @@ Ydb::Type* AddColumn(Ydb::Table::ColumnMeta NMiniKQL::ExportPrimitiveTypeToProto(protoType, *columnType); } } - newColumn->set_not_null(column.GetNotNull()); switch (column.GetDefaultValueCase()) { case NKikimrSchemeOp::TColumnDescription::kDefaultFromLiteral: { auto fromLiteral = newColumn->mutable_from_literal(); diff --git a/ydb/services/ydb/ydb_ut.cpp b/ydb/services/ydb/ydb_ut.cpp index cd3fc0dd6fed..a70a8f8488bf 100644 --- a/ydb/services/ydb/ydb_ut.cpp +++ b/ydb/services/ydb/ydb_ut.cpp @@ -1262,7 +1262,6 @@ columns { } } } - not_null: false } columns { name: "Value" @@ -1273,7 +1272,6 @@ columns { } } } - not_null: false } primary_key: "Key" partitioning_settings { @@ -1601,7 +1599,6 @@ columns { } } } - not_null: false } columns { name: "IValue" @@ -1612,7 +1609,6 @@ columns { } } } - not_null: false } primary_key: "Key" indexes { From d39295a2102477e76782f742d5a4ca1e8d8f2858 Mon Sep 17 00:00:00 2001 From: Alexander Rutkovsky Date: Mon, 8 Apr 2024 22:12:35 +0300 Subject: [PATCH 104/117] Straighten BSC <-> NW interoperation protocol (merge from main) (#3575) --- ydb/core/base/blobstorage.h | 87 +++++-------- .../blobstorage/ut_blobstorage/balancing.cpp | 6 +- .../ut_blobstorage/group_reconfiguration.cpp | 2 +- ydb/core/blobstorage/ut_blobstorage/lib/env.h | 19 +-- .../blobstorage/ut_blobstorage/mirror3of4.cpp | 20 +-- .../blobstorage/ut_blobstorage/osiris.cpp | 11 +- .../vdisk/common/blobstorage_event_filter.cpp | 6 - ydb/core/mind/bscontroller/config.cpp | 22 ++-- ydb/core/mind/bscontroller/config.h | 3 +- ydb/core/mind/bscontroller/get_group.cpp | 28 +++-- .../bscontroller/group_reconfigure_wipe.cpp | 89 +------------ ydb/core/mind/bscontroller/impl.h | 69 ++++++++++- ydb/core/mind/bscontroller/node_report.cpp | 4 + .../mind/bscontroller/propose_group_key.cpp | 30 +++-- ydb/core/mind/bscontroller/register_node.cpp | 117 ++++++++++++------ .../bscontroller/ut_bscontroller/main.cpp | 16 ++- 16 files changed, 261 insertions(+), 268 deletions(-) diff --git a/ydb/core/base/blobstorage.h b/ydb/core/base/blobstorage.h index 34c07e6feaa3..e7bfa37b25b7 100644 --- a/ydb/core/base/blobstorage.h +++ b/ydb/core/base/blobstorage.h @@ -786,64 +786,35 @@ struct TEvBlobStorage { EvBunchOfEvents, // blobstorage controller interface - // EvControllerReadSchemeString = EvPut + 11 * 512, - // EvControllerReadDataString, - EvControllerRegisterNode = EvPut + 11 * 512 + 2, - EvControllerCreatePDisk, - EvControllerCreateVDiskSlots, - EvControllerCreateGroup, - EvControllerSelectGroups, - EvControllerGetGroup, - EvControllerUpdateDiskStatus, - EvControllerUpdateGroupsUsage, // Not used. - EvControllerConfigRequest, - EvControllerConfigResponse, - EvControllerProposeRequest, - EvControllerProposeResponse, - EvControllerVDiskStatusSubscribeRequest, - EvControllerVDiskStatusReport, - EvControllerGroupStatusRequest, - EvControllerGroupStatusResponse, - EvControllerUpdateGroup, - EvControllerUpdateFaultyDisks, - EvControllerProposeGroupKey, - EvControllerUpdateGroupLatencies, // Not used. - EvControllerUpdateGroupStat, - EvControllerNotifyGroupChange, - EvControllerCommitGroupLatencies, - EvControllerUpdateSelfHealInfo, - EvControllerScrubQueryStartQuantum, - EvControllerScrubQuantumFinished, - EvControllerScrubReportQuantumInProgress, - EvControllerUpdateNodeDrives, - EvControllerGroupDecommittedNotify, - EvControllerGroupDecommittedResponse, - EvControllerGroupMetricsExchange, - - // EvControllerReadSchemeStringResult = EvPut + 12 * 512, - // EvControllerReadDataStringResult, - EvControllerNodeServiceSetUpdate = EvPut + 12 * 512 + 2, - EvControllerCreatePDiskResult, - EvControllerCreateVDiskSlotsResult, - EvControllerCreateGroupResult, - EvControllerSelectGroupsResult, - EvRequestControllerInfo, - EvResponseControllerInfo, - EvControllerGroupReconfigureReplace, // Not used. - EvControllerGroupReconfigureReplaceResult, // Not used. - EvControllerGroupReconfigureWipe, - EvControllerGroupReconfigureWipeResult, - EvControllerNodeReport, - EvControllerScrubStartQuantum, - - EvControllerMigrationPause, - EvControllerMigrationContinue, - EvControllerMigrationFinished, - EvControllerMigrationBatch, - EvControllerMigrationBatchRequest, - EvControllerMigrationDone, - - EvControllerUpdateSystemViews, + EvControllerRegisterNode = 0x10031602, + EvControllerSelectGroups = 0x10031606, + EvControllerGetGroup = 0x10031607, + EvControllerUpdateDiskStatus = 0x10031608, + EvControllerConfigRequest = 0x1003160a, + EvControllerConfigResponse = 0x1003160b, + EvControllerProposeGroupKey = 0x10031614, + EvControllerUpdateGroupStat = 0x10031616, + EvControllerNotifyGroupChange = 0x10031617, + EvControllerCommitGroupLatencies = 0x10031618, + EvControllerUpdateSelfHealInfo = 0x10031619, + EvControllerScrubQueryStartQuantum = 0x1003161a, + EvControllerScrubQuantumFinished = 0x1003161b, + EvControllerScrubReportQuantumInProgress = 0x1003161c, + EvControllerUpdateNodeDrives = 0x1003161d, + EvControllerGroupDecommittedNotify = 0x1003161e, + EvControllerGroupDecommittedResponse = 0x1003161f, + EvControllerGroupMetricsExchange = 0x10031620, + + // BSC interface result section + EvControllerNodeServiceSetUpdate = 0x10031802, + EvControllerSelectGroupsResult = 0x10031806, + EvRequestControllerInfo = 0x10031807, + EvResponseControllerInfo = 0x10031808, + EvControllerGroupReconfigureWipe = 0x1003180b, + EvControllerGroupReconfigureWipeResult = 0x1003180c, + EvControllerNodeReport = 0x1003180d, + EvControllerScrubStartQuantum = 0x1003180e, + EvControllerUpdateSystemViews = 0x10031815, // proxy - node controller interface EvConfigureProxy = EvPut + 13 * 512, diff --git a/ydb/core/blobstorage/ut_blobstorage/balancing.cpp b/ydb/core/blobstorage/ut_blobstorage/balancing.cpp index 983f9a674550..7a98768e0cfc 100644 --- a/ydb/core/blobstorage/ut_blobstorage/balancing.cpp +++ b/ydb/core/blobstorage/ut_blobstorage/balancing.cpp @@ -303,9 +303,11 @@ struct TRandomTest { ui32 pos = random() % Env->Settings.NodeCount; if (Env.RunningNodes.contains(pos)) { auto baseConfig = Env->FetchBaseConfig(); - const auto& somePDisk = baseConfig.GetPDisk(pos); const auto& someVSlot = baseConfig.GetVSlot(pos); - Env->Wipe(somePDisk.GetNodeId(), somePDisk.GetPDiskId(), someVSlot.GetVSlotId().GetVSlotId()); + const auto& loc = someVSlot.GetVSlotId(); + Env->Wipe(loc.GetNodeId(), loc.GetPDiskId(), loc.GetVSlotId(), + TVDiskID(someVSlot.GetGroupId(), someVSlot.GetGroupGeneration(), someVSlot.GetFailRealmIdx(), + someVSlot.GetFailDomainIdx(), someVSlot.GetVDiskIdx())); Env->Sim(TDuration::Seconds(10)); } } diff --git a/ydb/core/blobstorage/ut_blobstorage/group_reconfiguration.cpp b/ydb/core/blobstorage/ut_blobstorage/group_reconfiguration.cpp index d6ff8bc331f0..13a4d7f36f5e 100644 --- a/ydb/core/blobstorage/ut_blobstorage/group_reconfiguration.cpp +++ b/ydb/core/blobstorage/ut_blobstorage/group_reconfiguration.cpp @@ -331,7 +331,7 @@ Y_UNIT_TEST_SUITE(GroupReconfiguration) { Timer.Reset(); auto ev = std::make_unique(); ev->Record.AddGroupIDs(GroupId); - NTabletPipe::SendData(SelfId(), ClientId, ev.release(), 0); + NTabletPipe::SendData(SelfId(), ClientId, ev.release(), Max()); } } diff --git a/ydb/core/blobstorage/ut_blobstorage/lib/env.h b/ydb/core/blobstorage/ut_blobstorage/lib/env.h index 6c8bc1f9538a..470e1a7a8e92 100644 --- a/ydb/core/blobstorage/ut_blobstorage/lib/env.h +++ b/ydb/core/blobstorage/ut_blobstorage/lib/env.h @@ -751,17 +751,20 @@ struct TEnvironmentSetup { Sim(TDuration::Seconds(15)); } - void Wipe(ui32 nodeId, ui32 pdiskId, ui32 vslotId) { - const TActorId self = Runtime->AllocateEdgeActor(Settings.ControllerNodeId, __FILE__, __LINE__); - auto ev = std::make_unique(); - auto& record = ev->Record; - auto *vslot = record.MutableVSlotId(); + void Wipe(ui32 nodeId, ui32 pdiskId, ui32 vslotId, const TVDiskID& vdiskId) { + NKikimrBlobStorage::TConfigRequest request; + request.SetIgnoreGroupFailModelChecks(true); + request.SetIgnoreDegradedGroupsChecks(true); + request.SetIgnoreDisintegratedGroupsChecks(true); + auto *cmd = request.AddCommand(); + auto *wipe = cmd->MutableWipeVDisk(); + auto *vslot = wipe->MutableVSlotId(); vslot->SetNodeId(nodeId); vslot->SetPDiskId(pdiskId); vslot->SetVSlotId(vslotId); - Runtime->SendToPipe(TabletId, self, ev.release(), 0, TTestActorSystem::GetPipeConfigWithRetries()); - auto response = WaitForEdgeActorEvent(self); - UNIT_ASSERT_VALUES_EQUAL(response->Get()->Record.GetStatus(), NKikimrProto::OK); + VDiskIDFromVDiskID(vdiskId, wipe->MutableVDiskId()); + auto response = Invoke(request); + UNIT_ASSERT_C(response.GetSuccess(), response.GetErrorDescription()); } void WaitForVDiskToGetRunning(const TVDiskID& vdiskId, TActorId actorId) { diff --git a/ydb/core/blobstorage/ut_blobstorage/mirror3of4.cpp b/ydb/core/blobstorage/ut_blobstorage/mirror3of4.cpp index b9ffea9da2c4..2e6dcf73138c 100644 --- a/ydb/core/blobstorage/ut_blobstorage/mirror3of4.cpp +++ b/ydb/core/blobstorage/ut_blobstorage/mirror3of4.cpp @@ -65,26 +65,10 @@ Y_UNIT_TEST_SUITE(Mirror3of4) { UNIT_ASSERT_VALUES_EQUAL(res->Get()->Status, NKikimrProto::OK); } if (i == 500) { - const TActorId self = runtime->AllocateEdgeActor(1); - auto ev = std::make_unique(); - ev->Record.MutableVSlotId()->SetNodeId(2); - ev->Record.MutableVSlotId()->SetPDiskId(1000); - ev->Record.MutableVSlotId()->SetVSlotId(1000); - runtime->SendToPipe(env.TabletId, self, ev.release(), 0, TTestActorSystem::GetPipeConfigWithRetries()); - auto response = env.WaitForEdgeActorEvent(self); - auto& r = response->Get()->Record; - UNIT_ASSERT_EQUAL(r.GetStatus(), NKikimrProto::OK); + env.Wipe(2, 1000, 1000, TVDiskID(groupId, 1, 0, 1, 0)); } if (i == 600) { - const TActorId self = runtime->AllocateEdgeActor(1); - auto ev = std::make_unique(); - ev->Record.MutableVSlotId()->SetNodeId(3); - ev->Record.MutableVSlotId()->SetPDiskId(1000); - ev->Record.MutableVSlotId()->SetVSlotId(1000); - runtime->SendToPipe(env.TabletId, self, ev.release(), 0, TTestActorSystem::GetPipeConfigWithRetries()); - auto response = env.WaitForEdgeActorEvent(self); - auto& r = response->Get()->Record; - UNIT_ASSERT_EQUAL(r.GetStatus(), NKikimrProto::OK); + env.Wipe(3, 1000, 1000, TVDiskID(groupId, 1, 0, 2, 0)); } } diff --git a/ydb/core/blobstorage/ut_blobstorage/osiris.cpp b/ydb/core/blobstorage/ut_blobstorage/osiris.cpp index 39cbaf9f4a9b..d818edff1c0c 100644 --- a/ydb/core/blobstorage/ut_blobstorage/osiris.cpp +++ b/ydb/core/blobstorage/ut_blobstorage/osiris.cpp @@ -62,15 +62,8 @@ bool DoTestCase(TBlobStorageGroupType::EErasureSpecies erasure, const std::setAllocateEdgeActor(1); - auto ev = std::make_unique(); - auto *slotId = ev->Record.MutableVSlotId(); - slotId->CopyFrom(vslot.GetVSlotId()); - env.Runtime->SendToPipe(env.TabletId, sender, ev.release(), 0, TTestActorSystem::GetPipeConfigWithRetries()); - auto response = env.WaitForEdgeActorEvent(sender); - Y_ABORT_UNLESS(response->Get()->Record.GetStatus() == NKikimrProto::OK); - + const auto& v = vslot.GetVSlotId(); + env.Wipe(v.GetNodeId(), v.GetPDiskId(), v.GetVSlotId(), vdiskId); env.Sim(TDuration::Seconds(30)); } diff --git a/ydb/core/blobstorage/vdisk/common/blobstorage_event_filter.cpp b/ydb/core/blobstorage/vdisk/common/blobstorage_event_filter.cpp index ee912aff02e3..34603f90b722 100644 --- a/ydb/core/blobstorage/vdisk/common/blobstorage_event_filter.cpp +++ b/ydb/core/blobstorage/vdisk/common/blobstorage_event_filter.cpp @@ -54,12 +54,6 @@ namespace NKikimr { TEvBlobStorage::EvControllerUpdateDiskStatus, TEvBlobStorage::EvControllerConfigRequest, TEvBlobStorage::EvControllerConfigResponse, - TEvBlobStorage::EvControllerVDiskStatusSubscribeRequest, - TEvBlobStorage::EvControllerVDiskStatusReport, - TEvBlobStorage::EvControllerGroupStatusRequest, - TEvBlobStorage::EvControllerGroupStatusResponse, - TEvBlobStorage::EvControllerUpdateGroup, - TEvBlobStorage::EvControllerUpdateFaultyDisks, TEvBlobStorage::EvControllerUpdateGroupStat, TEvBlobStorage::EvControllerSelectGroupsResult, diff --git a/ydb/core/mind/bscontroller/config.cpp b/ydb/core/mind/bscontroller/config.cpp index 32ffdcb32c58..0854afdb3a00 100644 --- a/ydb/core/mind/bscontroller/config.cpp +++ b/ydb/core/mind/bscontroller/config.cpp @@ -17,22 +17,21 @@ namespace NKikimr::NBsController { , State(state) {} - void Execute(std::deque>& outbox) { + void Execute() { ApplyUpdates(); for (auto &pair : Services) { const TNodeId &nodeId = pair.first; - if (TNodeInfo *node = Self->FindNode(nodeId); node && node->ConnectedCount) { - auto event = MakeHolder(); + if (TNodeInfo *node = Self->FindNode(nodeId); node && node->ConnectedServerId) { + auto event = std::make_unique(); auto& record = event->Record; pair.second.Swap(&record); record.SetStatus(NKikimrProto::OK); record.SetNodeID(nodeId); record.SetInstanceId(Self->InstanceId); record.SetAvailDomain(AppData()->DomainsInfo->GetDomainUidByTabletId(Self->TabletID())); - outbox.push_back(std::make_unique(MakeBlobStorageNodeWardenID(nodeId), - Self->SelfId(), event.Release())); + State.Outbox.emplace_back(nodeId, std::move(event), 0); } } } @@ -448,7 +447,7 @@ namespace NKikimr::NBsController { } } - TNodeWardenUpdateNotifier(this, state).Execute(state.Outbox); + TNodeWardenUpdateNotifier(this, state).Execute(); state.CheckConsistency(); state.Commit(); @@ -460,7 +459,7 @@ namespace NKikimr::NBsController { } void TBlobStorageController::CommitSelfHealUpdates(TConfigState& state) { - auto ev = MakeHolder(); + auto ev = std::make_unique(); auto sh = MakeHolder(); for (auto&& [base, overlay] : state.Groups.Diff()) { @@ -500,7 +499,7 @@ namespace NKikimr::NBsController { } if (ev->Created || ev->Deleted) { - state.Outbox.push_back(std::make_unique(StatProcessorActorId, SelfId(), ev.Release())); + state.StatProcessorOutbox.push_back(std::move(ev)); } if (sh->GroupsToUpdate) { FillInSelfHealGroups(*sh, &state); @@ -590,8 +589,11 @@ namespace NKikimr::NBsController { } ui64 TBlobStorageController::TConfigState::ApplyConfigUpdates() { - for (auto& msg : Outbox) { - TActivationContext::Send(msg.release()); + for (auto& [nodeId, ev, cookie] : Outbox) { + Self.SendToWarden(nodeId, std::move(ev), cookie); + } + for (auto& ev : StatProcessorOutbox) { + Self.SelfId().Send(Self.StatProcessorActorId, ev.release()); } if (UpdateSelfHealInfoMsg) { diff --git a/ydb/core/mind/bscontroller/config.h b/ydb/core/mind/bscontroller/config.h index bfa0f9e6bfdd..e0e64654da84 100644 --- a/ydb/core/mind/bscontroller/config.h +++ b/ydb/core/mind/bscontroller/config.h @@ -89,7 +89,8 @@ namespace NKikimr { THashSet PDisksToRemove; // outgoing messages - std::deque> Outbox; + std::deque, ui64>> Outbox; + std::deque> StatProcessorOutbox; THolder UpdateSelfHealInfoMsg; // deferred callbacks diff --git a/ydb/core/mind/bscontroller/get_group.cpp b/ydb/core/mind/bscontroller/get_group.cpp index 63d1ce140b63..c9af06f6f17b 100644 --- a/ydb/core/mind/bscontroller/get_group.cpp +++ b/ydb/core/mind/bscontroller/get_group.cpp @@ -4,7 +4,8 @@ namespace NKikimr::NBsController { class TBlobStorageController::TTxGetGroup : public TTransactionBase { TEvBlobStorage::TEvControllerGetGroup::TPtr Request; - std::unique_ptr Response; + std::unique_ptr Response; + TNodeId NodeId = {}; public: TTxGetGroup(TEvBlobStorage::TEvControllerGetGroup::TPtr& ev, TBlobStorageController *controller) @@ -20,27 +21,34 @@ class TBlobStorageController::TTxGetGroup : public TTransactionBaseGet()->Record)); + NodeId = Request->Get()->Record.GetNodeID(); + + if (Request->Cookie != Max() && !Self->ValidateIncomingNodeWardenEvent(*Request)) { + Response = std::make_unique(NKikimrProto::ERROR, NodeId); + return true; + } + const auto& v = Request->Get()->Record.GetGroupIDs(); TSet groupIDsToRead(v.begin(), v.end()); - const TNodeId nodeId = Request->Get()->Record.GetNodeID(); - auto res = std::make_unique(NKikimrProto::OK, nodeId); - Self->ReadGroups(groupIDsToRead, true, res.get(), nodeId); + Response = std::make_unique(NKikimrProto::OK, NodeId); + Self->ReadGroups(groupIDsToRead, true, Response.get(), NodeId); - auto& node = Self->GetNode(nodeId); + auto& node = Self->GetNode(NodeId); for (TGroupId groupId : v) { node.GroupsRequested.insert(groupId); - Self->GroupToNode.emplace(groupId, nodeId); + Self->GroupToNode.emplace(groupId, NodeId); } - Response = std::make_unique(nodeId ? MakeBlobStorageNodeWardenID(nodeId) : Request->Sender, - Self->SelfId(), res.release()); - return true; } void Complete(const TActorContext&) override { - TActivationContext::Send(Response.release()); + if (NodeId) { + Self->SendToWarden(NodeId, std::move(Response), Request->Cookie); + } else { + Self->SendInReply(*Request, std::move(Response)); + } } }; diff --git a/ydb/core/mind/bscontroller/group_reconfigure_wipe.cpp b/ydb/core/mind/bscontroller/group_reconfigure_wipe.cpp index 9a7aff6c7fdf..bbce8a1e5cb2 100644 --- a/ydb/core/mind/bscontroller/group_reconfigure_wipe.cpp +++ b/ydb/core/mind/bscontroller/group_reconfigure_wipe.cpp @@ -1,93 +1,10 @@ #include "impl.h" -namespace NKikimr { -namespace NBsController { - -class TBlobStorageController::TTxGroupReconfigureWipe : public TTransactionBase { -protected: - TEvBlobStorage::TEvControllerGroupReconfigureWipe::TPtr Event; - NKikimrProto::EReplyStatus Status; - TString ErrorReason; - typedef TMap> TResultForNode; - TResultForNode ResultForNode; - -public: - TTxGroupReconfigureWipe(TEvBlobStorage::TEvControllerGroupReconfigureWipe::TPtr &ev, - TBlobStorageController *controller) - : TBase(controller) - , Event(ev) - , Status(NKikimrProto::OK) - {} - - TTxType GetTxType() const override { return NBlobStorageController::TXTYPE_GROUP_RECONFIGURE_WIPE; } - - bool Execute(TTransactionContext &txc, const TActorContext&) override { - STLOG(PRI_DEBUG, BS_CONTROLLER, BSCTXGRW01, "TTxGroupReconfigureWipe execute"); - NIceDb::TNiceDb db(txc.DB); - - Status = NKikimrProto::ERROR; - ResultForNode.clear(); - - auto& record = Event->Get()->Record; - const TVSlotId id(record.GetVSlotId()); - - if (TVSlotInfo *info = Self->FindVSlot(id); !info) { - STLOG(PRI_ERROR, BS_CONTROLLER, BSCTXGRW02, "VSlot does not exist", (VSlotId, id)); - ErrorReason = TStringBuilder() << "VSlotId# " << id << " does not exist"; - } else if (info->Mood != TMood::Normal) { // Reply ERROR if From VSlot is improper mood - STLOG(PRI_ERROR, BS_CONTROLLER, BSCTXGRW03, "VSlot is not in the 'Normal' mood", (VSlotId, id), - (Mood, TMood::Name(TMood::EValue(info->Mood)))); - ErrorReason = TStringBuilder() << "VSlotId# " << id << " is in Mood# " << TMood::Name(TMood::EValue(info->Mood)); - } else { - // TODO(cthulhu): Prohibit more than Max simultaneous reconfigurations on one group - - // Mark VSlot for wipe - info->Mood = TMood::Wipe; - db.Table().Key(id.GetKey()).Update(info->Mood); - - // Prepare results for nodes - if (TNodeInfo *node = Self->FindNode(id.NodeId); node && node->ConnectedCount) { - auto& msg = ResultForNode[id.NodeId]; - msg = MakeHolder(NKikimrProto::OK, id.NodeId); - Self->ReadVSlot(*info, msg.Get()); - TSet groupIDsToRead; - groupIDsToRead.insert(info->GroupId); - Self->ReadGroups(groupIDsToRead, false, msg.Get(), id.NodeId); - for (const TGroupId groupId : groupIDsToRead) { - STLOG(PRI_ERROR, BS_CONTROLLER, BSCTXGRW05, "No configuration for group", (GroupId, groupId)); - } - } - - Status = NKikimrProto::OK; - } - - return true; - } - - void Complete(const TActorContext&) override { - // Send results to nodes - if (Status == NKikimrProto::OK) { - for (auto& [nodeId, msg] : ResultForNode) { - // TODO(cthulhu): Availability Domain !!! - const auto& node = nodeId; - const auto& record = msg->Record; - STLOG(PRI_DEBUG, BS_CONTROLLER, BSCTXGRW07, "Sending update", (NodeId, node), (Message, record)); - TActivationContext::Send(new IEventHandle(MakeBlobStorageNodeWardenID(nodeId), Self->SelfId(), msg.Release())); - } - } - - // Respond - auto response = MakeHolder(Status, ErrorReason); - auto& record = Event->Get()->Record; - STLOG(Status == NKikimrProto::OK ? PRI_DEBUG : PRI_ERROR, BS_CONTROLLER, BSCTXGRW06, "TTxGroupReconfigureWipe complete", - (Status, Status), (Request, record), (Response, response->Record)); - TActivationContext::Send(new IEventHandle(Event->Sender, Self->SelfId(), response.Release(), 0, Event->Cookie)); - } -}; +namespace NKikimr::NBsController { void TBlobStorageController::Handle(TEvBlobStorage::TEvControllerGroupReconfigureWipe::TPtr& ev) { - Execute(new TTxGroupReconfigureWipe(ev, this)); + SendInReply(*ev, std::make_unique(NKikimrProto::ERROR, + "unsupported operation")); } } -} diff --git a/ydb/core/mind/bscontroller/impl.h b/ydb/core/mind/bscontroller/impl.h index adb21035673c..36dcf62c9c22 100644 --- a/ydb/core/mind/bscontroller/impl.h +++ b/ydb/core/mind/bscontroller/impl.h @@ -56,7 +56,6 @@ class TBlobStorageController : public TActor, public TTa class TTxUpdateDiskMetrics; class TTxUpdateGroupLatencies; class TTxGroupMetricsExchange; - class TTxGroupReconfigureWipe; class TTxNodeReport; class TTxUpdateSeenOperational; class TTxConfigCmd; @@ -862,7 +861,8 @@ class TBlobStorageController : public TActor, public TTa public: using Table = Schema::Node; - ui32 ConnectedCount = 0; + TActorId ConnectedServerId; // the latest ServerId who sent RegisterNode + TActorId InterconnectSessionId; Table::NextPDiskID::Type NextPDiskID; TInstant LastConnectTimestamp; TInstant LastDisconnectTimestamp; @@ -1981,10 +1981,67 @@ class TBlobStorageController : public TActor, public TTa } } + bool ValidateIncomingNodeWardenEvent(const IEventHandle& ev) { + auto makeError = [&](TString message) { + STLOG(PRI_ERROR, BS_CONTROLLER, BSC16, "ValidateIncomingNodeWardenEvent error", + (Sender, ev.Sender), (PipeServerId, ev.Recipient), (InterconnectSessionId, ev.InterconnectSession), + (Type, ev.GetTypeRewrite()), (Message, message)); + return false; + }; + + switch (ev.GetTypeRewrite()) { + case TEvBlobStorage::EvControllerRegisterNode: { + if (const auto pipeIt = PipeServerToNode.find(ev.Recipient); pipeIt == PipeServerToNode.end()) { + return makeError("incorrect pipe server"); + } else if (pipeIt->second) { + return makeError("duplicate RegisterNode event"); + } + break; + } + + case TEvBlobStorage::EvControllerGetGroup: + if (ev.Sender == SelfId()) { + break; + } else if (ev.Cookie == Max()) { + break; // for testing purposes + } + [[fallthrough]]; + case TEvBlobStorage::EvControllerUpdateDiskStatus: + case TEvBlobStorage::EvControllerProposeGroupKey: + case TEvBlobStorage::EvControllerUpdateGroupStat: + case TEvBlobStorage::EvControllerScrubQueryStartQuantum: + case TEvBlobStorage::EvControllerScrubQuantumFinished: + case TEvBlobStorage::EvControllerScrubReportQuantumInProgress: + case TEvBlobStorage::EvControllerUpdateNodeDrives: + case TEvBlobStorage::EvControllerNodeReport: { + if (const auto pipeIt = PipeServerToNode.find(ev.Recipient); pipeIt == PipeServerToNode.end()) { + return makeError("incorrect pipe server"); + } else if (const auto& nodeId = pipeIt->second; !nodeId) { + return makeError("no RegisterNode event received"); + } else if (*nodeId != ev.Sender.NodeId()) { + return makeError("NodeId mismatch"); + } else if (TNodeInfo *node = FindNode(*nodeId); !node) { + return makeError("no TNodeInfo record for node"); + } else if (node->InterconnectSessionId != ev.InterconnectSession) { + return makeError("InterconnectSession mismatch"); + } else if (node->ConnectedServerId != ev.Recipient) { + return makeError("pipe server mismatch"); + } + break; + } + } + + return true; + } + void ProcessControllerEvent(TAutoPtr ev) { const ui32 type = ev->GetTypeRewrite(); THPTimer timer; + if (!ValidateIncomingNodeWardenEvent(*ev)) { + return; + } + switch (type) { hFunc(TEvBlobStorage::TEvControllerRegisterNode, Handle); hFunc(TEvBlobStorage::TEvControllerGetGroup, Handle); @@ -2286,10 +2343,12 @@ class TBlobStorageController : public TActor, public TTa void Handle(TEvTabletPipe::TEvServerConnected::TPtr& ev); void Handle(TEvTabletPipe::TEvServerDisconnected::TPtr& ev); - bool OnRegisterNode(const TActorId& serverId, TNodeId nodeId); - void OnWardenConnected(TNodeId nodeId); - void OnWardenDisconnected(TNodeId nodeId); + bool OnRegisterNode(const TActorId& serverId, TNodeId nodeId, TActorId interconnectSessionId); + void OnWardenConnected(TNodeId nodeId, TActorId serverId, TActorId interconnectSessionId); + void OnWardenDisconnected(TNodeId nodeId, TActorId serverId); void EraseKnownDrivesOnDisconnected(TNodeInfo *nodeInfo); + void SendToWarden(TNodeId nodeId, std::unique_ptr ev, ui64 cookie); + void SendInReply(const IEventHandle& query, std::unique_ptr ev); using TVSlotFinder = std::function&)>; diff --git a/ydb/core/mind/bscontroller/node_report.cpp b/ydb/core/mind/bscontroller/node_report.cpp index 6cb9cfbbceb2..5c512940eca9 100644 --- a/ydb/core/mind/bscontroller/node_report.cpp +++ b/ydb/core/mind/bscontroller/node_report.cpp @@ -22,6 +22,10 @@ class TBlobStorageController::TTxNodeReport STLOG(PRI_DEBUG, BS_CONTROLLER, BSCTXNR01, "TTxNodeReport execute"); + if (!Self->ValidateIncomingNodeWardenEvent(*Event)) { + return true; + } + State.emplace(*Self, Self->HostRecords, TActivationContext::Now()); State->CheckConsistency(); diff --git a/ydb/core/mind/bscontroller/propose_group_key.cpp b/ydb/core/mind/bscontroller/propose_group_key.cpp index 9f346b4c0c0a..ed8b8b5d65dd 100644 --- a/ydb/core/mind/bscontroller/propose_group_key.cpp +++ b/ydb/core/mind/bscontroller/propose_group_key.cpp @@ -5,7 +5,7 @@ namespace NBsController { class TBlobStorageController::TTxProposeGroupKey : public TTransactionBase { protected: - NKikimrBlobStorage::TEvControllerProposeGroupKey Proto; + TEvBlobStorage::TEvControllerProposeGroupKey::TPtr Event; NKikimrProto::EReplyStatus Status = NKikimrProto::OK; ui32 NodeId = 0; ui32 GroupId = 0; @@ -15,18 +15,20 @@ class TBlobStorageController::TTxProposeGroupKey : public TTransactionBaseGet()->Record; + NodeId = proto.GetNodeId(); + GroupId = proto.GetGroupId(); + LifeCyclePhase = proto.GetLifeCyclePhase(); + MainKeyId = proto.GetMainKeyId(); + EncryptedGroupKey = proto.GetEncryptedGroupKey(); + MainKeyVersion = proto.GetMainKeyVersion(); + GroupKeyNonce = proto.GetGroupKeyNonce(); } TTxType GetTxType() const override { return NBlobStorageController::TXTYPE_PROPOSE_GROUP_KEY; } @@ -78,6 +80,10 @@ class TBlobStorageController::TTxProposeGroupKey : public TTransactionBaseValidateIncomingNodeWardenEvent(*Event)) { + Status = NKikimrProto::ERROR; + return true; + } Status = NKikimrProto::OK; ReadStep(); if (Status == NKikimrProto::OK) { @@ -99,7 +105,7 @@ class TBlobStorageController::TTxProposeGroupKey : public TTransactionBaseGet()->Record)); } if (!IsAnotherTxInProgress) { // Get groupinfo for the group and send it to all whom it may concern. @@ -113,7 +119,7 @@ void TBlobStorageController::Handle(TEvBlobStorage::TEvControllerProposeGroupKey STLOG(PRI_DEBUG, BS_CONTROLLER, BSCTXPGK11, "Handle TEvControllerProposeGroupKey", (Request, proto)); Y_ABORT_UNLESS(AppData()); NodesAwaitingKeysForGroup[proto.GetGroupId()].insert(proto.GetNodeId()); - Execute(new TTxProposeGroupKey(proto, this)); + Execute(new TTxProposeGroupKey(ev, this)); } } // NBlobStorageController diff --git a/ydb/core/mind/bscontroller/register_node.cpp b/ydb/core/mind/bscontroller/register_node.cpp index 8dabdab993ec..191ca5b975b2 100644 --- a/ydb/core/mind/bscontroller/register_node.cpp +++ b/ydb/core/mind/bscontroller/register_node.cpp @@ -10,7 +10,7 @@ class TBlobStorageController::TTxUpdateNodeDrives { NKikimrBlobStorage::TEvControllerUpdateNodeDrives Record; std::optional State; - std::unique_ptr Response; + std::unique_ptr Result; void UpdateDevicesInfo(TConfigState& state, TEvBlobStorage::TEvControllerNodeServiceSetUpdate* result) { auto nodeId = Record.GetNodeId(); @@ -163,14 +163,14 @@ class TBlobStorageController::TTxUpdateNodeDrives bool Execute(TTransactionContext& txc, const TActorContext&) override { const TNodeId nodeId = Record.GetNodeId(); - auto result = std::make_unique(NKikimrProto::OK, nodeId); + Result = std::make_unique(NKikimrProto::OK, nodeId); State.emplace(*Self, Self->HostRecords, TActivationContext::Now()); State->CheckConsistency(); auto updateIsSuccessful = true; try { - UpdateDevicesInfo(*State, result.get()); + UpdateDevicesInfo(*State, Result.get()); State->CheckConsistency(); } catch (const TExError& e) { updateIsSuccessful = false; @@ -180,16 +180,16 @@ class TBlobStorageController::TTxUpdateNodeDrives "Error during UpdateDevicesInfo after receiving TEvControllerRegisterNode", (TExError, e.what())); } - result->Record.SetInstanceId(Self->InstanceId); - result->Record.SetComprehensive(false); - result->Record.SetAvailDomain(AppData()->DomainsInfo->GetDomainUidByTabletId(Self->TabletID())); - Response = std::make_unique(MakeBlobStorageNodeWardenID(nodeId), Self->SelfId(), result.release(), 0, 0); + Result->Record.SetInstanceId(Self->InstanceId); + Result->Record.SetComprehensive(false); + Result->Record.SetAvailDomain(AppData()->DomainsInfo->GetDomainUidByTabletId(Self->TabletID())); TString error; if (!updateIsSuccessful || (State->Changed() && !Self->CommitConfigUpdates(*State, false, false, false, txc, &error))) { State->Rollback(); State.reset(); } + return true; } @@ -199,8 +199,8 @@ class TBlobStorageController::TTxUpdateNodeDrives State->ApplyConfigUpdates(); State.reset(); } - if (Response) { - TActivationContext::Send(Response.release()); + if (Result) { + Self->SendToWarden(Record.GetNodeId(), std::move(Result), 0); } } }; @@ -209,10 +209,9 @@ class TBlobStorageController::TTxRegisterNode : public TTransactionBase { TEvBlobStorage::TEvControllerRegisterNode::TPtr Request; - std::unique_ptr Response; + std::unique_ptr Response; NKikimrBlobStorage::TEvControllerUpdateNodeDrives UpdateNodeDrivesRecord; - public: TTxRegisterNode(TEvBlobStorage::TEvControllerRegisterNode::TPtr& ev, TBlobStorageController *controller) : TTransactionBase(controller) @@ -225,18 +224,26 @@ class TBlobStorageController::TTxRegisterNode Self->TabletCounters->Cumulative()[NBlobStorageController::COUNTER_REGISTER_NODE_COUNT].Increment(1); TRequestCounter counter(Self->TabletCounters, NBlobStorageController::COUNTER_REGISTER_NODE_USEC); - auto request = std::move(Request); - const auto& record = request->Get()->Record; + const auto& record = Request->Get()->Record; STLOG(PRI_DEBUG, BS_CONTROLLER, BSCTXRN01, "Handle TEvControllerRegisterNode", (Request, record)); + if (!Self->ValidateIncomingNodeWardenEvent(*Request)) { + return true; + } + const TNodeId nodeId = record.GetNodeID(); + if (nodeId != Request->Sender.NodeId()) { + STLOG(PRI_ERROR, BS_CONTROLLER, BSCTXRN07, "NodeId field mismatch", (Request, record), (Sender, Request->Sender)); + return true; + } + UpdateNodeDrivesRecord.SetNodeId(nodeId); for (const auto& data : record.GetDrivesData()) { UpdateNodeDrivesRecord.AddDrivesData()->CopyFrom(data); } - if (!Self->OnRegisterNode(request->Recipient, nodeId)) { + if (!Self->OnRegisterNode(Request->Recipient, nodeId, Request->InterconnectSession)) { return true; } Self->ProcessVDiskStatus(record.GetVDiskStatus()); @@ -253,13 +260,13 @@ class TBlobStorageController::TTxRegisterNode } } - auto res = std::make_unique(NKikimrProto::OK, nodeId); + Response = std::make_unique(NKikimrProto::OK, nodeId); TSet groupIDsToRead; const TPDiskId minPDiskId(TPDiskId::MinForNode(nodeId)); const TVSlotId vslotId = TVSlotId::MinForPDisk(minPDiskId); for (auto it = Self->VSlots.lower_bound(vslotId); it != Self->VSlots.end() && it->first.NodeId == nodeId; ++it) { - Self->ReadVSlot(*it->second, res.get()); + Self->ReadVSlot(*it->second, Response.get()); if (!it->second->IsBeingDeleted()) { groupIDsToRead.insert(it->second->GroupId); } @@ -298,19 +305,18 @@ class TBlobStorageController::TTxRegisterNode } } - Self->ReadGroups(groupIDsToRead, false, res.get(), nodeId); + Self->ReadGroups(groupIDsToRead, false, Response.get(), nodeId); Y_ABORT_UNLESS(groupIDsToRead.empty()); - Self->ReadGroups(groupsToDiscard, true, res.get(), nodeId); + Self->ReadGroups(groupsToDiscard, true, Response.get(), nodeId); for (auto it = Self->PDisks.lower_bound(minPDiskId); it != Self->PDisks.end() && it->first.NodeId == nodeId; ++it) { - Self->ReadPDisk(it->first, *it->second, res.get(), NKikimrBlobStorage::INITIAL); + Self->ReadPDisk(it->first, *it->second, Response.get(), NKikimrBlobStorage::INITIAL); } - res->Record.SetInstanceId(Self->InstanceId); - res->Record.SetComprehensive(true); - res->Record.SetAvailDomain(AppData()->DomainsInfo->GetDomainUidByTabletId(Self->TabletID())); - Response = std::make_unique(request->Sender, Self->SelfId(), res.release(), 0, request->Cookie); + Response->Record.SetInstanceId(Self->InstanceId); + Response->Record.SetComprehensive(true); + Response->Record.SetAvailDomain(AppData()->DomainsInfo->GetDomainUidByTabletId(Self->TabletID())); NIceDb::TNiceDb db(txc.DB); auto& node = Self->GetNode(nodeId); @@ -325,8 +331,10 @@ class TBlobStorageController::TTxRegisterNode } void Complete(const TActorContext&) override { - TActivationContext::Send(Response.release()); - Self->Execute(new TTxUpdateNodeDrives(std::move(UpdateNodeDrivesRecord), Self)); + if (Response) { + Self->SendInReply(*Request, std::move(Response)); + Self->Execute(new TTxUpdateNodeDrives(std::move(UpdateNodeDrivesRecord), Self)); + } } }; @@ -465,7 +473,7 @@ void TBlobStorageController::Handle(TEvTabletPipe::TEvServerConnected::TPtr& ev) void TBlobStorageController::Handle(TEvTabletPipe::TEvServerDisconnected::TPtr& ev) { if (auto it = PipeServerToNode.find(ev->Get()->ServerId); it != PipeServerToNode.end()) { if (auto&& nodeId = it->second) { - OnWardenDisconnected(*nodeId); + OnWardenDisconnected(*nodeId, it->first); } PipeServerToNode.erase(it); } else { @@ -473,23 +481,33 @@ void TBlobStorageController::Handle(TEvTabletPipe::TEvServerDisconnected::TPtr& } } -bool TBlobStorageController::OnRegisterNode(const TActorId& serverId, TNodeId nodeId) { +bool TBlobStorageController::OnRegisterNode(const TActorId& serverId, TNodeId nodeId, TActorId interconnectSessionId) { if (auto it = PipeServerToNode.find(serverId); it != PipeServerToNode.end()) { - if (!it->second) { - it->second = nodeId; - OnWardenConnected(nodeId); - } else { - Y_DEBUG_ABORT_UNLESS(*it->second == nodeId); - } + Y_ABORT_UNLESS(!it->second); + it->second = nodeId; + OnWardenConnected(nodeId, serverId, interconnectSessionId); return true; } else { return false; } } -void TBlobStorageController::OnWardenConnected(TNodeId nodeId) { +void TBlobStorageController::OnWardenConnected(TNodeId nodeId, TActorId serverId, TActorId interconnectSessionId) { TNodeInfo& node = GetNode(nodeId); - ++node.ConnectedCount; + if (node.ConnectedServerId) { // if this is a new connection instead of obsolete one, do reset some logic + for (const TGroupId groupId : std::exchange(node.WaitingForGroups, {})) { + if (TGroupInfo *group = FindGroup(groupId)) { + group->WaitingNodes.erase(nodeId); + } + } + for (TGroupId groupId : std::exchange(node.GroupsRequested, {})) { + GroupToNode.erase(std::make_tuple(groupId, nodeId)); + } + ScrubState.OnNodeDisconnected(nodeId); + EraseKnownDrivesOnDisconnected(&node); + } + node.ConnectedServerId = serverId; + node.InterconnectSessionId = interconnectSessionId; for (auto it = PDisks.lower_bound(TPDiskId::MinForNode(nodeId)); it != PDisks.end() && it->first.NodeId == nodeId; ++it) { it->second->UpdateOperational(true); @@ -499,11 +517,13 @@ void TBlobStorageController::OnWardenConnected(TNodeId nodeId) { node.LastConnectTimestamp = TInstant::Now(); } -void TBlobStorageController::OnWardenDisconnected(TNodeId nodeId) { +void TBlobStorageController::OnWardenDisconnected(TNodeId nodeId, TActorId serverId) { TNodeInfo& node = GetNode(nodeId); - if (--node.ConnectedCount) { - return; // there are still some connections from this NW + if (node.ConnectedServerId != serverId) { + return; // a race } + node.ConnectedServerId = {}; + node.InterconnectSessionId = {}; for (const TGroupId groupId : std::exchange(node.WaitingForGroups, {})) { if (TGroupInfo *group = FindGroup(groupId)) { @@ -554,4 +574,25 @@ void TBlobStorageController::EraseKnownDrivesOnDisconnected(TNodeInfo *nodeInfo) nodeInfo->KnownDrives.clear(); } +void TBlobStorageController::SendToWarden(TNodeId nodeId, std::unique_ptr ev, ui64 cookie) { + Y_ABORT_UNLESS(nodeId); + if (auto *node = FindNode(nodeId); node && node->ConnectedServerId) { + auto h = std::make_unique(MakeBlobStorageNodeWardenID(nodeId), SelfId(), ev.release(), 0, cookie); + if (node->InterconnectSessionId) { + h->Rewrite(TEvInterconnect::EvForward, node->InterconnectSessionId); + } + TActivationContext::Send(h.release()); + } else { + STLOG(PRI_WARN, BS_CONTROLLER, BSC17, "SendToWarden dropped event", (NodeId, nodeId), (Type, ev->Type())); + } +} + +void TBlobStorageController::SendInReply(const IEventHandle& query, std::unique_ptr ev) { + auto h = std::make_unique(query.Sender, SelfId(), ev.release(), 0, query.Cookie); + if (query.InterconnectSession) { + h->Rewrite(TEvInterconnect::EvForward, query.InterconnectSession); + } + TActivationContext::Send(h.release()); +} + } // NKikimr::NBsController diff --git a/ydb/core/mind/bscontroller/ut_bscontroller/main.cpp b/ydb/core/mind/bscontroller/ut_bscontroller/main.cpp index 54618a14d8ef..317aa32b873b 100644 --- a/ydb/core/mind/bscontroller/ut_bscontroller/main.cpp +++ b/ydb/core/mind/bscontroller/ut_bscontroller/main.cpp @@ -102,10 +102,18 @@ struct TEnvironmentSetup { void RegisterNode() { for (ui32 i = 1; i <= NodeCount; ++i) { - const TActorId self = Runtime->AllocateEdgeActor(); - auto ev = MakeHolder(i, TVector{}, TVector{}, TVector{}); - Runtime->SendToPipe(TabletId, self, ev.Release(), NodeId, GetPipeConfigWithRetries()); - auto response = Runtime->GrabEdgeEventRethrow(self); + ui32 nodeIndex; + for (nodeIndex = 0; nodeIndex < Runtime->GetNodeCount(); ++nodeIndex) { + if (Runtime->GetNodeId(nodeIndex) == i) { + break; + } + } + if (nodeIndex != Runtime->GetNodeCount()) { + const TActorId self = Runtime->AllocateEdgeActor(nodeIndex); + auto ev = MakeHolder(i, TVector{}, TVector{}, TVector{}); + Runtime->SendToPipe(TabletId, self, ev.Release(), nodeIndex, GetPipeConfigWithRetries()); + auto response = Runtime->GrabEdgeEventRethrow(self); + } } } From 89bfbfd7954d7f43f5b06388b45a69f0c01d304c Mon Sep 17 00:00:00 2001 From: Nikolay Shestakov Date: Tue, 9 Apr 2024 22:14:32 +0500 Subject: [PATCH 105/117] fix partition counter value (#3587) --- ydb/core/persqueue/partition.cpp | 10 +++++----- 1 file changed, 5 insertions(+), 5 deletions(-) diff --git a/ydb/core/persqueue/partition.cpp b/ydb/core/persqueue/partition.cpp index d8f90cb3de79..c841fbf6bac6 100644 --- a/ydb/core/persqueue/partition.cpp +++ b/ydb/core/persqueue/partition.cpp @@ -87,7 +87,7 @@ TString TPartition::LogPrefix() const { bool TPartition::CanWrite() const { if (PartitionConfig == nullptr) { - // Old format without AllPartitions configuration field. + // Old format without AllPartitions configuration field. // It is not split/merge partition. return true; } @@ -273,7 +273,7 @@ ui64 TPartition::ImportantClientsMinOffset() const { minOffset = Min(minOffset, curOffset); } - return minOffset; + return minOffset; } void TPartition::HandleWakeup(const TActorContext& ctx) { @@ -552,7 +552,7 @@ void TPartition::InitComplete(const TActorContext& ctx) { PartitionCountersLabeled->GetCounters()[METRIC_INIT_TIME] = InitDuration.MilliSeconds(); PartitionCountersLabeled->GetCounters()[METRIC_LIFE_TIME] = CreationTime.MilliSeconds(); PartitionCountersLabeled->GetCounters()[METRIC_PARTITIONS] = 1; - PartitionCountersLabeled->GetCounters()[METRIC_PARTITIONS_TOTAL] = Config.PartitionIdsSize(); + PartitionCountersLabeled->GetCounters()[METRIC_PARTITIONS_TOTAL] = std::max(Config.PartitionIdsSize(), Config.PartitionsSize()); ctx.Send(Tablet, new TEvPQ::TEvPartitionLabeledCounters(Partition, *PartitionCountersLabeled)); } UpdateUserInfoEndOffset(ctx.Now()); @@ -969,7 +969,7 @@ void TPartition::Handle(TEvPQ::TEvBlobResponse::TPtr& ev, const TActorContext& c auto it = ReadInfo.find(cookie); Y_ABORT_UNLESS(it != ReadInfo.end()); - + TReadInfo info = std::move(it->second); ReadInfo.erase(it); @@ -980,7 +980,7 @@ void TPartition::Handle(TEvPQ::TEvBlobResponse::TPtr& ev, const TActorContext& c info.Destination, GetSizeLag(info.Offset), Tablet, Config.GetMeteringMode() )); const auto& resp = dynamic_cast(answer.Event.Get())->Response; - + if (HasError(*ev->Get())) { if (info.IsSubscription) { TabletCounters.Cumulative()[COUNTER_PQ_READ_SUBSCRIPTION_ERROR].Increment(1); From 0585aac220a3e56fddfe743e345b21231aaa98c2 Mon Sep 17 00:00:00 2001 From: Sergey Veselov Date: Wed, 10 Apr 2024 14:50:58 +0300 Subject: [PATCH 106/117] Fix ThrottlingException raising in YMQ when doing GetQueueUrl with drained queue list budget in 24-1 (#3606) --- ydb/core/ymq/actor/action.h | 21 +++++---- .../sqs/cloud/test_yandex_cloud_mode.py | 47 +++++++++++++++++++ 2 files changed, 58 insertions(+), 10 deletions(-) diff --git a/ydb/core/ymq/actor/action.h b/ydb/core/ymq/actor/action.h index fcc52846eada..8ea1cb814c64 100644 --- a/ydb/core/ymq/actor/action.h +++ b/ydb/core/ymq/actor/action.h @@ -630,22 +630,23 @@ class TActionActor } } - if (ev->Get()->Throttled) { - MakeError(MutableErrorDesc(), NErrors::THROTTLING_EXCEPTION, "Too many requests for nonexistent queue."); - SendReplyAndDie(); - return; - } - if (ev->Get()->Fail) { MakeError(MutableErrorDesc(), NErrors::INTERNAL_FAILURE, "Failed to get configuration."); SendReplyAndDie(); return; } - if (TDerived::NeedExistingQueue() && !ev->Get()->QueueExists) { - MakeError(MutableErrorDesc(), NErrors::NON_EXISTENT_QUEUE); - SendReplyAndDie(); - return; + if (TDerived::NeedExistingQueue()) { + if (ev->Get()->Throttled) { + MakeError(MutableErrorDesc(), NErrors::THROTTLING_EXCEPTION, "Too many requests for nonexistent queue."); + SendReplyAndDie(); + return; + } + if (!ev->Get()->QueueExists) { + MakeError(MutableErrorDesc(), NErrors::NON_EXISTENT_QUEUE); + SendReplyAndDie(); + return; + } } bool isACLProtectedAccount = Cfg().GetForceAccessControl(); diff --git a/ydb/tests/functional/sqs/cloud/test_yandex_cloud_mode.py b/ydb/tests/functional/sqs/cloud/test_yandex_cloud_mode.py index c8fa26b7697d..415fcc54969d 100644 --- a/ydb/tests/functional/sqs/cloud/test_yandex_cloud_mode.py +++ b/ydb/tests/functional/sqs/cloud/test_yandex_cloud_mode.py @@ -838,3 +838,50 @@ def test_cloud_double_create_queue(self, is_fifo, tables_format): time.sleep(1) queue_url2 = self._sqs_api.create_queue(self.queue_name, is_fifo=is_fifo) assert queue_url1 == queue_url2, f'{queue_url1} vs {queue_url2}' + + @pytest.mark.parametrize(**TABLES_FORMAT_PARAMS) + @pytest.mark.parametrize(**IS_FIFO_PARAMS) + def test_not_throttling_with_custom_queue_name(self, is_fifo, tables_format): + self._init_with_params(is_fifo, tables_format) + + self._sqs_api = self._create_api_for_user( + user_name='ignored', + raise_on_error=True, + force_private=True, + iam_token=self.iam_token, + folder_id=self.folder_id, + ) + + custom_queue_name = 'MyCustomQueue' + queue_url = self._sqs_api.create_queue( + queue_name=self.queue_name, + private_api=True, + custom_name=custom_queue_name, + ) + + nonexistent_queue_url = queue_url.replace(self.queue_name, self.queue_name + '_nonex') + + def get_attributes_of_nonexistent_queue(): + self._sqs_api.get_queue_attributes(nonexistent_queue_url) + + # Draining budget + for _ in range(16): + try: + get_attributes_of_nonexistent_queue() + except Exception: + pass + + # Check that there is no more budget + assert_that( + get_attributes_of_nonexistent_queue, + raises( + RuntimeError, + pattern=".*ThrottlingException.*" + ) + ) + + # Check that getting queue url with custom name still works + assert_that( + lambda: self._sqs_api.get_queue_url(custom_queue_name), + not_(raises(RuntimeError)) + ) From e2f14c41adb988c31368ba1d01498e2af3a7adb3 Mon Sep 17 00:00:00 2001 From: Alexander Rutkovsky Date: Thu, 11 Apr 2024 09:46:07 +0300 Subject: [PATCH 107/117] Fix static group status calculation logic (merge from main) (#3632) --- ydb/core/mind/bscontroller/register_node.cpp | 1 + 1 file changed, 1 insertion(+) diff --git a/ydb/core/mind/bscontroller/register_node.cpp b/ydb/core/mind/bscontroller/register_node.cpp index 191ca5b975b2..1b9bf3a2a73f 100644 --- a/ydb/core/mind/bscontroller/register_node.cpp +++ b/ydb/core/mind/bscontroller/register_node.cpp @@ -554,6 +554,7 @@ void TBlobStorageController::OnWardenDisconnected(TNodeId nodeId, TActorId serve } for (auto it = StaticVSlots.lower_bound(startingId); it != StaticVSlots.end() && it->first.NodeId == nodeId; ++it) { it->second.VDiskStatus = NKikimrBlobStorage::EVDiskStatus::ERROR; + it->second.ReadySince = TMonotonic::Max(); } if (sh->VDiskStatusUpdate) { Send(SelfHealId, sh.Release()); From 0ef672974c1eeed53c9f2ce8666a3e1728661fa3 Mon Sep 17 00:00:00 2001 From: alexnick88 Date: Fri, 12 Apr 2024 10:48:15 +0300 Subject: [PATCH 108/117] do not check explicit sources every cleanup (#3674) --- ydb/core/persqueue/sourceid.cpp | 20 +++++++++++--------- ydb/core/persqueue/sourceid.h | 2 +- ydb/core/persqueue/ut/sourceid_ut.cpp | 20 ++++++++++++++++++++ 3 files changed, 32 insertions(+), 10 deletions(-) diff --git a/ydb/core/persqueue/sourceid.cpp b/ydb/core/persqueue/sourceid.cpp index e2176d8c3376..07a0d7895478 100644 --- a/ydb/core/persqueue/sourceid.cpp +++ b/ydb/core/persqueue/sourceid.cpp @@ -253,7 +253,7 @@ void TSourceIdStorage::DeregisterSourceId(const TString& sourceId) { ExplicitSourceIds.erase(sourceId); } - SourceIdsByOffset.erase(std::make_pair(it->second.Offset, sourceId)); + SourceIdsByOffset[it->second.Explicit].erase(std::make_pair(it->second.Offset, sourceId)); InMemorySourceIds.erase(it); auto jt = SourceIdOwners.find(sourceId); @@ -277,7 +277,7 @@ bool TSourceIdStorage::DropOldSourceIds(TEvKeyValue::TEvRequest* request, TInsta const auto ttl = TDuration::Seconds(config.GetSourceIdLifetimeSeconds()); ui32 size = request->Record.ByteSize(); - for (const auto& [offset, sourceId] : SourceIdsByOffset) { + for (const auto& [offset, sourceId] : SourceIdsByOffset[0]) { if (offset >= startOffset && toDelOffsets.size() >= maxDeleteSourceIds) { break; } @@ -323,7 +323,7 @@ bool TSourceIdStorage::DropOldSourceIds(TEvKeyValue::TEvRequest* request, TInsta size_t res = InMemorySourceIds.erase(t.second); Y_ABORT_UNLESS(res == 1); // delete sourceID from offsets - res = SourceIdsByOffset.erase(t); + res = SourceIdsByOffset[0].erase(t); Y_ABORT_UNLESS(res == 1); // save owners to drop and delete records from map auto it = SourceIdOwners.find(t.second); @@ -372,14 +372,14 @@ void TSourceIdStorage::RegisterSourceIdInfo(const TString& sourceId, TSourceIdIn auto it = InMemorySourceIds.find(sourceId); if (it != InMemorySourceIds.end()) { if (!load || it->second.Offset < sourceIdInfo.Offset) { - const auto res = SourceIdsByOffset.erase(std::make_pair(it->second.Offset, sourceId)); + const auto res = SourceIdsByOffset[sourceIdInfo.Explicit].erase(std::make_pair(it->second.Offset, sourceId)); Y_ABORT_UNLESS(res == 1); } else { return; } } - const bool res = SourceIdsByOffset.emplace(sourceIdInfo.Offset, sourceId).second; + const bool res = SourceIdsByOffset[sourceIdInfo.Explicit].emplace(sourceIdInfo.Offset, sourceId).second; Y_ABORT_UNLESS(res); if (sourceIdInfo.Explicit) { @@ -421,10 +421,12 @@ void TSourceIdStorage::MarkOwnersForDeletedSourceId(THashMapsecond); - Y_ABORT_UNLESS(it != InMemorySourceIds.end()); - ds = Min(ds, it->second.WriteTimestamp); + for (ui32 i = 0 ; i < 2; ++i) { + if (!SourceIdsByOffset[i].empty()) { + auto it = InMemorySourceIds.find(SourceIdsByOffset[i].begin()->second); + Y_ABORT_UNLESS(it != InMemorySourceIds.end()); + ds = Min(ds, it->second.WriteTimestamp); + } } return ds; diff --git a/ydb/core/persqueue/sourceid.h b/ydb/core/persqueue/sourceid.h index 897014363f29..19d9b908f6db 100644 --- a/ydb/core/persqueue/sourceid.h +++ b/ydb/core/persqueue/sourceid.h @@ -108,7 +108,7 @@ class TSourceIdStorage: private THeartbeatProcessor { TSourceIdMap InMemorySourceIds; THashMap SourceIdOwners; TVector OwnersToDrop; - TSet> SourceIdsByOffset; + TSet> SourceIdsByOffset[2]; // used to track heartbeats THashSet ExplicitSourceIds; diff --git a/ydb/core/persqueue/ut/sourceid_ut.cpp b/ydb/core/persqueue/ut/sourceid_ut.cpp index 43164c888c50..31853ccc9f4c 100644 --- a/ydb/core/persqueue/ut/sourceid_ut.cpp +++ b/ydb/core/persqueue/ut/sourceid_ut.cpp @@ -460,6 +460,26 @@ Y_UNIT_TEST_SUITE(TSourceIdTests) { } } + Y_UNIT_TEST(ExpensiveCleanup) { + TSourceIdStorage storage; + ui64 offset = 0; + + // initial info w/o heartbeats + for (ui32 i = 1; i <= 100000; ++i) { + storage.RegisterSourceId(TestSourceId(i), MakeExplicitSourceIdInfo(++offset)); + } + + NKikimrPQ::TPartitionConfig config; + config.SetSourceIdLifetimeSeconds(TDuration::Hours(1).Seconds()); + + auto request = MakeHolder(); + for (ui32 i = 0; i < 1000; ++i) { + Cerr << "Iteration " << i << "\n"; + const auto dropped = storage.DropOldSourceIds(request.Get(), TInstant::Hours(2), 1'000'000, TPartitionId(TestPartition), config); + UNIT_ASSERT_EQUAL(dropped, false); + } + + } } // TSourceIdTests } // namespace NKikimr::NPQ From 68050f512584de676e8604b7996798d7ceedda07 Mon Sep 17 00:00:00 2001 From: ildar-khisambeev Date: Mon, 15 Apr 2024 13:05:11 +0300 Subject: [PATCH 109/117] 24-1 cherry-pick remove redundant checks (#1417) (#3700) --- .../persqueue/topic_parser/topic_parser.cpp | 30 +++++-------------- .../ut/topic_names_converter_ut.cpp | 5 ++-- .../persqueue_v1/actors/schema_actors.cpp | 30 ++++++++----------- .../persqueue_v1/persqueue_compat_ut.cpp | 6 ++-- 4 files changed, 28 insertions(+), 43 deletions(-) diff --git a/ydb/library/persqueue/topic_parser/topic_parser.cpp b/ydb/library/persqueue/topic_parser/topic_parser.cpp index 680ea2b871ae..dec46a7d8034 100644 --- a/ydb/library/persqueue/topic_parser/topic_parser.cpp +++ b/ydb/library/persqueue/topic_parser/topic_parser.cpp @@ -320,7 +320,7 @@ bool TDiscoveryConverter::BuildFromFederationPath(const TString& rootPrefix) { auto res = topic.TrySplit("/", fst, snd); CHECK_SET_VALID(res, TStringBuilder() << "Could not split federation path: " << OriginalTopic, return false); Account_ = fst; - + if (!ParseModernPath(snd)) return false; if (!BuildFromShortModernName()) { @@ -341,7 +341,7 @@ bool TDiscoveryConverter::BuildFromFederationPath(const TString& rootPrefix) { bool TDiscoveryConverter::TryParseModernMirroredPath(TStringBuf path) { if (!path.Contains("-mirrored-from-")) { - CHECK_SET_VALID(!path.Contains("mirrored-from"), "Federation topics cannot contain 'mirrored-from' in name unless this is a mirrored topic", return false); + CHECK_SET_VALID(!path.Contains("mirrored-from"), "Federation topics cannot contain 'mirrored-from' in name unless this is a mirrored topic", return false); return false; } TStringBuf fst, snd; @@ -447,7 +447,7 @@ bool TDiscoveryConverter::BuildFromLegacyName(const TString& rootPrefix, bool fo return false); } if (Dc.empty() && !hasDcInName) { - CHECK_SET_VALID(!FstClass, TStringBuilder() << "Internal error: FirstClass mode enabled, but trying to parse Legacy-style name: " + CHECK_SET_VALID(!FstClass, TStringBuilder() << "Internal error: FirstClass mode enabled, but trying to parse Legacy-style name: " << OriginalTopic, return false;); CHECK_SET_VALID(!LocalDc.empty(), "Cannot determine DC: should specify either in topic name, Dc option or LocalDc option", @@ -466,7 +466,7 @@ bool TDiscoveryConverter::BuildFromLegacyName(const TString& rootPrefix, bool fo Dc = fst; topic = snd; } else { - CHECK_SET_VALID(!Dc.empty(), TStringBuilder() << "Internal error: Could not determine DC (despite beleiving the name contins one) for topic " + CHECK_SET_VALID(!Dc.empty(), TStringBuilder() << "Internal error: Could not determine DC (despite beleiving the name contins one) for topic " << OriginalTopic, return false;); TStringBuilder builder; builder << "rt3." << Dc << "--" << topic; @@ -513,7 +513,7 @@ bool TDiscoveryConverter::BuildFromLegacyName(const TString& rootPrefix, bool fo topicName = topic; } modernName << topicName; - CHECK_SET_VALID(!Dc.empty(), TStringBuilder() << "Internal error: Could not determine DC for topic: " + CHECK_SET_VALID(!Dc.empty(), TStringBuilder() << "Internal error: Could not determine DC for topic: " << OriginalTopic, return false); bool isMirrored = (!LocalDc.empty() && Dc != LocalDc); @@ -522,7 +522,7 @@ bool TDiscoveryConverter::BuildFromLegacyName(const TString& rootPrefix, bool fo } else { fullModernName << topicName; } - CHECK_SET_VALID(!fullLegacyName.empty(), TStringBuilder() << "Could not form a full legacy name for topic: " + CHECK_SET_VALID(!fullLegacyName.empty(), TStringBuilder() << "Could not form a full legacy name for topic: " << OriginalTopic, return false); ShortLegacyName = shortLegacyName; @@ -669,21 +669,7 @@ TTopicConverterPtr TTopicNameConverter::ForFederation( if (!res->IsValid()) { return res; } - if (parsed) { - Y_ABORT_UNLESS(!res->Dc.empty()); - if (!localDc.empty() && localDc == res->Dc) { - res->Valid = false; - res->Reason = TStringBuilder() << "Topic in modern mirrored-like style: " << schemeName - << " cannot be created in the same cluster " << res->Dc; - return res; - } - } if (isLocal) { - if(parsed) { - res->Valid = false; - res->Reason = TStringBuilder() << "Topic in modern mirrored-like style: " << schemeName << ", created as local"; - return res; - } if (localDc.empty()) { res->Valid = false; res->Reason = "Local DC option is mandatory when creating local modern-style topic"; @@ -694,7 +680,8 @@ TTopicConverterPtr TTopicNameConverter::ForFederation( if (!ok) { return res; } - } else { + } + else { if (!parsed) { res->Valid = false; res->Reason = TStringBuilder() << "Topic in modern style with non-mirrored-name: " << schemeName @@ -943,4 +930,3 @@ TConverterFactoryPtr TTopicsListController::GetConverterFactory() const { }; } // namespace NPersQueue - diff --git a/ydb/library/persqueue/topic_parser/ut/topic_names_converter_ut.cpp b/ydb/library/persqueue/topic_parser/ut/topic_names_converter_ut.cpp index 55f28de809b4..a71bddd43aaf 100644 --- a/ydb/library/persqueue/topic_parser/ut/topic_names_converter_ut.cpp +++ b/ydb/library/persqueue/topic_parser/ut/topic_names_converter_ut.cpp @@ -175,7 +175,7 @@ Y_UNIT_TEST_SUITE(DiscoveryConverterTest) { ); UNIT_ASSERT_VALUES_EQUAL(converter->GetFullModernName(), "account/account"); UNIT_ASSERT_VALUES_EQUAL(converter->GetSecondaryPath("account"), "/account/account/account"); - + converter = converterFactory.MakeDiscoveryConverter( "account/", {}, "dc1", "account" ); @@ -431,10 +431,11 @@ Y_UNIT_TEST_SUITE(TopicNameConverterForCPTest) { ); UNIT_ASSERT(!converter->IsValid()); + // this is valid, corresponding check relaxed converter = TTopicNameConverter::ForFederation( "", "", "topic-mirrored-from-sas", "/LbCommunal/account", "/LbCommunal/account", true, "sas", "account" ); - UNIT_ASSERT(!converter->IsValid()); + UNIT_ASSERT(converter->IsValid()); converter = TTopicNameConverter::ForFederation( "", "", "topic-mirrored-from-", "/LbCommunal/account", "/LbCommunal/account", true, "sas", "account" diff --git a/ydb/services/persqueue_v1/actors/schema_actors.cpp b/ydb/services/persqueue_v1/actors/schema_actors.cpp index eba8c06f68d2..636f7b4e2041 100644 --- a/ydb/services/persqueue_v1/actors/schema_actors.cpp +++ b/ydb/services/persqueue_v1/actors/schema_actors.cpp @@ -396,10 +396,6 @@ void TCreateTopicActor::FillProposeRequest(TEvTxUserProxy::TEvProposeTransaction << "' instead of " << LocalCluster, Ydb::PersQueue::ErrorCode::BAD_REQUEST)); return RespondWithCode(Ydb::StatusIds::BAD_REQUEST); } - if (Count(Clusters, config.GetDC()) == 0 && !Clusters.empty()) { - Request_->RaiseIssue(FillIssue(TStringBuilder() << "Unknown cluster '" << config.GetDC() << "'", Ydb::PersQueue::ErrorCode::BAD_REQUEST)); - return RespondWithCode(Ydb::StatusIds::BAD_REQUEST); - } } @@ -596,7 +592,7 @@ void TDescribeTopicActorImpl::Handle(TEvPQProxy::TEvRequestTablet::TPtr& ev, con Y_ABORT_UNLESS(RequestsInfly > 0); --RequestsInfly; } - + RequestTablet(tabletInfo, ctx); } @@ -635,7 +631,7 @@ void TDescribeTopicActorImpl::RequestBalancer(const TActorContext& ctx) { GotLocation = true; } - if (Settings.Mode == TDescribeTopicActorSettings::EMode::DescribeConsumer && Settings.RequireStats) { + if (Settings.Mode == TDescribeTopicActorSettings::EMode::DescribeConsumer && Settings.RequireStats) { if (!GotReadSessions) { RequestReadSessionsInfo(ctx); } @@ -671,7 +667,7 @@ void TDescribeTopicActorImpl::RequestPartitionsLocation(const TActorContext& ctx return RaiseError( TStringBuilder() << "No partition " << Settings.Partitions[0] << " in topic", Ydb::PersQueue::ErrorCode::BAD_REQUEST, Ydb::StatusIds::BAD_REQUEST, ctx - ); + ); } auto res = partIds.insert(p); if (res.second) { @@ -705,7 +701,7 @@ void TDescribeTopicActorImpl::Handle(NKikimr::TEvPersQueue::TEvStatusResponse::T auto& record = ev->Get()->Record; bool doRestart = (record.PartResultSize() == 0); - + for (auto& partResult : record.GetPartResult()) { if (partResult.GetStatus() == NKikimrPQ::TStatusResponse::STATUS_INITIALIZING || partResult.GetStatus() == NKikimrPQ::TStatusResponse::STATUS_UNKNOWN) { @@ -917,7 +913,7 @@ bool TDescribeTopicActor::ApplyResponse( } return true; } - + void TDescribeTopicActor::Reply(const TActorContext& ctx) { @@ -1030,7 +1026,7 @@ bool TDescribeConsumerActor::ApplyResponse( } return true; } - + bool FillConsumerProto(Ydb::Topic::Consumer *rr, const NKikimrPQ::TPQTabletConfig& config, ui32 i, const NActors::TActorContext& ctx, Ydb::StatusIds::StatusCode& status, TString& error) @@ -1272,11 +1268,11 @@ bool TDescribeTopicActorImpl::ProcessTablets( Tablets[pi.GetTabletId()].Partitions.push_back(pi.GetPartitionId()); Tablets[pi.GetTabletId()].TabletId = pi.GetTabletId(); } - + for (auto& pair : Tablets) { RequestTablet(pair.second, ctx); } - + if (RequestsInfly == 0) { Reply(ctx); return false; @@ -1332,7 +1328,7 @@ void TDescribePartitionActor::Bootstrap(const NActors::TActorContext& ctx) void TDescribePartitionActor::StateWork(TAutoPtr& ev) { switch (ev->GetTypeRewrite()) { - default: + default: if (!TDescribeTopicActorImpl::StateWork(ev, ActorContext())) { TBase::StateWork(ev); }; @@ -1359,12 +1355,12 @@ void TDescribePartitionActor::ApplyResponse(TTabletInfo&, NKikimr::TEvPersQueue: void TDescribePartitionActor::ApplyResponse(TTabletInfo& tabletInfo, NKikimr::TEvPersQueue::TEvStatusResponse::TPtr& ev, const TActorContext&) { auto* partResult = Result.mutable_partition(); - + const auto& record = ev->Get()->Record; for (auto partData : record.GetPartResult()) { if ((ui32)partData.GetPartition() != Settings.Partitions[0]) continue; - + Y_ABORT_UNLESS((ui32)(partData.GetPartition()) == Settings.Partitions[0]); partResult->set_partition_id(partData.GetPartition()); partResult->set_active(true); @@ -1411,7 +1407,7 @@ void TDescribePartitionActor::Reply(const TActorContext& ctx) { using namespace NIcNodeCache; -TPartitionsLocationActor::TPartitionsLocationActor(const TGetPartitionsLocationRequest& request, const TActorId& requester) +TPartitionsLocationActor::TPartitionsLocationActor(const TGetPartitionsLocationRequest& request, const TActorId& requester) : TBase(request, requester) , TDescribeTopicActorImpl(TDescribeTopicActorSettings::GetPartitionsLocation(request.PartitionIds)) { @@ -1429,7 +1425,7 @@ void TPartitionsLocationActor::Bootstrap(const NActors::TActorContext&) void TPartitionsLocationActor::StateWork(TAutoPtr& ev) { switch (ev->GetTypeRewrite()) { hFunc(TEvICNodesInfoCache::TEvGetAllNodesInfoResponse, Handle); - default: + default: if (!TDescribeTopicActorImpl::StateWork(ev, ActorContext())) { TBase::StateWork(ev); }; diff --git a/ydb/services/persqueue_v1/persqueue_compat_ut.cpp b/ydb/services/persqueue_v1/persqueue_compat_ut.cpp index 1cc7a80d50b7..82c431d69d6a 100644 --- a/ydb/services/persqueue_v1/persqueue_compat_ut.cpp +++ b/ydb/services/persqueue_v1/persqueue_compat_ut.cpp @@ -174,13 +174,15 @@ Y_UNIT_TEST_SUITE(TPQCompatTest) { // Local topic with client write disabled testServer.CreateTopic("/Root/LbCommunal/some-topic", "account", false, true); // Non-local topic with client write enabled - testServer.CreateTopic("/Root/LbCommunal/some-topic-mirrored-from-dc2", "account", true, true); testServer.CreateTopic("/Root/LbCommunal/.some-topic/mirrored-from-dc2", "account", true, true); + // this validation was relaxed + testServer.CreateTopic("/Root/LbCommunal/some-topic-mirrored-from-dc2", "account", true, false); // No account testServer.CreateTopic("/Root/LbCommunal/some-topic", "", true, true); // Mirrored-from local testServer.CreateTopic("/Root/LbCommunal/.some-topic/mirrored-from-dc1", "account", false, true); - testServer.CreateTopic("/Root/LbCommunal/some-topic-mirrored-from-dc1", "account", false, true); + // this validation was relaxed + testServer.CreateTopic("/Root/LbCommunal/some-topic-mirrored-from-dc1", "account", false, false); // Bad mirrored names testServer.CreateTopic("/Root/LbCommunal/.some-topic/some-topic", "account", false, true); // Mirrored-from non-existing From 3527639e4e63c5e51a9eca32e9adba960db90ec6 Mon Sep 17 00:00:00 2001 From: ildar-khisambeev Date: Mon, 15 Apr 2024 13:05:21 +0300 Subject: [PATCH 110/117] Cherry pick print sensitive (#3698) Co-authored-by: Nikolay Shestakov --- ydb/core/client/server/grpc_server.cpp | 24 ++------------ ydb/core/grpc_streaming/grpc_streaming.h | 27 ++------------- ydb/core/persqueue/partition_monitoring.cpp | 11 ++++++- ydb/core/persqueue/ya.make | 1 + ydb/core/protos/flat_tx_scheme.proto | 3 +- ydb/core/protos/pqconfig.proto | 8 +++-- .../tx/schemeshard/schemeshard__operation.cpp | 16 +++++++-- ydb/core/tx/schemeshard/ya.make | 1 + ydb/library/grpc/server/actors/ya.make | 1 + ydb/library/grpc/server/logger.h | 23 +++++++++++++ ydb/library/grpc/server/ya.make | 2 +- .../api/protos/draft/persqueue_common.proto | 7 ++-- ydb/public/api/protos/ydb_persqueue_v1.proto | 9 ++--- ydb/public/api/protos/ydb_topic.proto | 33 ++++++++++--------- 14 files changed, 88 insertions(+), 78 deletions(-) diff --git a/ydb/core/client/server/grpc_server.cpp b/ydb/core/client/server/grpc_server.cpp index 95079d6bc7dc..e510fdfbe3ee 100644 --- a/ydb/core/client/server/grpc_server.cpp +++ b/ydb/core/client/server/grpc_server.cpp @@ -11,8 +11,6 @@ #include -#include - #include #include #include @@ -266,15 +264,8 @@ class TSimpleRequest } void Finish(const TOut& resp, ui32 status) { - auto makeResponseString = [&] { - TString x; - google::protobuf::TextFormat::Printer printer; - printer.SetSingleLineMode(true); - printer.PrintToString(resp, &x); - return x; - }; LOG_DEBUG(ActorSystem, NKikimrServices::GRPC_SERVER, "[%p] issuing response Name# %s data# %s peer# %s", this, - Name, makeResponseString().data(), GetPeerName().c_str()); + Name, NYdbGrpc::FormatMessage(resp).data(), GetPeerName().c_str()); ResponseSize = resp.ByteSize(); ResponseStatus = status; StateFunc = &TSimpleRequest::FinishDone; @@ -300,19 +291,8 @@ class TSimpleRequest bool RequestDone(bool ok) { OnAfterCall(); - auto makeRequestString = [&] { - TString resp; - if (ok) { - google::protobuf::TextFormat::Printer printer; - printer.SetSingleLineMode(true); - printer.PrintToString(Request, &resp); - } else { - resp = ""; - } - return resp; - }; LOG_DEBUG(ActorSystem, NKikimrServices::GRPC_SERVER, "[%p] received request Name# %s ok# %s data# %s peer# %s current inflight# %li", this, - Name, ok ? "true" : "false", makeRequestString().data(), GetPeerName().c_str(), Server->GetCurrentInFlight()); + Name, ok ? "true" : "false", NYdbGrpc::FormatMessage(Request, ok).data(), GetPeerName().c_str(), Server->GetCurrentInFlight()); if (Context.c_call() == nullptr) { Y_ABORT_UNLESS(!ok); diff --git a/ydb/core/grpc_streaming/grpc_streaming.h b/ydb/core/grpc_streaming/grpc_streaming.h index 872ab75bda76..6beb16ce0ca5 100644 --- a/ydb/core/grpc_streaming/grpc_streaming.h +++ b/ydb/core/grpc_streaming/grpc_streaming.h @@ -11,7 +11,6 @@ #include #include -#include #include @@ -347,22 +346,10 @@ class TGRpcStreamingRequest final } void OnReadDone(NYdbGrpc::EQueueEventStatus status) { - auto dumpResultText = [&] { - TString text; - if (status == NYdbGrpc::EQueueEventStatus::OK) { - google::protobuf::TextFormat::Printer printer; - printer.SetSingleLineMode(true); - printer.PrintToString(ReadInProgress->Record, &text); - } else { - text = ""; - } - return text; - }; - LOG_DEBUG(ActorSystem, LoggerServiceId, "[%p] read finished Name# %s ok# %s data# %s peer# %s", this, Name, status == NYdbGrpc::EQueueEventStatus::OK ? "true" : "false", - dumpResultText().c_str(), + NYdbGrpc::FormatMessage(ReadInProgress->Record, status == NYdbGrpc::EQueueEventStatus::OK).c_str(), this->GetPeerName().c_str()); // Take current in-progress read first @@ -400,25 +387,17 @@ class TGRpcStreamingRequest final } bool Write(TOut&& message, const grpc::WriteOptions& options = { }, const grpc::Status* status = nullptr) { - auto dumpMessageText = [&] { - TString text; - google::protobuf::TextFormat::Printer printer; - printer.SetSingleLineMode(true); - printer.PrintToString(message, &text); - return text; - }; - if (status) { LOG_DEBUG(ActorSystem, LoggerServiceId, "[%p] facade write Name# %s data# %s peer# %s grpc status# (%d) message# %s", this, Name, - dumpMessageText().c_str(), + NYdbGrpc::FormatMessage(message).c_str(), this->GetPeerName().c_str(), static_cast(status->error_code()), status->error_message().c_str()); } else { LOG_DEBUG(ActorSystem, LoggerServiceId, "[%p] facade write Name# %s data# %s peer# %s", this, Name, - dumpMessageText().c_str(), + NYdbGrpc::FormatMessage(message).c_str(), this->GetPeerName().c_str()); } diff --git a/ydb/core/persqueue/partition_monitoring.cpp b/ydb/core/persqueue/partition_monitoring.cpp index 4343adcbb6a1..89c7f47a869c 100644 --- a/ydb/core/persqueue/partition_monitoring.cpp +++ b/ydb/core/persqueue/partition_monitoring.cpp @@ -12,6 +12,7 @@ #include #include #include +#include #include #include #include @@ -22,6 +23,14 @@ namespace NKikimr::NPQ { +TString PrintConfig(const NKikimrPQ::TPQTabletConfig& cfg) { + TSecurityTextFormatPrinter printer; + printer.SetSingleLineMode(true); + TString string; + printer.PrintToString(cfg, &string); + return string; +} + void HtmlOutput(IOutputStream& out, const TString& line, const std::deque>& keys) { HTML(out) { TABLE() { @@ -109,7 +118,7 @@ void TPartition::HandleMonitoring(TEvPQ::TEvMonRequest::TPtr& ev, const TActorCo out << "AvgWriteSize per " << avg.GetDuration().ToString() << " is " << avg.GetValue() << " bytes"; res.push_back(out.Str()); out.Clear(); } - out << Config.DebugString(); res.push_back(out.Str()); out.Clear(); + out << PrintConfig(Config); res.push_back(out.Str()); out.Clear(); HTML(out) { DIV_CLASS_ID("tab-pane fade", Sprintf("partition_%u", ui32(Partition))) { TABLE_SORTABLE_CLASS("table") { diff --git a/ydb/core/persqueue/ya.make b/ydb/core/persqueue/ya.make index 8000bbe68ae2..919301a5d3d0 100644 --- a/ydb/core/persqueue/ya.make +++ b/ydb/core/persqueue/ya.make @@ -59,6 +59,7 @@ PEERDIR( ydb/library/logger ydb/library/persqueue/counter_time_keeper ydb/library/persqueue/topic_parser + ydb/library/protobuf_printer ydb/public/lib/base ydb/public/sdk/cpp/client/ydb_persqueue_core ) diff --git a/ydb/core/protos/flat_tx_scheme.proto b/ydb/core/protos/flat_tx_scheme.proto index 694ee37abd00..e249ec1c80cf 100644 --- a/ydb/core/protos/flat_tx_scheme.proto +++ b/ydb/core/protos/flat_tx_scheme.proto @@ -7,6 +7,7 @@ import "ydb/core/protos/bind_channel_storage_pool.proto"; import "ydb/core/protos/flat_scheme_op.proto"; import "ydb/public/api/protos/ydb_cms.proto"; import "ydb/public/api/protos/ydb_issue_message.proto"; +import "ydb/public/api/protos/annotations/sensitive.proto"; package NKikimrScheme; option java_package = "ru.yandex.kikimr.proto"; @@ -53,7 +54,7 @@ message TEvModifySchemeTransaction { optional uint64 TabletId = 3; optional string Owner = 5; optional bool FailOnExist = 6; // depricated, TModifyScheme.FailOnExist is recomended - optional string UserToken = 7; // serialized NACLib::TUserToken + optional string UserToken = 7 [(Ydb.sensitive) = true]; // serialized NACLib::TUserToken optional string PeerName = 8; } diff --git a/ydb/core/protos/pqconfig.proto b/ydb/core/protos/pqconfig.proto index bb70645ab640..90f6a66969be 100644 --- a/ydb/core/protos/pqconfig.proto +++ b/ydb/core/protos/pqconfig.proto @@ -1,6 +1,8 @@ import "ydb/public/api/protos/draft/persqueue_error_codes.proto"; import "ydb/public/api/protos/draft/persqueue_common.proto"; +import "ydb/public/api/protos/annotations/sensitive.proto"; + import "ydb/core/protos/base.proto"; import "ydb/core/protos/msgbus_kv.proto"; import "ydb/core/protos/node_limits.proto"; @@ -208,11 +210,11 @@ message TMirrorPartitionConfig { message TCredentials { message IamCredentials { optional string Endpoint = 1; - optional string ServiceAccountKey = 2; + optional string ServiceAccountKey = 2 [(Ydb.sensitive) = true]; } oneof Credentials { - string OauthToken = 1; - string JwtParams = 2; + string OauthToken = 1 [(Ydb.sensitive) = true]; + string JwtParams = 2 [(Ydb.sensitive) = true]; IamCredentials Iam = 3; } } diff --git a/ydb/core/tx/schemeshard/schemeshard__operation.cpp b/ydb/core/tx/schemeshard/schemeshard__operation.cpp index 676771621098..29da42f0791f 100644 --- a/ydb/core/tx/schemeshard/schemeshard__operation.cpp +++ b/ydb/core/tx/schemeshard/schemeshard__operation.cpp @@ -12,6 +12,8 @@ #include #include +#include + #include namespace NKikimr::NSchemeShard { @@ -85,6 +87,14 @@ NKikimrScheme::TEvModifySchemeTransaction GetRecordForPrint(const NKikimrScheme: return recordForPrint; } +TString PrintSecurely(const NKikimrScheme::TEvModifySchemeTransaction& record) { + TSecurityTextFormatPrinter printer; + printer.SetSingleLineMode(true); + TString string; + printer.PrintToString(record, &string); + return string; +} + THolder TSchemeShard::IgniteOperation(TProposeRequest& request, TOperationContext& context) { THolder response = nullptr; @@ -183,7 +193,7 @@ THolder TSchemeShard::IgniteOperation(TProposeRequest& request << ", already accepted parts: " << operation->Parts.size() << ", propose result status: " << NKikimrScheme::EStatus_Name(response->Record.GetStatus()) << ", with reason: " << response->Record.GetReason() - << ", tx message: " << GetRecordForPrint(record).ShortDebugString()); + << ", tx message: " << PrintSecurely(record)); } Y_VERIFY_S(context.IsUndoChangesSafe(), @@ -194,7 +204,7 @@ THolder TSchemeShard::IgniteOperation(TProposeRequest& request << ", already accepted parts: " << operation->Parts.size() << ", propose result status: " << NKikimrScheme::EStatus_Name(response->Record.GetStatus()) << ", with reason: " << response->Record.GetReason() - << ", tx message: " << GetRecordForPrint(record).ShortDebugString()); + << ", tx message: " << PrintSecurely(record)); context.OnComplete = {}; // recreate context.DbChanges = {}; @@ -237,7 +247,7 @@ struct TSchemeShard::TTxOperationPropose: public NTabletFlatExecutor::TTransacti LOG_DEBUG_S(ctx, NKikimrServices::FLAT_TX_SCHEMESHARD, "TTxOperationPropose Execute" - << ", message: " << GetRecordForPrint(Request->Get()->Record).ShortDebugString() + << ", message: " << PrintSecurely(Request->Get()->Record) << ", at schemeshard: " << selfId); txc.DB.NoMoreReadsForTx(); diff --git a/ydb/core/tx/schemeshard/ya.make b/ydb/core/tx/schemeshard/ya.make index 8cbf4b637d3c..b3b9e032a154 100644 --- a/ydb/core/tx/schemeshard/ya.make +++ b/ydb/core/tx/schemeshard/ya.make @@ -268,6 +268,7 @@ PEERDIR( ydb/library/aclib/protos ydb/library/login ydb/library/login/protos + ydb/library/protobuf_printer ydb/library/yql/minikql ydb/services/bg_tasks ) diff --git a/ydb/library/grpc/server/actors/ya.make b/ydb/library/grpc/server/actors/ya.make index 94a143ac3414..fa71ec9a30c5 100644 --- a/ydb/library/grpc/server/actors/ya.make +++ b/ydb/library/grpc/server/actors/ya.make @@ -6,6 +6,7 @@ SRCS( PEERDIR( ydb/library/actors/core + ydb/library/grpc/server ) END() diff --git a/ydb/library/grpc/server/logger.h b/ydb/library/grpc/server/logger.h index 1460afa09633..8cfae2b240a3 100644 --- a/ydb/library/grpc/server/logger.h +++ b/ydb/library/grpc/server/logger.h @@ -1,11 +1,17 @@ #pragma once +#include + #include #include +#include + namespace NYdbGrpc { +static bool LogBodyEnabled = "BODY" == GetEnv("YDB_GRPC_SERVER_LOGGING"); + class TLogger: public TThrRefBase { protected: TLogger() = default; @@ -40,4 +46,21 @@ using TLoggerPtr = TIntrusivePtr; logger->Write(ELogPriority::TLOG_INFO, format, __VA_ARGS__); \ } else { } +template +inline TString FormatMessage(const TMsg& message, bool ok = true) { + if (ok) { + if (LogBodyEnabled) { + TString text; + NKikimr::TSecurityTextFormatPrinter printer; + printer.SetSingleLineMode(true); + printer.PrintToString(message, &text); + return text; + } else { + return ""; + } + } else { + return ""; + } +} + } // namespace NYdbGrpc diff --git a/ydb/library/grpc/server/ya.make b/ydb/library/grpc/server/ya.make index 9ed8f30ef2e6..2e44c832ba82 100644 --- a/ydb/library/grpc/server/ya.make +++ b/ydb/library/grpc/server/ya.make @@ -10,6 +10,7 @@ SRCS( GENERATE_ENUM_SERIALIZATION(grpc_request_base.h) PEERDIR( + ydb/library/protobuf_printer contrib/libs/grpc library/cpp/monlib/dynamic_counters/percentile ) @@ -17,4 +18,3 @@ PEERDIR( END() RECURSE_FOR_TESTS(ut) - diff --git a/ydb/public/api/protos/draft/persqueue_common.proto b/ydb/public/api/protos/draft/persqueue_common.proto index 87bb3f236d9f..bad67b8e551b 100644 --- a/ydb/public/api/protos/draft/persqueue_common.proto +++ b/ydb/public/api/protos/draft/persqueue_common.proto @@ -2,6 +2,8 @@ syntax = "proto3"; import "google/protobuf/descriptor.proto"; import "ydb/public/api/protos/draft/persqueue_error_codes.proto"; +import "ydb/public/api/protos/annotations/sensitive.proto"; + package NPersQueueCommon; option java_package = "com.yandex.ydb.persqueue"; @@ -35,8 +37,7 @@ enum ECodec { message Credentials { oneof credentials { - bytes tvm_service_ticket = 1; - bytes oauth_token = 2; + bytes tvm_service_ticket = 1 [(Ydb.sensitive) = true]; + bytes oauth_token = 2 [(Ydb.sensitive) = true]; } } - diff --git a/ydb/public/api/protos/ydb_persqueue_v1.proto b/ydb/public/api/protos/ydb_persqueue_v1.proto index 5262d50f3079..e4eecdbdee2f 100644 --- a/ydb/public/api/protos/ydb_persqueue_v1.proto +++ b/ydb/public/api/protos/ydb_persqueue_v1.proto @@ -3,6 +3,7 @@ import "ydb/public/api/protos/ydb_operation.proto"; import "ydb/public/api/protos/ydb_scheme.proto"; import "ydb/public/api/protos/ydb_status_codes.proto"; import "ydb/public/api/protos/ydb_issue_message.proto"; +import "ydb/public/api/protos/annotations/sensitive.proto"; import "ydb/public/api/protos/annotations/validation.proto"; package Ydb.PersQueue.V1; @@ -38,7 +39,7 @@ message OffsetsRange { // In-session reauthentication and reauthorization, lets user increase session lifetime. You should wait for 'update_token_response' before sending next 'update_token_request'. message UpdateTokenRequest { - string token = 1; + string token = 1 [(Ydb.sensitive) = true]; } message UpdateTokenResponse { @@ -788,7 +789,7 @@ message MigrationStreamingReadClientMessage { } // User credentials if update is needed or empty string. - bytes token = 20; + bytes token = 20 [(Ydb.sensitive) = true]; } /** @@ -1073,8 +1074,8 @@ message Credentials { string service_account_key = 2; } oneof credentials { - string oauth_token = 1; - string jwt_params = 2; + string oauth_token = 1 [(Ydb.sensitive) = true]; + string jwt_params = 2 [(Ydb.sensitive) = true]; Iam iam = 3; } } diff --git a/ydb/public/api/protos/ydb_topic.proto b/ydb/public/api/protos/ydb_topic.proto index 8b5c0aac9cf4..9bcf13e6972b 100644 --- a/ydb/public/api/protos/ydb_topic.proto +++ b/ydb/public/api/protos/ydb_topic.proto @@ -3,6 +3,7 @@ import "ydb/public/api/protos/ydb_operation.proto"; import "ydb/public/api/protos/ydb_scheme.proto"; import "ydb/public/api/protos/ydb_status_codes.proto"; import "ydb/public/api/protos/ydb_issue_message.proto"; +import "ydb/public/api/protos/annotations/sensitive.proto"; import "ydb/public/api/protos/annotations/validation.proto"; import "google/protobuf/duration.proto"; @@ -43,7 +44,7 @@ message OffsetsRange { // In-session reauthentication and reauthorization, lets user increase session lifetime. // Client should wait for UpdateTokenResponse before sending next UpdateTokenRequest. message UpdateTokenRequest { - string token = 1; + string token = 1 [(Ydb.sensitive) = true]; } message UpdateTokenResponse { @@ -167,7 +168,7 @@ message StreamWriteMessage { // Explicit partition id to write to. int64 partition_id = 6; // Explicit partition location to write to. - PartitionWithGeneration partition_with_generation = 8; + PartitionWithGeneration partition_with_generation = 8; } // Message metadata. Overall size is limited to 4096 symbols (all keys and values combined). repeated MetadataItem metadata_items = 7 [(Ydb.size).le = 1000]; @@ -534,7 +535,7 @@ message StreamReadMessage { // Flag of graceful stop, used only when InitRequest.direct_read is true // Client must pass this value unchanged from the StopPartitionSessionRequest. - // Server can sent two StopPartitionSessionRequests, the first with graceful=true, the second with graceful=false. The client must answer both of them. + // Server can sent two StopPartitionSessionRequests, the first with graceful=true, the second with graceful=false. The client must answer both of them. bool graceful = 2; } @@ -563,22 +564,22 @@ message StreamReadMessage { // Messages for bidirectional streaming rpc StreamDirectRead message StreamDirectReadMessage { - // Client-server message for direct read session. + // Client-server message for direct read session. // InitDirectRead - command from client to create and start a direct read session. // StartDirectReadPartitionSession - command from client to create and start a direct read partition session. - // UpdateTokenRequest - request to update auth token + // UpdateTokenRequest - request to update auth token message FromClient { oneof client_message { InitDirectRead init_direct_read = 1; StartDirectReadPartitionSession start_direct_read_partition_session = 2; - UpdateTokenRequest update_token_request = 3; + UpdateTokenRequest update_token_request = 3; } } - // Server-client message for direct read session. + // Server-client message for direct read session. // DirectReadResponse - portion of message data. // StopDirectReadPartitionSession - command from server to stop a direct read partition session. - // UpdateTokenResponse - acknowledgment of token update. + // UpdateTokenResponse - acknowledgment of token update. message FromServer { // Server status of response. Ydb.StatusIds.StatusCode status = 1; @@ -642,13 +643,13 @@ message StreamDirectReadMessage { message DirectReadResponse { // Partition session identifier. int64 partition_session_id = 1; - + // Read request identifier. int64 direct_read_id = 2; // Messages data StreamReadMessage.ReadResponse.PartitionData partition_data = 3; - } + } } message TransactionIdentity { @@ -843,7 +844,7 @@ message CreateTopicRequest { // How long data in partition should be stored. Must be greater than 0 and less than limit for this database. // Default limit - 36 hours. google.protobuf.Duration retention_period = 4; - + // How much data in partition should be stored. Must be greater than 0 and less than limit for this database. // Zero value means infinite limit. int64 retention_storage_mb = 5 [(Ydb.value) = ">= 0"]; @@ -923,7 +924,7 @@ message DescribeTopicResult { // Settings for partitioning PartitioningSettings partitioning_settings = 2; - + // Partitions description. repeated PartitionInfo partitions = 3; @@ -932,7 +933,7 @@ message DescribeTopicResult { // // How long data in partition should be stored. google.protobuf.Duration retention_period = 4; - + // How much data in partition should be stored. // Zero value means infinite limit. int64 retention_storage_mb = 5; @@ -943,7 +944,7 @@ message DescribeTopicResult { // Writes with codec not from this list are forbidden. // If empty, codec compatibility check for the topic is disabled. SupportedCodecs supported_codecs = 7; - + // Partition write speed in bytes per second. // Zero value means default limit: 1 MB per second. int64 partition_write_speed_bytes_per_second = 8; @@ -1135,7 +1136,7 @@ message AlterTopicRequest { // How long data in partition should be stored. Must be greater than 0 and less than limit for this database. // Default limit - 36 hours. google.protobuf.Duration set_retention_period = 4; - + // How much data in partition should be stored. Must be greater than 0 and less than limit for this database. optional int64 set_retention_storage_mb = 5 [(Ydb.value) = ">= 0"]; @@ -1148,7 +1149,7 @@ message AlterTopicRequest { // Partition write speed in bytes per second. Must be less than database limit. Default limit - 1 MB/s. optional int64 set_partition_write_speed_bytes_per_second = 8 [(Ydb.value) = ">= 0"]; - + // Burst size for write in partition, in bytes. Must be less than database limit. Default limit - 1 MB. optional int64 set_partition_write_burst_bytes = 9 [(Ydb.value) = ">= 0"]; From b571990602a9ba0a67b315d31372d7c8babecf4e Mon Sep 17 00:00:00 2001 From: Vitalii Gridnev Date: Thu, 18 Apr 2024 13:46:30 +0300 Subject: [PATCH 111/117] [KIKIMR-21355] Fix OrderedSqlRename without pragma OrderedColumns (#3853) Co-authored-by: Andrey Neporada --- .../yql/core/type_ann/type_ann_core.cpp | 4 ++-- .../sql/dq_file/part1/canondata/result.json | 22 +++++++++++++++++++ .../tests/sql/sql2yql/canondata/result.json | 14 ++++++++++++ .../insert_reorder_without_columnorder.cfg | 2 ++ .../insert_reorder_without_columnorder.sql | 14 ++++++++++++ .../part1/canondata/result.json | 21 ++++++++++++++++++ 6 files changed, 75 insertions(+), 2 deletions(-) create mode 100644 ydb/library/yql/tests/sql/suites/column_order/insert_reorder_without_columnorder.cfg create mode 100644 ydb/library/yql/tests/sql/suites/column_order/insert_reorder_without_columnorder.sql diff --git a/ydb/library/yql/core/type_ann/type_ann_core.cpp b/ydb/library/yql/core/type_ann/type_ann_core.cpp index 5ad0621f1d9c..c9109ff550be 100644 --- a/ydb/library/yql/core/type_ann/type_ann_core.cpp +++ b/ydb/library/yql/core/type_ann/type_ann_core.cpp @@ -9495,7 +9495,7 @@ template // somewhat ugly attempt to find SqlProject to obtain column order auto currInput = input->HeadPtr(); TString path = ToString(input->Content()); - while (currInput->IsCallable({"PersistableRepr", "SqlAggregateAll", "RemoveSystemMembers", "Sort"})) { + while (currInput->IsCallable({"PersistableRepr", "SqlAggregateAll", "RemoveSystemMembers", "Sort", "Take", "Skip"})) { path = path + " -> " + ToString(currInput->Content()); currInput = currInput->HeadPtr(); } @@ -9510,7 +9510,7 @@ template for (const auto& item : currInput->Child(1)->ChildrenList()) { if (!item->IsCallable("SqlProjectItem")) { ctx.Expr.AddError(TIssue(ctx.Expr.GetPosition(item->Pos()), - TStringBuilder() << "Failed to deduce column order for input - star / qualified star is prosent in projection")); + TStringBuilder() << "Failed to deduce column order for input - star / qualified star is present in projection")); return IGraphTransformer::TStatus::Error; } childColumnOrder->push_back(ToString(item->Child(1)->Content())); diff --git a/ydb/library/yql/tests/sql/dq_file/part1/canondata/result.json b/ydb/library/yql/tests/sql/dq_file/part1/canondata/result.json index bd6b83b0e943..dd38a7d87385 100644 --- a/ydb/library/yql/tests/sql/dq_file/part1/canondata/result.json +++ b/ydb/library/yql/tests/sql/dq_file/part1/canondata/result.json @@ -736,6 +736,28 @@ } ], "test.test[case-case_val_then_else-default.txt-Results]": [], + "test.test[column_order-insert_reorder_without_columnorder--Analyze]": [ + { + "checksum": "9f976dc964b65317600df5a37ad5c299", + "size": 5708, + "uri": "https://{canondata_backend}/1936273/9c0654be6d8c964c541bdf0c96b4980357ef29d2/resource.tar.gz#test.test_column_order-insert_reorder_without_columnorder--Analyze_/plan.txt" + } + ], + "test.test[column_order-insert_reorder_without_columnorder--Debug]": [ + { + "checksum": "e31bd3307574142ad420a09e5ad536e0", + "size": 2462, + "uri": "https://{canondata_backend}/1031349/a0b3e3db5f104c4fb6b8f2733a1f6bdd159cebf8/resource.tar.gz#test.test_column_order-insert_reorder_without_columnorder--Debug_/opt.yql_patched" + } + ], + "test.test[column_order-insert_reorder_without_columnorder--Plan]": [ + { + "checksum": "9f976dc964b65317600df5a37ad5c299", + "size": 5708, + "uri": "https://{canondata_backend}/1936273/9c0654be6d8c964c541bdf0c96b4980357ef29d2/resource.tar.gz#test.test_column_order-insert_reorder_without_columnorder--Plan_/plan.txt" + } + ], + "test.test[column_order-insert_reorder_without_columnorder--Results]": [], "test.test[column_order-select_limit_offset_reorder-default.txt-Analyze]": [ { "checksum": "e0cc08c6479b76e82c514b6c219d04a9", diff --git a/ydb/library/yql/tests/sql/sql2yql/canondata/result.json b/ydb/library/yql/tests/sql/sql2yql/canondata/result.json index 0a281e083086..0b798cfdc8f5 100644 --- a/ydb/library/yql/tests/sql/sql2yql/canondata/result.json +++ b/ydb/library/yql/tests/sql/sql2yql/canondata/result.json @@ -3695,6 +3695,13 @@ "uri": "https://{canondata_backend}/1936947/659b615f15086142a8960946dabd06b519d43335/resource.tar.gz#test_sql2yql.test_column_order-insert_/sql.yql" } ], + "test_sql2yql.test[column_order-insert_reorder_without_columnorder]": [ + { + "checksum": "d3105827a0ca8e095bcecc797540f34e", + "size": 1553, + "uri": "https://{canondata_backend}/1923547/0aba22156762a55d9c7578c76fffd5395d319f8b/resource.tar.gz#test_sql2yql.test_column_order-insert_reorder_without_columnorder_/sql.yql" + } + ], "test_sql2yql.test[column_order-insert_tmp]": [ { "checksum": "f7020067b63cf9ba560ad9e409933221", @@ -21167,6 +21174,13 @@ "uri": "https://{canondata_backend}/1880306/64654158d6bfb1289c66c626a8162239289559d0/resource.tar.gz#test_sql_format.test_column_order-insert_/formatted.sql" } ], + "test_sql_format.test[column_order-insert_reorder_without_columnorder]": [ + { + "checksum": "e0526a3060fc6b9c9a2d0c295066f135", + "size": 223, + "uri": "https://{canondata_backend}/1923547/0aba22156762a55d9c7578c76fffd5395d319f8b/resource.tar.gz#test_sql_format.test_column_order-insert_reorder_without_columnorder_/formatted.sql" + } + ], "test_sql_format.test[column_order-insert_tmp]": [ { "checksum": "ce56494a4e05ac5ccd812e10665c7541", diff --git a/ydb/library/yql/tests/sql/suites/column_order/insert_reorder_without_columnorder.cfg b/ydb/library/yql/tests/sql/suites/column_order/insert_reorder_without_columnorder.cfg new file mode 100644 index 000000000000..ad52c79527f6 --- /dev/null +++ b/ydb/library/yql/tests/sql/suites/column_order/insert_reorder_without_columnorder.cfg @@ -0,0 +1,2 @@ +in Input input.txt +out Output output.txt diff --git a/ydb/library/yql/tests/sql/suites/column_order/insert_reorder_without_columnorder.sql b/ydb/library/yql/tests/sql/suites/column_order/insert_reorder_without_columnorder.sql new file mode 100644 index 000000000000..0b9f6613ac24 --- /dev/null +++ b/ydb/library/yql/tests/sql/suites/column_order/insert_reorder_without_columnorder.sql @@ -0,0 +1,14 @@ +/* postgres can not */ +use plato; +pragma DisableOrderedColumns; +pragma warning("disable", "4517"); + +$Group = 1u; + +INSERT INTO Output(Group, Name) +SELECT + $Group, + value +FROM Input +WHERE key = "150" +LIMIT 1; diff --git a/ydb/library/yql/tests/sql/yt_native_file/part1/canondata/result.json b/ydb/library/yql/tests/sql/yt_native_file/part1/canondata/result.json index e416956271d9..528406c3c24d 100644 --- a/ydb/library/yql/tests/sql/yt_native_file/part1/canondata/result.json +++ b/ydb/library/yql/tests/sql/yt_native_file/part1/canondata/result.json @@ -719,6 +719,27 @@ "uri": "https://{canondata_backend}/1924537/4423f8f88aaeda4e03b0c158e2e6b0df92c41109/resource.tar.gz#test.test_case-case_val_then_else-default.txt-Results_/results.txt" } ], + "test.test[column_order-insert_reorder_without_columnorder--Debug]": [ + { + "checksum": "e2f603569cbeb53f1f75cc535fe4a542", + "size": 2248, + "uri": "https://{canondata_backend}/1817427/944e3e51d311ff192b733679255631e4b144c75c/resource.tar.gz#test.test_column_order-insert_reorder_without_columnorder--Debug_/opt.yql" + } + ], + "test.test[column_order-insert_reorder_without_columnorder--Plan]": [ + { + "checksum": "3fc5cf899c15ced58a2e419bbef6d2ce", + "size": 6210, + "uri": "https://{canondata_backend}/1936273/bfda7491784aceaa88c55429ca2306196db27d7c/resource.tar.gz#test.test_column_order-insert_reorder_without_columnorder--Plan_/plan.txt" + } + ], + "test.test[column_order-insert_reorder_without_columnorder--Results]": [ + { + "checksum": "e09e785295186f47f7f26ab8e0f0fbb3", + "size": 27, + "uri": "https://{canondata_backend}/1817427/944e3e51d311ff192b733679255631e4b144c75c/resource.tar.gz#test.test_column_order-insert_reorder_without_columnorder--Results_/Output.txt" + } + ], "test.test[column_order-select_limit_offset_reorder-default.txt-Debug]": [ { "checksum": "f810b94782294b9bafa467567637b4a3", From 1520164cfc3740bc16e438056deb1856f17c9a31 Mon Sep 17 00:00:00 2001 From: alexnick88 Date: Fri, 19 Apr 2024 21:58:57 +0300 Subject: [PATCH 112/117] YMQ Verify fix (#3945) Co-authored-by: Sergey Veselov --- ydb/core/ymq/actor/action.h | 4 +-- ydb/core/ymq/actor/service.cpp | 1 + .../test_throttling_nonexistent_queue.py | 26 +++++++++++++++++-- 3 files changed, 27 insertions(+), 4 deletions(-) diff --git a/ydb/core/ymq/actor/action.h b/ydb/core/ymq/actor/action.h index 8ea1cb814c64..a594f5eafee4 100644 --- a/ydb/core/ymq/actor/action.h +++ b/ydb/core/ymq/actor/action.h @@ -649,6 +649,8 @@ class TActionActor } } + Y_ABORT_UNLESS(SchemeCache_); + bool isACLProtectedAccount = Cfg().GetForceAccessControl(); if (!IsCloud() && (SecurityToken_ || (Cfg().GetForceAccessControl() && (isACLProtectedAccount = IsACLProtectedAccount(UserName_))))) { this->Become(&TActionActor::WaitAuthCheckMessages); @@ -666,8 +668,6 @@ class TActionActor return; } - Y_ABORT_UNLESS(SchemeCache_); - RequestSchemeCache(GetActionACLSourcePath()); // this also checks that requested queue (if any) does exist RequestTicketParser(); } else { diff --git a/ydb/core/ymq/actor/service.cpp b/ydb/core/ymq/actor/service.cpp index 04498866da82..9181d88d9b64 100644 --- a/ydb/core/ymq/actor/service.cpp +++ b/ydb/core/ymq/actor/service.cpp @@ -685,6 +685,7 @@ void TSqsService::AnswerThrottled(TSqsEvents::TEvGetConfiguration::TPtr& ev) { RLOG_SQS_REQ_DEBUG(ev->Get()->RequestId, "Throttled because of too many requests for nonexistent queue [" << ev->Get()->QueueName << "] for user [" << ev->Get()->UserName << "] while getting configuration"); auto answer = MakeHolder(); answer->Throttled = true; + answer->SchemeCache = SchemeCache_; Send(ev->Sender, answer.Release()); } diff --git a/ydb/tests/functional/sqs/common/test_throttling_nonexistent_queue.py b/ydb/tests/functional/sqs/common/test_throttling_nonexistent_queue.py index 2ed57a9ac3af..789d653e859b 100644 --- a/ydb/tests/functional/sqs/common/test_throttling_nonexistent_queue.py +++ b/ydb/tests/functional/sqs/common/test_throttling_nonexistent_queue.py @@ -4,6 +4,8 @@ from ydb.tests.library.sqs.test_base import KikimrSqsTestBase +throttling_exception_pattern = ".*ThrottlingException.*" + class TestSqsThrottlingOnNonexistentQueue(KikimrSqsTestBase): @@ -21,8 +23,6 @@ def get_attributes_of_nonexistent_queue(): except Exception: pass - throttling_exception_pattern = ".*ThrottlingException.*" - assert_that( get_attributes_of_nonexistent_queue, raises( @@ -46,3 +46,25 @@ def get_attributes_of_nonexistent_queue(): pattern=throttling_exception_pattern ) ) + + def test_action_which_does_not_requere_existing_queue(self): + queue_url = self._create_queue_and_assert(self.queue_name, False, True) + nonexistent_queue_url = queue_url + "_nonex" + + def get_attributes_of_nonexistent_queue(): + self._sqs_api.get_queue_attributes(nonexistent_queue_url) + + # Draining budget + for _ in range(16): + try: + get_attributes_of_nonexistent_queue() + except Exception: + pass + + assert_that( + lambda: self._sqs_api.get_queue_url(self.queue_name + "_nonex"), + raises( + RuntimeError, + pattern=throttling_exception_pattern + ) + ) From 36fc0ee4aa8fefc4ea866f1b28c705fc2a78277f Mon Sep 17 00:00:00 2001 From: Ilnaz Nizametdinov Date: Sun, 21 Apr 2024 16:15:58 +0300 Subject: [PATCH 113/117] Reserve change queue capacity in order not to overflow the queue (#3841) (#3917) --- ydb/core/tx/datashard/cdc_stream_scan.cpp | 24 +++++++-- ydb/core/tx/datashard/datashard.cpp | 63 ++++++++++++++++++++--- ydb/core/tx/datashard/datashard_impl.h | 21 +++++--- 3 files changed, 93 insertions(+), 15 deletions(-) diff --git a/ydb/core/tx/datashard/cdc_stream_scan.cpp b/ydb/core/tx/datashard/cdc_stream_scan.cpp index 09bed6daf3b1..4bae27518d4f 100644 --- a/ydb/core/tx/datashard/cdc_stream_scan.cpp +++ b/ydb/core/tx/datashard/cdc_stream_scan.cpp @@ -213,7 +213,7 @@ class TDataShard::TTxCdcStreamScanProgress TTxType GetTxType() const override { return TXTYPE_CDC_STREAM_SCAN_PROGRESS; } bool Execute(TTransactionContext& txc, const TActorContext& ctx) override { - const auto& ev = *Request->Get(); + auto& ev = *Request->Get(); const auto& tablePathId = ev.TablePathId; const auto& streamPathId = ev.StreamPathId; const auto& readVersion = ev.ReadVersion; @@ -238,7 +238,25 @@ class TDataShard::TTxCdcStreamScanProgress } ChangeRecords.clear(); - if (Self->CheckChangesQueueOverflow()) { + + if (!ev.ReservationCookie) { + ev.ReservationCookie = Self->ReserveChangeQueueCapacity(ev.Rows.size()); + } + + if (!ev.ReservationCookie) { + LOG_I("Cannot reserve change queue capacity"); + Reschedule = true; + return true; + } + + if (Self->GetFreeChangeQueueCapacity(ev.ReservationCookie) < ev.Rows.size()) { + LOG_I("Not enough change queue capacity"); + Reschedule = true; + return true; + } + + if (Self->CheckChangesQueueOverflow(ev.ReservationCookie)) { + LOG_I("Change queue overflow"); Reschedule = true; return true; } @@ -335,7 +353,7 @@ class TDataShard::TTxCdcStreamScanProgress LOG_I("Enqueue " << ChangeRecords.size() << " change record(s)" << ": streamPathId# " << Request->Get()->StreamPathId); - Self->EnqueueChangeRecords(std::move(ChangeRecords)); + Self->EnqueueChangeRecords(std::move(ChangeRecords), Request->Get()->ReservationCookie); ctx.Send(Request->Sender, Response.Release()); } else if (Reschedule) { LOG_I("Re-schedule progress tx" diff --git a/ydb/core/tx/datashard/datashard.cpp b/ydb/core/tx/datashard/datashard.cpp index 12bc7e28e7cb..1bf0be413b01 100644 --- a/ydb/core/tx/datashard/datashard.cpp +++ b/ydb/core/tx/datashard/datashard.cpp @@ -899,6 +899,13 @@ void TDataShard::RemoveChangeRecord(NIceDb::TNiceDb& db, ui64 order) { } } + if (auto rIt = ChangeQueueReservations.find(record.ReservationCookie); rIt != ChangeQueueReservations.end()) { + --ChangeQueueReservedCapacity; + if (!--rIt->second) { + ChangeQueueReservations.erase(rIt); + } + } + UpdateChangeExchangeLag(AppData()->TimeProvider->Now()); ChangesQueue.erase(it); @@ -908,7 +915,7 @@ void TDataShard::RemoveChangeRecord(NIceDb::TNiceDb& db, ui64 order) { CheckChangesQueueNoOverflow(); } -void TDataShard::EnqueueChangeRecords(TVector&& records) { +void TDataShard::EnqueueChangeRecords(TVector&& records, ui64 cookie) { if (!records) { return; } @@ -933,7 +940,7 @@ void TDataShard::EnqueueChangeRecords(TVectorsecond); @@ -956,6 +963,38 @@ void TDataShard::EnqueueChangeRecords(TVectorDataShardConfig.GetChangesQueueItemsLimit(); + if (sizeLimit < ChangesQueue.size()) { + return 0; + } + + const auto free = Min(sizeLimit - ChangesQueue.size(), Max(sizeLimit / 2, 1ul)); + + ui32 reserved = ChangeQueueReservedCapacity; + if (auto it = ChangeQueueReservations.find(cookie); it != ChangeQueueReservations.end()) { + reserved -= it->second; + } + + if (free < reserved) { + return 0; + } + + return free - reserved; +} + +ui64 TDataShard::ReserveChangeQueueCapacity(ui32 capacity) { + const auto sizeLimit = AppData()->DataShardConfig.GetChangesQueueItemsLimit(); + if (Max(sizeLimit / 2, 1ul) < ChangeQueueReservedCapacity) { + return 0; + } + + const auto cookie = NextChangeQueueReservationCookie++; + ChangeQueueReservations.emplace(cookie, capacity); + ChangeQueueReservedCapacity += capacity; + return cookie; +} + void TDataShard::UpdateChangeExchangeLag(TInstant now) { if (!ChangesList.Empty()) { const auto* front = ChangesList.Front(); @@ -3391,19 +3430,31 @@ bool TDataShard::CheckTxNeedWait(const TEvDataShard::TEvProposeTransaction::TPtr return false; } -bool TDataShard::CheckChangesQueueOverflow() const { +bool TDataShard::CheckChangesQueueOverflow(ui64 cookie) const { const auto* appData = AppData(); const auto sizeLimit = appData->DataShardConfig.GetChangesQueueItemsLimit(); const auto bytesLimit = appData->DataShardConfig.GetChangesQueueBytesLimit(); - return ChangesQueue.size() >= sizeLimit || ChangesQueueBytes >= bytesLimit; + + ui32 reserved = ChangeQueueReservedCapacity; + if (auto it = ChangeQueueReservations.find(cookie); it != ChangeQueueReservations.end()) { + reserved -= it->second; + } + + return (ChangesQueue.size() + reserved) >= sizeLimit || ChangesQueueBytes >= bytesLimit; } -void TDataShard::CheckChangesQueueNoOverflow() { +void TDataShard::CheckChangesQueueNoOverflow(ui64 cookie) { if (OverloadSubscribersByReason[RejectReasonIndex(ERejectReason::ChangesQueueOverflow)]) { const auto* appData = AppData(); const auto sizeLimit = appData->DataShardConfig.GetChangesQueueItemsLimit(); const auto bytesLimit = appData->DataShardConfig.GetChangesQueueBytesLimit(); - if (ChangesQueue.size() < sizeLimit && ChangesQueueBytes < bytesLimit) { + + ui32 reserved = ChangeQueueReservedCapacity; + if (auto it = ChangeQueueReservations.find(cookie); it != ChangeQueueReservations.end()) { + reserved -= it->second; + } + + if ((ChangesQueue.size() + reserved) < sizeLimit && ChangesQueueBytes < bytesLimit) { NotifyOverloadSubscribers(ERejectReason::ChangesQueueOverflow); } } diff --git a/ydb/core/tx/datashard/datashard_impl.h b/ydb/core/tx/datashard/datashard_impl.h index b277cfe1ef43..71847b2ef22c 100644 --- a/ydb/core/tx/datashard/datashard_impl.h +++ b/ydb/core/tx/datashard/datashard_impl.h @@ -531,6 +531,7 @@ class TDataShard const TRowVersion ReadVersion; const TVector ValueTags; TVector> Rows; + ui64 ReservationCookie = 0; const TCdcStreamScanManager::TStats Stats; }; @@ -1837,7 +1838,9 @@ class TDataShard void MoveChangeRecord(NIceDb::TNiceDb& db, ui64 order, const TPathId& pathId); void MoveChangeRecord(NIceDb::TNiceDb& db, ui64 lockId, ui64 lockOffset, const TPathId& pathId); void RemoveChangeRecord(NIceDb::TNiceDb& db, ui64 order); - void EnqueueChangeRecords(TVector&& records); + void EnqueueChangeRecords(TVector&& records, ui64 cookie = 0); + ui32 GetFreeChangeQueueCapacity(ui64 cookie); + ui64 ReserveChangeQueueCapacity(ui32 capacity); void UpdateChangeExchangeLag(TInstant now); void CreateChangeSender(const TActorContext& ctx); void KillChangeSender(const TActorContext& ctx); @@ -1976,8 +1979,8 @@ class TDataShard void WaitPredictedPlanStep(ui64 step); void SchedulePlanPredictedTxs(); - bool CheckChangesQueueOverflow() const; - void CheckChangesQueueNoOverflow(); + bool CheckChangesQueueOverflow(ui64 cookie = 0) const; + void CheckChangesQueueNoOverflow(ui64 cookie = 0); void DeleteReadIterator(TReadIteratorsMap::iterator it); void CancelReadIterators(Ydb::StatusIds::StatusCode code, const TString& issue, const TActorContext& ctx); @@ -2709,9 +2712,11 @@ class TDataShard TInstant EnqueuedAt; ui64 LockId; ui64 LockOffset; + ui64 ReservationCookie; explicit TEnqueuedRecord(ui64 bodySize, const TPathId& tableId, - ui64 schemaVersion, TInstant created, TInstant enqueued, ui64 lockId = 0, ui64 lockOffset = 0) + ui64 schemaVersion, TInstant created, TInstant enqueued, + ui64 lockId = 0, ui64 lockOffset = 0, ui64 cookie = 0) : BodySize(bodySize) , TableId(tableId) , SchemaVersion(schemaVersion) @@ -2720,12 +2725,13 @@ class TDataShard , EnqueuedAt(enqueued) , LockId(lockId) , LockOffset(lockOffset) + , ReservationCookie(cookie) { } - explicit TEnqueuedRecord(const IDataShardChangeCollector::TChange& record, TInstant now) + explicit TEnqueuedRecord(const IDataShardChangeCollector::TChange& record, TInstant now, ui64 cookie) : TEnqueuedRecord(record.BodySize, record.TableId, record.SchemaVersion, record.CreatedAt(), now, - record.LockId, record.LockOffset) + record.LockId, record.LockOffset, cookie) { } }; @@ -2745,6 +2751,9 @@ class TDataShard THashMap ChangesQueue; // ui64 is order TIntrusiveList ChangesList; ui64 ChangesQueueBytes = 0; + THashMap ChangeQueueReservations; + ui64 NextChangeQueueReservationCookie = 1; + ui32 ChangeQueueReservedCapacity = 0; TActorId OutChangeSender; bool OutChangeSenderSuspended = false; From b1eb0366ee582af0fc938c9f35c7063bbd144fab Mon Sep 17 00:00:00 2001 From: vporyadke Date: Mon, 22 Apr 2024 16:51:15 +0200 Subject: [PATCH 114/117] make stdev calculation more numerically stable (#3984) --- ydb/core/mind/hive/hive.h | 30 +++++++++++++++++++++-------- ydb/core/mind/hive/hive_impl_ut.cpp | 18 +++++++++++++++++ 2 files changed, 40 insertions(+), 8 deletions(-) diff --git a/ydb/core/mind/hive/hive.h b/ydb/core/mind/hive/hive.h index 8a585cac2ab6..e1ecff02ea48 100644 --- a/ydb/core/mind/hive/hive.h +++ b/ydb/core/mind/hive/hive.h @@ -1,5 +1,6 @@ #pragma once #include +#include #include #include @@ -201,20 +202,33 @@ TResourceNormalizedValues NormalizeRawValues(const TResourceRawValues& values, c NMetrics::EResource GetDominantResourceType(const TResourceRawValues& values, const TResourceRawValues& maximum); NMetrics::EResource GetDominantResourceType(const TResourceNormalizedValues& normValues); +// https://en.wikipedia.org/wiki/Kahan_summation_algorithm +template +std::ranges::range_value_t StableSum(const TRange& values) { + using TValue = std::ranges::range_value_t; + TValue sum{}; + TValue correction{}; + for (const auto& x : values) { + TValue y = x - correction; + TValue tmp = sum + y; + correction = (tmp - sum) - y; + sum = tmp; + } + return sum; +} + template inline std::tuple GetStDev(const TVector>& values) { std::tuple sum; if (values.empty()) return sum; - for (const auto& v : values) { - sum = sum + v; - } + sum = StableSum(values); auto mean = sum / values.size(); - sum = std::tuple(); - for (const auto& v : values) { - auto diff = v - mean; - sum = sum + diff * diff; - } + auto quadraticDev = [&] (const std::tuple& value) { + auto diff = value - mean; + return diff * diff; + }; + sum = StableSum(values | std::views::transform(quadraticDev)); auto div = sum / values.size(); auto st_dev = sqrt(div); return tuple_cast::cast(st_dev); diff --git a/ydb/core/mind/hive/hive_impl_ut.cpp b/ydb/core/mind/hive/hive_impl_ut.cpp index e3ba0468f58c..a2a734886b37 100644 --- a/ydb/core/mind/hive/hive_impl_ut.cpp +++ b/ydb/core/mind/hive/hive_impl_ut.cpp @@ -193,4 +193,22 @@ Y_UNIT_TEST_SUITE(THiveImplTest) { Ctest << "HIVE_TABLET_BALANCE_STRATEGY_RANDOM" << Endl; CheckSpeedAndDistribution(allTablets, BalanceTablets, EResourceToBalance::Memory); } + + Y_UNIT_TEST(TestStDev) { + using TSingleResource = std::tuple; + + TVector values(100, 50.0 / 1'000'000); + values.front() = 51.0 / 1'000'000; + + double stDev1 = std::get<0>(GetStDev(values)); + + std::swap(values.front(), values.back()); + + double stDev2 = std::get<0>(GetStDev(values)); + + double expectedStDev = sqrt(0.9703) / 1'000'000; + + UNIT_ASSERT_DOUBLES_EQUAL(expectedStDev, stDev1, 1e-6); + UNIT_ASSERT_VALUES_EQUAL(stDev1, stDev2); + } } From ff2698fc92f19e1083042102b19a9d0b0e04726f Mon Sep 17 00:00:00 2001 From: Ilnaz Nizametdinov Date: Thu, 25 Apr 2024 17:24:11 +0300 Subject: [PATCH 115/117] 24-1: Fix reordering of change records (#4087) (#4105) --- .../change_sender_common_ops.cpp | 23 ++++++++++++++++--- .../change_sender_common_ops.h | 2 +- 2 files changed, 21 insertions(+), 4 deletions(-) diff --git a/ydb/core/change_exchange/change_sender_common_ops.cpp b/ydb/core/change_exchange/change_sender_common_ops.cpp index b2b3e90718fa..a2450d21746e 100644 --- a/ydb/core/change_exchange/change_sender_common_ops.cpp +++ b/ydb/core/change_exchange/change_sender_common_ops.cpp @@ -95,7 +95,7 @@ void TBaseChangeSender::EnqueueRecords(TVectorBodySize) > MemLimit) { - break; + if (!forceAtLeastOne) { + break; + } + + forceAtLeastOne = false; } MemUsage += it->BodySize; @@ -161,7 +165,20 @@ void TBaseChangeSender::SendRecords() { THashSet registrations; bool needToResolve = false; + // used to avoid deadlock between RequestRecords & SendRecords + bool processedAtLeastOne = false; + while (it != PendingSent.end()) { + if (Enqueued && Enqueued.begin()->Order <= it->first) { + break; + } + + processedAtLeastOne = true; + + if (PendingBody && PendingBody.begin()->Order <= it->first) { + break; + } + if (!it->second->IsBroadcast()) { const ui64 partitionId = Resolver->GetPartitionId(it->second); if (!Senders.contains(partitionId)) { @@ -215,7 +232,7 @@ void TBaseChangeSender::SendRecords() { Resolver->Resolve(); } - RequestRecords(); + RequestRecords(!processedAtLeastOne); } void TBaseChangeSender::ForgetRecords(TVector&& records) { diff --git a/ydb/core/change_exchange/change_sender_common_ops.h b/ydb/core/change_exchange/change_sender_common_ops.h index 2e25c8aa72f4..a370d20e9587 100644 --- a/ydb/core/change_exchange/change_sender_common_ops.h +++ b/ydb/core/change_exchange/change_sender_common_ops.h @@ -99,7 +99,7 @@ class TBaseChangeSender: public IChangeSender { void CreateMissingSenders(const TVector& partitionIds); void RecreateSenders(const TVector& partitionIds); - bool RequestRecords(); + bool RequestRecords(bool forceAtLeastOne = false); void SendRecords(); void SendPreparedRecords(ui64 partitionId); From 34c57d8f70fbb4c4accf8bef8d12834e637cec44 Mon Sep 17 00:00:00 2001 From: alexnick88 Date: Thu, 25 Apr 2024 17:45:37 +0300 Subject: [PATCH 116/117] Fix 24 1 (#4112) --- ydb/core/persqueue/ut/sourceid_ut.cpp | 21 --------------------- 1 file changed, 21 deletions(-) diff --git a/ydb/core/persqueue/ut/sourceid_ut.cpp b/ydb/core/persqueue/ut/sourceid_ut.cpp index 31853ccc9f4c..6f8bd6961af7 100644 --- a/ydb/core/persqueue/ut/sourceid_ut.cpp +++ b/ydb/core/persqueue/ut/sourceid_ut.cpp @@ -459,27 +459,6 @@ Y_UNIT_TEST_SUITE(TSourceIdTests) { UNIT_ASSERT(!emitter.CanEmit().Defined()); } } - - Y_UNIT_TEST(ExpensiveCleanup) { - TSourceIdStorage storage; - ui64 offset = 0; - - // initial info w/o heartbeats - for (ui32 i = 1; i <= 100000; ++i) { - storage.RegisterSourceId(TestSourceId(i), MakeExplicitSourceIdInfo(++offset)); - } - - NKikimrPQ::TPartitionConfig config; - config.SetSourceIdLifetimeSeconds(TDuration::Hours(1).Seconds()); - - auto request = MakeHolder(); - for (ui32 i = 0; i < 1000; ++i) { - Cerr << "Iteration " << i << "\n"; - const auto dropped = storage.DropOldSourceIds(request.Get(), TInstant::Hours(2), 1'000'000, TPartitionId(TestPartition), config); - UNIT_ASSERT_EQUAL(dropped, false); - } - - } } // TSourceIdTests } // namespace NKikimr::NPQ From df1dd5c807611d39a158f3c304056f78da5a2dfa Mon Sep 17 00:00:00 2001 From: StekPerepolnen Date: Fri, 26 Apr 2024 08:00:47 +0000 Subject: [PATCH 117/117] json_tenantinfo disconected --- ydb/core/viewer/json_tenantinfo.h | 19 ++++++++++--------- 1 file changed, 10 insertions(+), 9 deletions(-) diff --git a/ydb/core/viewer/json_tenantinfo.h b/ydb/core/viewer/json_tenantinfo.h index d507ff2a8b2f..dc63594f58bf 100644 --- a/ydb/core/viewer/json_tenantinfo.h +++ b/ydb/core/viewer/json_tenantinfo.h @@ -436,16 +436,17 @@ class TJsonTenantInfo : public TViewerPipeClient { } void Disconnected(TEvInterconnect::TEvNodeDisconnected::TPtr &ev) { - ui32 nodeId = ev->Get()->NodeId; + TNodeId nodeId = ev->Get()->NodeId; + TString& tenantId = NodeIdsToTenant[nodeId]; BLOG_TRACE("NodeDisconnected for node " << nodeId); - if (NodeSysInfo.emplace(nodeId, NKikimrWhiteboard::TEvSystemStateResponse{}).second) { - RequestDone(); - } - auto tenantId = NodeIdsToTenant[nodeId]; - if (TenantNodeTabletInfo[tenantId].emplace(nodeId, NKikimrWhiteboard::TEvTabletStateResponse{}).second) { - RequestDone(); - } - if (!TenantNodes[tenantId].empty()) { + if (!OffloadMerge) { + if (NodeSysInfo.emplace(nodeId, NKikimrWhiteboard::TEvSystemStateResponse{}).second) { + RequestDone(); + } + if (Tablets && TenantNodeTabletInfo[tenantId].emplace(nodeId, NKikimrWhiteboard::TEvTabletStateResponse{}).second) { + RequestDone(); + } + } else if (!TenantNodes[tenantId].empty()) { if (Tablets) { SendViewerTabletRequest(tenantId); RequestDone();